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
 
AbstractConfigurationErrorTestCase - Class in org.mule.tck
 
AbstractConfigurationErrorTestCase() - Constructor for class org.mule.tck.AbstractConfigurationErrorTestCase
 
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
 
AbstractDbFunction - Class in org.mule.module.db.internal.el
Provides a base class for DB functions that creates custom DB types.
AbstractDbFunction(MuleContext) - Constructor for class org.mule.module.db.internal.el.AbstractDbFunction
Creates a new instance for a given context.
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
 
AbstractInboundEndpointNameableConnector - Class in org.mule.transport.nameable
AbstractInboundEndpointNameableConnector provides the identity criteria for those connectors that may be distinguished by name as well as by address
AbstractInboundEndpointNameableConnector(MuleContext) - Constructor for class org.mule.transport.nameable.AbstractInboundEndpointNameableConnector
 
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, Integer) - 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
 
AbstractStructuredDbType - Class in org.mule.module.db.internal.domain.type
Base class for structured DB types.
AbstractStructuredDbType(int, String) - Constructor for class org.mule.module.db.internal.domain.type.AbstractStructuredDbType
Creates a new DB type
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
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 #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
 
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.
addEvent(MuleEvent) - Method in class org.mule.routing.requestreply.MultipleRequestReplierEvent
 
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.processor.TransactionalInterceptingMessageProcessor
 
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 LocationExecutionContextProvider.SOURCE_ELEMENT_ANNOTATION_KEY 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
 
addPropertyValue(String, MutablePropertyValues) - Method in class org.mule.config.spring.parsers.generic.TextDefinitionParser
 
addPropertyValue(String, MutablePropertyValues) - Method in class org.mule.config.spring.parsers.specific.GlobalFunctionsDefintionParser
 
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_PATTERN - Static variable in class org.mule.api.util.CredentialsMaskUtil
 
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
 
afterPhaseExecution(LifecyclePhase, Object, Optional<Exception>) - Method in interface org.mule.api.lifecycle.LifecycleInterceptor
Invoked after the given phase was applied over the object.
afterPhaseExecution(LifecyclePhase, Object, Optional<Exception>) - Method in class org.mule.lifecycle.NullLifecycleInterceptor
NoOp implementation
afterPhaseExecution(LifecyclePhase, Object, Optional<Exception>) - Method in class org.mule.lifecycle.PhaseErrorLifecycleInterceptor
If the phase name is trackingPhase then it tracks the given object as successful on the trackingPhase.
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_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
 
allContexts - Variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
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
AMBIGUOUS_TYPE_ERROR_MESSAGE - Static variable in class org.mule.module.http.internal.multipart.HttpMultipartEncoder
 
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
 
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
 
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
 
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
 
ANONYMOUS_ATTACHMENT_FORMAT - Static variable in class org.mule.module.http.internal.multipart.HttpPartDataSource
 
ANT_TEMPLATE_PATTERN - Static variable in class org.mule.util.TemplateParser
 
ANT_TEMPLATE_STYLE - Static variable in class org.mule.util.TemplateParser
 
ANY - Static variable in interface org.mule.transformer.types.MimeTypes
 
ANY_MIME_TYPE - Static variable in interface org.mule.api.transformer.DataType
 
ANY_PATH - Static variable in class org.mule.transport.http.components.StaticResourceMessageProcessor
 
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.
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
 
applicationArchiveDeployer - Variable in class org.mule.module.launcher.DeploymentDirectoryWatcher
 
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, Properties) - Constructor for class org.mule.module.launcher.application.ApplicationMuleContextBuilder
 
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
 
ApplicationStartedSplashScreen - Class in org.mule.module.launcher.application
Splash screen specific for Application startup based on it's ApplicationDescriptor.
ApplicationStartedSplashScreen() - Constructor for class org.mule.module.launcher.application.ApplicationStartedSplashScreen
 
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
 
ArrayMessageSequence - Class in org.mule.routing.outbound
 
ArrayMessageSequence(Object[]) - Constructor for class org.mule.routing.outbound.ArrayMessageSequence
 
ArrayResolvedDbType - Class in org.mule.module.db.internal.domain.type
Defines a structured data type for Array
ArrayResolvedDbType(int, String) - Constructor for class org.mule.module.db.internal.domain.type.ArrayResolvedDbType
Creates a new instance
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.
ArtifactStartedSplashScreen<D extends ArtifactDescriptor> - Class in org.mule.module.launcher.artifact
Base splash screen to log messages when an Artifact is started based on it's ArtifactDescriptor.
ArtifactStartedSplashScreen() - Constructor for class org.mule.module.launcher.artifact.ArtifactStartedSplashScreen
 
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
 
assertConfigurationError(String) - Method in class org.mule.tck.AbstractConfigurationErrorTestCase
 
assertConfigurationError(String, String) - Method in class org.mule.tck.AbstractConfigurationErrorTestCase
 
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(double, double) - 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
ASYNCHRONOUS_RECONNECTION_ERROR_MESSAGE - Static variable in class org.mule.transport.ftp.FtpConnector
 
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(MuleContext) - Constructor for class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
Creates a new instance
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 - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_ID - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_ID - Static variable in class org.mule.config.spring.parsers.generic.AutoIdUtils
 
ATTRIBUTE_NAME - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_NAME - Static variable in class org.mule.config.spring.parsers.generic.AutoIdUtils
 
ATTRIBUTE_NAME - Static variable in class org.mule.config.spring.parsers.specific.FilterDefinitionParser
 
ATTRIBUTE_NAME - Static variable in class org.mule.config.spring.parsers.specific.InterceptorStackDefinitionParser
 
ATTRIBUTE_NAME - Static variable in class org.mule.config.spring.parsers.specific.SecurityFilterDefinitionParser
 
ATTRIBUTE_OBJECT_CLASS - Static variable in class org.mule.object.AbstractObjectFactory
 
ATTRIBUTE_OBJECT_CLASS_NAME - Static variable in class org.mule.object.AbstractObjectFactory
 
ATTRIBUTE_REF - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_REF_SUFFIX - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_REFS - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ATTRIBUTE_REFS_SUFFIX - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
AttributeConcatenation - Class in org.mule.config.spring.parsers.processors
 
AttributeConcatenation(String, String, String[]) - Constructor for class org.mule.config.spring.parsers.processors.AttributeConcatenation
 
AttributeEvaluator - Class in org.mule.util
This class acts as a wrapper for configuration attributes that support simple text, expression or regular expressions.
AttributeEvaluator(String) - Constructor for class org.mule.util.AttributeEvaluator
 
AttributeListEntryDefinitionParser - Class in org.mule.config.spring.parsers.collection
 
AttributeListEntryDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.collection.AttributeListEntryDefinitionParser
Only for use with dynamic naming
AttributeListEntryDefinitionParser(String, String) - Constructor for class org.mule.config.spring.parsers.collection.AttributeListEntryDefinitionParser
 
AttributeMapBeanAssembler - Class in org.mule.config.spring.parsers.assembly
This can be used inside a ChildDefinitionParser - it takes named properties and, instead of inserting them individually on the target, it packages them as a Map and inserts that.
AttributeMapBeanAssembler(PropertyConfiguration, BeanDefinitionBuilder, PropertyConfiguration, BeanDefinition) - Constructor for class org.mule.config.spring.parsers.assembly.AttributeMapBeanAssembler
 
AttributeMapBeanAssemblerFactory - Class in org.mule.config.spring.parsers.assembly
 
AttributeMapBeanAssemblerFactory() - Constructor for class org.mule.config.spring.parsers.assembly.AttributeMapBeanAssemblerFactory
 
AttributeMapDefinitionParser - Class in org.mule.config.spring.parsers.collection
Creates a single, stand-alone map object and processes all attributes to this map
AttributeMapDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.collection.AttributeMapDefinitionParser
 
attributeName - Variable in class org.mule.config.spring.parsers.collection.OrphanMapDefinitionParser
 
attributeName(Attr) - Static method in class org.mule.util.XMLUtils
 
attributeNameToPropertyName(String) - Static method in class org.mule.config.spring.parsers.assembly.configuration.Conventions
Overloads the Spring version of this method to tak into account the first character in the attribute name An upper case char as the first letter of a bean name is not allowed.
AttributePropertiesDefinitionParser - Class in org.mule.config.spring.parsers.generic
 
AttributePropertiesDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.generic.AttributePropertiesDefinitionParser
 
AttributePropertiesDefinitionParser(String, Class) - Constructor for class org.mule.config.spring.parsers.generic.AttributePropertiesDefinitionParser
 
AttributeSelectionDefinitionParser - Class in org.mule.config.spring.parsers.delegate
Select sub parser depending on presence of a particular attribute
AttributeSelectionDefinitionParser(String, MuleDefinitionParser) - Constructor for class org.mule.config.spring.parsers.delegate.AttributeSelectionDefinitionParser
 
authDeniedOnEndpoint(URI) - Static method in class org.mule.config.i18n.CoreMessages
 
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
 
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
 
BadRequestException - Exception in org.mule.transport.http.components
 
BadRequestException(Message) - Constructor for exception org.mule.transport.http.components.BadRequestException
 
BadRequestException(Message, Throwable) - Constructor for exception org.mule.transport.http.components.BadRequestException
 
BARE_URL_PATTERN - Static variable in class org.mule.api.util.CredentialsMaskUtil
 
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
 
BaseHttpMessage - Class in org.mule.module.http.internal.domain
Base implementation for that handles ignore case header operations.
BaseHttpMessage() - Constructor for class org.mule.module.http.internal.domain.BaseHttpMessage
 
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
 
beforePhaseExecution(LifecyclePhase, Object) - Method in interface org.mule.api.lifecycle.LifecycleInterceptor
Invoked before the given phase is applied over the object.
beforePhaseExecution(LifecyclePhase, Object) - Method in class org.mule.lifecycle.NullLifecycleInterceptor
 
beforePhaseExecution(LifecyclePhase, Object) - Method in class org.mule.lifecycle.PhaseErrorLifecycleInterceptor
Determines if the phase should be skipped if the phase name is phaseToPreventOnTrackingPhaseError and the object supports the phase phaseToPreventOnTrackingPhaseError and the phase trackingPhase phase was not successfully completed
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
 
BlobResolvedDataType - Class in org.mule.module.db.internal.domain.type
Defines a data type for Blob
BlobResolvedDataType(int, String) - Constructor for class org.mule.module.db.internal.domain.type.BlobResolvedDataType
 
BlockAttribute - Class in org.mule.config.spring.parsers.processors
Throws an exception if any of the disallowed attributes (after translation) is present.
BlockAttribute(String) - Constructor for class org.mule.config.spring.parsers.processors.BlockAttribute
 
BlockAttribute(String[]) - Constructor for class org.mule.config.spring.parsers.processors.BlockAttribute
 
BlockAttribute.BlockAttributeException - Exception in org.mule.config.spring.parsers.processors
 
blocked - Variable in class org.mule.module.launcher.FineGrainedControlClassLoader
 
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
 
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
 
BouncyCastleUtil - Class in org.mule.module.pgp.util
 
BouncyCastleUtil() - Constructor for class org.mule.module.pgp.util.BouncyCastleUtil
 
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(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.module.ws.consumer.MuleWSDLLocatorConfig.Builder
 
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
 
buildApplication() - Method in class org.mule.module.launcher.application.builder.DefaultMuleApplicationBuilder
 
buildApplication() - Method in interface org.mule.module.launcher.application.builder.MuleApplicationBuilder
 
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
buildDomain() - Method in class org.mule.module.launcher.application.builder.DefaultMuleDomainBuilder
 
buildDomain() - Method in interface org.mule.module.launcher.application.builder.MuleDomainBuilder
 
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, String) - 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.PathSkipMessageProcessorChainBuilder
 
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
 
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
 
BYTE_ARRAY_OUTPUT_STREAM - Static variable in class org.mule.transformer.types.DataTypeFactory
 
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
 
ByteArrayPart - Class in org.mule.module.http.internal.request.grizzly
Our version of Async Http Client's class to support setting headers to custom values (see MULE-10233).
ByteArrayPart(String, byte[]) - Constructor for class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
ByteArrayPart(String, byte[], String) - Constructor for class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
ByteArrayPart(String, byte[], String, Charset) - Constructor for class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
ByteArrayPart(String, byte[], String, Charset, String) - Constructor for class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
ByteArrayPart(String, byte[], String, Charset, String, String) - Constructor for class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
ByteArrayPart(String, byte[], String, Charset, String, String, String) - Constructor for class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
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.db.internal.el.AbstractDbFunction
 
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.BaseResponseCompletionHandler
 
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
 
canProcessAsync(MuleEvent) - Method in class org.mule.processor.AsyncInterceptingMessageProcessor
 
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
 
CaseInsensitiveParameterMap - Class in org.mule.module.http.internal
ParameterMap where the key's case is not taken into account when looking for it, adding or aggregating it.
CaseInsensitiveParameterMap(ParameterMap) - Constructor for class org.mule.module.http.internal.CaseInsensitiveParameterMap
 
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
CHARSET_PARAM - Static variable in class org.mule.transformer.types.SimpleDataType
 
CHARSET_PARAM_NAME - Static variable in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
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
 
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
 
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"
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
 
ClassWriter - Class in org.springframework.asm
A ClassVisitor that generates classes in bytecode form.
ClassWriter(int) - Constructor for class org.springframework.asm.ClassWriter
Constructs a new ClassWriter object.
ClassWriter(ClassReader, int) - Constructor for class org.springframework.asm.ClassWriter
Constructs a new ClassWriter object and enables optimizations for "mostly add" bytecode transformations.
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() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
clear() - Method in class org.mule.util.store.ObjectStorePartition
 
clear() - Method in class org.mule.util.store.ObjectStoreToMapAdapter
 
clear(String) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
clear() - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
 
clear(String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
clear() - Method in class org.mule.util.store.PersistentObjectStorePartition
 
clear() - Method in class org.mule.util.store.ProvidedObjectStoreWrapper
 
clear(String) - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
clear() - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
clear() - Method in class org.mule.util.store.QueueStoreAdapter
Deprecated.
 
clear() - Method in class org.mule.util.store.SimpleMemoryObjectStore
 
clear() - Method in class org.mule.util.store.TextFileObjectStore
 
CLEAR_POLL_TIMEOUT - Static variable in class org.mule.util.queue.TransientQueueTransactionContext
 
clearAttachments() - Method in interface org.mule.api.MuleMessage
Removes all outbound attachments on this message.
clearAttachments() - Method in class org.mule.DefaultMuleMessage
Removes all outbound attachments on this message.
clearContextForResourceOwner(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ConfigOAuthContext
 
clearDispatchers() - Method in class org.mule.transport.AbstractConnector
 
CLEARED - Static variable in class org.mule.module.launcher.util.ElementEvent
 
clearEnrichers() - Method in interface org.mule.api.expression.ExpressionManager
Clears all registered enrichers from the manager.
clearEnrichers() - Method in class org.mule.expression.DefaultExpressionManager
 
clearEvaluators() - Method in interface org.mule.api.expression.ExpressionManager
Clears all registered evaluators from the manager.
clearEvaluators() - Method in class org.mule.expression.DefaultExpressionManager
Clears all registered evaluators from the manager.
clearFlowAssertions() - Method in class org.mule.tck.junit4.FunctionalTestCase
 
clearFlowVariables() - Method in interface org.mule.api.MuleEvent
 
clearFlowVariables() - Method in class org.mule.DefaultMuleEvent
 
clearFlowVariables() - Method in class org.mule.VoidMuleEvent
 
clearProperties() - Method in interface org.mule.api.MuleMessage
clearProperties(PropertyScope) - Method in interface org.mule.api.MuleMessage
Removes all properties on this message in the given scope.
clearProperties() - Method in interface org.mule.api.MuleSession
 
clearProperties() - Method in class org.mule.DefaultMuleMessage
Removes all properties on this message in the PropertyScope.INVOCATION and PropertyScope.OUTBOUND.
clearProperties(PropertyScope) - Method in class org.mule.DefaultMuleMessage
Removes all properties on this message in the given scope.
clearProperties() - Method in class org.mule.message.ExceptionMessage
Removes all properties on this message
clearProperties() - Method in class org.mule.MessagePropertiesContext
Removes all properties from all scopes except for SESSION and INBOUND (which is read-only).
clearProperties(PropertyScope) - Method in class org.mule.MessagePropertiesContext
 
clearProperties() - Method in class org.mule.session.DefaultMuleSession
 
clearQueueConfiguration(String) - Method in class org.mule.util.queue.AbstractQueueManager
 
clearRequesters() - Method in class org.mule.transport.AbstractConnector
 
clearSessionVariables() - Method in interface org.mule.api.MuleEvent
Deprecated.
use getSession() to manipulate session state
clearSessionVariables() - Method in class org.mule.DefaultMuleEvent
 
clearSessionVariables() - Method in class org.mule.VoidMuleEvent
 
clearStatistics() - Method in class org.mule.module.management.mbean.FlowConstructService
 
clearStatistics() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
clearStatistics() - Method in interface org.mule.module.management.mbean.FlowConstructStatsMBean
 
clearStatistics() - Method in class org.mule.module.management.mbean.ServiceService
 
clearStoreCache() - Method in class org.mule.util.store.MuleObjectStoreManager
 
clearWarnings() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
clearWarnings() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
clearWarnings() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
CLI_OPTIONS - Static variable in class org.mule.module.boot.MuleBootstrap
 
CLI_OPTIONS - Static variable in class org.mule.module.launcher.MuleContainer
 
CLI_OPTIONS - Static variable in class org.mule.module.reboot.MuleContainerBootstrap
 
CLI_OPTIONS - Static variable in class org.mule.MuleServer
 
client - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
client - Variable in class org.mule.transport.ajax.AjaxMessageDispatcher
 
client - Variable in class org.mule.transport.http.HttpClientMessageRequester
 
CLIENT - Static variable in class org.mule.transport.tcp.TcpConnector
 
CLIENT_ID_PARAMETER - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
CLIENT_SECRET_PARAMETER - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
clientClass - Variable in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
clientConfig - Variable in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
clientConfig - Variable in class org.mule.transport.soap.axis.AxisMessageRequester
 
ClientConnection - Class in org.mule.module.http.internal.domain.request
Provides information about the client connection
ClientConnection(InetSocketAddress) - Constructor for class org.mule.module.http.internal.domain.request.ClientConnection
 
ClientConnection(SSLSession, InetSocketAddress) - Constructor for class org.mule.module.http.internal.domain.request.ClientConnection
 
clientConnectionManager - Variable in class org.mule.transport.http.HttpConnector
 
ClientCredentialsGrantType - Class in org.mule.module.oauth2.internal.clientcredentials
Authorization element for client credentials oauth grant type
ClientCredentialsGrantType() - Constructor for class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
ClientCredentialsTokenRequestHandler - Class in org.mule.module.oauth2.internal.clientcredentials
Handler for calling the token url, parsing the response and storing the oauth context data.
ClientCredentialsTokenRequestHandler() - Constructor for class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsTokenRequestHandler
 
ClientKeyStoreDefinitionParser - Class in org.mule.config.spring.parsers.specific.tls
 
ClientKeyStoreDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.tls.ClientKeyStoreDefinitionParser
 
ClientMessages - Class in org.mule.module.client.i18n
 
ClientMessages() - Constructor for class org.mule.module.client.i18n.ClientMessages
 
ClientNamespaceHandler - Class in org.mule.module.client.config
TODO
ClientNamespaceHandler() - Constructor for class org.mule.module.client.config.ClientNamespaceHandler
 
clientProviderAndClientConfigConfigured() - Static method in class org.mule.transport.soap.axis.i18n.AxisMessages
 
clientProxy - Variable in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
CLOB_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
ClobResolvedDataType - Class in org.mule.module.db.internal.domain.type
Defines a data type for Clob
ClobResolvedDataType(int, String) - Constructor for class org.mule.module.db.internal.domain.type.ClobResolvedDataType
 
clone() - Method in interface org.mule.api.context.notification.FlowCallStack
 
clone() - Method in interface org.mule.api.endpoint.EndpointBuilder
 
clone() - Method in interface org.mule.api.processor.CloneableMessageProcessor
Creates a new instance cloned from the current one
clone() - Method in class org.mule.context.notification.DefaultFlowCallStack
 
clone() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
clone() - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
clone() - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
clone() - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
clone() - Method in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
clone() - Method in class org.mule.transaction.constraints.BatchConstraint
 
clone() - Method in class org.mule.transaction.constraints.ConstraintFilter
 
clone() - Method in class org.mule.transformer.encryption.AbstractEncryptionTransformer
 
clone() - Method in class org.mule.transformer.simple.AbstractAddVariablePropertyTransformer
 
clone() - Method in class org.mule.transformer.simple.AbstractRemoveVariablePropertyTransformer
 
clone() - Method in class org.mule.transformer.simple.AddAttachmentTransformer
 
clone() - Method in class org.mule.transformer.simple.CopyAttachmentsTransformer
 
clone() - Method in class org.mule.transformer.simple.CopyPropertiesTransformer
 
clone() - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
clone() - Method in class org.mule.transformer.simple.RemoveAttachmentTransformer
 
clone() - Method in class org.mule.transport.http.MuleHostConfiguration
 
clone(Object) - Static method in class org.mule.transport.http.multipart.LazyList
 
clone() - Method in class org.mule.util.CaseInsensitiveHashMap
Clones the map without cloning the keys or values.
clone() - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
CloneableMessageProcessor - Interface in org.mule.api.processor
Adds clone capability to MessageProcessor

NOTE: Lifecycle management is shared with the original MessageProcessor instance

cloneDataType() - Method in interface org.mule.api.transformer.DataType
Create an exact copy of this datatype
cloneDataType() - Method in class org.mule.transformer.types.SimpleDataType
 
cloneMessage(MuleMessage) - Static method in class org.mule.api.context.notification.ServerNotification
 
cloneMessage(MuleMessage, MuleContext) - Static method in class org.mule.routing.AbstractRoutingStrategy
Create a fresh copy of a message.
cloneMessage(MuleEvent, MuleMessage, MuleContext) - Static method in class org.mule.routing.AbstractRoutingStrategy
 
cloneMessage(MuleMessage) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
Create a fresh copy of a message.
cloneMessage(MuleEvent, MuleMessage) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
Creates a fresh copy of a MuleMessage ensuring that the payload can be cloned (i.e.
ClosableClassReader - Class in org.mule.util.scan.annotations
Deprecated.
ClosableClassReader(String) - Constructor for class org.mule.util.scan.annotations.ClosableClassReader
Deprecated.
 
ClosableClassReader(InputStream) - Constructor for class org.mule.util.scan.annotations.ClosableClassReader
Deprecated.
 
close() - Method in class org.apache.commons.httpclient.HttpConnection
Closes the socket and streams.
close(Object) - Method in class org.guiceyfruit.mule.support.DisposableCloser
 
close() - Method in class org.hibernate.connection.SimpleConnectionProvider
 
close() - Method in interface org.mule.api.Closeable
Closes the resource.
close() - Method in interface org.mule.api.store.ListableObjectStore
Close the underlying store.
close(String) - Method in interface org.mule.api.store.PartitionableObjectStore
 
close(Object) - Method in interface org.mule.api.util.StreamCloser
 
close() - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
close() - Method in class org.mule.jndi.SimpleContext
 
close() - Method in class org.mule.model.streaming.CallbackOutputStream
 
close() - Method in class org.mule.model.streaming.DelegatingInputStream
 
close() - Method in class org.mule.model.streaming.DeleteOnCloseFileInputStream
 
close() - Method in class org.mule.module.cxf.support.DelegatingOutputStream
 
close(Message) - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
close() - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
close(Message) - Method in class org.mule.module.cxf.transport.MuleUniversalDestination.ResponseConduit
 
close() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
close() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
close() - Method in class org.mule.module.db.internal.result.resultset.ResultSetIterator
 
close(DbConnection, ResultSet) - Method in class org.mule.module.db.internal.result.resultset.SingleResultResultSetCloser
 
close(DbConnection, ResultSet) - Method in interface org.mule.module.db.internal.result.resultset.StreamingResultSetCloser
 
close(DbConnection, ResultSet) - Method in class org.mule.module.db.internal.result.statement.AbstractStreamingResultSetCloser
 
close() - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
close(DbConnection, ResultSet) - Method in class org.mule.module.db.internal.result.statement.StatementStreamingResultSetCloser
 
close() - Method in class org.mule.module.drools.WorkingMemorySLF4JLogger
 
CLOSE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
close() - Method in class org.mule.module.jersey.DeferredForwardOutputStream
 
close() - Method in class org.mule.module.ws.consumer.MuleWSDLLocator
 
close() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
close(Object) - Method in class org.mule.module.xml.util.XMLStreamCloser
 
close() - Method in class org.mule.streaming.AbstractConsumer
Closes the resource.
close() - Method in class org.mule.streaming.CompositeProducer
Closes all the producers
close() - Method in class org.mule.streaming.ConsumerIterator
Closes the underlying consumer
close() - Method in class org.mule.streaming.ListableObjectStoreProducer
 
close() - Method in class org.mule.streaming.ListConsumer
Closes the resource.
close() - Method in class org.mule.streaming.PagingDelegateProducer
Closes the delegate
close() - Method in class org.mule.streaming.PagingDelegateWrapper
Closes the resource.
close() - Method in class org.mule.streaming.processor.ManagedPagingDelegateAdapter
 
close() - Method in class org.mule.streaming.QueueProducer
 
close() - Method in class org.mule.tck.jndi.InMemoryContext
 
close() - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
 
close() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
close() - Method in class org.mule.transport.http.HttpServerConnection
 
close() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
close() - Method in class org.mule.transport.http.multipart.MultiPartOutputStream
End the current part.
close() - Method in class org.mule.transport.http.ReleasingInputStream
 
close() - Method in class org.mule.transport.http.ResponseWriter
 
close(Connection) - Static method in class org.mule.transport.jdbc.JdbcUtils
 
close() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
close() - Method in class org.mule.transport.jms.CustomCachingConnectionFactory
 
close(MessageProducer) - Method in class org.mule.transport.jms.JmsConnector
Closes the MessageProducer
close(MessageConsumer) - Method in class org.mule.transport.jms.JmsConnector
Closes the MessageConsumer
close(Session) - Method in class org.mule.transport.jms.JmsConnector
Closes the MuleSession
close(TemporaryQueue) - Method in class org.mule.transport.jms.JmsConnector
Closes the TemporaryQueue
close(TemporaryTopic) - Method in class org.mule.transport.jms.JmsConnector
Closes the TemporaryTopic
close() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
close() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
close() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
close() - Method in class org.mule.transport.sftp.SftpFileArchiveInputStream
 
close() - Method in class org.mule.transport.sftp.SftpInputStream
 
close() - Method in class org.mule.transport.soap.axis.AxisStringWriter
 
close() - Method in class org.mule.transport.tcp.protocols.ProtocolStream
 
close() - Method in class org.mule.util.Base64.OutputStream
Flushes and closes (I think, in the superclass) the stream.
close() - Method in class org.mule.util.ChainedReader
 
close() - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
 
close() - Method in class org.mule.util.journal.TransactionJournal
Release the resources used by the transaction journal
close() - Method in class org.mule.util.pool.CommonsPoolObjectPool
 
close() - Method in interface org.mule.util.pool.ObjectPool
 
close() - Method in class org.mule.util.queue.DefaultQueueStore
 
close() - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
close() - Method in class org.mule.util.queue.QueueControlDataFile
 
close() - Method in class org.mule.util.queue.QueueFileProvider
closes the random access file.
close() - Method in interface org.mule.util.queue.QueueStore
 
close() - Method in interface org.mule.util.queue.TransactionalQueueStoreDelegate
Releases all resources managed by this queue without removing the queue data.
close() - Method in class org.mule.util.store.AbstractPartitionedObjectStore
 
close() - Method in class org.mule.util.store.ManagedObjectStore
 
close() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
close() - Method in class org.mule.util.store.ObjectStorePartition
 
close(String) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
close() - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
 
close(String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
close() - Method in class org.mule.util.store.PersistentObjectStorePartition
 
close() - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
close(String) - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
close() - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
close() - Method in class org.mule.util.store.QueueStoreAdapter
Deprecated.
 
close() - Method in class org.mule.util.store.SimpleMemoryObjectStore
 
CLOSE_METHOD_NAME - Static variable in interface org.mule.transaction.XaTransaction.MuleXaObject
 
Closeable - Interface in org.mule.api
Marking interface to identity resources that need to be closed in order to release resources.
CloseableMap<K,V> - Class in org.mule.module.db.internal.result.statement
Defines a Map that will close any contained Closeable value
CloseableMap() - Constructor for class org.mule.module.db.internal.result.statement.CloseableMap
 
closeConnection(Connection) - Method in class org.hibernate.connection.SimpleConnectionProvider
 
closeConsumer() - Method in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
closeConsumer() - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.SubReceiver
 
closeConsumer() - Method in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
ClosedConsumerException - Exception in org.mule.streaming
Exception to signal that a consumer you're trying to access is already closed
ClosedConsumerException() - Constructor for exception org.mule.streaming.ClosedConsumerException
 
ClosedConsumerException(String) - Constructor for exception org.mule.streaming.ClosedConsumerException
 
closeIfStale() - Method in class org.apache.commons.httpclient.HttpConnection
Closes the connection if stale.
closeQueueStore(QueueStore) - Method in class org.mule.util.queue.AbstractQueueManager
 
closeQueueStore(QueueStore) - Method in interface org.mule.util.queue.QueueStoreCacheListener
 
closeQuietly(MessageProducer) - Method in class org.mule.transport.jms.JmsConnector
Closes the MessageProducer without throwing an exception (an error message is logged instead).
closeQuietly(MessageConsumer) - Method in class org.mule.transport.jms.JmsConnector
Closes the MessageConsumer without throwing an exception (an error message is logged instead).
closeQuietly(Session) - Method in class org.mule.transport.jms.JmsConnector
Closes the MuleSession without throwing an exception (an error message is logged instead).
closeQuietly(TemporaryQueue) - Method in class org.mule.transport.jms.JmsConnector
Closes the TemporaryQueue without throwing an exception (an error message is logged instead).
closeQuietly(TemporaryTopic) - Method in class org.mule.transport.jms.JmsConnector
Closes the TemporaryTopic without throwing an exception (an error message is logged instead).
closeQuietly(Channel) - Static method in class org.mule.util.FileUtils
Unconditionally close a Channel.
closeResource(boolean) - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
Close Session and consumer
closeResources() - Method in class org.mule.transaction.XaTransaction
 
closeResultSets(DbConnection) - Method in class org.mule.module.db.internal.result.statement.StatementStreamingResultSetCloser
Closes all tracked ResultSets for the passed connection.
closeSessionIfNoTransactionActive(Session) - Method in class org.mule.transport.jms.JmsConnector
Closes a session if there is no active transaction in the current thread, otherwise the session will continue active until there is a direct call to close it.
closeSocketAndStreams() - Method in class org.apache.commons.httpclient.HttpConnection
Closes everything out.
closeStatement(Statement) - Method in class org.mule.module.db.internal.result.resultset.SingleResultResultSetCloser
 
closeStream(Object) - Method in interface org.mule.api.util.StreamCloserService
 
closeStream(MuleMessage) - Method in class org.mule.exception.AbstractExceptionListener
 
closeStream(Object) - Method in class org.mule.util.DefaultStreamCloserService
 
CLUSTER_NODE_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
ClusterConfiguration - Interface in org.mule.config
Provides the cluster configuration attributes
ClusterizableMessageSource - Interface in org.mule.api.source
Defines a message source that runs in only one node of a cluster.
ClusterizableMessageSourceWrapper - Class in org.mule.source
Wraps a ClusterizableMessageSource in order to manage the lifecycle of the wrapped instance differently depending if the node is primary or not inside a cluster.
ClusterizableMessageSourceWrapper(ClusterizableMessageSource) - Constructor for class org.mule.source.ClusterizableMessageSourceWrapper
 
ClusterizableMessageSourceWrapper(MuleContext, ClusterizableMessageSource, FlowConstruct) - Constructor for class org.mule.source.ClusterizableMessageSourceWrapper
 
ClusterNodeNotification - Class in org.mule.context.notification
Notifies when there are a cluster node event
ClusterNodeNotification(Object, int) - Constructor for class org.mule.context.notification.ClusterNodeNotification
 
ClusterNodeNotificationListener<T extends ClusterNodeNotification> - Interface in org.mule.api.context.notification
Defines a listener for ClusterNodeNotification
CODE_PARAMETER - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
CollectAllAggregationStrategy - Class in org.mule.routing
If no routes generated exeption then it returns a new MuleEvent under the rules of DefaultRouterResultsHandler (you can change this behaviour by overriding CollectAllAggregationStrategy.aggregateWithoutFailedRoutes(AggregationContext).
CollectAllAggregationStrategy() - Constructor for class org.mule.routing.CollectAllAggregationStrategy
 
collectAllKeys() - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
collectEventsWithExceptions() - Method in class org.mule.api.routing.AggregationContext
Returns all the MuleEvents which messages have a not null ExceptionPayload and a not null ExceptionPayload.getException().
collectEventsWithoutExceptions() - Method in class org.mule.api.routing.AggregationContext
The exact opposite to AggregationContext.collectEventsWithExceptions() Returns all the MuleEvents which messages have a null ExceptionPayload or a null ExceptionPayload.getException().
CollectionCorrelatorCallback - Class in org.mule.routing.correlation
A Correlator that correlates messages based on Mule correlation settings
CollectionCorrelatorCallback(MuleContext, String) - Constructor for class org.mule.routing.correlation.CollectionCorrelatorCallback
 
CollectionDataType<T> - Class in org.mule.transformer.types
A data type that represents a generified collection.
CollectionDataType(Class<? extends Collection>) - Constructor for class org.mule.transformer.types.CollectionDataType
Creates an untyped collection data type
CollectionDataType(Class<? extends Collection>, String) - Constructor for class org.mule.transformer.types.CollectionDataType
 
CollectionDataType(Class<? extends Collection>, Class, String) - Constructor for class org.mule.transformer.types.CollectionDataType
 
CollectionDataType(Class<? extends Collection>, Class) - Constructor for class org.mule.transformer.types.CollectionDataType
 
CollectionMessageSequence<T> - Class in org.mule.routing.outbound
A MessageSequence that retrieves elements from a Collection.
CollectionMessageSequence(Collection<T>) - Constructor for class org.mule.routing.outbound.CollectionMessageSequence
 
CollectionSplitter - Class in org.mule.routing
Splits a message that has a Collection, Iterable, MessageSequence or Iterator payload invoking the next message processor one for each item in it.
CollectionSplitter() - Constructor for class org.mule.routing.CollectionSplitter
 
CollectionUtils - Class in org.mule.util
 
CollectionUtils() - Constructor for class org.mule.util.CollectionUtils
 
CollectionValueResolver<T> - Class in org.mule.module.extension.internal.runtime.resolver
A ValueResolver that takes a list of ValueResolvers and upon invocation of CollectionValueResolver.resolve(MuleEvent) it return a Collection of values with the outcome of each original resolver.
CollectionValueResolver(Class<? extends Collection>, List<ValueResolver<T>>) - Constructor for class org.mule.module.extension.internal.runtime.resolver.CollectionValueResolver
Creates a new instance
collectRouteExceptions() - Method in class org.mule.api.routing.AggregationContext
Returns a NavigableMap in which the key is a zero-based route index and the value is an Throwable generated by it.
COLUMN_INDEXES_PROPERTY - Static variable in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
COLUMN_NAMES_PROPERTY - Static variable in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
ColumnAliasRowProcessor - Class in org.mule.transport.jdbc
Processes a row from a ResultSet using the column labels instead of the column names.
ColumnAliasRowProcessor() - Constructor for class org.mule.transport.jdbc.ColumnAliasRowProcessor
 
ColumnIndexAutoGeneratedKeyStrategy - Class in org.mule.module.db.internal.domain.autogeneratedkey
 
ColumnIndexAutoGeneratedKeyStrategy(int[]) - Constructor for class org.mule.module.db.internal.domain.autogeneratedkey.ColumnIndexAutoGeneratedKeyStrategy
 
ColumnNameAutoGeneratedKeyStrategy - Class in org.mule.module.db.internal.domain.autogeneratedkey
 
ColumnNameAutoGeneratedKeyStrategy(String[]) - Constructor for class org.mule.module.db.internal.domain.autogeneratedkey.ColumnNameAutoGeneratedKeyStrategy
 
com.javaforge.bobber.archetype.model - package com.javaforge.bobber.archetype.model
 
com.javaforge.bobber.archetype.model.io.xpp3 - package com.javaforge.bobber.archetype.model.io.xpp3
 
com.javaforge.bobber.plugin.archetype - package com.javaforge.bobber.plugin.archetype
 
CombineCollectionsTransformer - Class in org.mule.transformer.simple
Takes a payload which is a Collection of Collections and turns into a single List.
CombineCollectionsTransformer() - Constructor for class org.mule.transformer.simple.CombineCollectionsTransformer
 
COMETD_CLIENT - Static variable in class org.mule.transport.ajax.embedded.AjaxConnector
 
COMMA - Static variable in class org.mule.transformer.TransformerUtils
 
COMMAND_PORT_PROPERTY - Static variable in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
commandReceived(String) - Method in interface org.mule.test.infrastructure.process.CommandServer.CommandListener
 
commandReceived(String) - Method in class org.mule.test.infrastructure.process.TestProcess
 
CommandServer - Class in org.mule.test.infrastructure.process
 
CommandServer(int) - Constructor for class org.mule.test.infrastructure.process.CommandServer
 
CommandServer.CommandListener - Interface in org.mule.test.infrastructure.process
 
commit() - Method in interface org.mule.api.transaction.Transaction
Commit the transaction
commit() - Method in class org.mule.exception.AbstractExceptionListener
 
commit() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
commit() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
commit() - Method in class org.mule.module.jaas.loginmodule.DefaultLoginModule
Commit if authentication succeeds, otherwise return false
commit() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
commit() - Method in class org.mule.transaction.AbstractTransaction
 
commit() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
commit() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
commit() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
commit() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
commit(Xid, boolean) - Method in class org.mule.transport.jms.xa.XAResourceWrapper
 
commit() - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
commit(Xid, boolean) - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
commit() - Method in interface org.mule.util.queue.QueueSession
Commits a transaction started with QueueSession.begin()
commit() - Method in class org.mule.util.queue.TransactionalQueueSession
 
commit(Xid, boolean) - Method in class org.mule.util.queue.TransactionalQueueSession
 
commit(Xid, boolean) - Method in class org.mule.util.xa.DefaultXASession
 
commitAndClose(Connection) - Static method in class org.mule.transport.jdbc.JdbcUtils
 
commitCurrentTransaction() - Method in class org.mule.transaction.TransactionCoordination
 
commitDandlingTransaction(Xid, boolean) - Method in class org.mule.util.xa.XaTransactionRecoverer
 
commitDanglingTransaction(Xid, boolean) - Method in class org.mule.util.queue.QueueXaResource
 
commitDanglingTransaction(Xid, boolean) - Method in class org.mule.util.xa.DefaultXASession
Commits a dangling transaction that can be caused by the failure of one of the XAResource involved in the transaction or a crash of the transaction manager.
committed - Variable in class org.mule.transaction.AbstractSingleResourceTransaction
 
commitTransaction(AbstractTransactionContext) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
commitTransaction(AbstractTransactionContext) - Method in class org.mule.util.xa.AbstractResourceManager
 
commitTxButNoResource(Transaction) - Static method in class org.mule.config.i18n.CoreMessages
 
commitTxFilter - Variable in class org.mule.exception.AbstractExceptionListener
 
commonInit(Class) - Method in class org.mule.config.spring.parsers.specific.TransactionDefinitionParser
 
CommonsPoolObjectPool - Class in org.mule.util.pool
CommonsPoolProxyPool is an implementation of ObjectPool that internally uses the commons-pool GenericObjectPool and uses a ObjectFactory for creating new pooled instances.
CommonsPoolObjectPool(ObjectFactory, PoolingProfile, MuleContext) - Constructor for class org.mule.util.pool.CommonsPoolObjectPool
Creates a new pool and an Object factory with the ServiceDescriptor
comparableQualifier() - Method in class org.mule.transport.polling.watermark.selector.ComparableWatermarkSelector
Returns an int value according to the Comparable contract (-1, 0, 1).
comparableQualifier() - Method in class org.mule.transport.polling.watermark.selector.MaxValueWatermarkSelector
 
comparableQualifier() - Method in class org.mule.transport.polling.watermark.selector.MinValueWatermarkSelector
 
ComparableWatermarkSelector - Class in org.mule.transport.polling.watermark.selector
Base class for WatermarkSelectors that evaluate Comparable objects.
ComparableWatermarkSelector() - Constructor for class org.mule.transport.polling.watermark.selector.ComparableWatermarkSelector
 
COMPARATOR_CLASS_NAME_PROPERTY - Static variable in class org.mule.transport.file.FileMessageReceiver
 
COMPARATOR_REVERSE_ORDER_PROPERTY - Static variable in class org.mule.transport.file.FileMessageReceiver
 
compare(PropertyScope, PropertyScope) - Method in class org.mule.api.transport.PropertyScope.ScopeComparator
 
compare(Preferred, Preferred) - Method in class org.mule.config.PreferredComparator
 
compare(MuleEvent, MuleEvent) - Method in class org.mule.routing.correlation.CorrelationSequenceComparator
 
compare(MuleEvent, MuleEvent) - Method in class org.mule.routing.EventGroup.ArrivalOrderEventComparator
 
compare(MuleMessage, MuleMessage) - Method in class org.mule.routing.EventGroup.ArrivalOrderMessageComparator
 
compare(String, String) - Method in class org.mule.routing.filters.MessagePropertyFilter
 
compare(Object, Object) - Method in class org.mule.transport.file.comparator.OlderFirstComparator
 
compare(Class[], Class[], boolean) - Static method in class org.mule.util.ClassUtils
 
compare(Class[], Class[], boolean, boolean) - Static method in class org.mule.util.ClassUtils
Returns true if the types from array c2 are assignable to the types from c1 and the arrays are the same size.
compareAndSet(boolean, boolean) - Method in class org.mule.util.concurrent.WaitableBoolean
 
compareTo(MessageProcessPhase) - Method in class org.mule.execution.AsyncResponseFlowProcessingPhase
 
compareTo(MessageProcessPhase) - Method in class org.mule.execution.FlowProcessingPhase
 
compareTo(MessageProcessPhase) - Method in class org.mule.execution.ValidationPhase
 
compareTo(EventGroup) - Method in class org.mule.routing.EventGroup
Compare this EventGroup to another one.
compareTo(Object) - Method in class org.mule.transformer.TransformerWeighting
 
compareTo(boolean) - Method in class org.mule.util.concurrent.WaitableBoolean
 
compareTo(WaitableBoolean) - Method in class org.mule.util.concurrent.WaitableBoolean
 
compareTo(Object) - Method in class org.mule.util.concurrent.WaitableBoolean
 
compareTo(JdkVersionUtils.JdkVersion) - Method in class org.mule.util.JdkVersionUtils.JdkVersion
 
compareTo(Xid) - Method in class org.mule.util.xa.MuleXid
 
COMPILED_EXPRESSION_MAX_CACHE_SIZE - Static variable in class org.mule.el.mvel.MVELExpressionExecutor
 
compiledExpressionsCache - Variable in class org.mule.el.mvel.MVELExpressionExecutor
 
compiledPatterns - Variable in class org.mule.transport.file.filters.FilenameRegexFilter
 
complement() - Method in class org.mule.util.concurrent.WaitableBoolean
 
completed(WriteResult) - Method in class org.mule.module.http.internal.listener.grizzly.ResponseCompletionHandler
Method gets called, when the message part was successfully sent.
completed(WriteResult) - Method in class org.mule.module.http.internal.listener.grizzly.ResponseStreamingCompletionHandler
Method gets called, when file chunk was successfully sent.
completedPhases - Variable in class org.mule.lifecycle.AbstractLifecycleManager
 
completeProcessingRequest() - Method in class org.mule.transport.servlet.jetty.JettyContinuationsMessageProcessTemplate
 
completeTask(Task) - Method in class org.mule.module.jbpm.Jbpm
 
completeTask(Task, String, Map) - Method in class org.mule.module.jbpm.Jbpm
 
CompletionHandler<R,E extends Throwable> - Interface in org.mule.api
Handles the result of asynchronous processing.
Component - Interface in org.mule.api.component
A Component component processes a MuleEvent by invoking the component instance that has been configured, optionally returning a result.
component - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
component - Variable in class org.mule.construct.builder.SimpleServiceBuilder
 
component(Class<?>) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
component(ObjectFactory) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
component(Callable) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
component(Object) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
component(Component) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
component - Variable in class org.mule.context.notification.ComponentMessageNotification
 
component - Variable in class org.mule.service.AbstractService
Deprecated.
 
COMPONENT_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
COMPONENT_POST_INVOKE - Static variable in class org.mule.context.notification.ComponentMessageNotification
 
COMPONENT_PRE_INVOKE - Static variable in class org.mule.context.notification.ComponentMessageNotification
 
ComponentBuilder - Class in org.mule.config.dsl
Deprecated.
ComponentBuilder.Scope - Enum in org.mule.config.dsl
Deprecated.
 
componentCausedErrorIs(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
ComponentDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
ComponentDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.ComponentDefinitionParser
 
ComponentDelegatingDefinitionParser - Class in org.mule.config.spring.parsers.specific
Allows for parsing either a shortcut component configuration by delegating to two different component parses depending on the existence of the class attribute.
ComponentDelegatingDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.ComponentDelegatingDefinitionParser
 
ComponentException - Exception in org.mule.component
ComponentException should be thrown when some action on a component fails, such as starting or stopping
ComponentException(Message, MuleEvent, Component) - Constructor for exception org.mule.component.ComponentException
 
ComponentException(Message, MuleEvent, Component, Throwable) - Constructor for exception org.mule.component.ComponentException
 
ComponentException(MuleEvent, Component, Throwable) - Constructor for exception org.mule.component.ComponentException
 
ComponentLifecycleManager - Class in org.mule.component
The lifecycle manager responsible for managing lifecycle transitions for a Mule service.
ComponentLifecycleManager(String, Component) - Constructor for class org.mule.component.ComponentLifecycleManager
 
ComponentMessageNotification - Class in org.mule.context.notification
These notifications are fired when before and after a service component is invoked.
ComponentMessageNotification(MuleMessage, Component, FlowConstruct, int) - Constructor for class org.mule.context.notification.ComponentMessageNotification
 
ComponentMessageNotificationListener<T extends ComponentMessageNotification> - Interface in org.mule.api.context.notification
ComponentMessageNotificationListener is an observer interface that objects can use to receive notifications about messages being processed by components
ComponentNotFoundRuntimeException - Exception in org.mule.module.cxf.support
 
ComponentNotFoundRuntimeException(Message, Throwable) - Constructor for exception org.mule.module.cxf.support.ComponentNotFoundRuntimeException
 
ComponentNotFoundRuntimeException(Message) - Constructor for exception org.mule.module.cxf.support.ComponentNotFoundRuntimeException
 
componentNotRegistered(String) - Static method in class org.mule.config.i18n.CoreMessages
 
componentObject - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
ComponentStatistics - Class in org.mule.management.stats
ComponentStatistics is a basic metrics aggregation class that is accessible via the JMX api.
ComponentStatistics() - Constructor for class org.mule.management.stats.ComponentStatistics
The constructor added to initialize the interval time in ms that stats are measured for from the property statIntervalTime.
composeName(Name, Name) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
composeName(String, String) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
composeName(String, String) - Method in class org.mule.jndi.SimpleContext
 
composeName(Name, Name) - Method in class org.mule.jndi.SimpleContext
 
composeName(Name, Name) - Method in class org.mule.tck.jndi.InMemoryContext
 
composeName(String, String) - Method in class org.mule.tck.jndi.InMemoryContext
 
CompositeApplicationClassLoader - Class in org.mule.module.launcher.application
Defines a classloader that delegates classes and resources resolution to a list of classloaders.
CompositeApplicationClassLoader(String, List<ClassLoader>) - Constructor for class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
CompositeApplicationClassLoaderFactory - Class in org.mule.module.launcher.application
Composes a CompositeApplicationClassLoader using a ApplicationClassLoaderFactory to getDomainClassLoader the classloader for a Mule application and the plugin classloaders available in the PluginClassLoaderManager
CompositeApplicationClassLoaderFactory(ApplicationClassLoaderFactory, PluginClassLoaderManager) - Constructor for class org.mule.module.launcher.application.CompositeApplicationClassLoaderFactory
 
CompositeCallbackHandler - Class in org.mule.module.ws.security
Callback handler implementation that delegates the handle operation to a list of callback handlers.
CompositeCallbackHandler() - Constructor for class org.mule.module.ws.security.CompositeCallbackHandler
 
CompositeConnectionFactoryDecorator - Class in org.mule.transport.jms
 
CompositeConnectionFactoryDecorator() - Constructor for class org.mule.transport.jms.CompositeConnectionFactoryDecorator
 
CompositeConverter - Class in org.mule.transformer
Composes many converters to behave as a single one.
CompositeConverter(Converter...) - Constructor for class org.mule.transformer.CompositeConverter
Create a new conversion chain using the specified converters
CompositeConverterFilter - Class in org.mule.transformer.graph
 
CompositeConverterFilter(ConverterFilter...) - Constructor for class org.mule.transformer.graph.CompositeConverterFilter
 
CompositeDataSourceDecorator - Class in org.mule.module.db.internal.domain.xa
Composes multiple DataSourceDecorator instances
CompositeDataSourceDecorator() - Constructor for class org.mule.module.db.internal.domain.xa.CompositeDataSourceDecorator
 
CompositeDataSourceDecorator - Class in org.mule.transport.jdbc.xa
 
CompositeDataSourceDecorator() - Constructor for class org.mule.transport.jdbc.xa.CompositeDataSourceDecorator
 
CompositeDbTypeManager - Class in org.mule.module.db.internal.domain.type
Uses DbTypeManager instances to manage DB types
CompositeDbTypeManager(List<DbTypeManager>) - Constructor for class org.mule.module.db.internal.domain.type.CompositeDbTypeManager
Creates a composed DB type manager
CompositeDeploymentListener - Class in org.mule.module.launcher
 
CompositeDeploymentListener() - Constructor for class org.mule.module.launcher.CompositeDeploymentListener
 
CompositeMessageSource - Interface in org.mule.api.source
Composes multiple MessageSources.
CompositeMessageSourceFactoryBean - Class in org.mule.config.spring.factories
 
CompositeMessageSourceFactoryBean() - Constructor for class org.mule.config.spring.factories.CompositeMessageSourceFactoryBean
 
CompositeOptionalObjectsController - Class in org.mule.config.spring
Implementation of OptionalObjectsController which groups a list of controllers and executes every operation on all of them.
CompositeOptionalObjectsController(OptionalObjectsController...) - Constructor for class org.mule.config.spring.CompositeOptionalObjectsController
 
CompositeProducer<T> - Class in org.mule.streaming
Implementation of Producer to expose streams from several producers as a single data feed.
CompositeProducer(List<Producer<T>>) - Constructor for class org.mule.streaming.CompositeProducer
Takes a list of producers to be composited.
CompositeProducer(Producer<T>...) - Constructor for class org.mule.streaming.CompositeProducer
 
CompositeRoutingException - Exception in org.mule.routing
This is a MessagingException used to aggregate exceptions thrown by several routes in the context of a single MessageRouter Exceptions are correlated to each route through a sequential id
CompositeRoutingException(Message, MuleEvent, Map<Integer, Throwable>) - Constructor for exception org.mule.routing.CompositeRoutingException
Constructs a new CompositeRoutingException
CompositeRoutingException(MuleEvent, Map<Integer, Throwable>) - Constructor for exception org.mule.routing.CompositeRoutingException
 
CompositeTransportCustomizer - Class in org.mule.module.http.internal.request.grizzly
 
CompositeTransportCustomizer() - Constructor for class org.mule.module.http.internal.request.grizzly.CompositeTransportCustomizer
 
COMPRESS - Static variable in class org.mule.module.http.api.HttpHeaders.Values
compressByteArray(byte[]) - Method in interface org.mule.util.compression.CompressionStrategy
Compresses a byte array.
compressByteArray(byte[]) - Method in class org.mule.util.compression.GZipCompression
Used for compressing a byte array into a new byte array using GZIP
compressInputStream(InputStream) - Method in interface org.mule.util.compression.CompressionStrategy
Compresses an InputStream.
compressInputStream(InputStream) - Method in class org.mule.util.compression.GZipCompression
 
COMPRESSION_DEFAULT - Static variable in interface org.mule.util.compression.CompressionStrategy
The fully qualified class name of the fallback CompressionStrategy implementation class to use, if no other can be found.
CompressionException - Exception in org.mule.util.compression
CompressionException TODO document
CompressionException(String) - Constructor for exception org.mule.util.compression.CompressionException
 
CompressionException(String, Throwable) - Constructor for exception org.mule.util.compression.CompressionException
 
CompressionHelper - Class in org.mule.util.compression
CompressionHelper a static class that provides facilities for compressing and uncompressing byte arrays
CompressionStrategy - Interface in org.mule.util.compression
CompressionStrategy is a base interface for Different compression strategies
compute() - Method in class org.mule.util.counters.impl.AggregateCounter
 
COMPUTE_FRAMES - Static variable in class org.springframework.asm.ClassWriter
Flag to automatically compute the stack map frames of methods from scratch.
COMPUTE_MAXS - Static variable in class org.springframework.asm.ClassWriter
Flag to automatically compute the maximum stack size and the maximum number of local variables of methods.
computeClassHierarchy(Class, List) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
Get all superclasses and interfaces recursively.
ConcurrentHashSet - Class in org.mule.util.concurrent
 
ConcurrentHashSet() - Constructor for class org.mule.util.concurrent.ConcurrentHashSet
 
ConcurrentHashSet(int) - Constructor for class org.mule.util.concurrent.ConcurrentHashSet
 
ConcurrentHashSet(int, float, int) - Constructor for class org.mule.util.concurrent.ConcurrentHashSet
 
ConcurrentWorkTracker - Class in org.mule.transport
 
ConcurrentWorkTracker() - Constructor for class org.mule.transport.ConcurrentWorkTracker
 
Config - Interface in org.mule.api.config
A generic component's configuration.
config - Variable in class org.mule.context.DefaultMuleContextBuilder
 
config - Variable in class org.mule.routing.ExpressionSplitter
 
config - Variable in class org.mule.routing.outbound.ExpressionMessageSplitter
Deprecated.
 
CONFIG_DEBUG_FIELD - Static variable in class org.mule.module.db.internal.processor.DbDebugInfoUtils
 
CONFIG_FILE_KEY - Static variable in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
CONFIG_PROPERTY - Static variable in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
ConfigChangeMonitorThreadFactory - Class in org.mule.module.launcher
A slightly tweaked default thread factory that uses the following pattern: [%s].config.change.%d.thread.%d, where %s stands for application name, the next number will tell one how many redeployments this app had during this container's lifetime and the last digit, thread count, should always be 1.
ConfigChangeMonitorThreadFactory(String) - Constructor for class org.mule.module.launcher.ConfigChangeMonitorThreadFactory
 
configFor(KeyStore, Set<TrustAnchor>) - Method in interface org.mule.api.security.tls.RevocationCheck
Configures trust store factory parameters for certificate revocation checking according to the method implementation.
configNotFoundUsage() - Static method in class org.mule.config.i18n.CoreMessages
 
ConfigOAuthContext - Class in org.mule.module.oauth2.internal.authorizationcode.state
Provides the OAuth context for a particular config
ConfigOAuthContext(LockFactory, ListableObjectStore<ResourceOwnerOAuthContext>, String) - Constructor for class org.mule.module.oauth2.internal.authorizationcode.state.ConfigOAuthContext
 
ConfigResource - Class in org.mule.config
A ConfigResource holds the url description (or location) and the url stream.
ConfigResource(String) - Constructor for class org.mule.config.ConfigResource
 
ConfigResource(URL) - Constructor for class org.mule.config.ConfigResource
 
ConfigResource(String, InputStream) - Constructor for class org.mule.config.ConfigResource
 
configResources - Variable in class org.mule.config.builders.AbstractResourceConfigurationBuilder
 
configResources - Variable in class org.mule.tck.AbstractServiceAndFlowTestCase
Deprecated.
 
ConfigurableDbConfigFactory - Interface in org.mule.module.db.internal.domain.database
Provides a way to configure a DbConfigFactory
ConfigurableJMXAuthenticator - Interface in org.mule.module.management.agent
 
ConfigurableKeyedObjectPool - Interface in org.mule.transport
A configurable KeyedObjectPool.
ConfigurableKeyedObjectPoolFactory - Interface in org.mule.transport
Simple factory for ConfigurableKeyedObjectPool instances.
ConfigurableProcessBuilder - Interface in org.mule.test.infrastructure.process
 
ConfigurableStatementFactory - Interface in org.mule.module.db.internal.domain.statement
Provides extra customization to a StatementFactory
ConfigurableTransportFactory - Class in org.mule.config.endpoint
TODO
ConfigurableTransportFactory(MuleContext) - Constructor for class org.mule.config.endpoint.ConfigurableTransportFactory
 
CONFIGURATION - Static variable in class org.mule.config.spring.parsers.specific.ConfigurationChildDefinitionParser
Name of the mule:configuration element
configuration - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
configuration - Variable in class org.mule.module.xml.transformer.XQueryTransformer
 
CONFIGURATION_LOCATION - Static variable in class org.mule.module.cxf.CxfConfiguration
 
ConfigurationBuilder - Interface in org.mule.api.config
A ConfigurationBuilder is used to configure a Mule instance, represented by a MuleContext instance.
configurationBuilderError(ConfigurationBuilder) - Static method in class org.mule.config.i18n.CoreMessages
 
configurationBuilderNoMatching(String) - Static method in class org.mule.config.i18n.CoreMessages
 
configurationBuilderSuccess(ConfigurationBuilder, int) - Static method in class org.mule.config.i18n.CoreMessages
 
configurationBuilderSuccess(ConfigurationBuilder, String) - Static method in class org.mule.config.i18n.CoreMessages
 
ConfigurationChildDefinitionParser - Class in org.mule.config.spring.parsers.specific
Extend ChildDefinitionParser to include logic for identifying parent configuration element (since this only applies to "default" elements there's an ugliness here - contradicitions (non-default children of configuration) are avoided by the mule.xsd schema).
ConfigurationChildDefinitionParser(String, Class) - Constructor for class org.mule.config.spring.parsers.specific.ConfigurationChildDefinitionParser
 
ConfigurationDefinitionParser - Class in org.mule.config.spring.parsers.specific
Parses the element.
ConfigurationDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.ConfigurationDefinitionParser
 
ConfigurationException - Exception in org.mule.api.config
 
ConfigurationException(Message) - Constructor for exception org.mule.api.config.ConfigurationException
 
ConfigurationException(Message, Throwable) - Constructor for exception org.mule.api.config.ConfigurationException
 
ConfigurationException(Throwable) - Constructor for exception org.mule.api.config.ConfigurationException
 
ConfigurationInstanceArgumentResolver - Class in org.mule.module.extension.internal.runtime.resolver
An implementation of ArgumentResolver which returns the value obtained through OperationContext.getConfigurationInstance()

Because this ArgumentResolver is stateless and thread-safe, it is exposed as a singleton

ConfigurationObjectBuilder - Class in org.mule.module.extension.internal.runtime
Implementation of ObjectBuilder to create instances that implement a given Configuration.
ConfigurationObjectBuilder(String, Extension, Configuration, ResolverSet, ConfigurationInstanceRegistrationCallback) - Constructor for class org.mule.module.extension.internal.runtime.ConfigurationObjectBuilder
 
ConfigurationPatternArchetypeMojo - Class in org.mule.tools.maven.archetype
Creates a new configuration pattern.
ConfigurationPatternArchetypeMojo() - Constructor for class org.mule.tools.maven.archetype.ConfigurationPatternArchetypeMojo
 
configure() - Method in class org.guiceyfruit.mule.MuleModule
Deprecated.
 
configure(Properties) - Method in class org.hibernate.connection.SimpleConnectionProvider
 
configure(MuleContext) - Method in interface org.mule.api.config.ConfigurationBuilder
Will configure a MuleContext based on the configuration provided.
configure(MuleContext) - Method in class org.mule.config.builders.AbstractConfigurationBuilder
Will configure a MuleContext object based on the builders configuration settings.
configure(MuleContext) - Method in class org.mule.config.builders.AbstractResourceConfigurationBuilder
Override to check for existence of configResouce before invocation, and set resources n configuration afterwards.
configure() - Method in class org.mule.module.guice.MuleSupportModule
Deprecated.
 
configure(RequestBuilder) - Method in interface org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient.RequestConfigurer
 
configure(Map) - Method in interface org.mule.module.management.agent.ConfigurableJMXAuthenticator
 
configure(Map) - Method in class org.mule.module.management.support.SimplePasswordJmxAuthenticator
 
configure(String, ConfigurableProcessBuilder) - Method in class org.mule.test.infrastructure.process.MuleCoreExtensionProcessConfigurer
 
configure(String, ConfigurableProcessBuilder) - Method in interface org.mule.test.infrastructure.process.ProcessBuilderConfigurer
 
configure(ServerSocket, Boolean, InetSocketAddress, int) - Method in class org.mule.transport.tcp.TcpServerSocketFactory
 
configureBinding(JavaComponent, Object) - Static method in class org.mule.component.BindingUtils
 
configureClient(Client) - Method in class org.mule.module.cxf.builder.AbstractClientMessageProcessorBuilder
 
configureClient(Client) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
configureClient(Client) - Method in class org.mule.module.cxf.builder.ProxyClientMessageProcessorBuilder
 
configureComponentBindings() - Method in class org.mule.module.scripting.component.ScriptComponent
 
configureComponentMessageProcessor(MuleContext, MessageProcessorChainBuilder, Component) - Method in enum org.mule.construct.SimpleService.Type
 
configureConnector(AbstractNetworkConnector, String, int) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
configureContentLengthRemover(AbstractConfigurationPattern, MessageProcessorChainBuilder) - Static method in class org.mule.transport.http.construct.HttpProxy
 
configureContext(ExpressionLanguageContext) - Method in interface org.mule.api.el.ExpressionLanguageExtension
 
configureContext(ExpressionLanguageContext) - Method in class org.mule.module.db.internal.el.DbModuleElExtension
 
configureContext(ExpressionLanguageContext) - Method in class org.mule.module.oauth2.internal.mel.OAuthExpressionLanguageExtension
 
configureContext(ExpressionLanguageContext) - Method in class org.mule.module.xml.el.XMLExpressionLanguageExtension
 
configured - Variable in class org.mule.config.builders.AbstractConfigurationBuilder
 
ConfiguredDbConfigResolver - Class in org.mule.module.db.internal.resolver.database
Resolves a DbConfig delegating to the DbConfigResolver corresponding to the configured config.
ConfiguredDbConfigResolver(DbConfigResolver) - Constructor for class org.mule.module.db.internal.resolver.database.ConfiguredDbConfigResolver
 
configureDefaultQueueSize(QueueProfile, ThreadingProfile) - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
configureDispatcherPool() - Method in class org.mule.transport.AbstractConnector
 
configureDispatcherPool() - Method in class org.mule.transport.file.FileConnector
 
configureEngine(AxisEngine) - Method in class org.mule.transport.soap.axis.extensions.MuleConfigProvider
Configure an AxisEngine.
configureHostChecking(Properties) - Method in class org.mule.transport.sftp.SftpClient
 
configureMessageProcessor(ServerFactoryBean, CxfInboundMessageProcessor) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
configureMessageProcessor(CxfOutboundMessageProcessor) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
configureMessageProcessor(CxfOutboundMessageProcessor) - Method in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
configureMessageProcessor(CxfOutboundMessageProcessor) - Method in class org.mule.module.cxf.builder.LocalClientMessageProcessorBuilder
 
configureMessageProcessor(CxfOutboundMessageProcessor) - Method in class org.mule.module.cxf.builder.ProxyClientMessageProcessorBuilder
 
configureMessageProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractConfigurationPattern
 
configureMessageProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractPipeline
 
configureMessageProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.Flow
 
configureMessageProcessorsAfterTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractConfigurationPattern
 
configureMessageProcessorsAfterTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.Bridge
 
configureMessageProcessorsAfterTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.SimpleService
 
configureMessageProcessorsAfterTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.Validator
 
configureMessageProcessorsAfterTransformation(MessageProcessorChainBuilder) - Method in class org.mule.module.ws.construct.WSProxy
 
configureMessageProcessorsAfterTransformation(MessageProcessorChainBuilder) - Method in class org.mule.transport.http.construct.HttpProxy
 
configureMessageProcessorsBeforeTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractConfigurationPattern
 
configureMessageProcessorsBeforeTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.Bridge
 
configureMessageProcessorsBeforeTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.SimpleService
 
configureMessageProcessorsBeforeTransformation(MessageProcessorChainBuilder) - Method in class org.mule.construct.Validator
 
configureMessageProcessorsBeforeTransformation(MessageProcessorChainBuilder) - Method in class org.mule.module.ws.construct.WSProxy
 
configureMessageProcessorsBeforeTransformation(MessageProcessorChainBuilder) - Method in class org.mule.transport.http.construct.HttpProxy
 
configureMuleContext(MuleContext) - Method in class org.mule.module.guice.AbstractMuleGuiceModule
Deprecated.
 
configureMuleContext(MuleContextBuilder) - Method in class org.mule.tck.junit4.ApplicationContextBuilder
Override this method to set properties of the MuleContextBuilder before it is used to create the MuleContext.
configureParserConfiguration(ParserConfiguration, Map<String, Class<?>>) - Static method in class org.mule.el.mvel.MVELExpressionLanguage
 
configurePostProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractPipeline
 
configurePostProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.Flow
 
configurePreProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractConfigurationPattern
 
configurePreProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.AbstractPipeline
 
configurePreProcessors(MessageProcessorChainBuilder) - Method in class org.mule.construct.Flow
 
configureProcessingStrategy(Element, BeanDefinitionBuilder, String) - Static method in class org.mule.config.spring.util.ProcessingStrategyUtils
 
configureProcessors(List<MessageProcessor>, StageNameSource, MessageProcessorChainBuilder, MuleContext) - Method in interface org.mule.api.processor.ProcessingStrategy
 
configureProcessors(List<MessageProcessor>, StageNameSource, MessageProcessorChainBuilder, MuleContext) - Method in class org.mule.processor.strategy.AsynchronousProcessingStrategy
 
configureProcessors(List<MessageProcessor>, StageNameSource, MessageProcessorChainBuilder, MuleContext) - Method in class org.mule.processor.strategy.NonBlockingProcessingStrategy
 
configureProcessors(List<MessageProcessor>, StageNameSource, MessageProcessorChainBuilder, MuleContext) - Method in class org.mule.processor.strategy.QueuedThreadPerProcessorProcessingStrategy
 
configureProcessors(List<MessageProcessor>, StageNameSource, MessageProcessorChainBuilder, MuleContext) - Method in class org.mule.processor.strategy.SynchronousProcessingStrategy
 
configureProcessors(List<MessageProcessor>, StageNameSource, MessageProcessorChainBuilder, MuleContext) - Method in class org.mule.processor.strategy.ThreadPerProcessorProcessingStrategy
 
configureQueue(MuleContext, String, QueueManager) - Method in class org.mule.config.QueueProfile
 
configureQueueManager(MuleContext) - Method in class org.mule.config.builders.DefaultsConfigurationBuilder
 
configureSchemaFactory(SchemaFactory) - Method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
configureServer(Server) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
configureServer(Server) - Method in class org.mule.module.cxf.builder.ProxyServiceMessageProcessorBuilder
 
configureSocket(boolean, Socket) - Method in class org.mule.transport.tcp.TcpConnector
 
configureStatementResultSetCloser(BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
configureStatistics() - Method in class org.mule.construct.AbstractFlowConstruct
 
configureStatistics() - Method in class org.mule.construct.Flow
 
configureSystemModel(MuleRegistry) - Method in class org.mule.config.builders.DefaultsConfigurationBuilder
Deprecated.
configureThread(Thread) - Method in class org.mule.util.concurrent.NamedThreadFactory
 
configureThreadFactory(String, ThreadingProfile, ThreadPoolExecutor) - Method in class org.mule.config.pool.DefaultThreadPoolFactory
 
configureThreadingProfiles(MuleRegistry) - Method in class org.mule.config.builders.DefaultsConfigurationBuilder
 
configureTransformerFactory(TransformerFactory) - Method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
configureTransformerFactory(TransformerFactory) - Method in class org.mule.util.xmlsecurity.XMLSecureFactories
 
configureValidator(Validator) - Method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
configureValidator(Validator) - Method in class org.mule.util.xmlsecurity.XMLSecureFactories
 
configureXMLInputFactory(XMLInputFactory) - Method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
configureXMLInputFactory(XMLInputFactory) - Method in class org.mule.util.xmlsecurity.XMLSecureFactories
 
connect() - Method in interface org.mule.api.transport.Connectable
Make the connection to the underlying transport.
connect() - Method in class org.mule.module.management.mbean.EndpointService
 
connect() - Method in interface org.mule.module.management.mbean.EndpointServiceMBean
 
connect() - Method in class org.mule.tck.util.ftp.FtpClient
Initiate a connection to the ftp server
connect() - Method in class org.mule.transport.AbstractConnector
 
connect() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
connect(EndpointURI) - Method in class org.mule.transport.http.HttpConnector
 
connect() - Method in class org.mule.transport.jms.JmsConnector
 
connect() - Method in class org.mule.transport.sftp.SftpConnector
 
connect() - Method in class org.mule.transport.soap.axis.transport.VoidURLConnection
 
connect() - Method in class org.mule.transport.xmpp.AbstractXmppConversation
 
connect(boolean) - Method in class org.mule.transport.xmpp.AbstractXmppConversation
 
connect() - Method in interface org.mule.transport.xmpp.XmppConversation
connect(boolean) - Method in interface org.mule.transport.xmpp.XmppConversation
Connect to the Jabber conversation, e.g.
Connectable - Interface in org.mule.api.transport
Interface for objects that should connect to a resource.
ConnectableLifecycleManager<O> - Class in org.mule.transport
TODO
ConnectableLifecycleManager(String, O) - Constructor for class org.mule.transport.ConnectableLifecycleManager
 
connectConnectorAndReceivers() - Method in class org.mule.transport.AbstractConnector
 
connected - Variable in class org.mule.transport.AbstractTransportMessageHandler
 
connected - Variable in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.SubReceiver
 
ConnectException - Exception in org.mule.transport
When this exception is thrown it will trigger a retry (reconnection) policy to go into effect if one is configured.
ConnectException(Message, Connectable) - Constructor for exception org.mule.transport.ConnectException
 
ConnectException(Message, Throwable, Connectable) - Constructor for exception org.mule.transport.ConnectException
 
ConnectException(Throwable, Connectable) - Constructor for exception org.mule.transport.ConnectException
 
connectHandler() - Method in class org.mule.transport.AbstractMessageReceiver
 
connectHandler() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
connecting - Variable in class org.mule.transport.AbstractConnector
 
CONNECTION - Static variable in class org.mule.module.http.api.HttpHeaders.Names
connection - Variable in class org.mule.transport.xmpp.AbstractXmppConversation
 
CONNECTION_CONNECTED - Static variable in class org.mule.context.notification.ConnectionNotification
 
CONNECTION_DEBUG_FIELD - Static variable in class org.mule.module.db.internal.processor.DbDebugInfoUtils
 
CONNECTION_DISCONNECTED - Static variable in class org.mule.context.notification.ConnectionNotification
 
CONNECTION_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
CONNECTION_FAILED - Static variable in class org.mule.context.notification.ConnectionNotification
 
CONNECTION_PROPERTIES_ELEMENT_NAME - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
CONNECTION_STOPPING_ERROR_MESSAGE - Static variable in class org.mule.transport.jms.JmsConnector
 
ConnectionBindingException - Exception in org.mule.module.db.internal.domain.connection
Thrown to indicates an error binding a connection to a transaction
ConnectionBindingException(String, Throwable) - Constructor for exception org.mule.module.db.internal.domain.connection.ConnectionBindingException
 
ConnectionClosingException - Exception in org.mule.module.db.internal.domain.connection
Thrown to indicate an error closing connection
ConnectionClosingException(Throwable) - Constructor for exception org.mule.module.db.internal.domain.connection.ConnectionClosingException
 
ConnectionCommitException - Exception in org.mule.module.db.internal.domain.connection
Thrown to indicate an error while committing a connection
ConnectionCommitException(Throwable) - Constructor for exception org.mule.module.db.internal.domain.connection.ConnectionCommitException
 
ConnectionCreationException - Exception in org.mule.module.db.internal.domain.connection
Thrown to indicate an error creating a connection
ConnectionCreationException(String) - Constructor for exception org.mule.module.db.internal.domain.connection.ConnectionCreationException
 
ConnectionCreationException(Throwable) - Constructor for exception org.mule.module.db.internal.domain.connection.ConnectionCreationException
 
ConnectionCreationException(Throwable, String) - Constructor for exception org.mule.module.db.internal.domain.connection.ConnectionCreationException
 
ConnectionException - Exception in org.mule.api
Exception thrown when connect method in cloud connectors fails to connect properly.
ConnectionException(ConnectionExceptionCode, String, String) - Constructor for exception org.mule.api.ConnectionException
Create a new connection exception
ConnectionException(ConnectionExceptionCode, String, String, Throwable) - Constructor for exception org.mule.api.ConnectionException
Create a new connection exception
ConnectionExceptionCode - Enum in org.mule.api
List of possible outcomes to a connection failure
ConnectionFactory - Interface in org.mule.module.db.internal.domain.connection
Creates Connection from DataSource
ConnectionFactoryDecorator - Interface in org.mule.transport.jms
Decorator for the jms ConnectionFactory.
ConnectionFactoryDefinitionParser - Class in org.mule.transport.jms.config
We want to set the connection factory as a pojo factory and then add attributes (username and password) on the parent
ConnectionFactoryDefinitionParser() - Constructor for class org.mule.transport.jms.config.ConnectionFactoryDefinitionParser
 
ConnectionInvocationHandler - Class in org.mule.transport.jms.xa
 
ConnectionInvocationHandler(Object) - Constructor for class org.mule.transport.jms.xa.ConnectionInvocationHandler
 
ConnectionInvocationHandler(Object, Boolean) - Constructor for class org.mule.transport.jms.xa.ConnectionInvocationHandler
 
ConnectionListener - Class in org.mule.tck.listener
Listener for connection notifications.
ConnectionListener(MuleContext) - Constructor for class org.mule.tck.listener.ConnectionListener
 
ConnectionNotification - Class in org.mule.context.notification
Is fired by a connector when a connection is made or disconnected.
ConnectionNotification(Connectable, String, int) - Constructor for class org.mule.context.notification.ConnectionNotification
 
ConnectionNotificationListener<T extends ConnectionNotification> - Interface in org.mule.api.context.notification
ConnectionNotificationListener is an observer interface that objects can implement and then register themselves with the Mule manager to be notified when a Connection event occurs.
ConnectionWrapper - Class in org.mule.module.db.internal.domain.xa
Using for unification XAConnection and Connection
ConnectionWrapper(XAConnection) - Constructor for class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
ConnectionWrapper - Class in org.mule.transport.jdbc.xa
Using for unification XAConnection and Connection
ConnectionWrapper(XAConnection) - Constructor for class org.mule.transport.jdbc.xa.ConnectionWrapper
 
ConnectNotifier - Class in org.mule.retry.notifiers
Fires a ConnectionNotification each time a retry attempt is made.
ConnectNotifier() - Constructor for class org.mule.retry.notifiers.ConnectNotifier
 
Connector - Interface in org.mule.api.transport
Connector is the mechanism used to connect to external systems and protocols in order to send and receive data.
connector - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
connector - Variable in class org.mule.endpoint.inbound.InboundExceptionDetailsMessageProcessor
 
connector - Variable in class org.mule.transport.AbstractTransportMessageHandler
 
connector - Variable in class org.mule.transport.ajax.container.MuleAjaxServlet
 
connector - Variable in class org.mule.transport.DefaultReplyToHandler
 
connector - Variable in class org.mule.transport.ftp.FtpMessageDispatcher
 
connector - Variable in class org.mule.transport.ftp.FtpMessageReceiver
 
connector - Variable in class org.mule.transport.ftp.FtpMessageRequester
 
connector - Variable in class org.mule.transport.http.HttpClientMessageRequester
 
connector - Variable in class org.mule.transport.jdbc.JdbcMessageDispatcher
 
connector - Variable in class org.mule.transport.jdbc.JdbcMessageReceiver
 
connector - Variable in class org.mule.transport.jms.Jms11Support
 
connector - Variable in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
connector - Variable in class org.mule.transport.jms.redelivery.AbstractRedeliveryHandler
 
connector - Variable in class org.mule.transport.jms.redelivery.AutoDiscoveryRedeliveryHandlerFactory
 
connector - Variable in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
connector - Variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
connector - Variable in class org.mule.transport.rmi.RmiCallbackMessageReceiver
 
connector - Variable in class org.mule.transport.rmi.RmiMessageReceiver
 
connector - Variable in class org.mule.transport.servlet.jetty.AbstractConnectorHolder
 
connector - Variable in class org.mule.transport.servlet.MuleReceiverServlet
 
connector - Variable in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
connector - Variable in class org.mule.transport.soap.axis.AxisMessageReceiver
 
connector - Variable in class org.mule.transport.soap.axis.AxisMessageRequester
 
connector - Variable in class org.mule.transport.udp.UdpMessageDispatcher
 
connector - Variable in class org.mule.transport.udp.UdpMessageRequester
 
CONNECTOR_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.EndpointUtils
 
CONNECTOR_CLASS - Static variable in class org.mule.api.config.MuleProperties
***************************************************************************** Transport Service descriptor properties *****************************************************************************
CONNECTOR_DEFAULT_EXCHANGE_PATTERN - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_DISPATCHER_FACTORY - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_ENDPOINT_BUILDER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_INBOUND_EXCHANGE_PATTERNS - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_INBOUND_TRANSFORMER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_MESSAGE_FACTORY - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_MESSAGE_RECEIVER_CLASS - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_META_ENDPOINT_BUILDER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_NAME - Static variable in class org.mule.transport.servlet.MuleServletContextListener
 
CONNECTOR_OUTBOUND_EXCHANGE_PATTERNS - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_OUTBOUND_TRANSFORMER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_PREFIX - Static variable in class org.mule.util.ObjectNameHelper
 
CONNECTOR_REQUESTER_FACTORY - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_RESPONSE_TRANSFORMER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_SERVER - Static variable in class org.mule.module.management.config.JmxAgentDefinitionParser
 
CONNECTOR_SERVICE_ERROR - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_SERVICE_FINDER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_SESSION_HANDLER - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_TRANSACTED_MESSAGE_RECEIVER_CLASS - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_TRANSACTION_FACTORY - Static variable in class org.mule.api.config.MuleProperties
 
CONNECTOR_XA_TRANSACTED_MESSAGE_RECEIVER_CLASS - Static variable in class org.mule.api.config.MuleProperties
 
connectorCausedError() - Static method in class org.mule.config.i18n.CoreMessages
 
connectorCausedError(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
connectorDoesNotSupportSyncReceiveWhenTransacted() - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
ConnectorException - Exception in org.mule.api.transport
ConnectorException Is thrown in the context of a Connector, usually some sort of transport level error where the connection has failed.
ConnectorException(Message, Connector) - Constructor for exception org.mule.api.transport.ConnectorException
 
ConnectorException(Message, Connector, Throwable) - Constructor for exception org.mule.api.transport.ConnectorException
 
ConnectorHolder<S extends Servlet,R extends MessageReceiver> - Interface in org.mule.transport.servlet.jetty
TODO
ConnectorLifecycleManager - Class in org.mule.transport
Manages the lifecycle of connectors in Mule.
ConnectorLifecycleManager(AbstractConnector) - Constructor for class org.mule.transport.ConnectorLifecycleManager
 
ConnectorMessageNotification - Class in org.mule.context.notification
Used to notify that a message was received or sent through a Connector.
ConnectorMessageNotification(MuleMessage, String, FlowConstruct, int) - Constructor for class org.mule.context.notification.ConnectorMessageNotification
 
ConnectorMessageNotificationListener<T extends ConnectorMessageNotification> - Interface in org.mule.api.context.notification
Observer interface to receive notifications about messages being sent and received from connectors
connectorName - Variable in class org.mule.endpoint.AbstractEndpointURIBuilder
 
connectorNotInJobDataMap() - Static method in class org.mule.transport.quartz.i18n.QuartzMessages
 
ConnectorOperationLocator - Interface in org.mule.api.connector
Locator for a MessageProcessor which is an operation from a Mule connector that fulfils the operation required.
ConnectorOperationProvider - Interface in org.mule.api.connector
Provider of operation for a Mule connector.
ConnectorPropertyEditor - Class in org.mule.config.spring.editors
Translates a connector name property into the corresponding Connector instance.
ConnectorPropertyEditor(MuleContext) - Constructor for class org.mule.config.spring.editors.ConnectorPropertyEditor
 
connectorSchemeIncompatibleWithEndpointScheme(Object, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
ConnectorService - Class in org.mule.module.management.mbean
 
ConnectorService(Connector) - Constructor for class org.mule.module.management.mbean.ConnectorService
 
ConnectorServiceMBean - Interface in org.mule.module.management.mbean
 
connectorWithProtocolNotRegistered(String) - Static method in class org.mule.config.i18n.CoreMessages
 
connectToJabberServer() - Method in class org.mule.transport.xmpp.XmppConnector
 
ConstantFactoryBean<T> - Class in org.mule.config.spring.factories
A FactoryBean which returns a fixed instanced obtained through the constructor.
ConstantFactoryBean(T) - Constructor for class org.mule.config.spring.factories.ConstantFactoryBean
 
ConstraintFilter - Class in org.mule.transaction.constraints
 
ConstraintFilter() - Constructor for class org.mule.transaction.constraints.ConstraintFilter
 
ConstructorReference - Class in org.mule.config.spring.parsers.processors
 
ConstructorReference(String) - Constructor for class org.mule.config.spring.parsers.processors.ConstructorReference
 
ConsumableMuleMessageFilter - Class in org.mule.routing.filters
Filters messages that have a consumable payload.
ConsumableMuleMessageFilter() - Constructor for class org.mule.routing.filters.ConsumableMuleMessageFilter
 
consume() - Method in class org.mule.streaming.AbstractConsumer
Retrieves the next available item.
consume() - Method in interface org.mule.streaming.Consumer
Retrieves the next available item.
Consumer<T> - Interface in org.mule.streaming
General interface for components able to consume data from any specific resource or stream, following the Producer-Consumer design pattern.
consumer - Variable in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
consumer - Variable in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
consumer - Variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver.JmsThreadContext
 
ConsumerIterator<T> - Class in org.mule.streaming
Implementation of Iterator that takes its elements from a Consumer .
ConsumerIterator(Consumer<T>) - Constructor for class org.mule.streaming.ConsumerIterator
 
ConsumerProducerInvocationHandler - Class in org.mule.transport.jms.xa
 
ConsumerProducerInvocationHandler(SessionInvocationHandler, Object) - Constructor for class org.mule.transport.jms.xa.ConsumerProducerInvocationHandler
 
consumers - Variable in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver
 
containerAlreadyRegistered(String) - Static method in class org.mule.config.i18n.CoreMessages
 
containerManaged - Variable in class org.mule.module.jbpm.Jbpm
Indicates whether jBPM has been instantiated by Mule (false) or was passed in from somewhere else (true).
ContainerManagedLifecyclePhase - Class in org.mule.lifecycle.phases
Deprecated.
as of 3.7.0 since it's no longer used
ContainerManagedLifecyclePhase(String, Class<?>, String) - Constructor for class org.mule.lifecycle.phases.ContainerManagedLifecyclePhase
Deprecated.
 
containerMode - Variable in class org.mule.module.management.agent.AbstractJmxAgent
 
contains(String) - Method in interface org.mule.api.el.ExpressionLanguageContext
 
contains(Serializable) - Method in interface org.mule.api.store.ObjectStore
Check whether the given Object is already registered with this store.
contains(Serializable, String) - Method in interface org.mule.api.store.PartitionableObjectStore
 
contains(String) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
contains(Object) - Method in class org.mule.module.launcher.util.ObservableList
 
contains(Serializable) - Method in class org.mule.tck.util.FakeObjectStore
 
contains(Object, Object) - Static method in class org.mule.transport.http.multipart.LazyList
 
contains(Serializable) - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
Check whether the given Object is already registered with this store.
contains(Object) - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
contains(JdkVersionUtils.JdkVersion) - Method in class org.mule.util.JdkVersionUtils.JdkVersionRange
 
contains(Serializable) - Method in class org.mule.util.queue.DefaultQueueStore
 
contains(Serializable) - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
contains(Serializable) - Method in interface org.mule.util.queue.RecoverableQueueStore
Checks if a certain object exists in the queue.
contains(Serializable) - Method in interface org.mule.util.queue.TransactionalQueueStoreDelegate
checks if the given value exists in the queue Used only during recovery phase which means this method does not require great performance
contains(Serializable) - Method in class org.mule.util.store.AbstractObjectStore
 
contains(Serializable) - Method in class org.mule.util.store.AbstractPartitionedObjectStore
 
contains(Serializable) - Method in class org.mule.util.store.InMemoryObjectStore
 
contains(Serializable) - Method in class org.mule.util.store.ManagedObjectStore
 
contains(Serializable) - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
contains(Serializable) - Method in class org.mule.util.store.ObjectStorePartition
 
contains(Serializable, String) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
contains(Serializable) - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
 
contains(Serializable, String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
contains(Serializable) - Method in class org.mule.util.store.PersistentObjectStorePartition
 
contains(Serializable) - Method in class org.mule.util.store.ProvidedObjectStoreWrapper
 
contains(Serializable, String) - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
contains(Serializable) - Method in class org.mule.util.store.QueueStoreAdapter
Deprecated.
 
containsAll(Collection<?>) - Method in class org.mule.module.launcher.util.ObservableList
 
containsBeanDefinition(String) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
containsHeader(String) - Method in class org.mule.transport.http.HttpRequest
 
containsHeader(String) - Method in class org.mule.transport.http.HttpResponse
 
containsHeader(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
containsKey(Object) - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
containsKey(Object) - Method in class org.mule.el.context.AbstractMapContext
 
containsKey(Object) - Method in class org.mule.expression.InboundAttachmentsMap
 
containsKey(Object) - Method in class org.mule.expression.OutboundAttachmentsMap
 
containsKey(Object) - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
containsKey(Object) - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
containsKey(Object) - Method in class org.mule.module.http.internal.ParameterMap
 
containsKey(Object) - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
containsKey(Object) - Method in class org.mule.transport.http.multipart.MultiMap
 
containsKey(Object) - Method in class org.mule.util.CaseInsensitiveMapWrapper
 
containsKey(Object) - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
containsKey(Object) - Method in class org.mule.util.MapCombiner
 
containsKey(Object) - Method in class org.mule.util.store.ObjectStoreToMapAdapter
 
containsServerFor(ServerAddress) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyServerManager
 
containsServerFor(ServerAddress) - Method in class org.mule.module.http.internal.listener.HttpListenerConnectionManager
 
containsServerFor(ServerAddress) - Method in interface org.mule.module.http.internal.listener.HttpServerManager
 
containsSharedResources() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
containsSharedResources() - Method in interface org.mule.module.launcher.domain.Domain
 
containsSharedResources() - Method in class org.mule.module.launcher.domain.DomainWrapper
 
ContainsTransformerMethods - Annotation Type in org.mule.api.annotations
Used to mark a that a class contains methods which are Mule Transformer.
containsType(Collection<?>, Class<?>) - Static method in class org.mule.util.CollectionUtils
 
containsType(Throwable, Class<?>) - Static method in class org.mule.util.ExceptionUtils
This method returns true if the throwable contains a Throwable that matches the specified class or subclass in the exception chain.
containsValue(Object) - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
containsValue(Object) - Method in class org.mule.el.context.AbstractMapContext
 
containsValue(Object) - Method in class org.mule.expression.InboundAttachmentsMap
 
containsValue(Object) - Method in class org.mule.expression.OutboundAttachmentsMap
 
containsValue(Object) - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
containsValue(Object) - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
containsValue(Object) - Method in class org.mule.module.http.internal.ParameterMap
 
containsValue(Object) - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
containsValue(Object) - Method in class org.mule.transport.http.multipart.MultiMap
 
containsValue(Object) - Method in class org.mule.util.CaseInsensitiveMapWrapper
 
containsValue(Object) - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
containsValue(Object) - Method in class org.mule.util.MapCombiner
 
containsValue(Object) - Method in class org.mule.util.store.ObjectStoreToMapAdapter
 
content - Variable in class org.mule.message.ds.StringDataSource
 
CONTENT_BASE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
CONTENT_DISPOSITION - Static variable in class org.mule.module.http.api.HttpHeaders.Names
CONTENT_ENCODING - Static variable in class org.mule.module.http.api.HttpHeaders.Names
CONTENT_ID - Static variable in class org.mule.module.http.api.HttpHeaders.Names
CONTENT_LANGUAGE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
CONTENT_LENGTH - Static variable in class org.mule.module.http.api.HttpHeaders.Names
CONTENT_LOCATION - Static variable in class org.mule.module.http.api.HttpHeaders.Names
CONTENT_MD5 - Static variable in class org.mule.module.http.api.HttpHeaders.Names
CONTENT_RANGE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
CONTENT_TRANSFER_ENCODING - Static variable in class org.mule.module.http.api.HttpHeaders.Names
CONTENT_TYPE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
CONTENT_TYPE - Static variable in class org.mule.transport.email.transformers.PlainTextDataSource
 
CONTENT_TYPE_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
CONTENT_TYPE_PROPERTY - Static variable in interface org.mule.transport.email.MailProperties
MuleEvent properties
CONTENT_TYPE_PROPERTY_KEY - Static variable in class org.mule.transport.servlet.ServletConnector
This property name is used to store the content type of the HttpServletRequest to the MuleMessage
CONTENT_TYPE_VALUE - Static variable in class org.mule.transport.http.components.RestServiceWrapper
 
ContentBasedRouter - Class in org.mule.config.dsl.routers
Deprecated.
ContentBasedRouter() - Constructor for class org.mule.config.dsl.routers.ContentBasedRouter
Deprecated.
 
contentType - Variable in class org.mule.message.ds.StringDataSource
 
context - Variable in class org.mule.api.schedule.SchedulerFactory
Mule context.
context - Variable in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
context - Variable in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
context - Variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
context - Variable in class org.mule.util.store.AbstractMonitoredObjectStore
 
context - Variable in class org.mule.util.store.MonitoredObjectStoreWrapper
 
CONTEXT_DISPOSED - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_DISPOSING - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
CONTEXT_INITIALISED - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_INITIALISING - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_STARTED - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_STARTING - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_STOPPED - Static variable in class org.mule.context.notification.MuleContextNotification
 
CONTEXT_STOPPING - Static variable in class org.mule.context.notification.MuleContextNotification
 
contextDestroyed(ServletContextEvent) - Method in class org.mule.config.builders.DeployableMuleXmlContextListener
 
contextDestroyed(ServletContextEvent) - Method in class org.mule.config.builders.MuleXmlBuilderContextListener
 
contextDestroyed(ServletContextEvent) - Method in class org.mule.transport.servlet.MuleServletContextListener
 
ContextExclusiveInjectorProcessor - Class in org.mule.config.spring.processors
Specialization of SelectiveInjectorProcessor which only considers beans which are defined on a given ApplicationContext.
ContextExclusiveInjectorProcessor(ApplicationContext) - Constructor for class org.mule.config.spring.processors.ContextExclusiveInjectorProcessor
 
contextInitialized(ServletContextEvent) - Method in class org.mule.config.builders.DeployableMuleXmlContextListener
 
contextInitialized(ServletContextEvent) - Method in class org.mule.config.builders.MuleXmlBuilderContextListener
 
contextInitialized(ServletContextEvent) - Method in class org.mule.transport.servlet.MuleServletContextListener
 
contextPropertyValueIsNull(String) - Static method in class org.mule.module.xml.i18n.XmlMessages
 
CONTINUE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
continueRoutingMessageAfter(MuleEvent) - Method in class org.mule.routing.outbound.AbstractSequenceRouter
Lets subclasses decide if the routing of a given message should continue or not after receiving a given response from a synchronous endpoint.
continueRoutingMessageAfter(MuleEvent) - Method in class org.mule.routing.outbound.MulticastingRouter
Deprecated.
Indicates that this router always routes messages to all the configured endpoints no matters what a given response is.
continueRoutingMessageAfter(MuleEvent) - Method in class org.mule.routing.outbound.SequenceRouter
Deprecated.
Determines if the routing should continue after receiving a given response from an synchronous endpoint.
ContinuousPollingReceiverWorker - Class in org.mule.transport
Bypass the regular scheduling mechanism in order to minimize latency and maximize throughput for transports which have low or no cost for performing a poll operation (such as an in-memory queue).
ContinuousPollingReceiverWorker(AbstractPollingMessageReceiver) - Constructor for class org.mule.transport.ContinuousPollingReceiverWorker
 
controlEvent(int) - Method in class org.mule.module.boot.MuleServerWrapper
Called whenever the native wrapper code traps a system control signal against the Java process.
controlEvent(int) - Method in class org.mule.module.boot.VersionWrapper
 
controlEvent(int) - Method in class org.mule.module.reboot.MuleContainerWrapper
Called whenever the native wrapper code traps a system control signal against the Java process.
Controller - Class in org.mule.test.infrastructure.process
 
Controller(String, int) - Constructor for class org.mule.test.infrastructure.process.Controller
 
Conventions - Class in org.mule.config.spring.parsers.assembly.configuration
Overloads the Spring Conventions class, specifically the Conventions.attributeNameToPropertyName(String) Method to evaluate the first character of the attribute name and ignore if it is upper case since this is not valid Bean notation and Mule uses upper case to signify a non-bean attribute name.
convert(String, MuleContext) - Method in interface org.mule.api.expression.PropertyConverter
 
convert(String, MuleContext) - Method in class org.mule.config.converters.FilterConverter
 
convert(String, MuleContext) - Method in class org.mule.config.converters.PropertiesConverter
 
convert(String, MuleContext) - Method in class org.mule.config.converters.TransformerConverter
 
convert(String[]) - Static method in class org.mule.config.endpoint.AnnotatedEndpointData
 
convert(String) - Static method in class org.mule.config.spring.editors.QNamePropertyEditor
 
convert(Element) - Method in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
Convert w3c element to dom4j element
convert(MuleEvent, HttpResponse, String) - Method in class org.mule.module.http.internal.request.HttpResponseToMuleEvent
 
convert(Source, XMLOutputFactory) - Method in class org.mule.module.json.transformers.AbstractToFromXmlTransformer
Return result of transformation
Converter - Interface in org.mule.api.transformer
Defines a Transformer that is a data type converters, ie: convert data from a type to another without modifying the meaning of the data.
converterClassDoesNotImplementInterface(Class) - Static method in class org.mule.module.xml.i18n.XmlMessages
 
ConverterFilter - Interface in org.mule.transformer.graph
Provides a way to filter a converters during the process of transformer resolution for a given source and result data types.
convertMultiPartHeaders(Map<String, Object>) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
convertMultiPartHeaders(Map<String, Object>) - Method in class org.mule.transport.http.HttpMultipartMuleMessageFactory
 
convertNumberToTargetClass(Number, Class<T>) - Static method in class org.mule.util.NumberUtils
 
convertProperties(String[]) - Method in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
convertProperty(Class, String) - Method in class org.mule.config.endpoint.AnnotatedEndpointHelper
 
convertsNullStringToNull(Object) - Static method in class org.mule.module.db.internal.util.ValueUtils
 
convertToBytes(Object, String) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
Converts an XML in-memory representation to a String using a specific encoding.
convertToFile(Object) - Method in class org.mule.transport.file.FileMuleMessageFactory
 
convertToText(Object) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
Deprecated.
Replaced by convertToText(Object obj, String ouputEncoding)
convertToText(Object, String) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
Converts an XML in-memory representation to a String using a specific encoding.
COOKIE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
COOKIE - Static variable in class org.mule.transport.tcp.protocols.SafeProtocol
 
COOKIE_SPEC_NETSCAPE - Static variable in class org.mule.transport.http.HttpConnector
 
COOKIE_SPEC_RFC2109 - Static variable in class org.mule.transport.http.HttpConnector
 
CookieHelper - Class in org.mule.transport.http
Helper functions for parsing, formatting, storing and retrieving cookie headers.
CookieWrapper - Class in org.mule.transport.http
 
CookieWrapper() - Constructor for class org.mule.transport.http.CookieWrapper
 
Copiable<T> - Interface in org.mule.api.util
A component that knows how to create copies of itself.
copy() - Method in interface org.mule.api.util.Copiable
Creates a new copy of this instance.
copy(MuleEvent) - Static method in class org.mule.DefaultMuleEvent
This method does a complete deep copy of the event.
copy(InputStream, OutputStream) - Static method in class org.mule.module.boot.MuleBootstrapUtils
 
copy(InputStream, OutputStream) - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
copy(XMLStreamReader, XMLStreamWriter) - Static method in class org.mule.module.xml.util.XMLUtils
Copies the reader to the writer.
copy(XMLStreamReader, XMLStreamWriter, boolean) - Static method in class org.mule.module.xml.util.XMLUtils
 
copy(InputStream, byte[], OutputStream) - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
Make a single transfer from source to dest via a byte array buffer
copy(InputStream, byte[], OutputStream, int) - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
Make a single transfer from source to dest via a byte array buffer
COPY_APPLICATION_NATIVE_LIBRARIES - Static variable in class org.mule.module.launcher.nativelib.DefaultNativeLibraryFinderFactory
 
COPY_APPLICATION_NATIVE_LIBRARIES_PROPERTY - Static variable in class org.mule.module.launcher.nativelib.DefaultNativeLibraryFinderFactory
 
CopyAttachmentInInterceptor - Class in org.mule.module.cxf.support
 
CopyAttachmentInInterceptor() - Constructor for class org.mule.module.cxf.support.CopyAttachmentInInterceptor
 
CopyAttachmentOutInterceptor - Class in org.mule.module.cxf.support
Copies any attachments which were stored by the proxy to the outbound CXF message.
CopyAttachmentOutInterceptor() - Constructor for class org.mule.module.cxf.support.CopyAttachmentOutInterceptor
 
CopyAttachmentsTransformer - Class in org.mule.transformer.simple
 
CopyAttachmentsTransformer() - Constructor for class org.mule.transformer.simple.CopyAttachmentsTransformer
 
copyAttributes(HttpServletRequest, Map<String, Object>) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
copyBeanToTarget() - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
Copy the properties from the bean we have been building into the target (typically the parent bean).
copyBeanToTarget() - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
Copy the properties from the bean we have been building into the target (typically the parent bean).
copyConfigurationFrom(ConfigurableBeanFactory) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
copyEnvironmentVariables() - Method in class org.mule.test.infrastructure.process.Controller
 
copyFile(File, File, boolean) - Static method in class org.mule.util.FileUtils
Copies a file to a new location.
copyHeaders(HttpServletRequest, Map<String, Object>) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
CopyInboundToOutboundPropertiesTransformerCallback - Class in org.mule.transport.http.construct.support
 
CopyInboundToOutboundPropertiesTransformerCallback() - Constructor for class org.mule.transport.http.construct.support.CopyInboundToOutboundPropertiesTransformerCallback
 
copyJMSProperties(Message, Message, JmsConnector) - Static method in class org.mule.transport.jms.JmsMessageUtils
 
copyLarge(InputStream, OutputStream) - Static method in class org.mule.module.boot.MuleBootstrapUtils
 
copyLarge(InputStream, OutputStream) - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
copyLarge(InputStream, OutputStream) - Static method in class org.mule.util.IOUtils
Re-implement copy method to allow buffer size to be configured.
copyLarge(Reader, Writer) - Static method in class org.mule.util.IOUtils
Re-implement copy method to allow buffer size to be configured.
copyMessageProperties(MuleMessage) - Method in class org.mule.DefaultMuleMessage
 
copyOnVoidEvent - Variable in class org.mule.processor.BlockingProcessorExecutor
 
CopyOnWriteCaseInsensitiveMap<K,V> - Class in org.mule.util
Implementation of Map that provides copy on write semantics while providing the case-insensitivity of CaseInsensitiveHashMap.
CopyOnWriteCaseInsensitiveMap() - Constructor for class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
CopyOnWriteCaseInsensitiveMap(Map<K, V>) - Constructor for class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
copyOutboundProperties(HttpResponse, MuleMessage) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
copyParameters(HttpServletRequest, Map<String, Object>) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
copyProperties(MuleMessage, ContainerRequest) - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
CopyPropertiesTransformer - Class in org.mule.transformer.simple
 
CopyPropertiesTransformer() - Constructor for class org.mule.transformer.simple.CopyPropertiesTransformer
 
copyStream(InputStream, OutputStream) - Method in class org.mule.transport.tcp.protocols.StreamingProtocol
 
copyStreamToFile(InputStream, File) - Method in class org.mule.transport.sftp.SftpUtil
Should be moved to a util class that is not based on an endpoint...
copyStreamToFile(InputStream, File) - Static method in class org.mule.util.FileUtils
 
copyToInbound(DefaultMuleMessage) - Method in class org.mule.DefaultMuleMessage
copy outbound artifacts to inbound artifacts in the new message
CORE_EXTENSION_PROPERTIES - Static variable in class org.mule.module.launcher.coreextension.ClasspathMuleCoreExtensionDiscoverer
 
CoreExtensionsAware - Interface in org.mule
Enables injection of all available MuleCoreExtension.
CoreMessages - Class in org.mule.config.i18n
 
CoreMessages() - Constructor for class org.mule.config.i18n.CoreMessages
 
CorePatternNamespaceHandler - Class in org.mule.pattern.core.config
Registers a Bean Definition Parser for handling elements.
CorePatternNamespaceHandler() - Constructor for class org.mule.pattern.core.config.CorePatternNamespaceHandler
 
CORRELATION_TIMEOUT - Static variable in class org.mule.context.notification.RoutingNotification
 
CorrelationMode - Enum in org.mule.routing
 
CorrelationPropertiesExpressionEvaluator - Class in org.mule.routing.correlation
CorrelationPropertiesExpressionEvaluator is a default implementation used for getting the Correlation information from a message.
CorrelationPropertiesExpressionEvaluator() - Constructor for class org.mule.routing.correlation.CorrelationPropertiesExpressionEvaluator
 
CorrelationSequenceComparator - Class in org.mule.routing.correlation
CorrelationSequenceComparator is a Comparator for MuleEvents using their respective correlation sequences.
CorrelationSequenceComparator() - Constructor for class org.mule.routing.correlation.CorrelationSequenceComparator
 
correlationTimedOut(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
CorrelationTimeoutException - Exception in org.mule.routing.correlation
 
CorrelationTimeoutException(Message, MuleEvent) - Constructor for exception org.mule.routing.correlation.CorrelationTimeoutException
 
CorrelationTimeoutException(Message, MuleEvent, Throwable) - Constructor for exception org.mule.routing.correlation.CorrelationTimeoutException
 
CORRUPTED_FOLDER - Static variable in class org.mule.util.store.PersistentObjectStorePartition
 
couldNotCreateScheduler() - Static method in class org.mule.modules.schedulers.i18n.SchedulerMessages
 
couldNotDetermineDestinationComponentFromEndpoint(String) - Static method in class org.mule.config.i18n.CoreMessages
 
couldNotFindEndpoint(QName, List<QName>) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
couldNotFindSoapProvider(String) - Static method in class org.mule.transport.soap.axis.i18n.AxisMessages
 
couldNotFindStreamWithName(ImmutableEndpoint) - Static method in class org.mule.transport.stdio.i18n.StdioMessages
 
couldNotGetSchedulerStatus() - Static method in class org.mule.modules.schedulers.i18n.SchedulerMessages
 
couldNotInitAnnotationProcessor(Object) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
couldNotPauseSchedulers() - Static method in class org.mule.modules.schedulers.i18n.SchedulerMessages
 
couldNotRegisterNewScheduler(String) - Static method in class org.mule.config.i18n.CoreMessages
 
CouldNotRouteOutboundMessageException - Exception in org.mule.api.routing
CouldNotRouteOutboundMessageException thrown if Mule fails to route the current outbound event.
CouldNotRouteOutboundMessageException(MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.routing.CouldNotRouteOutboundMessageException
 
CouldNotRouteOutboundMessageException(MuleEvent, MessageProcessor, Throwable) - Constructor for exception org.mule.api.routing.CouldNotRouteOutboundMessageException
 
CouldNotRouteOutboundMessageException(Message, MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.routing.CouldNotRouteOutboundMessageException
 
CouldNotRouteOutboundMessageException(Message, MuleEvent, MessageProcessor, Throwable) - Constructor for exception org.mule.api.routing.CouldNotRouteOutboundMessageException
 
couldNotScheduleJob() - Static method in class org.mule.modules.schedulers.i18n.SchedulerMessages
 
couldNotSendExpect100() - Static method in class org.mule.transport.http.i18n.HttpMessages
 
couldNotShutdownScheduler() - Static method in class org.mule.modules.schedulers.i18n.SchedulerMessages
 
count - Variable in class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
count - Variable in class org.mule.tck.testmodels.services.TestComponent
 
count - Variable in class org.mule.tck.testmodels.services.TestReceiver
 
COUNT_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 
CountdownCallback - Class in org.mule.tck.functional
 
CountdownCallback(int) - Constructor for class org.mule.tck.functional.CountdownCallback
 
Counter - Interface in org.mule.util.counters
This interface is the interface implemented for all counter types.
COUNTER_PROPERTY - Static variable in class org.mule.routing.Foreach
 
CounterCallback - Class in org.mule.tck.functional
A test callback that counts the number of messages received.
CounterCallback() - Constructor for class org.mule.tck.functional.CounterCallback
 
CounterCallback(AtomicInteger) - Constructor for class org.mule.tck.functional.CounterCallback
 
CounterFactory - Class in org.mule.util.counters
This class is the Counter's factory.
CounterFactory.Type - Class in org.mule.util.counters
Enum class for all different types of counters.
CounterFactory.Type(String) - Constructor for class org.mule.util.counters.CounterFactory.Type
Constructor of the type
CounterFactoryImpl - Class in org.mule.util.counters.impl
 
counterVariableName - Variable in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
countFailOrNullEvent() - Method in class org.mule.tck.functional.AssertionMessageProcessor
 
CountingRedeliveryHandler - Class in org.mule.transport.jms.redelivery
This redelivery handler will keep counting the redelivery attempts for each message redelivered.
CountingRedeliveryHandler() - Constructor for class org.mule.transport.jms.redelivery.CountingRedeliveryHandler
 
CountingRedeliveryHandlerFactory - Class in org.mule.transport.jms.redelivery
 
CountingRedeliveryHandlerFactory() - Constructor for class org.mule.transport.jms.redelivery.CountingRedeliveryHandlerFactory
 
countRetry() - Method in class org.mule.retry.policies.SimpleRetryPolicy.RetryCounter
 
CPU_J2EE - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
CPU_SAMPLING - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
CPU_TRACING - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
CR - Static variable in class org.mule.transport.http.multipart.MultiPartInputStream
 
create(Object, JavaComponent, FlowConstruct, EntryPointResolverSet, MuleContext) - Method in interface org.mule.api.component.LifecycleAdapterFactory
 
create(Map<?, ?>) - Method in interface org.mule.api.config.PropertyFactory
Creates a property using code execution.
create(ServiceType, String, Properties, Properties, MuleContext, ClassLoader) - Static method in class org.mule.api.registry.ServiceDescriptorFactory
Factory method to create a new service descriptor.
create(String, T) - Method in class org.mule.api.schedule.SchedulerFactory
Creates a scheduler for a job and runs all the registered post processors.
create(Authentication) - Method in interface org.mule.api.security.SecurityContextFactory
 
create(MuleConfiguration) - Method in interface org.mule.api.transaction.TransactionManagerFactory
Creates of obtains the jta transaction manager to use for mule transactions
create(OutboundEndpoint) - Method in interface org.mule.api.transport.MessageDispatcherFactory
Creates a new message dispatcher instance, initialised with the passed endpoint.
create(InboundEndpoint) - Method in interface org.mule.api.transport.MessageRequesterFactory
Creates a new message requester instance, initialised with the passed endpoint.
create(Object, String) - Method in interface org.mule.api.transport.MuleMessageFactory
Deprecated.
create(Object, MuleMessage, String) - Method in interface org.mule.api.transport.MuleMessageFactory
create(Object, String, MuleContext) - Method in interface org.mule.api.transport.MuleMessageFactory
Creates a MuleMessage instance from transportMessage by extracting its payload and, if available, any relevant message properties and attachments.
create(Object, MuleMessage, String, MuleContext) - Method in interface org.mule.api.transport.MuleMessageFactory
Creates a MuleMessage instance by extracting the payload from transportMessage.
create(Object, JavaComponent, FlowConstruct, EntryPointResolverSet, MuleContext) - Method in class org.mule.component.DefaultComponentLifecycleAdapterFactory
 
create() - Method in interface org.mule.config.bootstrap.BootstrapObjectFactory
 
create(MuleContext) - Method in interface org.mule.config.dsl.Builder
Deprecated.
 
create(Map<?, ?>) - Method in class org.mule.config.factories.HostNameFactory
 
create(Locator) - Method in interface org.mule.config.spring.XmlMetadataAnnotationsFactory
 
create() - Method in class org.mule.module.atom.AbderaFactory
 
create(DataSource) - Method in class org.mule.module.db.internal.domain.connection.AbstractConnectionFactory
 
create(DataSource) - Method in interface org.mule.module.db.internal.domain.connection.ConnectionFactory
Creates a connection for a DataSource
create(DataSourceConfig) - Method in class org.mule.module.db.internal.domain.database.DataSourceFactory
Creates a dataSource from a given dataSource config
create(String, Map<QName, Object>, DataSource) - Method in interface org.mule.module.db.internal.domain.database.DbConfigFactory
Creates a DbConfig to access a given DataSource
create(String, Map<QName, Object>, DataSource) - Method in class org.mule.module.db.internal.domain.database.GenericDbConfigFactory
 
create() - Method in interface org.mule.module.db.internal.domain.executor.BulkQueryExecutorFactory
 
create() - Method in class org.mule.module.db.internal.domain.executor.BulkUpdateExecutorFactory
 
create() - Method in interface org.mule.module.db.internal.domain.executor.QueryExecutorFactory
 
create() - Method in class org.mule.module.db.internal.domain.executor.SelectExecutorFactory
 
create() - Method in class org.mule.module.db.internal.domain.executor.StoredProcedureExecutorFactory
 
create() - Method in class org.mule.module.db.internal.domain.executor.UpdateExecutorFactory
 
create(DbConnection, QueryTemplate) - Method in class org.mule.module.db.internal.domain.statement.QueryStatementFactory
 
create(DbConnection, QueryTemplate, AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.domain.statement.QueryStatementFactory
 
create(DbConnection, QueryTemplate) - Method in interface org.mule.module.db.internal.domain.statement.StatementFactory
Creates a JDBC statement
create(DbConnection, QueryTemplate, AutoGeneratedKeyStrategy) - Method in interface org.mule.module.db.internal.domain.statement.StatementFactory
Creates a JDBC statement with auto generated keys processing
create(QueryTemplate) - Method in class org.mule.module.db.internal.resolver.param.GenericParamTypeResolverFactory
 
create(QueryTemplate) - Method in interface org.mule.module.db.internal.resolver.param.ParamTypeResolverFactory
Creates a new parameter type resolver to resolve the parameter types of a given query template.
create(DbConnection, Statement, QueryTemplate, AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.result.statement.GenericStatementResultIteratorFactory
 
create(DbConnection, Statement, QueryTemplate, AutoGeneratedKeyStrategy) - Method in interface org.mule.module.db.internal.result.statement.StatementResultIteratorFactory
 
create(HttpClientConfiguration) - Method in interface org.mule.module.http.internal.request.HttpClientFactory
 
create(MuleEvent, String, String) - Method in class org.mule.module.http.internal.request.MuleEventToHttpRequest
 
create(MuleConfiguration) - Method in class org.mule.module.jboss.transaction.JBossArjunaTransactionManagerFactory
 
create(ApplicationDescriptor) - Method in interface org.mule.module.launcher.application.ApplicationClassLoaderFactory
 
create(ApplicationDescriptor) - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoaderFactory
 
create(ApplicationDescriptor) - Method in class org.mule.module.launcher.application.MuleApplicationClassLoaderFactory
 
create(String) - Method in class org.mule.module.launcher.nativelib.DefaultNativeLibraryFinderFactory
 
create(String) - Method in interface org.mule.module.launcher.nativelib.NativeLibraryFinderFactory
Creates a ntive library finder for the given application
create(Authentication) - Method in class org.mule.module.pgp.PGPSecurityContextFactory
 
create(Authentication) - Method in class org.mule.module.spring.security.SpringSecurityContextFactory
 
create(MuleConfiguration) - Method in class org.mule.module.spring.transaction.SpringTransactionManagerFactory
 
create(Authentication) - Method in class org.mule.security.DefaultSecurityContextFactory
 
create(MuleConfiguration) - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
create(MuleConfiguration) - Method in class org.mule.transaction.lookup.WebsphereTransactionManagerLookupFactory
This constructor retrieves the WebSphere TransactionManager factory class, so we can get access to the JTA TransactionManager.
create(Class<T>) - Static method in class org.mule.transformer.types.DataTypeFactory
 
create(Class<T>, String) - Static method in class org.mule.transformer.types.DataTypeFactory
 
create(Class<? extends Collection>, Class<T>) - Static method in class org.mule.transformer.types.DataTypeFactory
 
create(Class<? extends Collection>, Class<T>, String) - Static method in class org.mule.transformer.types.DataTypeFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.AbstractMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.AbstractMessageRequesterFactory
 
create(Object, String) - Method in class org.mule.transport.AbstractMuleMessageFactory
create(Object, MuleMessage, String) - Method in class org.mule.transport.AbstractMuleMessageFactory
create(Object, MuleMessage, String, MuleContext) - Method in class org.mule.transport.AbstractMuleMessageFactory
 
create(Object, String, MuleContext) - Method in class org.mule.transport.AbstractMuleMessageFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.ajax.AjaxMessageDispatcherFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.ejb.EjbMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.email.RetrieveMessageRequesterFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.email.SmtpMessageDispatcherFactory
Creates a new message dispatcher instance, initialised with the passed endpoint.
create(OutboundEndpoint) - Method in class org.mule.transport.file.FileMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.file.FileMessageRequesterFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.ftp.FtpMessageDispatcherFactory
Creates a new message dispatcher instance, initialised with the passed endpoint.
create(InboundEndpoint) - Method in class org.mule.transport.ftp.FtpMessageRequesterFactory
Creates a new message requester instance, initialised with the passed endpoint.
create(OutboundEndpoint) - Method in class org.mule.transport.http.HttpClientMessageDispatcherFactory
Creates a new message dispatcher instance, initialised with the passed endpoint.
create(InboundEndpoint) - Method in class org.mule.transport.http.HttpClientMessageRequesterFactory
Creates a new message requester instance, initialised with the passed endpoint.
create(OutboundEndpoint) - Method in class org.mule.transport.http.HttpsClientMessageDispatcherFactory
 
create - Variable in class org.mule.transport.jdbc.config.DerbyDataSourceFactoryBean
 
create(OutboundEndpoint) - Method in class org.mule.transport.jdbc.JdbcMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.jdbc.JdbcMessageRequesterFactory
 
create(String, Object) - Method in class org.mule.transport.jdbc.sqlstrategy.DefaultSqlStatementStrategyFactory
 
create(String, Object) - Method in interface org.mule.transport.jdbc.sqlstrategy.SqlStatementStrategyFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.jms.JmsMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.jms.JmsMessageRequesterFactory
 
create() - Method in class org.mule.transport.jms.redelivery.AutoDiscoveryRedeliveryHandlerFactory
 
create() - Method in class org.mule.transport.jms.redelivery.CountingRedeliveryHandlerFactory
 
create() - Method in class org.mule.transport.jms.redelivery.JmsXRedeliveryHandlerFactory
 
create() - Method in interface org.mule.transport.jms.redelivery.RedeliveryHandlerFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
create(InboundEndpoint) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
create(OutboundEndpoint) - Method in class org.mule.transport.quartz.QuartzMessageDispatcherFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.rmi.RmiMessageDispatcherFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.sftp.SftpMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.sftp.SftpMessageRequesterFactory
Creates a new message requester instance, initialised with the passed endpoint.
create(OutboundEndpoint) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcherFactory
 
create() - Method in class org.mule.transport.soap.axis.AxisMessageReceiver
 
create(InboundEndpoint) - Method in class org.mule.transport.soap.axis.AxisMessageRequesterFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.soap.axis.wsdl.AxisWsdlMessageDispatcherFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.stdio.StdioMessageDispatcherFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.tcp.LocalSocketTcpMessageDispatcherFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.tcp.TcpMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.tcp.TcpMessageRequesterFactory
 
create(Work, WorkListener) - Method in class org.mule.transport.TrackerWorkListenerWrapperFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.udp.UdpMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.udp.UdpMessageRequesterFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.UnsupportedMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.UnsupportedMessageRequesterFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.vm.VMMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.vm.VMMessageRequesterFactory
 
create(Work, WorkListener) - Method in interface org.mule.transport.WorkListenerWrapperFactory
 
create(ImmutableEndpoint) - Method in class org.mule.transport.xmpp.XmppConversationFactory
 
create(OutboundEndpoint) - Method in class org.mule.transport.xmpp.XmppMessageDispatcherFactory
 
create(InboundEndpoint) - Method in class org.mule.transport.xmpp.XmppMessageRequesterFactory
 
create(Class<?>, Collection<?>) - Static method in class org.mule.util.Multicaster
 
create(Class<?>, Collection<?>, Multicaster.InvokeListener) - Static method in class org.mule.util.Multicaster
 
create(Class<?>[], Collection<?>) - Static method in class org.mule.util.Multicaster
 
create(Class<?>[], Collection<?>, Multicaster.InvokeListener) - Static method in class org.mule.util.Multicaster
 
create() - Method in interface org.mule.util.xa.XAResourceFactory
 
createAdapter(MuleEvent, String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Create a new adapter using the specified verifier and insert it into the pool.
createAdapter(MuleEvent, String) - Method in interface org.mule.security.oauth.OAuth2Manager
Create a new adapter using the specified verifier and insert it into the pool.
createAdaptor() - Method in class org.mule.module.management.agent.JdmkAgent
 
createAdaptor() - Method in class org.mule.module.management.agent.Mx4jAgent
 
createAlgorithmParameterSpec() - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
createAlgorithmParameterSpec() - Method in class org.mule.security.PasswordBasedEncryptionStrategy
 
createAlgorithmParameterSpec() - Method in class org.mule.security.SecretKeyEncryptionStrategy
Deprecated.
 
createAnchorFile(String) - Method in class org.mule.module.launcher.ArtifactArchiveInstaller
 
createAndInitCiphers() - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
createAndInitCiphers() - Method in class org.mule.security.SecretKeyEncryptionStrategy
Deprecated.
 
createAnnotationsParserFactory() - Method in class org.mule.config.AnnotationsConfigurationBuilder
 
createAntStyleParser() - Static method in class org.mule.util.TemplateParser
 
createAppFrom(ApplicationDescriptor) - Method in class org.mule.module.launcher.application.DefaultApplicationFactory
 
createApplication(Set<Class<?>>) - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
createApplicationConfigurationBuilder(Application) - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
createApplicationConfigurationBuilder(Application) - Method in interface org.mule.module.launcher.domain.Domain
Creates a ConfigurationBuilder for a certain application which is going to be configured to use the correct domain.
createApplicationConfigurationBuilder(Application) - Method in class org.mule.module.launcher.domain.DomainWrapper
 
createAppMuleContext(String[]) - Method in class org.mule.tck.junit4.DomainFunctionalTestCase
 
createArchetype(String, String, String, ArtifactRepository, List, Map) - Method in class com.javaforge.bobber.plugin.archetype.BobberArchetype
 
createArgument(Class<?>, MuleContext) - Method in class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
If the resolver cannot locate the required object of type AbstractAnnotatedTransformerArgumentResolver.getArgumentClass() this method will be invoked an instance of the object.
createArgument(Class<?>, MuleContext) - Method in class org.mule.module.json.transformers.JsonMapperResolver
If the resolver cannot locate the required object of type AbstractAnnotatedTransformerArgumentResolver.getArgumentClass() this method will be invoked an instance of the object.
createArgument(Class, MuleContext) - Method in class org.mule.module.xml.transformer.jaxb.JAXBContextResolver
 
createArrayOf(String, Object[]) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
createArrayOf(String, Object[]) - Method in class org.mule.module.db.internal.domain.connection.OracleDbConnection
 
createArrayOf(String, Object[]) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
createArrayOf(String, Object[]) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
createArtifact(String) - Method in interface org.mule.module.launcher.application.ApplicationFactory
Creates an application
createArtifact(String, Optional<Properties>) - Method in class org.mule.module.launcher.application.DefaultApplicationFactory
 
createArtifact(String) - Method in class org.mule.module.launcher.application.DefaultApplicationFactory
 
createArtifact(String) - Method in interface org.mule.module.launcher.artifact.ArtifactFactory
Creates an Artifact
createArtifact(String, Optional<Properties>) - Method in interface org.mule.module.launcher.artifact.ArtifactFactory
Creates an Artifact
createArtifact(String, Optional<Properties>) - Method in class org.mule.module.launcher.domain.DefaultDomainFactory
 
createArtifact(String) - Method in class org.mule.module.launcher.domain.DefaultDomainFactory
 
createAsyncMessageProcessor(StageNameSource, MuleContext) - Method in class org.mule.construct.flow.DefaultFlowProcessingStrategy
 
createAsyncMessageProcessor(StageNameSource, MuleContext) - Method in class org.mule.processor.strategy.AsynchronousProcessingStrategy
 
createAsyncMessageProcessor(StageNameSource, MuleContext) - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
createAsyncReplyProcessor() - Method in class org.mule.service.AbstractService
Deprecated.
 
createAuthentication(String, String, MuleEvent) - Method in class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
 
createAuthorizationCodeProcessor(TokenResponseConfiguration, ExpressionManager) - Static method in class org.mule.module.oauth2.internal.TokenResponseProcessor
 
createAxisProvider(String) - Method in class org.mule.transport.soap.axis.AxisConnector
 
createBeanDefinitionBuilder(Element, Class<?>) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
createBeanDefinitionBuilder(Element, Class<?>) - Method in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
createBeanDefinitionBuilder(Element, Class<?>) - Method in class org.mule.config.spring.parsers.specific.endpoint.support.ChildEndpointDefinitionParser
 
createBeanDefinitionParserDelegate(XmlReaderContext) - Method in class org.mule.config.spring.MuleBeanDefinitionDocumentReader
 
createBeanDefinitionParserDelegate(XmlReaderContext) - Method in class org.mule.config.spring.MuleDomainBeanDefinitionDocumentReader
 
createBeanDefinitionReader(DefaultListableBeanFactory) - Method in class org.mule.config.spring.MuleArtifactContext
 
createBeanFactory() - Method in class org.mule.config.spring.MuleArtifactContext
 
createBeginNotification(MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundNotificationMessageProcessor
 
createBlob() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
createBlob() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
createBlob() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
createBrowser(Queue) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createBrowser(Queue, String) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createBrowser(Queue) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createBrowser(Queue, String) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createBrowser(Queue) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createBrowser(Queue, String) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createBulkQuery(MuleEvent) - Method in class org.mule.module.db.internal.resolver.query.AbstractBulkQueryResolver
 
createBulkQuery(MuleEvent) - Method in class org.mule.module.db.internal.resolver.query.StaticBulkQueryResolver
 
createBulkQueryLogger(Log, QueryTemplate, int) - Method in class org.mule.module.db.internal.domain.logger.DefaultQueryLoggerFactory
 
createBulkQueryLogger(Log) - Method in class org.mule.module.db.internal.domain.logger.DefaultQueryLoggerFactory
 
createBulkQueryLogger(Log, QueryTemplate, int) - Method in interface org.mule.module.db.internal.domain.logger.QueryLoggerFactory
Creates a logger for a single query running in bulk mode
createBulkQueryLogger(Log) - Method in interface org.mule.module.db.internal.domain.logger.QueryLoggerFactory
Creates a logger for a bulk query
createBytesMessage() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createBytesMessage() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createBytesMessage() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createCallback(HttpCallbackAdapter, String, FetchAccessTokenMessageProcessor, MessageProcessor, MuleContext, FlowConstruct) - Method in interface org.mule.api.callback.HttpCallbackFactory
returns a new callback that has not been started
createCallback(HttpCallbackAdapter, String, FetchAccessTokenMessageProcessor, MessageProcessor, MuleContext, FlowConstruct) - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackFactory
 
createChatConversation(ImmutableEndpoint) - Method in class org.mule.transport.xmpp.XmppConversationFactory
 
createCheckpointJournalEntry(T, byte) - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
Creates a checkpoint JournalEntry.
createCheckpointJournalEntry(Integer, byte) - Method in class org.mule.util.journal.queue.LocalTxQueueTransactionJournal
 
createCheckpointJournalEntry(Xid, byte) - Method in class org.mule.util.journal.queue.XaTxQueueTransactionJournal
 
createChildDefinitionParser(Class) - Static method in class org.mule.module.cxf.config.WsSecurityDefinitionParser
 
createClient() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
createClient() - Method in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
createClient() - Method in class org.mule.module.cxf.builder.LocalClientMessageProcessorBuilder
 
createClient() - Method in class org.mule.module.cxf.builder.ProxyClientMessageProcessorBuilder
 
createClient() - Method in class org.mule.module.cxf.builder.SimpleClientMessageProcessorBuilder
 
createClient() - Method in class org.mule.module.cxf.builder.WsdlClientMessageProcessorBuilder
 
createClient() - Method in class org.mule.transport.sftp.SftpConnectionFactory
 
createClientCredentialsProcessor(TokenResponseConfiguration, ExpressionManager) - Static method in class org.mule.module.oauth2.internal.TokenResponseProcessor
 
createClientFromLocalServer() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
createClob() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
createClob() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
createClob() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
createConfigResourcesString() - Method in class org.mule.config.builders.AbstractResourceConfigurationBuilder
 
createConfiguration() - Method in class org.mule.config.PropertiesMuleConfigurationFactory
 
createConfigurationBuilder() - Method in class org.mule.MuleServer
 
createConfigurationBuilderFromApplicationProperties() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
createConfigurationBuilderFromDeploymentProperties() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
createConfigurationInstanceProvider(String, Extension, Configuration, ResolverSet, MuleContext, ConfigurationInstanceRegistrationCallback) - Static method in class org.mule.module.extension.internal.util.MuleExtensionUtils
 
createConnection(TransactionalAction) - Method in interface org.mule.module.db.internal.domain.connection.DbConnectionFactory
Creates a connection with a given TransactionalAction
createConnection(TransactionalAction) - Method in class org.mule.module.db.internal.domain.connection.TransactionalDbConnectionFactory
 
createConnection(String, String) - Method in class org.mule.transport.jms.CustomCachingConnectionFactory
 
createConnection(ConnectionFactory, String, String) - Method in class org.mule.transport.jms.Jms102bSupport
 
createConnection(ConnectionFactory) - Method in class org.mule.transport.jms.Jms102bSupport
 
createConnection(ConnectionFactory, String, String) - Method in class org.mule.transport.jms.Jms11Support
 
createConnection(ConnectionFactory) - Method in class org.mule.transport.jms.Jms11Support
 
createConnection() - Method in class org.mule.transport.jms.JmsConnector
 
createConnection(ConnectionFactory) - Method in interface org.mule.transport.jms.JmsSupport
 
createConnection(ConnectionFactory, String, String) - Method in interface org.mule.transport.jms.JmsSupport
 
createConnection() - Method in class org.mule.transport.jms.xa.DefaultXAConnectionFactoryWrapper
 
createConnection(String, String) - Method in class org.mule.transport.jms.xa.DefaultXAConnectionFactoryWrapper
 
createConnectionFactory() - Method in class org.mule.transport.jms.JmsConnector
 
createConnector(EndpointURI) - Method in class org.mule.config.endpoint.ConfigurableTransportFactory
 
createConnector - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
createConnector() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createConnector() - Method in class org.mule.transport.service.MetaTransportServiceDescriptor
Override the connector cration and register our Meta scheme with the connecotr so that the connector can be used when creating endpoints using this meta transport
createConnector(EndpointURI) - Method in class org.mule.transport.service.TransportFactory
Creates an uninitialied connector from the provided MuleEndpointURI.
createConnector(String) - Method in class org.mule.transport.service.TransportFactory
 
createConnector() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createConsumer(Session, Destination, String, boolean, String, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms102bSupport
 
createConsumer(Session, Destination, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms11Support
 
createConsumer(Session, Destination, String, boolean, String, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms11Support
 
createConsumer() - Method in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
Create a consumer for the jms destination
createConsumer(Session, Destination, String, boolean, String, boolean, ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsSupport
 
createConsumer(Session, Destination, boolean, ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsSupport
 
createConsumer() - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.SubReceiver
Create a consumer for the jms destination.
createConsumer(Destination) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createConsumer(Destination, String) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createConsumer(Destination, String, boolean) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createConsumer(Destination) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createConsumer(Destination, String) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createConsumer(Destination, String, boolean) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createConsumer(Destination) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createConsumer(Destination, String) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createConsumer(Destination, String, boolean) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createConsumer() - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
Create a consumer for the jms destination
createContainerSystemClassLoader() - Method in class org.mule.module.reboot.MuleContainerWrapper
 
createContent(MultipartHttpEntity, String) - Static method in class org.mule.module.http.internal.multipart.HttpMultipartEncoder
 
createContext(Resource) - Method in class org.mule.config.spring.jndi.SpringInitialContextFactory
 
createContext(Connection, FilterChainContext.Operation) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
 
createContextHolder(Connector, InboundEndpoint, MessageReceiver) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
createCookie() - Method in class org.mule.transport.http.CookieWrapper
 
createCounter(String, CounterFactory.Type) - Static method in class org.mule.util.counters.CounterFactory
Create a new public counter of the given type.
createCounter(String, CounterFactory.Type, boolean) - Static method in class org.mule.util.counters.CounterFactory
Create a new counter of the given type and visibility.
createCounter(String, String, CounterFactory.Type) - Static method in class org.mule.util.counters.CounterFactory
Create a new public aggregate counter of the given type.
createCounter(String, String, CounterFactory.Type, boolean) - Static method in class org.mule.util.counters.CounterFactory
Create a new aggregate counter of the given type and visibility.
createCounter(String, String, String, CounterFactory.Type) - Static method in class org.mule.util.counters.CounterFactory
Create a new public aggregate counter of the given type.
createCounter(String, String, String, CounterFactory.Type, boolean) - Static method in class org.mule.util.counters.CounterFactory
Create a new aggregate counter of the given type and visibility.
createCounter(String, String, String, CounterFactory.Type, boolean) - Static method in class org.mule.util.counters.impl.CounterFactoryImpl
 
createCurlyBracesStyleParser() - Static method in class org.mule.util.TemplateParser
 
createDataBase(String) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
Create a new embedded database
createDataBase(String, String) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
Create a new embedded database
createDataBase(String, String[]) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
Create a new embedded database
createDataBase(String, String[], Properties) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
Create a new embedded database
createDataContentHandler(String) - Method in class org.mule.transport.email.DefaultDataContentHandlerFactory
 
createDataHandlerFrom(Collection<HttpPart>) - Static method in class org.mule.module.http.internal.multipart.HttpPartDataSource
 
createDataSourceFactory() - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
createDbConnectionFactory(DataSource, ConnectionFactory, DbTypeManager) - Method in class org.mule.module.db.internal.domain.database.GenericDbConfigFactory
Creates the DbConnectionFactory to use on the created DbConfig
createDbConnectionFactory(DataSource, ConnectionFactory, DbTypeManager) - Method in class org.mule.module.db.internal.domain.database.OracleDbConfigFactory
 
createDefault(MuleContext) - Static method in class org.mule.module.oauth2.internal.tokenmanager.TokenManagerConfig
 
createDefault() - Static method in class org.mule.util.xmlsecurity.XMLSecureFactories
 
createDefaultDomain() - Method in class org.mule.module.launcher.domain.DefaultDomainFactory
 
createDefaultDomain() - Method in interface org.mule.module.launcher.domain.DomainFactory
 
createDefaultInMemoryObjectStore() - Method in interface org.mule.util.store.DefaultObjectStoreFactory
Creates an in memory object store for mule components
createDefaultInMemoryObjectStore() - Static method in class org.mule.util.store.DefaultObjectStoreFactoryBean
 
createDefaultInMemoryObjectStore() - Method in class org.mule.util.store.MuleDefaultObjectStoreFactory
 
createDefaultInMemoryQueueStore() - Method in interface org.mule.util.store.DefaultObjectStoreFactory
Creates an in memory object store for storing queue events
createDefaultInMemoryQueueStore() - Static method in class org.mule.util.store.DefaultObjectStoreFactoryBean
 
createDefaultInMemoryQueueStore() - Method in class org.mule.util.store.MuleDefaultObjectStoreFactory
 
createDefaultMuleContext() - Method in class org.mule.context.DefaultMuleContextBuilder
 
createDefaultMuleContext() - Method in class org.mule.module.launcher.application.ApplicationMuleContextBuilder
 
createDefaultMuleContext() - Method in class org.mule.module.launcher.domain.DomainMuleContextBuilder
 
createDefaultNotificationManager() - Static method in class org.mule.context.DefaultMuleContextBuilder
 
createDefaultPersistentObjectStore() - Method in interface org.mule.util.store.DefaultObjectStoreFactory
Creates a persistent object store for mule components
createDefaultPersistentObjectStore() - Static method in class org.mule.util.store.DefaultObjectStoreFactoryBean
 
createDefaultPersistentObjectStore() - Method in class org.mule.util.store.MuleDefaultObjectStoreFactory
 
createDefaultPersistentQueueStore() - Method in interface org.mule.util.store.DefaultObjectStoreFactory
Creates a persistent object store for storing queue events
createDefaultPersistentQueueStore() - Static method in class org.mule.util.store.DefaultObjectStoreFactoryBean
 
createDefaultPersistentQueueStore() - Method in class org.mule.util.store.MuleDefaultObjectStoreFactory
 
createDefaultProcessingStrategy() - Method in class org.mule.construct.AbstractPipeline
A fallback method for creating a ProcessingStrategy to be used in case the user hasn't specified one through either AbstractPipeline.setProcessingStrategy(ProcessingStrategy), through MuleConfiguration.getDefaultProcessingStrategy() or the MuleProperties.MULE_DEFAULT_PROCESSING_STRATEGY system property
createDefaultProcessingStrategy() - Method in class org.mule.construct.Flow
A fallback method for creating a ProcessingStrategy to be used in case the user hasn't specified one through either AbstractPipeline.setProcessingStrategy(ProcessingStrategy), through MuleConfiguration.getDefaultProcessingStrategy() or the MuleProperties.MULE_DEFAULT_PROCESSING_STRATEGY system property
createDefaultRedeliveryPolicy(int) - Method in interface org.mule.api.endpoint.InboundEndpoint
 
createDefaultRedeliveryPolicy(int) - Method in interface org.mule.api.transport.Connector
 
createDefaultRedeliveryPolicy(int) - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
createDefaultRedeliveryPolicy(int) - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
createDefaultRedeliveryPolicy(int) - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
createDefaultRedeliveryPolicy(int) - Method in class org.mule.transport.AbstractConnector
 
createDefaultTrustStoreProperties() - Static method in class org.mule.module.ws.security.WSCryptoUtils
Creates a Properties object configured to use the default trust store.
createDefaultUserObjectStore() - Method in interface org.mule.util.store.DefaultObjectStoreFactory
Creates a persistent object store for custom components
createDefaultUserObjectStore() - Static method in class org.mule.util.store.DefaultObjectStoreFactoryBean
 
createDefaultUserObjectStore() - Method in class org.mule.util.store.MuleDefaultObjectStoreFactory
 
createDefaultUserTransientObjectStore() - Method in interface org.mule.util.store.DefaultObjectStoreFactory
Creates a transient object store for custom components
createDefaultUserTransientObjectStore() - Static method in class org.mule.util.store.DefaultObjectStoreFactoryBean
 
createDefaultUserTransientObjectStore() - Method in class org.mule.util.store.MuleDefaultObjectStoreFactory
 
createDelegate(XmlReaderContext, Element, BeanDefinitionParserDelegate) - Method in class org.mule.config.spring.MuleBeanDefinitionDocumentReader
 
createDelegate(QueueInfo, MuleContext) - Method in interface org.mule.util.queue.objectstore.QueueInfo.QueueInfoDelegateFactory
Deprecated.
Create a delegate
createDeleteMethod(MuleMessage) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
createDestination(Session, String, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms102bSupport
 
createDestination(Session, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms11Support
 
createDestination(Session, String, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms11Support
 
createDestination(Session, String, boolean, ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsSupport
 
createDestination(Session, ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsSupport
 
createDirectory(File) - Method in class org.mule.util.store.PersistentObjectStorePartition
 
createDispatcherFactory() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createDispatcherFactory() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createDispatcherMessageProcessor(OutboundEndpoint) - Method in class org.mule.transport.AbstractConnector
 
createDispatcherMessageProcessor(OutboundEndpoint) - Method in class org.mule.transport.http.HttpConnector
 
createDispatcherMessageProcessor(OutboundEndpoint) - Method in class org.mule.transport.jdbc.JdbcConnector
 
createDocumentBuilderFactory() - Method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
createDurableSubscriber(Topic, String) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createDurableSubscriber(Topic, String) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createDurableSubscriber(Topic, String) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createDynamicFlow(MuleContext, String, List<MessageProcessor>) - Static method in class org.mule.module.oauth2.internal.DynamicFlowFactory
Creates a programmatic flow
createDynamicReferenceMessageProcessor(String) - Method in class org.mule.config.spring.factories.FlowRefFactoryBean
 
createEndpointBuilder(String) - Method in class org.mule.module.guice.AbstractMuleGuiceModule
Deprecated.
Creates an EndpointBuilder instance for the endpoint uri.
createEndpointBuilder(String) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createEndpointBuilder(String, MuleContext) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createEndpointBuilder(EndpointURIEndpointBuilder) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createEndpointBuilder(EndpointURIEndpointBuilder, MuleContext) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createEndpointBuilder(Object[]) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createEndpointBuilder(String) - Method in interface org.mule.transport.service.TransportServiceDescriptor
Deprecated.
createEndpointBuilder(String, MuleContext) - Method in interface org.mule.transport.service.TransportServiceDescriptor
Creates a EndpointBuilder
createEndpointBuilder(EndpointURIEndpointBuilder) - Method in interface org.mule.transport.service.TransportServiceDescriptor
Deprecated.
createEndpointBuilder(EndpointURIEndpointBuilder, MuleContext) - Method in interface org.mule.transport.service.TransportServiceDescriptor
Creates a EndpointBuilder wrapping an existing builder
createEndpointData(Annotation) - Method in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
createEndpointData(Annotation) - Method in class org.mule.transport.quartz.config.ScheduleAnnotationParser
 
createEndpointInfo(ServiceInfo, BindingInfo, List<?>) - Method in class org.mule.module.cxf.transport.MuleUniversalTransport
 
createEndpointURIBuilder() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createEndpointURIBuilder() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createEnrichmentExpression(String) - Method in class org.mule.expression.DefaultExpressionManager
 
createEntityMethod(MuleEvent, Object, EntityEnclosingMethod) - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
createEntryPointResolverSet() - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
createErrorHandlingExecutionTemplate(MuleContext, MessagingExceptionHandler) - Static method in class org.mule.execution.ErrorHandlingExecutionTemplate
Creates a ErrorHandlingExecutionTemplate to be used as the main enthat will route any MessagingException thrown to an exception listener
createEventFromMuleMessage(MuleMessage) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
createEventGroup(MuleEvent, Object) - Method in class org.mule.routing.correlation.CollectionCorrelatorCallback
Creates a new EventGroup that will expect the number of events as returned by MuleMessage.getCorrelationGroupSize().
createEventGroup(MuleEvent, Object) - Method in interface org.mule.routing.correlation.EventCorrelatorCallback
Creates the event group with a specific correlation size based on the Mule Correlation support
createEventLock() - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
Creates the lock used to synchronize a given event
createEventToRoute(MuleEvent, MuleMessage, MessageProcessor) - Method in class org.mule.routing.AbstractRoutingStrategy
Create a new event to be routed to the target MP
createEventToRoute(MuleEvent, MuleMessage, MessageProcessor) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
Create a new event to be routed to the target MP
CreateException - Exception in org.mule.api.lifecycle
CreateException is thrown when creating an object inside Mule wasn't possible due to inconsistent internal state or wrong input.
CreateException(Message, Object) - Constructor for exception org.mule.api.lifecycle.CreateException
 
CreateException(Message, Throwable, Object) - Constructor for exception org.mule.api.lifecycle.CreateException
 
CreateException(Throwable, Object) - Constructor for exception org.mule.api.lifecycle.CreateException
 
createExceptionTransformerExecutionTemplate() - Static method in class org.mule.execution.MessageProcessorExecutionTemplate
 
createExecutionTemplate() - Static method in class org.mule.execution.MessageProcessorExecutionTemplate
 
createExecutionTemplate() - Method in class org.mule.transport.AbstractMessageReceiver
 
createExecutor() - Method in class org.mule.module.extension.internal.runtime.ReflectiveOperationExecutorFactory
 
createExecutorFactory(Element) - Method in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
createExecutorFactory(Element) - Method in class org.mule.module.db.internal.config.processor.BulkExecuteProcessorBeanDefinitionParser
 
createExecutorFactory(Element) - Method in class org.mule.module.db.internal.config.processor.ExecuteDdlProcessorBeanDefinitionParser
 
createExecutorFactory(Element) - Method in class org.mule.module.db.internal.config.processor.PreparedBulkUpdateProcessorBeanDefinitionParser
 
createExecutorFactory(Element) - Method in class org.mule.module.db.internal.config.processor.SelectProcessorDefinitionParser
 
createExecutorFactory(Element) - Method in class org.mule.module.db.internal.config.processor.SingleUpdateProcessorDefinitionParser
 
createExecutorFactory(Element) - Method in class org.mule.module.db.internal.config.processor.StoredProcedureProcessorBeanDefinitionParser
 
createExpressionLanguageContext() - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
createFactory() - Method in class org.mule.util.xmlsecurity.XMLFactoryConfig
 
createFieldDebugInfo(String, Class<?>, AttributeEvaluator, MuleEvent) - Static method in class org.mule.api.debug.FieldDebugInfoFactory
Creates a debug info for a field
createFieldDebugInfo(String, Class<?>, FieldDebugInfoFactory.FieldEvaluator) - Static method in class org.mule.api.debug.FieldDebugInfoFactory
Creates a debug info for a field
createFieldDebugInfo(String, Class<?>, Object) - Static method in class org.mule.api.debug.FieldDebugInfoFactory
Creates a debug info for a simple field
createFieldDebugInfo(String, Class<?>, List<FieldDebugInfo<?>>) - Static method in class org.mule.api.debug.FieldDebugInfoFactory
Creates a debug info for an object field
createFieldDebugInfo(String, Class<?>, Exception) - Static method in class org.mule.api.debug.FieldDebugInfoFactory
Creates an error debug info for a field
createFieldDebugInfo(String, String, Object) - Static method in class org.mule.api.debug.FieldDebugInfoFactory
Creates a debug info for a simple field
createFieldDebugInfo(String, String, List<FieldDebugInfo<?>>) - Static method in class org.mule.api.debug.FieldDebugInfoFactory
Creates a debug info for an object field
createFieldDebugInfo(String, String, Exception) - Static method in class org.mule.api.debug.FieldDebugInfoFactory
Creates an error debug info for a field
createFile() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
createFile(String) - Static method in class org.mule.util.FileUtils
 
createFileToStoreObject() - Method in class org.mule.util.store.PersistentObjectStorePartition
 
createFilter(String) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
 
createFilter() - Method in class org.mule.transport.xmpp.filters.AbstractXmppFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppAndFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppFromContainsFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppMessageTypeFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppNotFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppOrFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppPacketIDFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppPacketTypeFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppThreadFilter
 
createFilter() - Method in class org.mule.transport.xmpp.filters.XmppToContainsFilter
 
createFlowConstruct() - Method in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
createForDisjunctGroups(Element, Collection<CheckExclusiveAttributes.AttributeSet>) - Static method in exception org.mule.config.spring.parsers.processors.CheckExclusiveAttributes.CheckExclusiveAttributesException
 
createForInsufficientAttributes(Element, Collection<CheckExclusiveAttributes.AttributeSet>) - Static method in exception org.mule.config.spring.parsers.processors.CheckExclusiveAttributes.CheckExclusiveAttributesException
 
createFrom(Descriptor) - Method in class org.mule.module.extension.internal.introspection.DefaultExtensionFactory
createFrom(Descriptor, DescribingContext) - Method in class org.mule.module.extension.internal.introspection.DefaultExtensionFactory
createFrom(Collection<HttpPart>) - Static method in class org.mule.module.http.internal.multipart.HttpPartDataSource
 
createFrom(Map<String, DataHandler>) - Static method in class org.mule.module.http.internal.multipart.HttpPartDataSource
 
createFromField(Field) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createFromField(Field, String) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createFromMethodParam(Method, int) - Static method in class org.mule.transformer.types.CollectionDataType
 
createFromMethodParam(Method, int, String) - Static method in class org.mule.transformer.types.CollectionDataType
 
createFromMethodReturn(Method) - Static method in class org.mule.transformer.types.CollectionDataType
 
createFromMethodReturn(Method, String) - Static method in class org.mule.transformer.types.CollectionDataType
 
createFromObject(Object) - Static method in class org.mule.transformer.types.DataTypeFactory
Will create a DataType object from an object instance.
createFromParameterType(Method, int) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createFromParameterType(Method, int, String) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createFromReturnType(Method) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createFromReturnType(Method, String) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createFromString(String) - Static method in enum org.mule.config.bootstrap.ArtifactType
 
createFtpClient() - Method in class org.mule.transport.ftp.FtpConnectionFactory
 
createFtpClient(ImmutableEndpoint) - Method in class org.mule.transport.ftp.FtpConnector
Creates a new FTPClient that logs in and changes the working directory using the data provided in endpoint.
createGetMethod(MuleMessage, String) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
createGroupchatConversation(ImmutableEndpoint) - Method in class org.mule.transport.xmpp.XmppConversationFactory
 
createHeader(String, char[]) - Static method in class org.mule.security.MuleCredentials
 
createHeader(String, String, String, EncryptionStrategy) - Static method in class org.mule.security.MuleCredentials
 
createHeaders() - Method in class org.mule.module.cxf.MuleSoapHeaders
 
createHeadMethod(MuleMessage) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
createHelper(XmlReaderContext, Element) - Method in class org.mule.config.spring.MuleBeanDefinitionDocumentReader
 
createHttpRequest() - Method in class org.mule.transport.http.HttpServerConnection
 
createImmutable(Class<T>) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createInboundEndpoint(EndpointURI, List<MessageProcessor>, List<MessageProcessor>, Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
createInboundMessage() - Method in interface org.mule.api.MuleMessage
Copy an inbound message to an outbound one, moving all message properties and attachments
createInboundMessage() - Method in class org.mule.DefaultMessageCollection
Copy an inbound message to an outbound one, moving all message properties and attachments
createInboundMessage() - Method in class org.mule.DefaultMuleMessage
 
createInboundMessageProcessorChain(InboundEndpoint, FlowConstruct, MessageProcessor) - Method in interface org.mule.api.endpoint.EndpointMessageProcessorChainFactory
 
createInboundMessageProcessorChain(InboundEndpoint, FlowConstruct, MessageProcessor) - Method in class org.mule.endpoint.DefaultEndpointMessageProcessorChainFactory
 
createInboundMessageProcessors(InboundEndpoint) - Method in class org.mule.endpoint.DefaultEndpointMessageProcessorChainFactory
Override this method to change the default MessageProcessors.
createInboundResponseMessageProcessors(InboundEndpoint) - Method in class org.mule.endpoint.DefaultEndpointMessageProcessorChainFactory
Override this method to change the default MessageProcessors.
createInboundTransformers(ImmutableEndpoint) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createInboundTransformers(ImmutableEndpoint) - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createIndexedVariable(int, String, Object) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
createIndexedVariable(int, String, Object, Class<?>) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
createInitialContext() - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
Creates a JNDI context using the current AbstractJndiNameResolver.contextFactory
createInjector(Module...) - Static method in class org.guiceyfruit.mule.MuleModule
Deprecated.
Returns a new Injector with support for Mule lifecycle support along with JSR 250 support included.
createInnerChain(LinkedList<MessageProcessor>) - Method in class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
 
createInnerChain(LinkedList<MessageProcessor>) - Method in class org.mule.processor.chain.SimpleMessageProcessorChainBuilder
 
createInstance() - Method in class org.mule.config.spring.factories.AbstractQueueStoreFactoryBean
 
createInstance() - Method in class org.mule.config.spring.factories.AnnotatedObjectFactoryBean
 
createInstance() - Method in class org.mule.config.spring.factories.ObjectStoreFromRegistryFactoryBean
 
createInstance() - Method in class org.mule.config.spring.factories.QueueProfileFactoryBean
 
createInstance() - Method in class org.mule.config.spring.factories.WatermarkFactoryBean
 
createInstance() - Method in class org.mule.module.db.internal.config.domain.query.QueryTemplateFactoryBean
 
createInstance() - Method in class org.mule.module.json.config.MapperFactoryBean
 
createInstance() - Method in class org.mule.module.xml.config.JaxbContextFactoryBean
 
createInstance(String) - Static method in class org.mule.module.xml.util.XMLUtils
 
createInstance() - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
createInstance() - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
createInstance() - Method in class org.mule.transport.jms.redelivery.AutoDiscoveryRedeliveryHandlerFactory
Create an instance using the discovery mechanism.
createInvoker(CxfInboundMessageProcessor) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
createInvoker(CxfInboundMessageProcessor) - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
createJarFileEntries(File, LinkedHashMap) - Static method in class org.mule.util.JarUtils
 
createJdkVersionRanges(String) - Static method in class org.mule.util.JdkVersionUtils
 
createJdmkAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
createJettyConnector() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
createJettyConnector() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
createJettyConnector() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
createJmsSupport() - Method in class org.mule.transport.jms.JmsConnector
A factory method to create various JmsSupport class versions.
createJmxAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
createJmxNotificationAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
createKeySpec() - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
createKeySpec() - Method in class org.mule.security.PasswordBasedEncryptionStrategy
 
createKeySpec() - Method in class org.mule.security.SecretKeyEncryptionStrategy
Deprecated.
 
createKeyStoreProperties(TlsContextKeyStoreConfiguration) - Static method in class org.mule.module.ws.security.WSCryptoUtils
Creates a Properties object with the attributes of a key store.
createLifecycleAdaptor() - Method in class org.mule.component.AbstractJavaComponent
Creates and initialises a new LifecycleAdaptor instance wrapped the component object instance obtained from the configured object factory.
createLifecycleManager() - Method in class org.mule.config.spring.SpringRegistry
 
createLifecycleManager() - Method in class org.mule.context.DefaultMuleContextBuilder
 
createLifecycleManager() - Method in class org.mule.registry.AbstractRegistry
 
createLifecycleManager() - Method in class org.mule.transport.AbstractMessageDispatcher
 
createLifecycleManager() - Method in class org.mule.transport.AbstractMessageReceiver
 
createLifecycleManager() - Method in class org.mule.transport.AbstractMessageRequester
 
createLifecycleManager() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
createLifecycleState() - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
createListenerForRedirectUrl() - Method in class org.mule.module.oauth2.internal.authorizationcode.AbstractAuthorizationCodeTokenRequestHandler
 
createLoader() - Method in class org.mule.config.spring.MuleArtifactContext
 
createLocalTxQueueJournalEntrySerializer(MuleContext) - Static method in class org.mule.util.journal.queue.LocalTxQueueTransactionJournal
 
createLock(String) - Method in interface org.mule.util.lock.LockFactory
Provides a lock to create thread safe Mule components.
createLock(String) - Method in interface org.mule.util.lock.LockProvider
Returns an instance of a Lock.
createLock(String) - Method in class org.mule.util.lock.MuleLockFactory
 
createLock(String) - Method in class org.mule.util.lock.SingleServerLockProvider
 
createLog4jAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
createMainExecutionTemplate(MuleContext, MessagingExceptionHandler) - Static method in class org.mule.execution.TransactionalErrorHandlingExecutionTemplate
Creates a TransactionalErrorHandlingExecutionTemplate to be used as first processing template in a flow using no transaction configuration
createMainExecutionTemplate(MuleContext, TransactionConfig, MessagingExceptionHandler) - Static method in class org.mule.execution.TransactionalErrorHandlingExecutionTemplate
Creates a TransactionalErrorHandlingExecutionTemplate to be used as first processing template in a flow
createMainExecutionTemplate(MuleContext, TransactionConfig) - Static method in class org.mule.execution.TransactionalErrorHandlingExecutionTemplate
Creates a TransactionalErrorHandlingExecutionTemplate to be used as first processing template in a flow using no particular exception listener.
createMapMessage() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createMapMessage() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createMapMessage() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createMessage(String, int, Object) - Method in class org.mule.config.i18n.MessageFactory
Factory method to create a new Message instance that is filled with the formatted message with id code from the resource bundle bundlePath.
createMessage(String, int, Object, Object) - Method in class org.mule.config.i18n.MessageFactory
Factory method to create a new Message instance that is filled with the formatted message with id code from the resource bundle bundlePath.
createMessage(String, int, Object, Object, Object) - Method in class org.mule.config.i18n.MessageFactory
Factory method to create a new Message instance that is filled with the formatted message with id code from the resource bundle bundlePath.
createMessage(String, int, Object...) - Method in class org.mule.config.i18n.MessageFactory
Factory method to create a new Message instance that is filled with the formatted message with id code from the resource bundle bundlePath.
createMessage(String, int) - Method in class org.mule.config.i18n.MessageFactory
Factory method to create a new Message instance that is filled with the formatted message with id code from the resource bundle bundlePath.
createMessage(ApplicationDescriptor) - Method in class org.mule.module.launcher.application.ApplicationStartedSplashScreen
 
createMessage(D) - Method in class org.mule.module.launcher.artifact.ArtifactStartedSplashScreen
 
createMessage(DomainDescriptor) - Method in class org.mule.module.launcher.domain.DomainStartedSplashScreen
 
createMessage(Object, MuleMessage, Object, String, MuleContext) - Method in class org.mule.transport.AbstractMuleMessageFactory
 
createMessage() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createMessage() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createMessage() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createMessage(Object, Call, MuleContext) - Static method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
createMessageConversation(ImmutableEndpoint) - Method in class org.mule.transport.xmpp.XmppConversationFactory
 
createMessageFromSource(Object) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
createMessageFromSource(Object) - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
createMessageFromSource(Object) - Method in class org.mule.transport.servlet.jetty.JettyMessageProcessTemplate
 
createMessageIdStore() - Method in class org.mule.routing.IdempotentMessageFilter
 
createMessageProcessor() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
createMessageProcessorChain(FlowConstruct) - Method in class org.mule.endpoint.AbstractEndpoint
 
createMessageProcessorChain(FlowConstruct) - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
createMessageProcessorChain(FlowConstruct) - Method in class org.mule.endpoint.DefaultOutboundEndpoint
 
createMessageProcessorChain() - Method in class org.mule.service.ServiceAsyncReplyCompositeMessageSource
Deprecated.
 
createMessageProcessorChain() - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
createMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createMessageReceiver(Connector, FlowConstruct, InboundEndpoint, Object...) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createMessageReceiver(Connector, FlowConstruct, InboundEndpoint, Object...) - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createMessageWithJmsMessagePayload(Message) - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
createModel() - Method in interface org.mule.api.model.ModelServiceDescriptor
Deprecated.
 
createModel() - Method in class org.mule.model.DefaultModelServiceDescriptor
Deprecated.
createModule() - Method in interface org.mule.module.guice.GuiceModuleFactory
Deprecated.
 
createMuleConfiguration() - Method in class org.mule.context.DefaultMuleContextBuilder
 
createMuleConfiguration() - Method in class org.mule.module.launcher.application.ApplicationMuleContextBuilder
 
createMuleConfiguration() - Method in class org.mule.MuleServer
 
createMuleContext() - Method in interface org.mule.api.context.MuleContextFactory
Returns an existing instance of MuleContext is one exists, otherwise a new MuleContext instance is created with defaults.
createMuleContext(MuleContextBuilder) - Method in interface org.mule.api.context.MuleContextFactory
Creates a new MuleContext using the MuleContextBuilder provided.
createMuleContext(ConfigurationBuilder) - Method in interface org.mule.api.context.MuleContextFactory
Creates a new MuleContext using the given configurationBuilder
createMuleContext(ConfigurationBuilder, MuleContextBuilder) - Method in interface org.mule.api.context.MuleContextFactory
Creates a new MuleContext using the MuleContextBuilder provided and configures it with the list of configuration builder and c onfigures it with configurationBuilder
createMuleContext(List<ConfigurationBuilder>, MuleContextBuilder) - Method in interface org.mule.api.context.MuleContextFactory
Creates a new MuleContext using the MuleContextBuilder provided and configures it with the list of configuration builders.
createMuleContext(String, ServletContext) - Method in class org.mule.config.builders.MuleXmlBuilderContextListener
Creates the MuleContext based on the configuration resource(s) and possibly init parameters for the Servlet.
createMuleContext() - Method in class org.mule.context.DefaultMuleContextFactory
Use default ConfigurationBuilder, default MuleContextBuilder
createMuleContext(ConfigurationBuilder) - Method in class org.mule.context.DefaultMuleContextFactory
Use default MuleContextBuilder
createMuleContext(MuleContextBuilder) - Method in class org.mule.context.DefaultMuleContextFactory
Use default ConfigurationBuilder
createMuleContext(List<ConfigurationBuilder>, MuleContextBuilder) - Method in class org.mule.context.DefaultMuleContextFactory
Creates a new MuleContext using the MuleContextBuilder provided and configures it with the list of configuration builders.
createMuleContext(ConfigurationBuilder, MuleContextBuilder) - Method in class org.mule.context.DefaultMuleContextFactory
Creates a new MuleContext using the MuleContextBuilder provided and configures it with the list of configuration builder and c onfigures it with configurationBuilder
createMuleContext(String) - Method in class org.mule.context.DefaultMuleContextFactory
Creates a new MuleContext instance from the resource provided.
createMuleContext(String, Properties) - Method in class org.mule.context.DefaultMuleContextFactory
Creates a new MuleContext instance from the resource provided.
createMuleContext(ConfigurationBuilder, Properties) - Method in class org.mule.context.DefaultMuleContextFactory
Creates a new MuleContext using the given configurationBuilder.
createMuleContext(ConfigurationBuilder, Properties, MuleConfiguration) - Method in class org.mule.context.DefaultMuleContextFactory
Creates a new MuleContext using the given configurationBuilder and configuration.
createMuleContext() - Method in class org.mule.tck.AbstractConfigurationErrorTestCase
 
createMuleContextBuilder() - Method in class org.mule.context.DefaultMuleContextFactory
 
createMuleEvent(MuleMessage, OutboundEndpoint) - Method in class org.mule.client.DefaultLocalMuleClient
 
createMuleEvent(MuleMessage, OutboundEndpoint, MuleSession) - Method in class org.mule.client.DefaultLocalMuleClient
 
createMuleEvent(MuleMessage, OutputStream) - Method in class org.mule.transport.AbstractMessageReceiver
 
createMuleEvent(MuleMessage, OutputStream) - Method in class org.mule.transport.quartz.QuartzMessageReceiver
 
createMuleMessage(Object, String) - Method in interface org.mule.api.transport.MessageDispatcher
 
createMuleMessage(Object) - Method in interface org.mule.api.transport.MessageDispatcher
 
createMuleMessage(Object, String) - Method in interface org.mule.api.transport.MessageReceiver
 
createMuleMessage(Object) - Method in interface org.mule.api.transport.MessageReceiver
 
createMuleMessage(Object, String) - Method in interface org.mule.api.transport.MessageRequester
 
createMuleMessage(Object) - Method in interface org.mule.api.transport.MessageRequester
 
createMuleMessage(Object, MuleMessage, String) - Method in class org.mule.transport.AbstractTransportMessageHandler
Uses this object's MuleMessageFactory to create a new MuleMessage instance.
createMuleMessage(Object, String) - Method in class org.mule.transport.AbstractTransportMessageHandler
Uses this object's MuleMessageFactory to create a new MuleMessage instance.
createMuleMessage(Object) - Method in class org.mule.transport.AbstractTransportMessageHandler
Uses this object's MuleMessageFactory to create a new MuleMessage instance.
createMuleMessage(Message, MuleContext) - Method in class org.mule.transport.jms.redelivery.AbstractRedeliveryHandler
 
createMuleMessage(Object, String) - Method in class org.mule.transport.sftp.SftpMessageReceiver
 
createMuleMessageFactory() - Method in interface org.mule.api.transport.Connector
Creates a new MuleMessageFactory using what's defined in the connector's transport service descriptor.
createMuleMessageFactory() - Method in class org.mule.transport.AbstractConnector
Create a MuleMessageFactory from this connector's configuration, typically through the transport descriptor.
createMuleMessageFactory() - Method in class org.mule.transport.AbstractTransportMessageHandler
This method uses the connector's createMuleMessageFactory method to create a new MuleMessageFactory.
createMuleMessageFactory() - Method in class org.mule.transport.file.FileConnector
 
createMuleMessageFactory(FTPClient) - Method in class org.mule.transport.ftp.FtpMessageReceiver
 
createMuleMessageFactory(FTPClient) - Method in class org.mule.transport.ftp.FtpMessageRequester
 
createMuleMessageFactory() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createMuleMessageFactory() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createMuleMessages(List<Object>) - Method in class org.mule.transport.jdbc.JdbcMessageReceiver
Creates a mule message per each data record.
createMuleStyleParser() - Static method in class org.mule.util.TemplateParser
 
createMuleWorkManager() - Method in class org.mule.context.DefaultMuleContextBuilder
 
createMultiPart(MuleMessage) - Method in class org.mule.module.http.internal.request.MuleEventToHttpRequest
 
createMultiPart(MuleMessage, EntityEnclosingMethod) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
createMultipartContent(MultipartHttpEntity, String) - Static method in class org.mule.module.http.internal.multipart.HttpMultipartEncoder
 
createMultipleTransactedReceivers - Variable in class org.mule.transport.AbstractConnector
 
createMx4jAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
createNClob() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
createNClob() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
createNClob() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
createNotification(MuleContext, String) - Method in class org.mule.lifecycle.NotificationLifecycleObject
 
createNotificationExecutionTemplate() - Static method in class org.mule.execution.MessageProcessorExecutionTemplate
 
createNotificationManager() - Method in class org.mule.context.DefaultMuleContextBuilder
 
createNotificationManager() - Method in class org.mule.module.launcher.domain.DomainMuleContextBuilder
 
createNullMuleMessage() - Method in class org.mule.transport.AbstractTransportMessageHandler
Uses this object's MuleMessageFactory to create a new MuleMessage instance.
createObjectMessage() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createObjectMessage(Serializable) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createObjectMessage() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createObjectMessage(Serializable) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createObjectMessage() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createObjectMessage(Serializable) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createObjectPool() - Method in interface org.mule.transport.ConfigurableKeyedObjectPoolFactory
 
createObjectPool() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPoolFactory
 
createOperationResource(ImmutableEndpoint) - Method in class org.mule.transport.AbstractConnector
 
createOperationResource(ImmutableEndpoint) - Method in class org.mule.transport.jdbc.JdbcConnector
 
createOperationResource(ImmutableEndpoint) - Method in class org.mule.transport.jms.JmsConnector
 
createOperationResource(ImmutableEndpoint) - Method in class org.mule.transport.vm.VMConnector
 
createOptionsMethod(MuleMessage) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
createOrLocateShouldBeSet() - Static method in class org.mule.module.management.i18n.ManagementMessages
 
createOrRetrievePartitionDescriptorFile() - Method in class org.mule.util.store.PersistentObjectStorePartition
 
createOutboundEndpoint(EndpointURI, List<MessageProcessor>, List<MessageProcessor>, Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
createOutboundMessageProcessor() - Method in class org.mule.module.ws.consumer.WSConsumerConfig
Creates an outbound endpoint for the service address.
createOutboundMessageProcessorChain(OutboundEndpoint, MessageProcessor) - Method in interface org.mule.api.endpoint.EndpointMessageProcessorChainFactory
 
createOutboundMessageProcessorChain(OutboundEndpoint, MessageProcessor) - Method in class org.mule.endpoint.DefaultEndpointMessageProcessorChainFactory
 
createOutboundMessageProcessors(OutboundEndpoint) - Method in class org.mule.endpoint.DefaultEndpointMessageProcessorChainFactory
Override this method to change the default MessageProcessors.
createOutboundResponseMessageProcessors(OutboundEndpoint) - Method in class org.mule.endpoint.DefaultEndpointMessageProcessorChainFactory
Override this method to change the default MessageProcessors.
createOutboundTransformers(ImmutableEndpoint) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createOutboundTransformers(ImmutableEndpoint) - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createOuterChain(LinkedList<MessageProcessor>) - Method in class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
 
createOuterChain(LinkedList<MessageProcessor>) - Method in class org.mule.processor.chain.SimpleMessageProcessorChainBuilder
 
createPacket() - Method in class org.mule.transport.udp.UdpMessageReceiver
 
createPacketCollector() - Method in class org.mule.transport.xmpp.AbstractXmppConversation
 
createPacketCollector() - Method in class org.mule.transport.xmpp.XmppMultiUserChatConversation
createPacketFilter() - Method in class org.mule.transport.xmpp.AbstractXmppConversation
 
createPacketFilter() - Method in class org.mule.transport.xmpp.XmppChatConversation
 
createPacketFilter() - Method in class org.mule.transport.xmpp.XmppMessageConversation
 
createParserConfiguration(Map<String, Class<?>>) - Static method in class org.mule.el.mvel.MVELExpressionLanguage
 
createPatchMethod(MuleMessage, String) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
createPersistentTransactionContext() - Method in class org.mule.util.queue.LocalTxQueueTransactionContext
 
createPersistentTransactionContext() - Method in interface org.mule.util.queue.QueueTransactionContextFactory
 
createPersistentTransactionContext() - Method in class org.mule.util.queue.XaQueueTypeTransactionContextAdapter
 
createPipeline() - Method in class org.mule.construct.AbstractPipeline
Creates a MessageProcessor that will process messages from the configured MessageSource .
createPool() - Method in interface org.mule.api.config.ThreadingProfile
 
createPool(String) - Method in interface org.mule.api.config.ThreadingProfile
 
createPool() - Method in class org.mule.config.ChainedThreadingProfile
 
createPool(String) - Method in class org.mule.config.ChainedThreadingProfile
 
createPool() - Method in class org.mule.config.ImmutableThreadingProfile
 
createPool(String) - Method in class org.mule.config.ImmutableThreadingProfile
 
createPool() - Method in class org.mule.config.MutableThreadingProfile
 
createPool(String) - Method in class org.mule.config.MutableThreadingProfile
 
createPool(String, ThreadingProfile) - Method in class org.mule.config.pool.DefaultThreadPoolFactory
 
createPool(String, ThreadingProfile) - Method in class org.mule.config.pool.ThreadPoolFactory
 
createPool(FtpConnectionFactory) - Method in class org.mule.transport.ftp.FtpConnector
 
createPooledDataSource(DataSourceConfig) - Method in class org.mule.module.db.internal.domain.database.DataSourceFactory
 
createPooledStandardDataSource(DataSource, DbPoolingProfile) - Method in class org.mule.module.db.internal.domain.database.DataSourceFactory
 
createPoolFactory(OAuth2Manager<OAuth2Adapter>, ObjectStore<Serializable>) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Returns the concrete instance of KeyedPoolableObjectFactory that's going to be in charge of creating the objects in the pool
createPortExtensors(EndpointInfo, Service) - Method in class org.mule.module.cxf.transport.MuleUniversalTransport
 
createPostMethod(MuleMessage, String) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
createProcessorExecutor(MuleEvent, List<MessageProcessor>, MessageProcessorExecutionTemplate, boolean) - Method in class org.mule.processor.chain.ProcessorExecutorFactory
 
createProducer(Session, Destination, boolean) - Method in class org.mule.transport.jms.Jms102bSupport
 
createProducer(Session, Destination, boolean) - Method in class org.mule.transport.jms.Jms11Support
 
createProducer(Session, Destination, boolean) - Method in interface org.mule.transport.jms.JmsSupport
 
createProducer(Destination) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createProducer(Destination) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createProducer(Destination) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createProfilerAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
createProxy(Object) - Method in interface org.mule.api.component.InterfaceBinding
This wires the dynamic proxy to the service object.
createProxy(Object) - Method in class org.mule.component.DefaultInterfaceBinding
 
createProxy(AbstractMessageReceiver, boolean, Class[]) - Static method in class org.mule.transport.soap.axis.AxisServiceProxy
 
createPublisher(Topic) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createPutMethod(MuleMessage, String) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
createQName(String) - Static method in class org.mule.transport.soap.axis.NamedParameter
 
createQueryFieldDebugInfo(String, QueryTemplate) - Static method in class org.mule.module.db.internal.processor.DbDebugInfoUtils
Creates debug information for a query
createQueryLogger(Log, QueryTemplate) - Method in class org.mule.module.db.internal.domain.logger.DefaultQueryLoggerFactory
 
createQueryLogger(Log, QueryTemplate) - Method in interface org.mule.module.db.internal.domain.logger.QueryLoggerFactory
Creates a logger for a single query
createQueryResolverBeanDefinition(BeanDefinition) - Method in class org.mule.module.db.internal.config.processor.AbstractSingleQueryProcessorDefinitionParser
 
createQueue(String) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createQueue(String) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createQueue(String) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createQueueConnection() - Method in class org.mule.transport.jms.xa.DefaultXAConnectionFactoryWrapper
 
createQueueConnection(String, String) - Method in class org.mule.transport.jms.xa.DefaultXAConnectionFactoryWrapper
 
createQueueStore(String, QueueConfiguration) - Method in class org.mule.util.queue.AbstractQueueManager
Creates a QueueStore
createQueueStore(String, QueueConfiguration) - Method in class org.mule.util.queue.TransactionalQueueManager
 
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.AbstractConnector
Create a Message receiver for this connector
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.email.SmtpConnector
 
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.file.FileConnector
Registers a listener for a particular directory The following properties can be overriden in the endpoint declaration moveToDirectory filterPatterns filterClass pollingFrequency
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.ftp.FtpConnector
 
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.jdbc.JdbcConnector
 
createReceiver(Queue) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createReceiver(Queue, String) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.rmi.RmiConnector
 
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.sftp.SftpConnector
 
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.stdio.StdioConnector
 
createReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.vm.VMConnector
 
createReceiverFileInputStream(File, File) - Method in class org.mule.transport.file.FileMessageReceiver
 
createReceiverFileInputStream(File, File, InputStreamCloseListener) - Method in class org.mule.transport.file.FileMessageReceiver
 
createRedirectUrlProcessor() - Method in class org.mule.module.oauth2.internal.authorizationcode.AbstractAuthorizationCodeTokenRequestHandler
 
createRedirectUrlProcessor() - Method in class org.mule.module.oauth2.internal.authorizationcode.AutoAuthorizationCodeTokenRequestHandler
 
createRegistryBroker() - Method in class org.mule.DefaultMuleContext
 
createRegistryHelper(DefaultRegistryBroker) - Method in class org.mule.DefaultMuleContext
 
createReplyToConsumer(Message, MuleEvent, Session, Destination, boolean) - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
createReplyToHandler(MuleEvent) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
 
createRequestBuilder(HttpRequest, GrizzlyHttpClient.RequestConfigurer) - Method in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
createRequesterFactory() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createRequesterFactory() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createRequestResponseMuleEvent(MuleMessage) - Method in class org.mule.client.DefaultLocalMuleClient
 
createResourceReleaserInstance() - Method in class org.mule.module.launcher.artifact.AbstractArtifactClassLoader
 
createResponse(Object, String, MuleMessage) - Method in class org.mule.transport.http.transformers.MuleMessageToHttpResponse
 
createResponse(Socket) - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
 
createResponse(Socket) - Method in class org.mule.transport.tcp.protocols.SafeProtocol
 
createResponse(Socket) - Method in interface org.mule.transport.tcp.TcpProtocol
This lets protocols encode a response stream.
createResponseBody(RPCElement, MessageContext, OperationDesc, ServiceDesc, Object, SOAPEnvelope, ArrayList) - Method in class org.mule.transport.soap.axis.extensions.MuleRPCProvider
 
createResponseTransformers(ImmutableEndpoint) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createResponseTransformers(ImmutableEndpoint) - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createResultEvent(MuleEvent, Object) - Method in class org.mule.component.AbstractComponent
 
createResultEvent(MuleEvent, Object) - Method in class org.mule.processor.InvokerMessageProcessor
 
createResultMap() - Method in class org.mule.module.db.internal.result.statement.AbstractMapStatementResultHandler
 
createResultMap() - Method in class org.mule.module.db.internal.result.statement.EagerStatementResultHandler
 
createResultMap() - Method in class org.mule.module.db.internal.result.statement.StreamingStatementResultHandler
 
createRetryInstance() - Method in interface org.mule.api.retry.RetryPolicyTemplate
 
createRetryInstance() - Method in class org.mule.retry.async.AsynchronousRetryTemplate
 
createRetryInstance() - Method in class org.mule.retry.policies.NoRetryPolicyTemplate
 
createRetryInstance() - Method in class org.mule.retry.policies.RetryForeverPolicyTemplate
 
createRetryInstance() - Method in class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
createRmiAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
createRoom() - Method in class org.mule.transport.xmpp.XmppMultiUserChatConversation
 
createRootDefinitionParser(Class) - Static method in class org.mule.config.spring.parsers.specific.ExceptionStrategyDefinitionParser
 
createRootDefinitionParser(Class) - Static method in class org.mule.module.cxf.config.WsSecurityDefinitionParser
 
createSaxonTransformerFactory() - Static method in class org.mule.module.xml.util.XMLUtils
 
createSaxParserFactory() - Method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
createScheduledPool(String) - Method in interface org.mule.api.config.ThreadingProfile
 
createScheduledPool(String) - Method in class org.mule.config.ChainedThreadingProfile
 
createScheduledPool(String) - Method in class org.mule.config.ImmutableThreadingProfile
 
createScheduledPool(String) - Method in class org.mule.config.MutableThreadingProfile
 
createScheduledPool(String, ThreadingProfile) - Method in class org.mule.config.pool.DefaultThreadPoolFactory
 
createScheduledPool(String, ThreadingProfile) - Method in class org.mule.config.pool.ThreadPoolFactory
By limitations of java's ScheduledThreadPoolExecutor, ThreadingProfile.getMaxThreadsActive() will be ignored and a fixed pool with ThreadingProfile.getMaxThreadsIdle() will be created.
createScheduledRetriesPool(String) - Method in class org.mule.routing.UntilSuccessful
 
createScheduledRetriesPool(String) - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
createScheduler() - Method in class org.mule.transport.AbstractConnector
 
createSchedulerFactory() - Method in class org.mule.transport.quartz.QuartzConnector
Creates a SchedulerFactory used to create Quartz scheduler instances
createSchemaFactory(String) - Method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
createScopeExecutionTemplate(MuleContext, TransactionConfig, MessagingExceptionHandler) - Static method in class org.mule.execution.TransactionalErrorHandlingExecutionTemplate
Creates a TransactionalErrorHandlingExecutionTemplate for inner scopes within a flow
createScriptEngineByExtension(String) - Method in class org.mule.module.scripting.component.Scriptable
 
createScriptEngineByName(String) - Method in class org.mule.module.scripting.component.Scriptable
 
createSecurityContext(Authentication) - Method in interface org.mule.api.security.SecurityManager
 
createSecurityContext(Authentication) - Method in interface org.mule.api.security.SecurityProvider
 
createSecurityContext(Authentication) - Method in class org.mule.security.AbstractSecurityProvider
 
createSecurityContext(Authentication) - Method in class org.mule.security.MuleSecurityManager
 
createSender(Queue) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createServer(ServerAddress, WorkManagerSource, boolean, int) - Method in class org.mule.module.http.internal.listener.HttpListenerConnectionManager
 
createServerFactory() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
createServerFactory() - Method in class org.mule.module.cxf.builder.ProxyServiceMessageProcessorBuilder
 
createServerFactory() - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
createServerFor(ServerAddress, WorkManagerSource, boolean, int) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyServerManager
 
createServerFor(ServerAddress, WorkManagerSource, boolean, int) - Method in interface org.mule.module.http.internal.listener.HttpServerManager
 
createServerSocket() - Method in class org.mule.api.security.tls.RestrictedSSLServerSocketFactory
 
createServerSocket(int) - Method in class org.mule.api.security.tls.RestrictedSSLServerSocketFactory
 
createServerSocket(int, int) - Method in class org.mule.api.security.tls.RestrictedSSLServerSocketFactory
 
createServerSocket(int, int, InetAddress) - Method in class org.mule.api.security.tls.RestrictedSSLServerSocketFactory
 
createServerSocket(URI, int, Boolean) - Method in interface org.mule.transport.tcp.SimpleServerSocketFactory
 
createServerSocket(InetAddress, int, int, Boolean) - Method in interface org.mule.transport.tcp.SimpleServerSocketFactory
 
createServerSocket(int, int, Boolean) - Method in interface org.mule.transport.tcp.SimpleServerSocketFactory
 
createServerSocket(URI, int, Boolean) - Method in class org.mule.transport.tcp.TcpServerSocketFactory
 
createServerSocket(InetAddress, int, int, Boolean) - Method in class org.mule.transport.tcp.TcpServerSocketFactory
 
createServerSocket(int, int, Boolean) - Method in class org.mule.transport.tcp.TcpServerSocketFactory
 
createService(ImmutableEndpoint) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
createService(ImmutableEndpoint) - Method in class org.mule.transport.soap.axis.AxisMessageRequester
 
createService(MuleEvent) - Method in class org.mule.transport.soap.axis.wsdl.AxisWsdlMessageDispatcher
 
createServiceDescriptor(ServiceType, String, Properties) - Method in class org.mule.registry.MuleRegistryHelper
 
createServiceHandler(AbstractMessageReceiver, boolean) - Static method in class org.mule.transport.soap.axis.AxisServiceProxy
 
createServlet(AbstractNetworkConnector, ImmutableEndpoint) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
createServlet(AbstractNetworkConnector, ImmutableEndpoint) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
createServlet(Connector, ImmutableEndpoint) - Method in interface org.mule.transport.servlet.jetty.ServletAware
 
createServletEndpointParser(Class<?>) - Method in class org.mule.transport.ajax.config.AjaxNamespaceHandler
 
createServletGlobalEndpointParser(Class<?>) - Method in class org.mule.transport.ajax.config.AjaxNamespaceHandler
 
createSession(Rules) - Method in interface org.mule.module.bpm.RulesEngine
Create a provider-specific session for interacting with the Rules Engine.
createSession(Rules) - Method in class org.mule.module.drools.Drools
 
createSession(Connection, boolean, boolean, int, boolean) - Method in class org.mule.transport.jms.Jms102bSupport
 
createSession(Connection, boolean, boolean, int, boolean) - Method in class org.mule.transport.jms.Jms11Support
 
createSession(ImmutableEndpoint) - Method in class org.mule.transport.jms.JmsConnector
 
createSession(Connection, boolean, boolean, int, boolean) - Method in interface org.mule.transport.jms.JmsSupport
 
createSessionHandler() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createSessionHandler() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createSftpClient(ImmutableEndpoint) - Method in class org.mule.transport.sftp.SftpConnector
 
createSftpClient(ImmutableEndpoint, SftpNotifier) - Method in class org.mule.transport.sftp.SftpConnector
 
createSftpDirIfNotExists(ImmutableEndpoint, String) - Method in class org.mule.transport.sftp.SftpClient
Creates the directory if it not already exists.
createSftpReceiverRequesterUtil(InboundEndpoint) - Method in class org.mule.transport.sftp.SftpMessageReceiver
 
createSftpUtil(ImmutableEndpoint) - Method in class org.mule.transport.sftp.SftpReceiverRequesterUtil
Creates an SftpUtil instance.
createSingleDataSource(DataSourceConfig) - Method in class org.mule.module.db.internal.domain.database.DataSourceFactory
 
createSocket(String, int) - Method in class org.mule.api.security.tls.RestrictedSSLSocketFactory
 
createSocket(String, int, InetAddress, int) - Method in class org.mule.api.security.tls.RestrictedSSLSocketFactory
 
createSocket(InetAddress, int) - Method in class org.mule.api.security.tls.RestrictedSSLSocketFactory
 
createSocket(InetAddress, int, InetAddress, int) - Method in class org.mule.api.security.tls.RestrictedSSLSocketFactory
 
createSocket(Socket, String, int, boolean) - Method in class org.mule.api.security.tls.RestrictedSSLSocketFactory
 
createSocket() - Method in class org.mule.api.security.tls.RestrictedSSLSocketFactory
 
createSocket(Socket, String, int, boolean) - Method in class org.mule.api.security.tls.TlsPropertiesSocketFactory
 
createSocket(String, int) - Method in class org.mule.api.security.tls.TlsPropertiesSocketFactory
 
createSocket(InetAddress, int) - Method in class org.mule.api.security.tls.TlsPropertiesSocketFactory
 
createSocket(String, int, InetAddress, int) - Method in class org.mule.api.security.tls.TlsPropertiesSocketFactory
 
createSocket(InetAddress, int, InetAddress, int) - Method in class org.mule.api.security.tls.TlsPropertiesSocketFactory
 
createSocket() - Method in class org.mule.api.security.tls.TlsPropertiesSocketFactory
 
createSocket(String, int) - Method in class org.mule.module.management.agent.FixedHostRmiClientSocketFactory
Deprecated.
Create a client socket connected to the specified overrideHost and port.
createSocket(Socket, String, int, boolean) - Method in class org.mule.transport.http.MuleSecureProtocolSocketFactory
 
createSocket(String, int) - Method in class org.mule.transport.http.MuleSecureProtocolSocketFactory
 
createSocket(String, int, InetAddress, int) - Method in class org.mule.transport.http.MuleSecureProtocolSocketFactory
 
createSocket(String, int, InetAddress, int, HttpConnectionParams) - Method in class org.mule.transport.http.MuleSecureProtocolSocketFactory
 
createSocket(URI, InetAddress) - Method in class org.mule.transport.multicast.MulticastMessageReceiver
 
createSocket() - Method in class org.mule.transport.multicast.MulticastSocketFactory
 
createSocket(int) - Method in class org.mule.transport.multicast.MulticastSocketFactory
 
createSocket(int, InetAddress) - Method in class org.mule.transport.multicast.MulticastSocketFactory
 
createSocket(TcpSocketKey) - Method in class org.mule.transport.tcp.AbstractTcpSocketFactory
 
createSocket(TcpSocketKey) - Method in class org.mule.transport.tcp.TcpSocketFactory
 
createSocket(URI, InetAddress) - Method in class org.mule.transport.udp.UdpMessageReceiver
 
createSocket() - Method in class org.mule.transport.udp.UdpSocketFactory
 
createSocket(int) - Method in class org.mule.transport.udp.UdpSocketFactory
 
createSocket(int, InetAddress) - Method in class org.mule.transport.udp.UdpSocketFactory
 
createSocket(String, int, int) - Static method in class org.mule.util.TimedSocket
Creates a socket and waits until the given timeout is reached.
createSocketWithTimeout(String, int, InetAddress, int, int) - Method in class org.mule.transport.http.MuleSecureProtocolSocketFactory
 
createSpringRegistry(MuleContext, ApplicationContext) - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
createSQLXML() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
createSQLXML() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
createSQLXML() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
createSquareBracesStyleParser() - Static method in class org.mule.util.TemplateParser
 
createSslServer(ServerAddress, WorkManagerSource, TlsContextFactory, boolean, int) - Method in class org.mule.module.http.internal.listener.HttpListenerConnectionManager
 
createSslServerFor(TlsContextFactory, WorkManagerSource, ServerAddress, boolean, int) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyServerManager
 
createSslServerFor(TlsContextFactory, WorkManagerSource, ServerAddress, boolean, int) - Method in interface org.mule.module.http.internal.listener.HttpServerManager
 
createStatement() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
createStatement(int, int) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
createStatement(int, int, int) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
createStatement() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
createStatement(int, int) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
createStatement(int, int, int) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
createStatement() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
createStatement(int, int) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
createStatement(int, int, int) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
createStaticContext() - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
createStaticMessage(String) - Static method in class org.mule.config.i18n.MessageFactory
Factory method to create a Message instance that is not read from a resource bundle.
createStaticMessage(String, Object...) - Static method in class org.mule.config.i18n.MessageFactory
Factory method to create a Message instance that is not read from a resource bundle.
createStatistics() - Method in class org.mule.model.seda.SedaService
Deprecated.
 
createStatistics() - Method in class org.mule.service.AbstractService
Deprecated.
 
createStoreDirectory(File) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
createStoreDirectory(File) - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
createStoreFile(Serializable) - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
createStreamMessage() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createStreamMessage() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createStreamMessage() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createStringFromByteArray(byte[], String) - Method in class org.mule.transformer.simple.ObjectToString
 
createStringFromByteArray(byte[], String) - Method in class org.mule.transformer.simple.StringToObjectArray
 
createStringFromInputStream(InputStream, String) - Method in class org.mule.transformer.simple.ObjectToString
 
createStringFromInputStream(InputStream) - Method in class org.mule.transformer.simple.StringToObjectArray
 
createStringFromOutputHandler(OutputHandler, String) - Method in class org.mule.transformer.simple.ObjectToString
 
createStruct(String, Object[]) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
createStruct(String, Object[]) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
createStruct(String, Object[]) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
createSubcontext(Name) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
createSubcontext(String) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
createSubcontext(Name) - Method in class org.mule.jndi.SimpleContext
 
createSubcontext(String) - Method in class org.mule.jndi.SimpleContext
 
createSubcontext(Name) - Method in class org.mule.tck.jndi.InMemoryContext
 
createSubcontext(String) - Method in class org.mule.tck.jndi.InMemoryContext
 
createSubscriber(Topic) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createSubscriber(Topic, String, boolean) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createTemporaryDestination(Session, boolean) - Method in class org.mule.transport.jms.Jms102bSupport
 
createTemporaryDestination(Session, boolean) - Method in class org.mule.transport.jms.Jms11Support
 
createTemporaryDestination(Session, boolean) - Method in interface org.mule.transport.jms.JmsSupport
 
createTemporaryQueue() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createTemporaryQueue() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createTemporaryQueue() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createTemporaryTopic() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createTemporaryTopic() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createTemporaryTopic() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createTextMessage() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createTextMessage(String) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createTextMessage() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createTextMessage(String) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createTextMessage() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createTextMessage(String) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createThreadingProfile(MuleContext) - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
createTopic(String) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
createTopic(String) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
createTopic(String) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
createTopicConnection() - Method in class org.mule.transport.jms.xa.DefaultXAConnectionFactoryWrapper
 
createTopicConnection(String, String) - Method in class org.mule.transport.jms.xa.DefaultXAConnectionFactoryWrapper
 
createTraceMethod(MuleMessage) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
createTransactionalExecutionTemplate(MuleContext, TransactionConfig) - Static method in class org.mule.execution.TransactionalExecutionTemplate
Creates a ExecutionTemplate that will manage transactional context according to configured TransactionConfig
createTransactionConfig(String) - Method in class org.mule.config.spring.factories.TransactionalMessageProcessorsFactoryBean
 
createTransactionContext(Object) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
createTransactionContext(Object) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
createTransactionContext(Xid) - Method in class org.mule.util.queue.QueueXaResource
 
createTransactionContext(Xid) - Method in class org.mule.util.xa.DefaultXASession
Creates a new transaction context with the given transaction identifier
createTransactionFactory() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createTransactionFactory() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
createTransformer(String, ImmutableEndpoint) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
createTransformerFactory() - Method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
createTransientTransactionContext() - Method in class org.mule.util.queue.LocalTxQueueTransactionContext
 
createTransientTransactionContext() - Method in interface org.mule.util.queue.QueueTransactionContextFactory
 
createTransientTransactionContext() - Method in class org.mule.util.queue.XaQueueTypeTransactionContextAdapter
 
createTrustStoreProperties(TlsContextTrustStoreConfiguration) - Static method in class org.mule.module.ws.security.WSCryptoUtils
Creates a Properties object with the attributes of a trust store.
createType1Message(String, String) - Method in class org.mule.transport.http.ntlm.NtlmMessageFactory
Creates a Type1Message for NTLM authentication.
createType2Message(String) - Method in class org.mule.transport.http.ntlm.NtlmMessageFactory
Creates a Type2Message for NTLM authentication from a challenge received from the NTLM server.
createType3Message(NTCredentials, Type2Message) - Method in class org.mule.transport.http.ntlm.NtlmMessageFactory
Creates a Type3Message for NTLM authentication.
createUnboundTransaction(MuleContext) - Method in interface org.mule.api.transaction.UnboundTransactionFactory
 
createUnboundTransaction(MuleContext) - Method in class org.mule.transport.jdbc.JdbcTransactionFactory
 
createUnboundTransaction(MuleContext) - Method in class org.mule.transport.jms.JmsTransactionFactory
 
createUnboundTransaction(MuleContext) - Method in class org.mule.transport.vm.VMTransactionFactory
 
createUniqueSuffix(String) - Method in class org.mule.transport.sftp.SftpUtil
 
createUnsupportedTypeErrorMessage(Object) - Static method in class org.mule.module.db.internal.domain.type.ArrayResolvedDbType
Creates error message for the case when a given class is not supported
createUnsupportedTypeErrorMessage(Object) - Static method in class org.mule.module.db.internal.domain.type.BlobResolvedDataType
 
createUnsupportedTypeErrorMessage(Object) - Static method in class org.mule.module.db.internal.domain.type.ClobResolvedDataType
 
createUnsupportedTypeErrorMessage(Object) - Static method in class org.mule.module.db.internal.domain.type.StructDbType
Creates error message for the case when a given class is not supported
createUpdateJournalEntry(T, byte, String, Serializable) - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
Creates a JournalEntry for an update operation in the queue.
createUpdateJournalEntry(Integer, byte, String, Serializable) - Method in class org.mule.util.journal.queue.LocalTxQueueTransactionJournal
 
createUpdateJournalEntry(Xid, byte, String, Serializable) - Method in class org.mule.util.journal.queue.XaTxQueueTransactionJournal
 
createUriStringWithPasswordMasked() - Method in class org.mule.endpoint.MuleEndpointURI
 
createURLStreamHandler(String) - Method in class org.mule.module.launcher.GoodCitizenClassLoader.NonCachingURLStreamHandlerFactory
 
createURLStreamHandler(String) - Method in class org.mule.util.MuleUrlStreamHandlerFactory
 
createUserManager() - Method in class org.mule.tck.util.ftp.Server
 
createValidator() - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
createValidator() - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
createValidator() - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
createValidator() - Method in class org.mule.module.xml.filters.SchemaValidationFilter
Create a validator.
createValue(DbConnection, String, Object[]) - Method in class org.mule.module.db.internal.el.AbstractDbFunction
Creates the structured type value
createValue(DbConnection, String, Object[]) - Method in class org.mule.module.db.internal.el.DbCreateArrayFunction
 
createValue(DbConnection, String, Object[]) - Method in class org.mule.module.db.internal.el.DbCreateStructFunction
 
createVariable(String, Object) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
createVariable(String, Object, Class<?>) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
createVariable(String, Object) - Method in class org.mule.el.mvel.MuleBaseVariableResolverFactory
 
createVariable(String, Object, Class<?>) - Method in class org.mule.el.mvel.MuleBaseVariableResolverFactory
 
createVariableAssociation(Variable) - Method in class com.javaforge.bobber.archetype.model.Variable
Method createVariableAssociation.
createVariableVariableResolverFactory(MuleEvent) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
createVariableVariableResolverFactory(MuleMessage) - Method in class org.mule.el.mvel.MVELExpressionLanguage
Deprecated.
createVersionRanges(String) - Static method in class org.mule.util.VersionRange
 
createWithConfig(Boolean, Boolean) - Static method in class org.mule.util.xmlsecurity.XMLSecureFactories
 
createWithEncoding(Class<T>, String) - Static method in class org.mule.transformer.types.DataTypeFactory
 
createWork() - Method in class org.mule.transport.AbstractPollingMessageReceiver
 
createWork(Socket) - Method in class org.mule.transport.http.OldHttpMessageReceiver
 
createWork(Socket) - Method in class org.mule.transport.http.OldHttpsMessageReceiver
 
createWork(DatagramPacket) - Method in class org.mule.transport.multicast.MulticastMessageReceiver
 
createWork(Socket) - Method in class org.mule.transport.tcp.ExceptionReturnTcpMessageReceiver
 
createWork(Socket) - Method in class org.mule.transport.tcp.TcpMessageReceiver
 
createWork(DatagramPacket) - Method in class org.mule.transport.udp.UdpMessageReceiver
 
createWork() - Method in class org.mule.transport.vm.VMMessageReceiver
 
createWork(Packet) - Method in class org.mule.transport.xmpp.XmppMessageReceiver
 
createWorkListener() - Method in class org.mule.context.DefaultMuleContextBuilder
 
createWorkManager(String, int) - Method in interface org.mule.api.config.ThreadingProfile
 
createWorkManager(ThreadingProfile, String, int) - Method in interface org.mule.api.config.ThreadingProfile.WorkManagerFactory
 
createWorkManager(String, int) - Method in class org.mule.config.ChainedThreadingProfile
 
createWorkManager(String, int) - Method in class org.mule.config.ImmutableThreadingProfile
 
createWorkManager(ThreadingProfile, String, int) - Method in class org.mule.config.ImmutableThreadingProfile.DefaultWorkManagerFactory
 
createWorkManager(String, int) - Method in class org.mule.config.MutableThreadingProfile
 
createWorkManager() - Method in class org.mule.context.DefaultMuleContextBuilder
 
createWorkManager() - Method in class org.mule.module.launcher.application.ApplicationMuleContextBuilder
 
createWorkManager(FlowConstruct) - Method in class org.mule.processor.strategy.NonBlockingProcessingStrategy
 
createWrapper(Session) - Static method in class org.mule.transport.jms.ReusableSessionWrapperFactory
 
createWSDLRetrieverStrategy() - Method in class org.mule.module.ws.consumer.wsdl.strategy.factory.HttpRequesterWsdlRetrieverStrategyFactory
 
createWSDLRetrieverStrategy() - Method in class org.mule.module.ws.consumer.wsdl.strategy.factory.URLWSDLRetrieverStrategyFactory
 
createWSDLRetrieverStrategy() - Method in interface org.mule.module.ws.consumer.wsdl.strategy.factory.WSDLRetrieverStrategyFactory
 
createWstxXmlInputFactory() - Static method in class org.mule.module.xml.util.XMLUtils
 
createWstxXmlInputFactory(Boolean, Boolean) - Static method in class org.mule.module.xml.util.XMLUtils
 
createXMLInputFactory() - Method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
createXmlType(Connection, String) - Static method in class org.mule.module.db.internal.domain.type.oracle.OracleXmlType
Creates an OracleXmlType.ORACLE_XMLTYPE_CLASS object from the received XML string
createXmlType(Connection, InputStream) - Static method in class org.mule.module.db.internal.domain.type.oracle.OracleXmlType
Creates an OracleXmlType.ORACLE_XMLTYPE_CLASS object from the received XML InputStream
createXmppConnection() - Method in class org.mule.transport.xmpp.XmppConnector
 
createXPath(String, Object) - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
createXPath(String, Object) - Method in class org.mule.module.xml.expression.BeanPayloadExpressionEvaluator
Deprecated.
 
createXPath(String) - Method in class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
 
createXPath(String, Object) - Method in class org.mule.module.xml.expression.XPathExpressionEvaluator
Deprecated.
 
createXPathFactory() - Method in class org.mule.module.xml.xpath.JaxpXPathEvaluator
Returns the XPathFactory to be used when compiling expressions
createXPathFactory() - Method in class org.mule.module.xml.xpath.SaxonXpathEvaluator
Returns the XPathFactory to be used when compiling expressions
Credentials - Interface in org.mule.api.security
Credentials holds credentials information for a user.
CredentialsAccessor - Interface in org.mule.api.security
CredentialsAccessor is a template for obtaining user credentials from the current message and writing the user credentials to an outbound message
CredentialsMaskUtil - Class in org.mule.api.util
 
CredentialsMaskUtil() - Constructor for class org.mule.api.util.CredentialsMaskUtil
 
CredentialsNotSetException - Exception in org.mule.api.security
CredentialsNotSetException is thrown when user credentials cannot be obtained from the current message
CredentialsNotSetException(Message, MuleEvent) - Constructor for exception org.mule.api.security.CredentialsNotSetException
 
CredentialsNotSetException(Message, MuleEvent, Throwable) - Constructor for exception org.mule.api.security.CredentialsNotSetException
 
CredentialsNotSetException(MuleEvent, SecurityContext, SecurityFilter) - Constructor for exception org.mule.api.security.CredentialsNotSetException
 
CredentialsNotSetException(MuleEvent, SecurityContext, URI, SecurityFilter) - Constructor for exception org.mule.api.security.CredentialsNotSetException
Deprecated.
criticalSetEvent(MuleEvent) - Static method in class org.mule.OptimizedRequestContext
Deprecated.
Set an event for out-of-scope thread access.
CRLF - Static variable in class org.mule.transport.http.HttpConstants
 
CRLF - Static variable in class org.mule.transport.http.ResponseWriter
 
cronExpressionOrIntervalMustBeSet() - Static method in class org.mule.transport.quartz.i18n.QuartzMessages
 
CronJob - Class in org.mule.modules.schedulers.cron
StatefulJob for polling.
CronJob() - Constructor for class org.mule.modules.schedulers.cron.CronJob
 
CronScheduler - Class in org.mule.modules.schedulers.cron
Cron Scheduler implemented with Quartz.
CronScheduler(String, PollingReceiverWorker, String, TimeZone) - Constructor for class org.mule.modules.schedulers.cron.CronScheduler
 
CronSchedulerFactory - Class in org.mule.modules.schedulers.cron
Factory of the Cron Scheduler for poll
CronSchedulerFactory() - Constructor for class org.mule.modules.schedulers.cron.CronSchedulerFactory
 
cryptoFailure(String) - Static method in class org.mule.config.i18n.CoreMessages
 
CryptoFailureException - Exception in org.mule.api.security
CryptoFailureException is a generic exception thrown by an CryptoStrategy if encryption or decryption fails.
CryptoFailureException(Message, EncryptionStrategy) - Constructor for exception org.mule.api.security.CryptoFailureException
 
CryptoFailureException(Message, EncryptionStrategy, Throwable) - Constructor for exception org.mule.api.security.CryptoFailureException
 
CryptoFailureException(EncryptionStrategy, Throwable) - Constructor for exception org.mule.api.security.CryptoFailureException
 
CSVPrinter - Class in org.mule.management.stats.printers
CSVPrinter prints service stats in CSV format
CSVPrinter(Writer) - Constructor for class org.mule.management.stats.printers.CSVPrinter
 
CSVPrinter(OutputStream) - Constructor for class org.mule.management.stats.printers.CSVPrinter
 
CURLY_TEMPLATE_PATTERN - Static variable in class org.mule.util.TemplateParser
 
CURLY_TEMPLATE_STYLE - Static variable in class org.mule.util.TemplateParser
 
current() - Method in class org.mule.retry.policies.SimpleRetryPolicy.RetryCounter
 
currentAnnotation - Variable in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
currentFiles - Variable in class org.mule.transport.ftp.FtpMessageReceiver
 
currentlyProcessing - Variable in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
currentPhase - Variable in class org.mule.lifecycle.AbstractLifecycleManager
 
currentScope() - Method in class org.mule.module.ws.consumer.ScopeSaverXMLStreamReader
 
CUSTOM_EVALUATOR - Static variable in class org.mule.expression.ExpressionConfig
 
CUSTOM_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
CUSTOM_HEADER_PREFIX - Static variable in class org.mule.transport.http.HttpConstants
 
CUSTOM_HEADERS_MAP_PROPERTY - Static variable in interface org.mule.transport.email.MailProperties
 
CUSTOM_MAX_HTTP_PACKET_HEADER_SIZE - Static variable in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
CustomCachingConnectionFactory - Class in org.mule.transport.jms
 
CustomCachingConnectionFactory(ConnectionFactory, String, String) - Constructor for class org.mule.transport.jms.CustomCachingConnectionFactory
 
CustomClassLoadingLengthProtocol - Class in org.mule.transport.tcp.protocols
A length protocol that uses a specific class loader to load objects from streams
CustomClassLoadingLengthProtocol() - Constructor for class org.mule.transport.tcp.protocols.CustomClassLoadingLengthProtocol
 
customContentDisposition - Variable in class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
customContentType - Variable in class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
customHeaderMapDeprecated() - Static method in class org.mule.transport.http.i18n.HttpMessages
 
customize(TCPNIOTransport, FilterChainBuilder) - Method in class org.mule.module.http.internal.request.grizzly.CompositeTransportCustomizer
 
customize(TCPNIOTransport, FilterChainBuilder) - Method in class org.mule.module.http.internal.request.grizzly.IOStrategyTransportCustomizer
 
customize(TCPNIOTransport, FilterChainBuilder) - Method in class org.mule.module.http.internal.request.grizzly.LoggerTransportCustomizer
 
customize(TCPNIOTransport, FilterChainBuilder) - Method in class org.mule.module.http.internal.request.grizzly.MemoryManagerTransportCustomizer
 
customize(TCPNIOTransport, FilterChainBuilder) - Method in class org.mule.module.http.internal.request.grizzly.SocketConfigTransportCustomizer
 
CustomJob - Class in org.mule.transport.quartz.jobs
Extracts the Job object to invoke from the context.
CustomJob() - Constructor for class org.mule.transport.quartz.jobs.CustomJob
 
CustomJobConfig - Class in org.mule.transport.quartz.jobs
This configuration simply holds a reference to a user defined job to execute.
CustomJobConfig() - Constructor for class org.mule.transport.quartz.jobs.CustomJobConfig
 
CustomJobFromMessageConfig - Class in org.mule.transport.quartz.jobs
This configuration simply holds a reference to a user defined job to execute.
CustomJobFromMessageConfig() - Constructor for class org.mule.transport.quartz.jobs.CustomJobFromMessageConfig
 
CustomNotification - Class in org.mule.context.notification
CustomNotification Custom notifications can be used by components and other objects such as routers, transformers, agents, etc to communicate a change of state to each other.
CustomNotification(Object, int) - Constructor for class org.mule.context.notification.CustomNotification
Creates a custom action event
CustomNotification(Object, int, String) - Constructor for class org.mule.context.notification.CustomNotification
 
CustomNotificationListener<T extends ServerNotification> - Interface in org.mule.api.context.notification
CustomNotificationListener is an observer interface that can be used to listen for Custom notifications using MuleContext.fireCustomEvent(..).
CustomTimeoutThrottleRequestFilter - Class in org.mule.module.http.internal.request.grizzly
A RequestFilter that throttles requests and blocks when the number of permits is reached, waiting for the response to arrive before executing the next request.
CustomTimeoutThrottleRequestFilter(int) - Constructor for class org.mule.module.http.internal.request.grizzly.CustomTimeoutThrottleRequestFilter
 
cwdToTempDirOnOutbound(SftpClient, String) - Method in class org.mule.transport.sftp.SftpUtil
Changes the directory to the temp-dir on the outbound endpoint.
CXF - Static variable in class org.mule.module.cxf.CxfConfiguration
 
CXF_OUTBOUND_MESSAGE_PROCESSOR - Static variable in class org.mule.module.cxf.CxfConstants
 
CxfComponentExceptionStrategy - Class in org.mule.module.cxf
Deprecated.
Currently the result is the same if no exception strategy is defined within the flow. The only difference is that when you set the CxfComponentExceptionStrategy the exception is unwrapped inside of the exception block, but the exceptionPayload doesn't change.
CxfComponentExceptionStrategy() - Constructor for class org.mule.module.cxf.CxfComponentExceptionStrategy
Deprecated.
 
CxfConfiguration - Class in org.mule.module.cxf
Provides global CXF configuration defaults.
CxfConfiguration() - Constructor for class org.mule.module.cxf.CxfConfiguration
 
CxfConstants - Class in org.mule.module.cxf
 
CxfConstants() - Constructor for class org.mule.module.cxf.CxfConstants
 
CxfEndpointBuilder - Class in org.mule.module.cxf.endpoint
 
CxfEndpointBuilder() - Constructor for class org.mule.module.cxf.endpoint.CxfEndpointBuilder
 
CxfEndpointBuilder(EndpointURI) - Constructor for class org.mule.module.cxf.endpoint.CxfEndpointBuilder
 
CxfEndpointBuilder(EndpointURIEndpointBuilder) - Constructor for class org.mule.module.cxf.endpoint.CxfEndpointBuilder
 
CxfEndpointBuilder(ImmutableEndpoint) - Constructor for class org.mule.module.cxf.endpoint.CxfEndpointBuilder
 
CxfEndpointBuilder(String, MuleContext) - Constructor for class org.mule.module.cxf.endpoint.CxfEndpointBuilder
 
CxfEndpointBuilder(URIBuilder) - Constructor for class org.mule.module.cxf.endpoint.CxfEndpointBuilder
 
CxfInboundMessageProcessor - Class in org.mule.module.cxf
The CxfInboundMessageProcessor performs inbound CXF processing, sending an event through the CXF service, then on to the next MessageProcessor.
CxfInboundMessageProcessor() - Constructor for class org.mule.module.cxf.CxfInboundMessageProcessor
 
CxfMessages - Class in org.mule.module.cxf.i18n
 
CxfMessages() - Constructor for class org.mule.module.cxf.i18n.CxfMessages
 
CxfNamespaceHandler - Class in org.mule.module.cxf.config
 
CxfNamespaceHandler() - Constructor for class org.mule.module.cxf.config.CxfNamespaceHandler
 
CxfOutboundMessageProcessor - Class in org.mule.module.cxf
The CxfOutboundMessageProcessor performs outbound CXF processing, sending an event through the CXF client, then on to the next MessageProcessor.
CxfOutboundMessageProcessor(Client) - Constructor for class org.mule.module.cxf.CxfOutboundMessageProcessor
 
CxfPayloadToArguments - Enum in org.mule.module.cxf
This enum defines the strategies to convert a Payload to an array of arguments that will be used to call the webservice in CxfOutboundMessageProcessor.doSendWithClient(org.mule.api.MuleEvent) and in CxfOutboundMessageProcessor.doSendWithProxy(org.mule.api.MuleEvent).
CxfUtils - Class in org.mule.module.cxf.support
 
CxfUtils() - Constructor for class org.mule.module.cxf.support.CxfUtils
 

D

DaemonThreadFactory - Class in org.mule.util.concurrent
 
DaemonThreadFactory(String) - Constructor for class org.mule.util.concurrent.DaemonThreadFactory
 
DaemonThreadFactory(String, ClassLoader) - Constructor for class org.mule.util.concurrent.DaemonThreadFactory
 
DASH - Static variable in class org.mule.utils.IdUtils
 
DATA_BINDING - Static variable in class org.mule.module.cxf.CxfConstants
 
DATA_SOURCE_REF_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
DATA_TYPE_ELEMENT - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
DATA_TYPES_ELEMENT - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
database - Variable in class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
database - Variable in class org.mule.transport.jdbc.config.DerbyDataSourceFactoryBean
 
DATABASE_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
databinding - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
DataConversion - Class in org.mule.el.mvel
 
DataConversion() - Constructor for class org.mule.el.mvel.DataConversion
 
DataHandlerToInputStreamTransformer - Class in org.mule.transformer.simple
 
DataHandlerToInputStreamTransformer() - Constructor for class org.mule.transformer.simple.DataHandlerToInputStreamTransformer
 
dataIn - Variable in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
dataInWorkFinished - Variable in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
DATALINK_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
DataObjectDefinitionParser - Class in org.mule.config.spring.parsers.specific
Represents a static config data object where the body of the element can be the data of a file attribute can be set.
DataObjectDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser
The class will be inferred from the class attribute
DataObjectDefinitionParser(String, Class) - Constructor for class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser
The class (which is inferred from the class attribute if null here) is checked to be a subclass of the constraint
DataObjectDefinitionParser(String, Class, boolean) - Constructor for class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser
The class (which is inferred from the class attribute if null here) is checked to be a subclass of the constraint.
DataObjectDefinitionParser.DataObjectFactoryBean - Class in org.mule.config.spring.parsers.specific
 
DataObjectDefinitionParser.DataObjectFactoryBean() - Constructor for class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
dataOut - Variable in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
dataSource - Variable in class org.mule.transport.jdbc.JdbcConnector
 
DataSourceConfig - Class in org.mule.module.db.internal.domain.database
Maintains configuration information about how to build a DataSource
DataSourceConfig() - Constructor for class org.mule.module.db.internal.domain.database.DataSourceConfig
 
DataSourceDecorator - Interface in org.mule.module.db.internal.domain.xa
Decorates DataSource if required in order to work with XA transactions
DataSourceDecorator - Interface in org.mule.transport.jdbc.xa
 
DataSourceDefinitionParser - Class in org.mule.transport.jdbc.config
 
DataSourceDefinitionParser(Class<? extends AbstractDataSourceFactoryBean>) - Constructor for class org.mule.transport.jdbc.config.DataSourceDefinitionParser
 
DataSourceFactory - Class in org.mule.module.db.internal.domain.database
Creates DataSource instances
DataSourceFactory(String) - Constructor for class org.mule.module.db.internal.domain.database.DataSourceFactory
 
DataSourceWrapper - Class in org.mule.module.db.internal.domain.xa
Using for unification XADataSource and DataSource
DataSourceWrapper(XADataSource) - Constructor for class org.mule.module.db.internal.domain.xa.DataSourceWrapper
 
DataSourceWrapper - Class in org.mule.transport.jdbc.xa
Using for unification XADataSource and DataSource
DataSourceWrapper() - Constructor for class org.mule.transport.jdbc.xa.DataSourceWrapper
 
DataSourceWrapper(XADataSource) - Constructor for class org.mule.transport.jdbc.xa.DataSourceWrapper
 
DataType<T> - Interface in org.mule.api.transformer
Defines a Java type associated with additional information about the data.
DataTypeConversionResolver - Interface in org.mule
Resolves a conversion from one data type to another returning a converter Transformer that is able to convert the data.
datatypeFactory - Static variable in class org.mule.el.datetime.AbstractInstant
 
DataTypeFactory - Class in org.mule.transformer.types
Factory class used to create DataType objects based on the parameter types passed into the factory methods.
DataTypeFactory() - Constructor for class org.mule.transformer.types.DataTypeFactory
 
dataTypePropagator - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
dataTypeResolver - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
DataTypeUtils - Class in org.mule.util
Provides utilities to manage DataType
Date - Interface in org.mule.api.el.datetime
 
DATE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
DATE_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
DATE_FORMAT_RFC822 - Static variable in class org.mule.transport.http.HttpConstants
 
DATE_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 
dateInServerTimeZone() - Static method in class org.mule.transport.http.i18n.HttpMessages
 
DatePropertyEditor - Class in org.mule.config.spring.editors
Handles the conversion of date strings in Date objects.
DatePropertyEditor(DateFormat, DateFormat, boolean) - Constructor for class org.mule.config.spring.editors.DatePropertyEditor
Create a new CustomDateEditor instance, using the given DateFormat for parsing and rendering.
DatePropertyEditor(DateFormat, boolean, int) - Constructor for class org.mule.config.spring.editors.DatePropertyEditor
Create a new CustomDateEditor instance, using the given DateFormat for parsing and rendering.
DateService - Interface in org.mule.tck.testmodels.services
DateService defines a Date service
DATESTAMP_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 
DateTime - Class in org.mule.el.datetime
Models a DateTime and simplifies the parsing/formatting and very basic manipulation of dates via Mule expression language.
DateTime(Calendar, Locale) - Constructor for class org.mule.el.datetime.DateTime
 
DateTime() - Constructor for class org.mule.el.datetime.DateTime
 
DateTime(Calendar) - Constructor for class org.mule.el.datetime.DateTime
 
DateTime(Date) - Constructor for class org.mule.el.datetime.DateTime
 
DateTime(XMLGregorianCalendar) - Constructor for class org.mule.el.datetime.DateTime
 
DateTime(String) - Constructor for class org.mule.el.datetime.DateTime
 
DateTime(String, String) - Constructor for class org.mule.el.datetime.DateTime
 
DateTimeExpressionLanguageFuntion - Class in org.mule.el.function
 
DateTimeExpressionLanguageFuntion() - Constructor for class org.mule.el.function.DateTimeExpressionLanguageFuntion
 
DateUtils - Class in org.mule.util
DateUtils contains some useful methods dealing date/time conversion, formatting etc.
DateUtils() - Constructor for class org.mule.util.DateUtils
 
days() - Static method in class org.mule.config.i18n.CoreMessages
 
Db2DatasourceFactoryBean - Class in org.mule.transport.jdbc.config
 
Db2DatasourceFactoryBean() - Constructor for class org.mule.transport.jdbc.config.Db2DatasourceFactoryBean
 
DB_CREATE_ARRAY_FUNCTION - Static variable in class org.mule.module.db.internal.el.DbCreateArrayFunction
 
DB_CREATE_STRUCT_FUNCTION - Static variable in class org.mule.module.db.internal.el.DbCreateStructFunction
 
DbConfig - Interface in org.mule.module.db.internal.domain.database
Database configuration used in the connector
DbConfigDefinitionParser - Class in org.mule.module.db.internal.config.domain.database
 
DbConfigDefinitionParser(Class<? extends DbConfigResolverFactoryBean>, CheckExclusiveAttributes) - Constructor for class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
DbConfigFactory - Interface in org.mule.module.db.internal.domain.database
Creates DbConfig instances
dbConfigResolver - Variable in class org.mule.module.db.internal.metadata.AbstractQueryMetadataProvider
 
dbConfigResolver - Variable in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
DbConfigResolver - Interface in org.mule.module.db.internal.resolver.database
Resolves a DbConfig for a given MuleEvent
DbConfigResolverFactoryBean - Class in org.mule.module.db.internal.config.domain.database
Creates DbConfigResolver instances
DbConfigResolverFactoryBean() - Constructor for class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
DbConfigResolverFactoryBean(ConfigurableDbConfigFactory) - Constructor for class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
dbConfigResolverFactoryBeanDefinition - Variable in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
DbConnection - Interface in org.mule.module.db.internal.domain.connection
Wraps a Connection adding connector's specific functionality
DbConnectionException - Exception in org.mule.module.db.internal.processor
DbConnectionException is an exception thrown when an error connecting to a DB occurs, regardless of the message.
DbConnectionException(SQLException, DbConfig) - Constructor for exception org.mule.module.db.internal.processor.DbConnectionException
 
DbConnectionFactory - Interface in org.mule.module.db.internal.domain.connection
Creates database connections
DbConnectionReleaser - Interface in org.mule.module.db.internal.domain.connection
Notifies that a connection can be released
DbCreateArrayFunction - Class in org.mule.module.db.internal.el
Provides a MEL function that creates Array instances.
DbCreateStructFunction - Class in org.mule.module.db.internal.el
Provides a MEL function that creates Struct instances.
DbDebugInfoUtils - Class in org.mule.module.db.internal.processor
 
DbMessages - Class in org.mule.module.db.internal.i18n
 
DbMessages() - Constructor for class org.mule.module.db.internal.i18n.DbMessages
 
DbModuleElExtension - Class in org.mule.module.db.internal.el
A ExpressionLanguageExtension which provides functions to use with the DB connector.
DbModuleElExtension() - Constructor for class org.mule.module.db.internal.el.DbModuleElExtension
 
DbNamespaceHandler - Class in org.mule.module.db.config
 
DbNamespaceHandler() - Constructor for class org.mule.module.db.config.DbNamespaceHandler
 
DbPoolingProfile - Class in org.mule.module.db.internal.domain.connection
Describes a database pooling profile
DbPoolingProfile() - Constructor for class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
DbTransaction - Class in org.mule.module.db.internal.domain.transaction
Provides a database transactions
DbTransaction(MuleContext) - Constructor for class org.mule.module.db.internal.domain.transaction.DbTransaction
 
DbTransactionFactory - Class in org.mule.module.db.internal.domain.transaction
Creates database transactions
DbTransactionFactory() - Constructor for class org.mule.module.db.internal.domain.transaction.DbTransactionFactory
 
dbTransactionManager - Variable in class org.mule.module.db.internal.domain.connection.TransactionalDbConnectionFactory
 
DbTransactionManager - Interface in org.mule.module.db.internal.domain.transaction
Manages transactions for the connector
DbType - Interface in org.mule.module.db.internal.domain.type
Database data type
dbTypeManager - Variable in class org.mule.module.db.internal.domain.connection.TransactionalDbConnectionFactory
 
DbTypeManager - Interface in org.mule.module.db.internal.domain.type
Manages types for a database instance
dbTypeManager - Variable in class org.mule.module.db.internal.resolver.param.DefaultParamTypeResolver
 
DdlMetadataProvider - Class in org.mule.module.db.internal.metadata
Provides metadata for DDL queries
DdlMetadataProvider(DbConfigResolver, Query, AutoGeneratedKeyStrategy) - Constructor for class org.mule.module.db.internal.metadata.DdlMetadataProvider
 
deadLetterQueue - Variable in class org.mule.processor.AbstractRedeliveryPolicy
 
debug(String, Throwable) - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
debug(Throwable) - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
debug(String, Object...) - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
debug(Object) - Method in class org.mule.util.MuleLogger
 
debug(Object, Throwable) - Method in class org.mule.util.MuleLogger
 
DEBUG_MODE_SYSTEM_PROPERTY_KEY - Static variable in class org.mule.test.infrastructure.process.TestUtils
 
DebugBulkQueryLogger - Class in org.mule.module.db.internal.domain.logger
 
DebugBulkQueryLogger(Log) - Constructor for class org.mule.module.db.internal.domain.logger.DebugBulkQueryLogger
 
DebuggableReentrantLock - Class in org.mule.module.launcher.util
 
DebuggableReentrantLock() - Constructor for class org.mule.module.launcher.util.DebuggableReentrantLock
 
DebuggableReentrantLock(boolean) - Constructor for class org.mule.module.launcher.util.DebuggableReentrantLock
 
Debuggeable - Interface in org.mule.api.debug
Specifies that a message processor can debug its internal execution.
DebuggerCallback - Interface in org.mule.api.debug
Callback to the mule debugger framework.
DebuggerFrame - Class in org.mule.api.debug
Represents an execution frame with the current debugging state.
DebuggerFrame(List<FieldDebugInfo<?>>, String) - Constructor for class org.mule.api.debug.DebuggerFrame
A new debugger frame with the list of variables and a given name for this frame.
DebuggingSession - Interface in org.mule.api.debug
Represents a debugging session.
DebugInfoProvider - Interface in org.mule.api.debug
Provides information about an object for debugging purposes
DebugPreparedBulkQueryLogger - Class in org.mule.module.db.internal.domain.logger
Logs a prepared bulk query in debug level
DebugPreparedBulkQueryLogger(Log, QueryTemplate, int) - Constructor for class org.mule.module.db.internal.domain.logger.DebugPreparedBulkQueryLogger
 
DebugSingleQueryLogger - Class in org.mule.module.db.internal.domain.logger
Logs a single query in debug level
DebugSingleQueryLogger(Log, QueryTemplate) - Constructor for class org.mule.module.db.internal.domain.logger.DebugSingleQueryLogger
 
DebugUtils - Class in org.mule.util
Useful for enumerating debug information about the current Java environment
DECIMAL_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
declareFunction(String, ExpressionLanguageFunction) - Method in interface org.mule.api.el.ExpressionLanguageContext
 
declareFunction(String, ExpressionLanguageFunction) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
declareInputOutputClasses() - Method in class org.mule.transport.jms.transformers.AbstractJmsTransformer
 
declareInputOutputClasses() - Method in class org.mule.transport.jms.transformers.JMSMessageToObject
 
declareInputOutputClasses() - Method in class org.mule.transport.jms.transformers.ObjectToJMSMessage
 
DECODE - Static variable in class org.mule.util.Base64
Specify decoding.
decode(byte[], int, int) - Static method in class org.mule.util.Base64
Very low-level access to decoding ASCII characters in the form of a byte array.
decode(String) - Static method in class org.mule.util.Base64
Decodes the given s.
decodeFromFile(String) - Static method in class org.mule.util.Base64
Convenience method for reading a base64-encoded file and decoding it.
decodeOnCompleteRedirectTo() - Method in class org.mule.module.oauth2.internal.StateDecoder
Decodes the resource owner id from an encoded state using StateEncoder.encodeResourceOwnerIdInState(java.lang.String)
decodeOriginalState() - Method in class org.mule.module.oauth2.internal.StateDecoder
Decodes the original state from an encoded state using StateEncoder.encodeResourceOwnerIdInState(java.lang.String)
decodeQueryString(String) - Static method in class org.mule.module.http.internal.HttpParser
 
decodeResourceOwnerId() - Method in class org.mule.module.oauth2.internal.StateDecoder
Decodes the resource owner id from an encoded state using #encodeResourceOwnerIdInState
decodeString(String, String) - Static method in class org.mule.module.http.internal.HttpParser
 
decodeString(String) - Static method in class org.mule.util.XMLEntityCodec
 
decodeToFile(String, String) - Static method in class org.mule.util.Base64
Convenience method for decoding data to a file.
decodeToObject(String) - Static method in class org.mule.util.Base64
Attempts to decode Base64 data and deserialize a Java Object within.
decodeUriParams(String, String) - Static method in class org.mule.module.http.internal.HttpParser
Decodes uri params from a request path
decodeUrlEncodedBody(String, String) - Static method in class org.mule.module.http.internal.HttpParser
 
decodeWithoutUnzipping(String) - Static method in class org.mule.util.Base64
Similar to Base64.decode(String) only that it will not check the decoded value for GZip compression and thus will not decompress anything
decorate(DataSource, String, DbPoolingProfile, MuleContext) - Method in class org.mule.module.db.internal.domain.xa.CompositeDataSourceDecorator
 
decorate(DataSource, String, DbPoolingProfile, MuleContext) - Method in interface org.mule.module.db.internal.domain.xa.DataSourceDecorator
Decorates a dataSource
decorate(DataSource, String, DbPoolingProfile, MuleContext) - Method in class org.mule.module.db.internal.domain.xa.DefaultDataSourceDecorator
 
decorate(DataSource, String, MuleContext) - Method in class org.mule.transport.jdbc.xa.CompositeDataSourceDecorator
 
decorate(DataSource, String, MuleContext) - Method in interface org.mule.transport.jdbc.xa.DataSourceDecorator
 
decorate(DataSource, String, MuleContext) - Method in class org.mule.transport.jdbc.xa.DefaultDataSourceDecorator
 
decorate(ConnectionFactory, JmsConnector, MuleContext) - Method in class org.mule.transport.jms.AbstractConnectionFactoryDecorator
 
decorate(ConnectionFactory, JmsConnector, MuleContext) - Method in class org.mule.transport.jms.CompositeConnectionFactoryDecorator
 
decorate(ConnectionFactory, JmsConnector, MuleContext) - Method in interface org.mule.transport.jms.ConnectionFactoryDecorator
 
decorateDataSource(DataSource, DbPoolingProfile, MuleContext) - Method in class org.mule.module.db.internal.domain.database.DataSourceFactory
 
DecoratingAnnotatedServiceProcessor - Class in org.mule.config.processors
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)
DecoratingAnnotatedServiceProcessor() - Constructor for class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
DecoratingAnnotatedServiceProcessor(MuleContext) - Constructor for class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
DecoratingFlowAnnotationsBeanProcessor - Class in org.mule.config.spring.processors
TODO
DecoratingFlowAnnotationsBeanProcessor() - Constructor for class org.mule.config.spring.processors.DecoratingFlowAnnotationsBeanProcessor
 
decoupledEndpoint - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
decQueuedEvent() - Method in class org.mule.management.stats.FlowConstructStatistics
 
decQueuedEvent() - Method in interface org.mule.management.stats.QueueStatistics
 
decQueuedEvent() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
decreaseNestingLevel() - Method in class org.mule.util.generics.MethodParameter
Decrease this parameter's nesting level.
decrement() - Method in interface org.mule.util.counters.Counter
Decrement the counter's value by 1.0.
decrement() - Method in class org.mule.util.counters.impl.AbstractCounter
 
decrement() - Method in class org.mule.util.counters.impl.AggregateCounter
 
decrement() - Method in class org.mule.util.counters.impl.Number
 
decrementLockCount() - Method in class org.mule.util.lock.InstanceLockGroup.LockEntry
 
decrypt(InputStream, Object) - Method in interface org.mule.api.EncryptionStrategy
 
decrypt(byte[], Object) - Method in interface org.mule.api.EncryptionStrategy
 
decrypt(InputStream, Object) - Method in class org.mule.module.pgp.KeyBasedEncryptionStrategy
 
decrypt(InputStream, Object) - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
decrypt(byte[], Object) - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
decrypt(byte[], Object) - Method in class org.mule.security.AbstractNamedEncryptionStrategy
 
decrypt(byte[], Object) - Method in class org.mule.tck.security.MockEncryptionStrategy
 
decrypt(InputStream, Object) - Method in class org.mule.tck.security.MockEncryptionStrategy
 
decryptCipher - Variable in class org.mule.security.AbstractJCEEncryptionStrategy
 
DecryptionTransformer - Class in org.mule.transformer.encryption
EncryptionTransformer will transform an encrypted array of bytes or string into an decrypted array of bytes
DecryptionTransformer() - Constructor for class org.mule.transformer.encryption.DecryptionTransformer
 
DecryptStreamTransformer - Class in org.mule.module.pgp
 
DecryptStreamTransformer(PGPSecretKey, PGPSecretKeyRingCollection, String) - Constructor for class org.mule.module.pgp.DecryptStreamTransformer
 
DEFAULT - Static variable in class org.mule.util.ObjectNameHelper
 
DEFAULT_AGENT_NAME - Static variable in class org.mule.module.management.agent.JmxServerNotificationAgent
 
DEFAULT_ALGORITHM - Static variable in class org.mule.security.PasswordBasedEncryptionStrategy
 
DEFAULT_ALGORITHM - Static variable in class org.mule.security.SecretKeyEncryptionStrategy
Deprecated.
 
DEFAULT_APP_CONFIGURATION - Static variable in class org.mule.MuleServer
 
DEFAULT_APP_PROPERTIES_RESOURCE - Static variable in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
DEFAULT_AUTO_ACK_COUNT - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_AXIS_HOME - Static variable in class org.mule.transport.soap.axis.AxisServiceComponent
 
DEFAULT_BACKLOG - Static variable in class org.mule.transport.tcp.TcpConnector
 
DEFAULT_BASE_PATH - Static variable in class org.mule.transport.servlet.JarResourceServlet
 
DEFAULT_BROKER_URL - Static variable in class org.mule.transport.jms.activemq.ActiveMQJmsConnector
 
DEFAULT_BUFFER_OUTPUT - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_BUFFER_SIZE - Static variable in class org.mule.routing.MessageChunkAggregator
 
DEFAULT_BUFFER_SIZE - Static variable in class org.mule.transformer.simple.ObjectToString
 
DEFAULT_BUFFER_SIZE - Static variable in class org.mule.transport.stdio.StdioMessageReceiver
 
DEFAULT_BUFFER_SIZE - Static variable in class org.mule.transport.tcp.TcpConnector
 
DEFAULT_BUFFER_SIZE - Static variable in class org.mule.transport.udp.UdpConnector
 
DEFAULT_BUFFER_SIZE - Static variable in class org.mule.util.compression.GZipCompression
 
DEFAULT_CHANGES_CHECK_INTERVAL_MS - Static variable in class org.mule.module.launcher.DeploymentDirectoryWatcher
 
DEFAULT_CHECK_FREQUENCY - Static variable in class org.mule.transport.email.AbstractRetrieveMailConnector
 
DEFAULT_COMMIT_TIMEOUT_FACTOR - Static variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
DEFAULT_COMMIT_TIMEOUT_FACTOR - Static variable in class org.mule.util.xa.AbstractResourceManager
 
DEFAULT_CONFIGURATION - Static variable in class org.mule.MuleServer
 
DEFAULT_CONFIGURATION_RESOURCE - Static variable in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
DEFAULT_CONNECTION_IDLE_TIMEOUT - Static variable in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
DEFAULT_CONNECTION_TIMEOUT - Static variable in class org.mule.transport.http.HttpConnector
 
DEFAULT_CONNECTOR_SERVER_PROPERTIES - Static variable in class org.mule.module.management.agent.AbstractJmxAgent
 
DEFAULT_CONNECTOR_SERVER_PROPERTIES - Static variable in class org.mule.module.management.agent.JmxAgentConfigurer
 
DEFAULT_CONTENT_CHARSET - Static variable in class org.mule.transport.http.HttpResponse
 
DEFAULT_CONTENT_TYPE - Static variable in class org.mule.transport.email.SmtpConnector
 
DEFAULT_CONTENT_TYPE - Static variable in class org.mule.transport.http.HttpConstants
 
DEFAULT_CONTENT_TYPE_PROPERTY - Static variable in class org.mule.transport.servlet.AbstractReceiverServlet
 
DEFAULT_CONTEXT_START_TIMEOUT - Static variable in class org.mule.transport.AbstractConnector
 
DEFAULT_CXF_CONFIGURATION - Static variable in class org.mule.module.cxf.CxfConstants
 
DEFAULT_DATE_FORMAT - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 
DEFAULT_DATE_FORMAT - Static variable in class org.mule.transport.file.ExpressionFilenameParser
 
DEFAULT_DEBUG_PORT - Static variable in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
DEFAULT_DEPLOY_PROPERTIES_RESOURCE - Static variable in class org.mule.module.launcher.descriptor.ArtifactDescriptor
 
DEFAULT_DESCRIPTION_BUFFER_SIZE - Static variable in class org.mule.agent.Log4jNotificationLoggerAgent
 
DEFAULT_DISC_ON_CLUSTER_FAILURE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_DO_THREADING - Static variable in interface org.mule.api.config.ThreadingProfile
Default value for do threading
DEFAULT_DOMAIN_NAME - Static variable in interface org.mule.module.launcher.domain.DomainFactory
 
DEFAULT_EMPTY_BODY_METHODS - Static variable in class org.mule.module.http.internal.request.DefaultHttpRequester
 
DEFAULT_ENABLE_MULTIPLEXED_CONNECTIONS - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_ENABLE_SHARED_DURABLE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_ENCODING - Static variable in class org.mule.util.FileUtils
 
DEFAULT_EVICTION_INTERVAL_MILLIS - Static variable in class org.mule.config.PoolingProfile
Determines the number of milliseconds between runs of the object evictor.
DEFAULT_EXCEPTION_STRATEGY_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.ConfigurationDefinitionParser
 
DEFAULT_EXPRESSION - Static variable in class org.mule.transport.file.ExpressionFilenameParser
 
DEFAULT_EXPRESSION_POSTFIX - Static variable in interface org.mule.api.expression.ExpressionManager
 
DEFAULT_EXPRESSION_PREFIX - Static variable in interface org.mule.api.expression.ExpressionManager
 
DEFAULT_FETCH_SIZE - Static variable in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
DEFAULT_FLAGS - Static variable in class org.mule.util.scan.ClasspathScanner
Deprecated.
 
DEFAULT_FOLLOW_REDIRECTS - Static variable in class org.mule.module.http.internal.request.DefaultHttpRequester
 
DEFAULT_FREQUENCY - Static variable in class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
DEFAULT_FTP_CONNECTION_FACTORY_CLASS - Static variable in class org.mule.transport.ftp.FtpConnector
TODO it makes sense to have a type-safe adapter for FTP specifically, but without Java 5's covariant return types the benefits are diminished.
DEFAULT_GET_TIMEOUT - Static variable in class org.mule.transport.servlet.AbstractReceiverServlet
 
DEFAULT_GLOBAL_STORE_CAPACITY - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_GROUP_NAME - Static variable in class org.mule.transport.quartz.QuartzConnector
 
DEFAULT_HOST - Static variable in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
DEFAULT_HOST - Variable in class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
DEFAULT_HOST - Static variable in class org.mule.transport.servlet.jetty.WebappsConfiguration
 
DEFAULT_HOSTNAME - Static variable in class org.mule.module.management.agent.JdmkAgent
 
DEFAULT_HOSTNAME - Static variable in class org.mule.module.management.agent.Mx4jAgent
 
DEFAULT_HOSTNAME - Static variable in class org.mule.module.management.agent.RmiRegistryAgent
 
DEFAULT_HTTP_GET_BODY_PARAM_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
 
DEFAULT_HTTP_PORT - Static variable in class org.mule.transport.http.HttpConstants
 
DEFAULT_HTTP_REQUEST_CONFIG_NAME - Static variable in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
DEFAULT_HTTP_VERSION - Static variable in class org.mule.transport.http.HttpConstants
 
DEFAULT_IMAP_PORT - Static variable in class org.mule.transport.email.ImapConnector
 
DEFAULT_IMAPS_PORT - Static variable in class org.mule.transport.email.ImapsConnector
 
DEFAULT_INITIAL_RETRY_COUNT - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_ITERATION_COUNT - Static variable in class org.mule.security.PasswordBasedEncryptionStrategy
 
DEFAULT_JMS_POLL_FREQUENCY - Static variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
DEFAULT_JMS_POLL_TIMEUNIT - Static variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
DEFAULT_JMX_ADAPTOR_URL - Static variable in class org.mule.module.management.agent.JdmkAgent
 
DEFAULT_JMX_ADAPTOR_URL - Static variable in class org.mule.module.management.agent.Mx4jAgent
 
DEFAULT_JMX_AUTHENTICATOR - Static variable in class org.mule.module.management.agent.AbstractJmxAgent
Default JMX Authenticator to use for securing remote access.
DEFAULT_JMX_DOMAIN_PREFIX - Static variable in interface org.mule.module.management.support.JmxSupport
Default Mule domain prefix for all instances.
DEFAULT_JMX_NAME - Static variable in interface org.mule.module.management.mbean.MuleConfigurationServiceMBean
 
DEFAULT_JMX_NAME - Static variable in interface org.mule.module.management.mbean.MuleServiceMBean
 
DEFAULT_JMX_NAME - Static variable in interface org.mule.module.management.mbean.StatisticsServiceMBean
 
DEFAULT_JMX_NAME_PREFIX - Static variable in interface org.mule.module.management.mbean.ConnectorServiceMBean
 
DEFAULT_JMX_NAME_PREFIX - Static variable in interface org.mule.module.management.mbean.ModelServiceMBean
 
DEFAULT_JMX_NAME_PREFIX - Static variable in interface org.mule.module.management.mbean.ServiceServiceMBean
Deprecated.
 
DEFAULT_KEYMANAGER_ALGORITHM - Static variable in class org.mule.api.security.tls.TlsConfiguration
 
DEFAULT_KEYSTORE - Static variable in class org.mule.api.security.tls.TlsConfiguration
 
DEFAULT_KEYSTORE_TYPE - Static variable in class org.mule.api.security.tls.TlsConfiguration
 
DEFAULT_LENGTH_MULE_EVENT_ID - Static variable in class org.mule.DefaultMuleEvent
EventId is concatenated with a dash character and a default clusterNodeId, which has two digits at most.
DEFAULT_LOG_CONFIGURATION_FACTORY - Static variable in class org.mule.api.config.MuleProperties
 
DEFAULT_LOG_CONTEXT_SELECTOR - Static variable in class org.mule.api.config.MuleProperties
 
DEFAULT_MAX_BUFFER_SIZE - Static variable in class org.mule.api.config.DefaultThreadingProfileConfig
Default value for MAX_BUFFER_SIZE
DEFAULT_MAX_BUFFER_SIZE - Static variable in interface org.mule.api.config.ThreadingProfile
Default value for MAX_BUFFER_SIZE
DEFAULT_MAX_POOL_ACTIVE - Static variable in class org.mule.config.PoolingProfile
Controls the maximum number of Mule components that can be borrowed from a service pool at one time.
DEFAULT_MAX_POOL_IDLE - Static variable in class org.mule.config.PoolingProfile
Controls the maximum number of Mule components that can sit idle in the pool at any time.
DEFAULT_MAX_POOL_WAIT - Static variable in class org.mule.config.PoolingProfile
When the threadPoolExhaustedAction is set to WHEN_EXHAUSTED_WAIT this can specify the maximum milliseconds the pool should block before throwing a NoSuchElementException
DEFAULT_MAX_REDELIVERY - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_MAX_THREAD_TTL - Static variable in class org.mule.api.config.DefaultThreadingProfileConfig
Default value for MAX_THREAD_TTL
DEFAULT_MAX_THREAD_TTL - Static variable in interface org.mule.api.config.ThreadingProfile
Default value for MAX_THREAD_TTL
DEFAULT_MAX_THREADS - Static variable in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
DEFAULT_MAX_THREADS_ACTIVE - Static variable in class org.mule.api.config.DefaultThreadingProfileConfig
Default value for MAX_THREADS_ACTIVE
DEFAULT_MAX_THREADS_ACTIVE - Static variable in interface org.mule.api.config.ThreadingProfile
Default value for MAX_THREADS_ACTIVE
DEFAULT_MAX_THREADS_IDLE - Static variable in class org.mule.api.config.DefaultThreadingProfileConfig
Default value for MAX_THREADS_IDLE
DEFAULT_MAX_THREADS_IDLE - Static variable in interface org.mule.api.config.ThreadingProfile
Default value for MAX_THREADS_IDLE
DEFAULT_MAX_UNACKED_SIZE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_MESSAGE_THREAD_POOL_SIZE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_MESSAGE_WIDTH - Static variable in class org.mule.util.StringMessageUtils
 
DEFAULT_METHOD_NAME_TOKEN - Static variable in class org.mule.component.BindingInvocationHandler
 
DEFAULT_MIME_TYPE - Static variable in class org.mule.transport.http.components.StaticResourceMessageProcessor
 
DEFAULT_MIME_TYPE - Static variable in class org.mule.transport.servlet.JarResourceServlet
 
DEFAULT_MIN_EVICTION_MILLIS - Static variable in class org.mule.config.PoolingProfile
Determines the minimum amount of time an object may sit idle in the pool before it is eligible for eviction.
DEFAULT_MIN_REFRESH_INTERVAL - Static variable in interface org.mule.security.oauth.RefreshTokenManager
 
DEFAULT_MODEL_NAME - Static variable in class org.mule.model.AbstractModel
Deprecated.
 
DEFAULT_MULE_AXIS_CLIENT_CONFIG - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
DEFAULT_MULE_AXIS_SERVER_CONFIG - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
DEFAULT_MULE_NAMESPACE_URI - Static variable in class org.mule.module.cxf.CxfConfiguration
 
DEFAULT_MULE_NAMESPACE_URI - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
DEFAULT_NUM_CONCURRENT_TX_RECEIVERS - Static variable in class org.mule.transport.AbstractConnector
Default number of concurrent transactional receivers.
DEFAULT_PACKAGE - Static variable in class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
DEFAULT_PARTITION - Static variable in class org.mule.util.store.AbstractPartitionedObjectStore
 
DEFAULT_PATH_IN_JAR - Static variable in class org.mule.module.management.agent.Mx4jAgent
 
DEFAULT_PATH_SPEC - Static variable in class org.mule.transport.servlet.JarResourceServlet
 
DEFAULT_PAYLOAD_EXPRESSION - Static variable in class org.mule.module.http.internal.request.DefaultHttpRequester
 
DEFAULT_PAYLOAD_PARAMETER_NAME - Static variable in class org.mule.transport.servlet.AbstractReceiverServlet
 
DEFAULT_POLL_FREQUENCY - Static variable in class org.mule.transport.AbstractPollingMessageReceiver
 
DEFAULT_POLL_TIMEUNIT - Static variable in class org.mule.transport.AbstractPollingMessageReceiver
 
DEFAULT_POLLING_FREQUENCY - Static variable in class org.mule.transport.file.FileConnector
 
DEFAULT_POLLING_FREQUENCY - Static variable in class org.mule.transport.ftp.FtpConnector
 
DEFAULT_POLLING_FREQUENCY - Static variable in class org.mule.transport.jdbc.JdbcConnector
 
DEFAULT_POLLING_FREQUENCY - Static variable in class org.mule.transport.sftp.SftpConnector
 
DEFAULT_POOL_EXHAUST_ACTION - Static variable in interface org.mule.api.config.ThreadingProfile
Default action to perform on pool exhaustion
DEFAULT_POOL_EXHAUSTED_ACTION - Static variable in class org.mule.config.PoolingProfile
Specifies the behaviour of the Mule component pool when the pool is exhausted: WHEN_EXHAUSTED_FAIL : will throw a NoSuchElementException WHEN_EXHAUSTED_WAIT : will block (invoke Object.wait(long) until a new or idle object is available. WHEN_EXHAUSTED_GROW : will create a new Mule and return it (essentially making maxActive meaningless). If a positive maxWait value is supplied, it will block for at most that many milliseconds, after which a NoSuchElementException will be thrown.
DEFAULT_POOL_INITIALISATION_POLICY - Static variable in class org.mule.config.PoolingProfile
Determines how components in a pool should be initialised.
DEFAULT_POP3_PORT - Static variable in class org.mule.transport.email.Pop3Connector
 
DEFAULT_POP3S_PORT - Static variable in class org.mule.transport.email.Pop3sConnector
 
DEFAULT_PORT - Static variable in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
DEFAULT_PORT - Static variable in class org.mule.module.management.agent.JdmkAgent
 
DEFAULT_PORT - Static variable in class org.mule.module.management.agent.Mx4jAgent
 
DEFAULT_PORT - Static variable in class org.mule.module.management.agent.RmiRegistryAgent
 
DEFAULT_PORT - Static variable in class org.mule.tck.util.ftp.Server
 
DEFAULT_PORT - Static variable in class org.mule.transport.servlet.jetty.WebappsConfiguration
 
DEFAULT_PRIORITY_WEIGHTING - Static variable in interface org.mule.api.transformer.Converter
 
DEFAULT_PROCESS_MESSAGE_ACTION - Static variable in class org.mule.transport.email.config.EmailNamespaceHandler
 
DEFAULT_PROCESSING_STRATEGY - Static variable in class org.mule.config.spring.util.ProcessingStrategyUtils
 
DEFAULT_QUEUE_SIZE_MAX_THREADS_FACTOR - Static variable in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
DEFAULT_QUEUE_STORE - Static variable in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
The default queueStore directory for persistence
DEFAULT_QUEUE_WINDOW_SIZE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_RANDOMISE_R_NAMES - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_REALM_URL - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_REFRESH_TOKEN_WHEN_EXPRESSION - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
DEFAULT_RELOAD_CONTROL - Static variable in class org.mule.config.i18n.MessageFactory
Default is ReloadControl.Always.
DEFAULT_REMOTING_URI - Static variable in class org.mule.module.management.agent.AbstractJmxAgent
 
DEFAULT_RESOURCE_OWNER_ID - Static variable in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
DEFAULT_RETRY_COMMIT - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_RETRY_COUNT - Static variable in class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
DEFAULT_RMI_muleRegistry_PORT - Static variable in class org.mule.transport.rmi.RmiConnector
 
DEFAULT_SCHEMA_LANGUAGE - Static variable in class org.mule.module.xml.filters.SchemaValidationFilter
 
DEFAULT_SECURITY_MODEL - Static variable in class org.mule.api.security.tls.TlsConfiguration
 
DEFAULT_SELECTOR_EVALUATOR - Static variable in class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
DEFAULT_SELECTOR_EVALUATOR - Static variable in class org.mule.routing.outbound.ExpressionRecipientList
 
DEFAULT_SELECTOR_EXPRESSION - Static variable in class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
DEFAULT_SELECTOR_EXPRESSION - Static variable in class org.mule.routing.outbound.ExpressionRecipientList
 
DEFAULT_SELECTOR_PROPERTY - Static variable in class org.mule.routing.outbound.ExpressionRecipientList
 
DEFAULT_SERVER_URI - Static variable in class org.mule.module.management.agent.RmiRegistryAgent
 
DEFAULT_SESSION_CACHE_SIZE - Static variable in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
DEFAULT_SLEEP_MILLIS - Static variable in class org.mule.transport.TrackingWorkManager
 
DEFAULT_SMTP_HOST - Static variable in class org.mule.transport.email.SmtpConnector
 
DEFAULT_SMTP_PORT - Static variable in class org.mule.transport.email.SmtpConnector
 
DEFAULT_SMTPS_PORT - Static variable in class org.mule.transport.email.SmtpsConnector
 
DEFAULT_SO_LINGER - Static variable in class org.mule.transport.tcp.TcpConnector
 
DEFAULT_SOCKET_FACTORY - Static variable in class org.mule.transport.email.SmtpsConnector
 
DEFAULT_SOCKET_TIMEOUT - Static variable in class org.mule.transport.tcp.TcpConnector
 
DEFAULT_SOCKET_TIMEOUT - Static variable in class org.mule.transport.udp.UdpConnector
 
DEFAULT_SSL_TYPE - Static variable in class org.mule.api.security.tls.TlsConfiguration
 
DEFAULT_STACKTRACE_FILTER - Static variable in class org.mule.config.DefaultMuleConfiguration
 
DEFAULT_STARTUP_DELAY - Static variable in class org.mule.transport.AbstractPollingMessageReceiver
 
DEFAULT_STORE_PREFIX - Static variable in class org.mule.routing.EventGroup
 
DEFAULT_SUBJECT_VALUE - Static variable in class org.mule.transport.email.SmtpConnector
 
DEFAULT_SYNC_BATCH_SIZE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_SYNC_TIME - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_SYNC_WRITES - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_TEXT - Static variable in class org.mule.tck.functional.StringAppendTestTransformer
 
DEFAULT_THREAD_WAIT_TIMEOUT - Static variable in class org.mule.api.config.DefaultThreadingProfileConfig
Default value for DEFAULT_THREAD_WAIT_TIMEOUT
DEFAULT_THREAD_WAIT_TIMEOUT - Static variable in interface org.mule.api.config.ThreadingProfile
Default value for DEFAULT_THREAD_WAIT_TIMEOUT
DEFAULT_THREADING_PROFILE - Static variable in interface org.mule.api.config.ThreadingProfile
 
DEFAULT_TIMEOUT_MSECS - Static variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
DEFAULT_TIMEOUT_MSECS - Static variable in class org.mule.util.xa.AbstractResourceManager
 
DEFAULT_TRANSFORMATION_RESOLVE_NON_DIRECT - Static variable in class org.mule.config.DefaultMuleConfiguration
 
DEFAULT_TYPE_1_MESSAGE_FLAGS - Static variable in class org.mule.transport.http.ntlm.NtlmMessageFactory
 
DEFAULT_TYPE_3_MESSAGE_FLAGS - Static variable in class org.mule.transport.http.ntlm.NtlmMessageFactory
 
DEFAULT_USE_JMS_ENGINE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DEFAULT_USER_OBJECT_STORE_NAME - Static variable in class org.mule.api.config.MuleProperties
 
DEFAULT_USER_TRANSIENT_OBJECT_STORE_NAME - Static variable in class org.mule.api.config.MuleProperties
 
DEFAULT_VALUE_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.param.InputParamValueBeanDefinitionParser
 
DEFAULT_WAIT_TIMEOUT - Static variable in class org.mule.transport.tcp.TcpConnector
 
DEFAULT_WRAPPER_MBEAN_NAME - Static variable in class org.mule.module.management.agent.WrapperManagerAgent
For cases when Mule is embedded in another process and that external process had registered the MBean.
DEFAULT_XA_RECEIVER_CLASS - Static variable in class org.mule.transport.jms.websphere.WebsphereJmsConnector
 
DefaultAppBloodhound - Class in org.mule.module.launcher
 
DefaultAppBloodhound() - Constructor for class org.mule.module.launcher.DefaultAppBloodhound
 
DefaultApplicationFactory - Class in org.mule.module.launcher.application
Creates default mule applications
DefaultApplicationFactory(ApplicationClassLoaderFactory, DomainFactory) - Constructor for class org.mule.module.launcher.application.DefaultApplicationFactory
 
DefaultArchiveDeployer<T extends Artifact> - Class in org.mule.module.launcher
Deployer of an artifact within mule container.
DefaultArchiveDeployer(ArtifactDeployer, ArtifactFactory, ObservableList<T>, ArtifactDeploymentTemplate) - Constructor for class org.mule.module.launcher.DefaultArchiveDeployer
 
DefaultArtifactDeployer<T extends Artifact> - Class in org.mule.module.launcher
 
DefaultArtifactDeployer() - Constructor for class org.mule.module.launcher.DefaultArtifactDeployer
 
DefaultAuthorizationCodeGrantType - Class in org.mule.module.oauth2.internal.authorizationcode
Represents the config element for oauth:authentication-code-config.
DefaultAuthorizationCodeGrantType() - Constructor for class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
DefaultAutoGeneratedKeyStrategy - Class in org.mule.module.db.internal.domain.autogeneratedkey
 
DefaultAutoGeneratedKeyStrategy() - Constructor for class org.mule.module.db.internal.domain.autogeneratedkey.DefaultAutoGeneratedKeyStrategy
 
DefaultBeanAssembler - Class in org.mule.config.spring.parsers.assembly
 
DefaultBeanAssembler(PropertyConfiguration, BeanDefinitionBuilder, PropertyConfiguration, BeanDefinition) - Constructor for class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
DefaultBeanAssemblerFactory - Class in org.mule.config.spring.parsers.assembly
 
DefaultBeanAssemblerFactory() - Constructor for class org.mule.config.spring.parsers.assembly.DefaultBeanAssemblerFactory
 
defaultCharsetName() - Static method in class org.mule.util.CharSetUtils
 
DefaultComponentLifecycleAdapter - Class in org.mule.component
DefaultComponentLifecycleAdapter is a default implementation of LifecycleAdapter for use with JavaComponent that expects component instances to implement Mule lifecycle interfaces in order to receive lifecycle.
DefaultComponentLifecycleAdapter(Object, JavaComponent, FlowConstruct, MuleContext) - Constructor for class org.mule.component.DefaultComponentLifecycleAdapter
 
DefaultComponentLifecycleAdapter(Object, JavaComponent, FlowConstruct, EntryPointResolverSet, MuleContext) - Constructor for class org.mule.component.DefaultComponentLifecycleAdapter
 
DefaultComponentLifecycleAdapterFactory - Class in org.mule.component
DefaultComponentLifecycleAdapterFactory creates a DefaultComponentLifecycleAdapter.
DefaultComponentLifecycleAdapterFactory() - Constructor for class org.mule.component.DefaultComponentLifecycleAdapterFactory
 
DefaultConfigurableKeyedObjectPool - Class in org.mule.transport
Implements ConfigurableKeyedObjectPool as a delegate of a KeyedPoolableObjectFactory instance.
DefaultConfigurableKeyedObjectPool() - Constructor for class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
DefaultConfigurableKeyedObjectPoolFactory - Class in org.mule.transport
DefaultConfigurableKeyedObjectPoolFactory() - Constructor for class org.mule.transport.DefaultConfigurableKeyedObjectPoolFactory
 
DefaultConnectionFactoryDecorator - Class in org.mule.transport.jms
Decorates the jms ConnectionFactory with a DefaultXAConnectionFactoryWrapper in order to avoid releasing jms resources before the XA transaction has ended.
DefaultConnectionFactoryDecorator() - Constructor for class org.mule.transport.jms.DefaultConnectionFactoryDecorator
 
defaultContentType - Variable in class org.mule.transport.servlet.AbstractReceiverServlet
 
DefaultDataContentHandlerFactory - Class in org.mule.transport.email
This is a default registry for mapping MimeTypes to DataHandlers
DefaultDataSourceDecorator - Class in org.mule.module.db.internal.domain.xa
Decorates a DataSource using a DataSourceWrapper if required
DefaultDataSourceDecorator() - Constructor for class org.mule.module.db.internal.domain.xa.DefaultDataSourceDecorator
 
DefaultDataSourceDecorator - Class in org.mule.transport.jdbc.xa
 
DefaultDataSourceDecorator() - Constructor for class org.mule.transport.jdbc.xa.DefaultDataSourceDecorator
 
DefaultDbConfigResolver - Class in org.mule.module.db.internal.resolver.database
Resolves the default database configuration defined in an application
DefaultDbConfigResolver(MuleRegistry) - Constructor for class org.mule.module.db.internal.resolver.database.DefaultDbConfigResolver
 
DefaultDbConfigResolverFactoryBean - Class in org.mule.module.db.internal.config.resolver.database
 
DefaultDbConfigResolverFactoryBean() - Constructor for class org.mule.module.db.internal.config.resolver.database.DefaultDbConfigResolverFactoryBean
 
DefaultDbConnection - Class in org.mule.module.db.internal.domain.connection
Delegates Connection behaviour to a delegate
DefaultDbConnection(Connection, TransactionalAction, DefaultDbConnectionReleaser, ParamTypeResolverFactory) - Constructor for class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
DefaultDbConnectionReleaser - Class in org.mule.module.db.internal.domain.connection
 
DefaultDbConnectionReleaser(DbConnectionFactory) - Constructor for class org.mule.module.db.internal.domain.connection.DefaultDbConnectionReleaser
 
defaultDerbyCleanAndInit(String, String) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
 
DefaultDescribingContext - Class in org.mule.module.extension.internal
Default implementation of DescribingContext.
DefaultDescribingContext(DeclarationDescriptor) - Constructor for class org.mule.module.extension.internal.DefaultDescribingContext
 
DefaultDomainFactory - Class in org.mule.module.launcher.domain
 
DefaultDomainFactory(DomainClassLoaderRepository) - Constructor for class org.mule.module.launcher.domain.DefaultDomainFactory
 
DefaultEndpointFactory - Class in org.mule.endpoint
 
DefaultEndpointFactory() - Constructor for class org.mule.endpoint.DefaultEndpointFactory
 
DefaultEndpointMessageProcessorChainFactory - Class in org.mule.endpoint
 
DefaultEndpointMessageProcessorChainFactory() - Constructor for class org.mule.endpoint.DefaultEndpointMessageProcessorChainFactory
 
DefaultEntryPointResolverSet - Class in org.mule.model.resolvers
Provides the default implementation of an EntryPointResolverSet It resolves a method to call on the given service when an event is received.
DefaultEntryPointResolverSet() - Constructor for class org.mule.model.resolvers.DefaultEntryPointResolverSet
 
DefaultExceptionPayload - Class in org.mule.message
DefaultExceptionPayload TODO
DefaultExceptionPayload(Throwable) - Constructor for class org.mule.message.DefaultExceptionPayload
 
DefaultExceptionReader - Class in org.mule.config
This is the default exception reader used if there is no specific one registered for the current exception.
DefaultExceptionReader() - Constructor for class org.mule.config.DefaultExceptionReader
 
DefaultExpressionManager - Class in org.mule.expression
Provides universal access for evaluating expressions embedded in Mule configurations, such as Xml, Java, scripting and annotations.
DefaultExpressionManager() - Constructor for class org.mule.expression.DefaultExpressionManager
 
DefaultExtensionFactory - Class in org.mule.module.extension.internal.introspection
Default implementation of ExtensionFactory which uses a ServiceRegistry to locate instances of DescriberPostProcessor.
DefaultExtensionFactory(ServiceRegistry) - Constructor for class org.mule.module.extension.internal.introspection.DefaultExtensionFactory
Creates a new instance and uses the given serviceRegistry to locate instances of DescriberPostProcessor
DefaultExtensionManager - Class in org.mule.module.extension.internal.manager
Default implementation of ExtensionManagerAdapter.
DefaultExtensionManager() - Constructor for class org.mule.module.extension.internal.manager.DefaultExtensionManager
 
DefaultFileReader - Class in org.mule.module.db.internal.util
Reads files using IOUtils
DefaultFileReader() - Constructor for class org.mule.module.db.internal.util.DefaultFileReader
 
DefaultFlowCallStack - Class in org.mule.context.notification
Keeps context information about the executing flows and its callers in order to provide augmented troubleshooting information for an application developer.
DefaultFlowCallStack() - Constructor for class org.mule.context.notification.DefaultFlowCallStack
 
DefaultFlowProcessingStrategy - Class in org.mule.construct.flow
This processing strategy uses the 'queued-asynchronous' strategy where possible, but if an event is synchronous it processes it synchronously rather than failing.
DefaultFlowProcessingStrategy() - Constructor for class org.mule.construct.flow.DefaultFlowProcessingStrategy
 
defaultForNull(String, String) - Static method in class org.mule.api.security.tls.TlsConfiguration
 
defaultHandler(Throwable) - Method in class org.mule.exception.AbstractMessagingExceptionStrategy
Deprecated.
Override doHandleException(Exception e, MuleEvent event) instead
DefaultHttpAuthentication - Class in org.mule.module.http.internal.request
 
DefaultHttpAuthentication(HttpAuthenticationType) - Constructor for class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
DefaultHttpCallback - Class in org.mule.security.oauth
Default implementation of HttpCallback.
DefaultHttpCallback(Flow, MuleContext, String, Integer, Integer, Boolean) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback(MessageProcessor, MuleContext, String, Integer, Integer, Boolean) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback(MessageProcessor, MuleContext, String, Integer, Integer, String, Boolean) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback(Flow, MuleContext, String, Integer, Integer, Boolean, Object) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback(MessageProcessor, MuleContext, String, Integer, Integer, Boolean, Object) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback(MessageProcessor, MuleContext, String, Integer, Integer, String, Boolean, Object) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback(List<MessageProcessor>, MuleContext, String, Integer, Integer, Boolean, Object) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback(List<MessageProcessor>, MuleContext, String, Integer, Integer, String, Boolean, Object) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback(List<MessageProcessor>, MuleContext, String, Integer, Integer, Boolean) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback(List<MessageProcessor>, MuleContext, String, Integer, Integer, String, Boolean) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback(List<MessageProcessor>, MuleContext, String, Integer, Integer, String, Boolean, MessagingExceptionHandler) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback(List<MessageProcessor>, MuleContext, String, Integer, Integer, String, Boolean, MessagingExceptionHandler, Object) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback(MessageProcessor, MuleContext, String, Integer, Integer, String, Boolean, MessagingExceptionHandler, Object) - Constructor for class org.mule.security.oauth.DefaultHttpCallback
 
DefaultHttpCallback.FlowRefMessageProcessor - Class in org.mule.security.oauth
 
DefaultHttpCallback.FlowRefMessageProcessor() - Constructor for class org.mule.security.oauth.DefaultHttpCallback.FlowRefMessageProcessor
 
DefaultHttpCallbackAdapter - Class in org.mule.security.oauth.callback
 
DefaultHttpCallbackAdapter() - Constructor for class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
 
DefaultHttpCallbackFactory - Class in org.mule.security.oauth.callback
 
DefaultHttpCallbackFactory() - Constructor for class org.mule.security.oauth.callback.DefaultHttpCallbackFactory
 
DefaultHttpListener - Class in org.mule.module.http.internal.listener
 
DefaultHttpListener() - Constructor for class org.mule.module.http.internal.listener.DefaultHttpListener
 
DefaultHttpListenerConfig - Class in org.mule.module.http.internal.listener
 
DefaultHttpListenerConfig() - Constructor for class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
DefaultHttpRequest - Class in org.mule.module.http.internal.domain.request
 
DefaultHttpRequest(String, String, String, ParameterMap, ParameterMap, HttpEntity) - Constructor for class org.mule.module.http.internal.domain.request.DefaultHttpRequest
DefaultHttpRequest constructor
DefaultHttpRequester - Class in org.mule.module.http.internal.request
 
DefaultHttpRequester() - Constructor for class org.mule.module.http.internal.request.DefaultHttpRequester
 
DefaultHttpRequesterConfig - Class in org.mule.module.http.internal.request
 
DefaultHttpRequesterConfig() - Constructor for class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
DefaultHttpRequestOptions - Class in org.mule.module.http.internal.request.client
Default implementation for HttpRequestOptions
DefaultHttpRequestOptions(String, Boolean, HttpStreamingType, HttpRequesterConfig, boolean, boolean, TlsContextFactory, Long) - Constructor for class org.mule.module.http.internal.request.client.DefaultHttpRequestOptions
 
DefaultHttpResponse - Class in org.mule.module.http.internal.domain.response
 
DefaultHttpResponse(ResponseStatus, MultiMap, HttpEntity) - Constructor for class org.mule.module.http.internal.domain.response.DefaultHttpResponse
 
DefaultInboundEndpoint - Class in org.mule.endpoint
 
DefaultInboundEndpoint(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.DefaultInboundEndpoint
 
defaultInboundTransformers - Variable in class org.mule.transport.AbstractMessageReceiver
 
DefaultInOutQueryParam - Class in org.mule.module.db.internal.domain.param
 
DefaultInOutQueryParam(int, DbType, String, Object) - Constructor for class org.mule.module.db.internal.domain.param.DefaultInOutQueryParam
 
DefaultInputQueryParam - Class in org.mule.module.db.internal.domain.param
 
DefaultInputQueryParam(int, DbType, Object) - Constructor for class org.mule.module.db.internal.domain.param.DefaultInputQueryParam
 
DefaultInputQueryParam(int, DbType, Object, String) - Constructor for class org.mule.module.db.internal.domain.param.DefaultInputQueryParam
 
DefaultInterfaceBinding - Class in org.mule.component
 
DefaultInterfaceBinding() - Constructor for class org.mule.component.DefaultInterfaceBinding
 
DefaultJavaComponent - Class in org.mule.component
Default implementation of JavaComponent.
DefaultJavaComponent() - Constructor for class org.mule.component.DefaultJavaComponent
For spring only
DefaultJavaComponent(ObjectFactory) - Constructor for class org.mule.component.DefaultJavaComponent
 
DefaultJavaComponent(ObjectFactory, EntryPointResolverSet, List<InterfaceBinding>) - Constructor for class org.mule.component.DefaultJavaComponent
 
DefaultJmsTopicResolver - Class in org.mule.transport.jms
A default implementation of the resolver uses endpoint's resource info and Java's instanceof operator to detect JMS topics.
DefaultJmsTopicResolver(JmsConnector) - Constructor for class org.mule.transport.jms.DefaultJmsTopicResolver
Create an instance of the resolver.
DefaultJmxSupportAgent - Class in org.mule.module.management.agent
 
DefaultJmxSupportAgent() - Constructor for class org.mule.module.management.agent.DefaultJmxSupportAgent
 
DefaultJsonParser - Class in org.mule.module.json
Default implementation of JsonParser.
DefaultJsonParser(MuleContext) - Constructor for class org.mule.module.json.DefaultJsonParser
 
DefaultLifecycleEnabledObjectPool - Class in org.mule.util.pool
A LifecyleEnabledObjectPool implementation for pooling LifecycleAdapter instances for implementations of JavaComponent that require LifecycleAdapter pooling such as PooledJavaComponent.
DefaultLifecycleEnabledObjectPool(ObjectFactory, PoolingProfile, MuleContext) - Constructor for class org.mule.util.pool.DefaultLifecycleEnabledObjectPool
 
DefaultLifecycleManager<T extends Lifecycle> - Class in org.mule.lifecycle
Default implementation of a SimpleLifecycleManager it allows Lifecycle objects to manage their lifecycle easily.
DefaultLifecycleManager(String, T) - Constructor for class org.mule.lifecycle.DefaultLifecycleManager
 
DefaultLifecyclePhase - Class in org.mule.lifecycle.phases
Represents a configurable lifecycle phase.
DefaultLifecyclePhase(String, Class<?>, String) - Constructor for class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
DefaultLifecycleState - Class in org.mule.lifecycle
A safe facade for lifecycle manager that objects can use to monitor its own state
DefaultListableBeanFactory - Class in org.springframework.beans.factory.support
Repackaged version from the Spring framework which includes temporal fix for Spring Issue SPR-12970, which was the root cause for MULE-8556.
DefaultListableBeanFactory() - Constructor for class org.springframework.beans.factory.support.DefaultListableBeanFactory
Create a new DefaultListableBeanFactory.
DefaultListableBeanFactory(BeanFactory) - Constructor for class org.springframework.beans.factory.support.DefaultListableBeanFactory
Create a new DefaultListableBeanFactory with the given parent.
DefaultLocalMuleClient - Class in org.mule.client
 
DefaultLocalMuleClient(MuleContext) - Constructor for class org.mule.client.DefaultLocalMuleClient
 
DefaultLocalMuleClient.MuleClientFlowConstruct - Class in org.mule.client
Placeholder class which makes the default exception handler available.
DefaultLocalMuleClient.MuleClientFlowConstruct(MuleContext) - Constructor for class org.mule.client.DefaultLocalMuleClient.MuleClientFlowConstruct
 
DefaultLoginModule - Class in org.mule.module.jaas.loginmodule
This is the Default Login Module for the Mule Jaas Authentication.
DefaultLoginModule() - Constructor for class org.mule.module.jaas.loginmodule.DefaultLoginModule
 
DefaultMemoryQueueStoreFactoryBean - Class in org.mule.config.spring.factories
 
DefaultMemoryQueueStoreFactoryBean() - Constructor for class org.mule.config.spring.factories.DefaultMemoryQueueStoreFactoryBean
 
DefaultMessageCollection - Class in org.mule
A MuleMessage type that manages a collection of MuleMessage Objects.
DefaultMessageCollection(MuleContext) - Constructor for class org.mule.DefaultMessageCollection
 
DefaultMessageCollection(DefaultMessageCollection, MuleContext) - Constructor for class org.mule.DefaultMessageCollection
Performs a shallow copy
DefaultMessageCollection(DefaultMessageCollection, MuleContext, boolean) - Constructor for class org.mule.DefaultMessageCollection
Performs a shallow or deep copy of the messages
defaultMessageInfoMapping - Variable in class org.mule.transport.AbstractTransportMessageHandler
 
DefaultMessageProcessorChain - Class in org.mule.processor.chain
 
DefaultMessageProcessorChain(List<MessageProcessor>) - Constructor for class org.mule.processor.chain.DefaultMessageProcessorChain
 
DefaultMessageProcessorChain(MessageProcessor...) - Constructor for class org.mule.processor.chain.DefaultMessageProcessorChain
 
DefaultMessageProcessorChain(String, List<MessageProcessor>) - Constructor for class org.mule.processor.chain.DefaultMessageProcessorChain
 
DefaultMessageProcessorChain(String, MessageProcessor...) - Constructor for class org.mule.processor.chain.DefaultMessageProcessorChain
 
DefaultMessageProcessorChainBuilder - Class in org.mule.processor.chain
Constructs a chain of MessageProcessors and wraps the invocation of the chain in a composite MessageProcessor.
DefaultMessageProcessorChainBuilder() - Constructor for class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
 
DefaultMessageProcessorChainBuilder(FlowConstruct) - Constructor for class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
 
DefaultMessageProcessorPathElement - Class in org.mule.api.processor
 
DefaultMessageProcessorPathElement(MessageProcessor, String) - Constructor for class org.mule.api.processor.DefaultMessageProcessorPathElement
 
DefaultMessagingExceptionStrategy - Class in org.mule.exception
This is the default exception handler for flows and services.
DefaultMessagingExceptionStrategy() - Constructor for class org.mule.exception.DefaultMessagingExceptionStrategy
 
DefaultMessagingExceptionStrategy(MuleContext) - Constructor for class org.mule.exception.DefaultMessagingExceptionStrategy
 
defaultMethod - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
defaultMethodName - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
DefaultModelServiceDescriptor - Class in org.mule.model
 
DefaultModelServiceDescriptor(String, Properties) - Constructor for class org.mule.model.DefaultModelServiceDescriptor
 
DefaultMuleApplication - Class in org.mule.module.launcher.application
 
DefaultMuleApplication(ApplicationDescriptor, ApplicationClassLoaderFactory, Domain) - Constructor for class org.mule.module.launcher.application.DefaultMuleApplication
 
DefaultMuleApplicationBuilder - Class in org.mule.module.launcher.application.builder
DefaultMuleApplicationBuilder() - Constructor for class org.mule.module.launcher.application.builder.DefaultMuleApplicationBuilder
 
DefaultMuleArtifact - Class in org.mule.config.spring
 
DefaultMuleArtifact(Object) - Constructor for class org.mule.config.spring.DefaultMuleArtifact
 
DefaultMuleAuthentication - Class in org.mule.security
 
DefaultMuleAuthentication(Credentials) - Constructor for class org.mule.security.DefaultMuleAuthentication
 
DefaultMuleAuthentication(Credentials, MuleEvent) - Constructor for class org.mule.security.DefaultMuleAuthentication
 
DefaultMuleClassPathConfig - Class in org.mule.module.boot
Constructs a default set of JAR Urls located under Mule home folder.
DefaultMuleClassPathConfig(File, File) - Constructor for class org.mule.module.boot.DefaultMuleClassPathConfig
Constructs a new DefaultMuleClassPathConfig.
DefaultMuleClassPathConfig - Class in org.mule.module.reboot
Constructs a default set of JAR Urls located under Mule home folder.
DefaultMuleClassPathConfig(File, File) - Constructor for class org.mule.module.reboot.DefaultMuleClassPathConfig
 
DefaultMuleConfiguration - Class in org.mule.config
Configuration info.
DefaultMuleConfiguration() - Constructor for class org.mule.config.DefaultMuleConfiguration
 
DefaultMuleConfiguration(boolean) - Constructor for class org.mule.config.DefaultMuleConfiguration
 
DefaultMuleContext - Class in org.mule
 
DefaultMuleContext(MuleConfiguration, WorkManager, WorkListener, MuleContextLifecycleManager, ServerNotificationManager) - Constructor for class org.mule.DefaultMuleContext
Deprecated.
Use empty constructor instead and use setter for dependencies.
DefaultMuleContext() - Constructor for class org.mule.DefaultMuleContext
 
DefaultMuleContextBuilder - Class in org.mule.context
Implementation of MuleContextBuilder that uses DefaultMuleContext as the default MuleContext implementation and builds it with defaults values for MuleConfiguration, LifecycleManager, WorkManager, WorkListener and ServerNotificationManager.
DefaultMuleContextBuilder() - Constructor for class org.mule.context.DefaultMuleContextBuilder
 
DefaultMuleContextFactory - Class in org.mule.context
Default implementation that uses DefaultMuleContextBuilder to build new MuleContext instances.
DefaultMuleContextFactory() - Constructor for class org.mule.context.DefaultMuleContextFactory
 
DefaultMuleCoreExtensionManager - Class in org.mule.module.launcher.coreextension
 
DefaultMuleCoreExtensionManager() - Constructor for class org.mule.module.launcher.coreextension.DefaultMuleCoreExtensionManager
 
DefaultMuleCoreExtensionManager(MuleCoreExtensionDiscoverer, MuleCoreExtensionDependencyResolver) - Constructor for class org.mule.module.launcher.coreextension.DefaultMuleCoreExtensionManager
 
DefaultMuleDomain - Class in org.mule.module.launcher.domain
 
DefaultMuleDomain(DomainClassLoaderRepository, DomainDescriptor) - Constructor for class org.mule.module.launcher.domain.DefaultMuleDomain
 
DefaultMuleDomainBuilder - Class in org.mule.module.launcher.application.builder
Builder for DefaultMuleDomain
DefaultMuleDomainBuilder() - Constructor for class org.mule.module.launcher.application.builder.DefaultMuleDomainBuilder
 
DefaultMuleEvent - Class in org.mule
DefaultMuleEvent represents any data event occurring in the Mule environment.
DefaultMuleEvent(MuleMessage, MessageExchangePattern, FlowConstruct, MuleSession) - Constructor for class org.mule.DefaultMuleEvent
Constructor used to create an event with no message source with minimal arguments and a MuleSession
DefaultMuleEvent(MuleMessage, MessageExchangePattern, FlowConstruct) - Constructor for class org.mule.DefaultMuleEvent
Constructor used to create an event with no message source with minimal arguments
DefaultMuleEvent(MuleMessage, MessageExchangePattern, ReplyToHandler, FlowConstruct) - Constructor for class org.mule.DefaultMuleEvent
Constructor used to create an event with no message source with minimal arguments and a ReplyToHandler
DefaultMuleEvent(MuleMessage, MessageExchangePattern, FlowConstruct, MuleSession, OutputStream) - Constructor for class org.mule.DefaultMuleEvent
Constructor used to create an event with no message source with minimal arguments and OutputStream
DefaultMuleEvent(MuleMessage, MessageExchangePattern, FlowConstruct, MuleSession, int, Credentials, OutputStream) - Constructor for class org.mule.DefaultMuleEvent
Constructor used to create an event with no message source with all additional arguments
DefaultMuleEvent(MuleMessage, URI, MessageExchangePattern, FlowConstruct, MuleSession) - Constructor for class org.mule.DefaultMuleEvent
Constructor used to create an event with a uri that idendifies the message source with minimal arguments
DefaultMuleEvent(MuleMessage, URI, MessageExchangePattern, FlowConstruct, MuleSession, OutputStream) - Constructor for class org.mule.DefaultMuleEvent
Constructor used to create an event with a uri that idendifies the message source with minimal arguments and OutputStream
DefaultMuleEvent(MuleMessage, URI, MessageExchangePattern, FlowConstruct, MuleSession, int, Credentials, OutputStream, ReplyToHandler) - Constructor for class org.mule.DefaultMuleEvent
Constructor used to create an event with a identifiable message source with all additional arguments
DefaultMuleEvent(MuleMessage, URI, MessageExchangePattern, FlowConstruct, MuleSession, int, Credentials, OutputStream) - Constructor for class org.mule.DefaultMuleEvent
Constructor used to create an event with a identifiable message source with all additional arguments except a ReplyToHandler
DefaultMuleEvent(MuleMessage, InboundEndpoint, FlowConstruct, MuleSession) - Constructor for class org.mule.DefaultMuleEvent
 
DefaultMuleEvent(MuleMessage, InboundEndpoint, FlowConstruct) - Constructor for class org.mule.DefaultMuleEvent
 
DefaultMuleEvent(MuleMessage, InboundEndpoint, FlowConstruct, MuleSession, ReplyToHandler, Object, OutputStream) - Constructor for class org.mule.DefaultMuleEvent
 
DefaultMuleEvent(MuleMessage, MuleEvent) - Constructor for class org.mule.DefaultMuleEvent
A helper constructor used to rewrite an event payload
DefaultMuleEvent(MuleEvent, FlowConstruct) - Constructor for class org.mule.DefaultMuleEvent
 
DefaultMuleEvent(MuleEvent, ReplyToHandler) - Constructor for class org.mule.DefaultMuleEvent
Copy constructor used when ReplyToHandler instance needs switching out
DefaultMuleEvent(MuleEvent, FlowConstruct, ReplyToHandler, Object) - Constructor for class org.mule.DefaultMuleEvent
 
DefaultMuleEvent(MuleEvent, FlowConstruct, ReplyToHandler, Object, boolean) - Constructor for class org.mule.DefaultMuleEvent
 
DefaultMuleEvent(MuleMessage, MuleEvent, boolean) - Constructor for class org.mule.DefaultMuleEvent
 
DefaultMuleEvent(MuleMessage, MuleEvent, boolean, boolean) - Constructor for class org.mule.DefaultMuleEvent
 
DefaultMuleEvent(MuleMessage, MuleEvent, boolean, boolean, MessageExchangePattern) - Constructor for class org.mule.DefaultMuleEvent
Copy constructor to be used when synchronicity and MessageExchangePattern both need changing.
DefaultMuleEvent(MuleMessage, MuleEvent, boolean, boolean, MessageExchangePattern, ReplyToHandler) - Constructor for class org.mule.DefaultMuleEvent
Copy constructor to be used when synchronicity, MessageExchangePattern and ReplyToHandler all need changing.
DefaultMuleEvent(MuleMessage, MuleEvent, MuleSession) - Constructor for class org.mule.DefaultMuleEvent
A helper constructor used to rewrite an event payload
DefaultMuleEvent(MuleMessage, MuleEvent, FlowConstruct, MuleSession, boolean) - Constructor for class org.mule.DefaultMuleEvent
 
DefaultMuleEvent(MuleMessage, MuleEvent, FlowConstruct, MuleSession, boolean, boolean, MessageExchangePattern, ReplyToHandler) - Constructor for class org.mule.DefaultMuleEvent
 
DefaultMuleEvent(MuleMessage, MuleEvent, FlowConstruct, MuleSession, boolean, ReplyToHandler, Object, boolean, MessageExchangePattern) - Constructor for class org.mule.DefaultMuleEvent
 
DefaultMuleEvent(MuleMessage, URI, String, MessageExchangePattern, FlowConstruct, MuleSession, int, Credentials, OutputStream, String, boolean, boolean, Object, ReplyToHandler) - Constructor for class org.mule.DefaultMuleEvent
 
DefaultMuleEvent(MuleMessage, MessageExchangePattern, MuleSession) - Constructor for class org.mule.DefaultMuleEvent
Deprecated.
DefaultMuleEvent(MuleMessage, MessageExchangePattern, MuleSession, OutputStream) - Constructor for class org.mule.DefaultMuleEvent
Deprecated.
DefaultMuleEvent(MuleMessage, MessageExchangePattern, MuleSession, int, Credentials, OutputStream) - Constructor for class org.mule.DefaultMuleEvent
Deprecated.
DefaultMuleEvent(MuleMessage, URI, MessageExchangePattern, MuleSession) - Constructor for class org.mule.DefaultMuleEvent
Deprecated.
DefaultMuleEvent(MuleMessage, URI, MessageExchangePattern, MuleSession, OutputStream) - Constructor for class org.mule.DefaultMuleEvent
Deprecated.
DefaultMuleEvent(MuleMessage, URI, MessageExchangePattern, MuleSession, int, Credentials, OutputStream) - Constructor for class org.mule.DefaultMuleEvent
Deprecated.
DefaultMuleEvent(MuleMessage, InboundEndpoint, MuleSession) - Constructor for class org.mule.DefaultMuleEvent
Deprecated.
DefaultMuleEvent(MuleMessage, InboundEndpoint, MuleSession, ReplyToHandler, OutputStream, Object) - Constructor for class org.mule.DefaultMuleEvent
Deprecated.
DefaultMuleEvent(MuleMessage, URI, String, MessageExchangePattern, MuleSession, int, Credentials, OutputStream, String, boolean, boolean, Object, ReplyToHandler) - Constructor for class org.mule.DefaultMuleEvent
Deprecated.
DefaultMuleEventContext - Class in org.mule
DefaultMuleEventContext is the context object for the current request.
DefaultMuleEventContext(MuleEvent) - Constructor for class org.mule.DefaultMuleEventContext
 
DefaultMuleException - Exception in org.mule.api
MuleException Is the base exception type for the Mule application any other exceptions thrown by Mule code will be based on this exception.
DefaultMuleException(String) - Constructor for exception org.mule.api.DefaultMuleException
 
DefaultMuleException(Message) - Constructor for exception org.mule.api.DefaultMuleException
 
DefaultMuleException(String, Throwable) - Constructor for exception org.mule.api.DefaultMuleException
 
DefaultMuleException(Message, Throwable) - Constructor for exception org.mule.api.DefaultMuleException
 
DefaultMuleException(Throwable) - Constructor for exception org.mule.api.DefaultMuleException
 
DefaultMuleMessage - Class in org.mule
DefaultMuleMessage is a wrapper that contains a payload and properties associated with the payload.
DefaultMuleMessage(MuleMessage) - Constructor for class org.mule.DefaultMuleMessage
 
DefaultMuleMessage(Object, MuleContext) - Constructor for class org.mule.DefaultMuleMessage
 
DefaultMuleMessage(Object, Map<String, Object>, MuleContext) - Constructor for class org.mule.DefaultMuleMessage
 
DefaultMuleMessage(Object, Map<String, Object>, Map<String, DataHandler>, MuleContext) - Constructor for class org.mule.DefaultMuleMessage
 
DefaultMuleMessage(Object, Map<String, Object>, Map<String, Object>, Map<String, DataHandler>, MuleContext) - Constructor for class org.mule.DefaultMuleMessage
 
DefaultMuleMessage(Object, Map<String, Object>, Map<String, Object>, Map<String, DataHandler>, MuleContext, DataType) - Constructor for class org.mule.DefaultMuleMessage
 
DefaultMuleMessage(Object, MuleMessage, MuleContext) - Constructor for class org.mule.DefaultMuleMessage
 
DefaultMuleMessage.SerializedDataHandler - Class in org.mule
 
DefaultMuleMessage.SerializedDataHandler(String, DataHandler, MuleContext) - Constructor for class org.mule.DefaultMuleMessage.SerializedDataHandler
 
DefaultMuleMessageFactory - Class in org.mule.transport
 
DefaultMuleMessageFactory() - Constructor for class org.mule.transport.DefaultMuleMessageFactory
 
DefaultMuleMessageFactory(MuleContext) - Constructor for class org.mule.transport.DefaultMuleMessageFactory
DefaultMuleSession - Class in org.mule.session
DefaultMuleSession manages the interaction and distribution of events for Mule Services.
DefaultMuleSession() - Constructor for class org.mule.session.DefaultMuleSession
 
DefaultMuleSession(MuleSession) - Constructor for class org.mule.session.DefaultMuleSession
 
DefaultMuleSession(MuleContext) - Constructor for class org.mule.session.DefaultMuleSession
Deprecated.
DefaultMuleSession(FlowConstruct, MuleContext) - Constructor for class org.mule.session.DefaultMuleSession
Deprecated.
DefaultMuleSession(MuleSession, MuleContext) - Constructor for class org.mule.session.DefaultMuleSession
Deprecated.
DefaultMuleSession(MuleSession, FlowConstruct) - Constructor for class org.mule.session.DefaultMuleSession
Deprecated.
DefaultNameMuleOrphanDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
DefaultNameMuleOrphanDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.DefaultNameMuleOrphanDefinitionParser
 
DefaultNameMuleOrphanDefinitionParser(boolean) - Constructor for class org.mule.config.spring.parsers.specific.DefaultNameMuleOrphanDefinitionParser
 
DefaultNameMuleOrphanDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.DefaultNameMuleOrphanDefinitionParser
 
DefaultNameParser - Class in org.mule.config.spring.jndi
A default implementation of NameParser
DefaultNameParser() - Constructor for class org.mule.config.spring.jndi.DefaultNameParser
 
DefaultNativeLibraryFinderFactory - Class in org.mule.module.launcher.nativelib
Creates different NativeLibraryFinder instances depending on the value of system property "mule.copyApplicationNativeLibraries", which value is true by default.
DefaultNativeLibraryFinderFactory() - Constructor for class org.mule.module.launcher.nativelib.DefaultNativeLibraryFinderFactory
 
DefaultOAuthResponseParser - Class in org.mule.security.oauth.util
 
DefaultOAuthResponseParser() - Constructor for class org.mule.security.oauth.util.DefaultOAuthResponseParser
 
DefaultObjectBuilder<T> - Class in org.mule.module.extension.internal.runtime
Default implementation of ObjectBuilder which creates instances through a provided Class.
DefaultObjectBuilder(Class<T>) - Constructor for class org.mule.module.extension.internal.runtime.DefaultObjectBuilder
Creates a new instance that will build instances of prototypeClass.
DefaultObjectSerializer - Annotation Type in org.mule.api.serialization
A Qualifier annotation for injecting the ObjectSerializer which has been selected as the default in the MuleConfiguration
DefaultObjectSerializerFactoryBean - Class in org.mule.config.spring
An eager SmartFactoryBean which returns the ObjectSerializer which got configured as the MuleContext's default by invoking MuleContext.getObjectSerializer()

Because this class is annotated with the DefaultObjectSerializer qualified, this factory bean will be used to resolve injections requests for such qualifier

DefaultObjectSerializerFactoryBean(MuleContext) - Constructor for class org.mule.config.spring.DefaultObjectSerializerFactoryBean
 
DefaultObjectStoreFactory - Interface in org.mule.util.store
Create the default object stores
DefaultObjectStoreFactoryBean - Class in org.mule.util.store
Manage the creation of the default Mule object stores.
defaultOperation() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
DefaultOperationContext - Class in org.mule.module.extension.internal.runtime
Default implementation of OperationContextAdapter which adds additional information which is relevant to this implementation of the extensions-api, even though it's not part of the API itself
DefaultOperationContext(Extension, Operation, String, ResolverSetResult, MuleEvent, ExtensionManagerAdapter) - Constructor for class org.mule.module.extension.internal.runtime.DefaultOperationContext
Creates a new instance with the given state
DefaultOptionalObjectsController - Class in org.mule.config.spring
Default implementation of OptionalObjectsController
DefaultOptionalObjectsController() - Constructor for class org.mule.config.spring.DefaultOptionalObjectsController
 
DefaultOutboundEndpoint - Class in org.mule.endpoint
 
DefaultOutboundEndpoint(Connector, EndpointURI, String, Map, TransactionConfig, boolean, MessageExchangePattern, int, String, String, String, MuleContext, RetryPolicyTemplate, AbstractRedeliveryPolicy, String, EndpointMessageProcessorChainFactory, List<MessageProcessor>, List<MessageProcessor>, boolean, String) - Constructor for class org.mule.endpoint.DefaultOutboundEndpoint
 
DefaultOutboundRouterCollection - Class in org.mule.routing.outbound
Deprecated.
DefaultOutboundRouterCollection() - Constructor for class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
defaultOutboundTransformers - Variable in class org.mule.transport.AbstractMessageDispatcher
 
DefaultOutputQueryParam - Class in org.mule.module.db.internal.domain.param
 
DefaultOutputQueryParam(int, DbType, String) - Constructor for class org.mule.module.db.internal.domain.param.DefaultOutputQueryParam
 
DefaultParamTypeResolver - Class in org.mule.module.db.internal.resolver.param
Resolves unknown and dynamic types using metadata if possible
DefaultParamTypeResolver(DbTypeManager, ParamTypeResolver) - Constructor for class org.mule.module.db.internal.resolver.param.DefaultParamTypeResolver
 
DefaultPersistentQueueStoreFactoryBean - Class in org.mule.config.spring.factories
 
DefaultPersistentQueueStoreFactoryBean() - Constructor for class org.mule.config.spring.factories.DefaultPersistentQueueStoreFactoryBean
 
DefaultPollingController - Class in org.mule.transport
By default, polling is alwaus enabled.
DefaultPollingController() - Constructor for class org.mule.transport.DefaultPollingController
 
DefaultProcessingTimeWatcher - Class in org.mule.management.stats
 
DefaultProcessingTimeWatcher() - Constructor for class org.mule.management.stats.DefaultProcessingTimeWatcher
 
DefaultProcessorsTrace - Class in org.mule.context.notification
Keeps context information about the message processors that were executed as part of the processing of an event.
DefaultProcessorsTrace() - Constructor for class org.mule.context.notification.DefaultProcessorsTrace
 
DefaultProxyConfig - Class in org.mule.module.http.internal.request
Basic HTTP Proxy configuration based on host and port, and optionally a username and password for proxy authentication.
DefaultProxyConfig() - Constructor for class org.mule.module.http.internal.request.DefaultProxyConfig
 
DefaultQueryLoggerFactory - Class in org.mule.module.db.internal.domain.logger
Creates query loggers with different implementations depending on whether a given Log has the debug level enabled or not
DefaultQueryLoggerFactory() - Constructor for class org.mule.module.db.internal.domain.logger.DefaultQueryLoggerFactory
 
DefaultQueueConfiguration - Class in org.mule.util.queue
 
DefaultQueueConfiguration() - Constructor for class org.mule.util.queue.DefaultQueueConfiguration
 
DefaultQueueConfiguration(int, boolean) - Constructor for class org.mule.util.queue.DefaultQueueConfiguration
 
DefaultQueueInfoDelegate - Class in org.mule.util.queue.objectstore
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
DefaultQueueInfoDelegate(int) - Constructor for class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
Deprecated.
 
DefaultQueueStore - Class in org.mule.util.queue
Internal queue implementation that will execute operations directly to the queue storage.
DefaultQueueStore(String, MuleContext, QueueConfiguration) - Constructor for class org.mule.util.queue.DefaultQueueStore
 
DefaultQueueStoreDelegate - Class in org.mule.util.queue
The default QueueStoreDelegate.
DefaultQueueStoreDelegate(int) - Constructor for class org.mule.util.queue.DefaultQueueStoreDelegate
 
DefaultRefreshTokenManager - Class in org.mule.security.oauth
Implementation of RefreshTokenManager that guarantees that no refresh token is used more than once.
DefaultRefreshTokenManager() - Constructor for class org.mule.security.oauth.DefaultRefreshTokenManager
 
DefaultRegistryBroker - Class in org.mule.registry
Deprecated.
as of 3.7.0. This will be removed in Mule 4.0
DefaultRegistryBroker(MuleContext) - Constructor for class org.mule.registry.DefaultRegistryBroker
Deprecated.
 
DefaultReplyToHandler - Class in org.mule.transport
DefaultReplyToHandler is responsible for processing a message replyTo header.
DefaultReplyToHandler(MuleContext) - Constructor for class org.mule.transport.DefaultReplyToHandler
 
DefaultRequestHandlerManager - Class in org.mule.module.http.internal.listener
 
DefaultRequestHandlerManager(HttpListenerRegistry.PathMap, HttpListenerRegistry.RequestHandlerMatcherPair) - Constructor for class org.mule.module.http.internal.listener.DefaultRequestHandlerManager
 
DefaultResourceReleaser - Class in org.mule.module.launcher.artifact
 
DefaultResourceReleaser() - Constructor for class org.mule.module.launcher.artifact.DefaultResourceReleaser
 
defaultResponseTransformers - Variable in class org.mule.transport.AbstractMessageDispatcher
 
defaultResponseTransformers - Variable in class org.mule.transport.AbstractMessageReceiver
 
DefaultRestoreAccessTokenCallback - Class in org.mule.security.oauth.callback
 
DefaultRestoreAccessTokenCallback() - Constructor for class org.mule.security.oauth.callback.DefaultRestoreAccessTokenCallback
 
DefaultRetryContext - Class in org.mule.retry
The RetryContext is used to store any data which carries over from attempt to attempt such as response messages.
DefaultRetryContext(String, Map<Object, Object>) - Constructor for class org.mule.retry.DefaultRetryContext
 
defaultRoute - Variable in class org.mule.routing.AbstractMatchingRouter
 
DefaultRouterResultsHandler - Class in org.mule.routing
The default results handler for all outbound endpoint.
DefaultRouterResultsHandler() - Constructor for class org.mule.routing.DefaultRouterResultsHandler
 
DefaultRouterResultsHandler(boolean) - Constructor for class org.mule.routing.DefaultRouterResultsHandler
 
DefaultSaveAccessTokenCallback - Class in org.mule.security.oauth.callback
 
DefaultSaveAccessTokenCallback() - Constructor for class org.mule.security.oauth.callback.DefaultSaveAccessTokenCallback
 
DefaultsConfigurationBuilder - Class in org.mule.config.builders
Configures defaults required by Mule.
DefaultsConfigurationBuilder() - Constructor for class org.mule.config.builders.DefaultsConfigurationBuilder
 
DefaultSecurityContext - Class in org.mule.security
Trivial SecurityContext implementation which simply holds the Authentication object.
DefaultSecurityContext(Authentication) - Constructor for class org.mule.security.DefaultSecurityContext
 
DefaultSecurityContextFactory - Class in org.mule.security
 
DefaultSecurityContextFactory() - Constructor for class org.mule.security.DefaultSecurityContextFactory
 
DefaultServiceExceptionStrategy - Class in org.mule.exception
Deprecated.
DefaultServiceExceptionStrategy() - Constructor for class org.mule.exception.DefaultServiceExceptionStrategy
Deprecated.
 
DefaultServiceExceptionStrategy(MuleContext) - Constructor for class org.mule.exception.DefaultServiceExceptionStrategy
Deprecated.
 
DefaultSpringJndiContext - Class in org.mule.config.spring.jndi
A simple spring based JNDI context which is mutable

Borrowed from the XBean (xbean.codehaus.org) project.

DefaultSpringJndiContext() - Constructor for class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
DefaultSpringJndiContext(Hashtable) - Constructor for class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
DefaultSpringJndiContext(Hashtable, Map) - Constructor for class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
DefaultSpringJndiContext(Hashtable, Map, String) - Constructor for class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
DefaultSpringJndiContext(DefaultSpringJndiContext, Hashtable) - Constructor for class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
DefaultSpringJndiContext(DefaultSpringJndiContext, Hashtable, String) - Constructor for class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
DefaultSqlParamResolverFactoryBean - Class in org.mule.module.db.internal.config.domain.param
 
DefaultSqlParamResolverFactoryBean() - Constructor for class org.mule.module.db.internal.config.domain.param.DefaultSqlParamResolverFactoryBean
 
DefaultSqlStatementStrategyFactory - Class in org.mule.transport.jdbc.sqlstrategy
 
DefaultSqlStatementStrategyFactory() - Constructor for class org.mule.transport.jdbc.sqlstrategy.DefaultSqlStatementStrategyFactory
 
DefaultStreamCloserService - Class in org.mule.util
Closes streams of different types by looking up available StreamCloser's from the Mule registry.
DefaultStreamCloserService() - Constructor for class org.mule.util.DefaultStreamCloserService
 
DefaultSystemExceptionStrategy - Class in org.mule.exception
This is the default exception handler for any exception which does not inherit from MessagingException, i.e, when no message is in play.
DefaultSystemExceptionStrategy(MuleContext) - Constructor for class org.mule.exception.DefaultSystemExceptionStrategy
 
DefaultTcpClientSocketProperties - Class in org.mule.transport.tcp
Default mutable implementation of the TcpClientSocketProperties interface.
DefaultTcpClientSocketProperties() - Constructor for class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
DefaultTcpServerSocketProperties - Class in org.mule.transport.tcp
Default mutable implementation of the TcpServerSocketProperties interface.
DefaultTcpServerSocketProperties() - Constructor for class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
DefaultThreadingProfileConfig - Class in org.mule.api.config
 
DefaultThreadingProfileDefinitionParser - Class in org.mule.config.spring.parsers.specific
This parser is responsible for processing the configuration elements.
DefaultThreadingProfileDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.specific.DefaultThreadingProfileDefinitionParser
 
DefaultThreadPoolFactory - Class in org.mule.config.pool
 
DefaultThreadPoolFactory() - Constructor for class org.mule.config.pool.DefaultThreadPoolFactory
 
defaultTimeout - Variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
defaultTimeout - Variable in class org.mule.util.xa.AbstractResourceManager
 
defaultTokenManagerConfigIndex - Static variable in class org.mule.module.oauth2.internal.tokenmanager.TokenManagerConfig
 
DefaultTransportServiceDescriptor - Class in org.mule.transport.service
 
DefaultTransportServiceDescriptor(String, Properties, ClassLoader) - Constructor for class org.mule.transport.service.DefaultTransportServiceDescriptor
 
DefaultWorkListener - Class in org.mule.work
Default exception Handler used when executing work in the work manager
DefaultWorkListener() - Constructor for class org.mule.work.DefaultWorkListener
 
DefaultXAConnectionFactoryWrapper - Class in org.mule.transport.jms.xa
 
DefaultXAConnectionFactoryWrapper(Object) - Constructor for class org.mule.transport.jms.xa.DefaultXAConnectionFactoryWrapper
 
DefaultXAConnectionFactoryWrapper(Object, Boolean) - Constructor for class org.mule.transport.jms.xa.DefaultXAConnectionFactoryWrapper
 
DefaultXASession - 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
DefaultXASession(AbstractXAResourceManager) - Constructor for class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
DefaultXASession<T extends AbstractXaTransactionContext> - Class in org.mule.util.xa
Base class for an XAResource implementation.
DefaultXASession(AbstractXAResourceManager) - Constructor for class org.mule.util.xa.DefaultXASession
 
DefaultXmlMetadataAnnotations - Class in org.mule.config.spring.parsers
Stores the metadata annotations from the XML parser so they are available when building the actual objects of the application.
DefaultXmlMetadataAnnotations() - Constructor for class org.mule.config.spring.parsers.DefaultXmlMetadataAnnotations
 
DefaultXMLSecureFactories - Class in org.mule.util.xmlsecurity
Create different XML factories configured through the same interface for disabling vulnerabilities.
DeferredForwardOutputStream - Class in org.mule.module.jersey
An OutputStream that forwards its write invokations to another stream.
DeferredForwardOutputStream() - Constructor for class org.mule.module.jersey.DeferredForwardOutputStream
 
DEFLATE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
delay(long) - Method in class org.mule.routing.EventProcessingThread
 
DelayedResult - Interface in org.mule.module.xml.transformer
A result type which delays writing until something further down stream can setup the underlying output result.
delayTime - Variable in class org.mule.routing.EventProcessingThread
 
delegate - Variable in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
delegate - Variable in class org.mule.el.mvel.DelegateVariableResolverFactory
 
delegate - Variable in class org.mule.module.db.internal.domain.connection.AbstractDbConnection
 
delegate - Variable in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
delegate - Variable in class org.mule.processor.AsyncDelegateMessageProcessor
 
delegate - Variable in class org.mule.transport.xmpp.filters.AbstractXmppFilter
 
delegateHandler - Variable in class org.mule.transport.jms.redelivery.AutoDiscoveryRedeliveryHandlerFactory
 
DelegateQueueManager - Class in org.mule.util.queue
Delegates every call to the real QueueManager.
DelegateQueueManager() - Constructor for class org.mule.util.queue.DelegateQueueManager
 
DelegateTransaction - Class in org.mule.processor
Transaction placeholder to replace with proper transaction once transactional resource is discovered by mule
DelegateTransaction(MuleContext) - Constructor for class org.mule.processor.DelegateTransaction
 
DelegateTransactionFactory - Class in org.mule.processor
Transaction factory for DelegateTransaction.
DelegateTransactionFactory() - Constructor for class org.mule.processor.DelegateTransactionFactory
 
DelegateVariableResolverFactory - Class in org.mule.el.mvel
 
DelegateVariableResolverFactory(VariableResolverFactory) - Constructor for class org.mule.el.mvel.DelegateVariableResolverFactory
 
DelegateVariableResolverFactory(VariableResolverFactory, VariableResolverFactory) - Constructor for class org.mule.el.mvel.DelegateVariableResolverFactory
Convenience constructor to allow for more concise creation of VariableResolverFactory chains without and performance overhead incurred by using a builder.
DelegateXMLStreamReader - Class in org.mule.module.xml.stax
 
DelegateXMLStreamReader(XMLStreamReader) - Constructor for class org.mule.module.xml.stax.DelegateXMLStreamReader
 
DelegatingInputStream - Class in org.mule.model.streaming
 
DelegatingInputStream(InputStream) - Constructor for class org.mule.model.streaming.DelegatingInputStream
 
DelegatingOutputStream - Class in org.mule.module.cxf.support
 
DelegatingOutputStream(OutputStream) - Constructor for class org.mule.module.cxf.support.DelegatingOutputStream
 
delete() - Method in class org.mule.module.http.internal.multipart.HttpPart
 
DELETE - Static variable in class org.mule.transport.http.components.RestServiceWrapper
 
delete() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
delete() - Method in interface org.mule.transport.http.multipart.Part
Deletes the underlying storage for a file item, including deleting any associated temporary disk file.
delete() - Method in class org.mule.util.queue.QueueControlDataFile
Deletes the underlying file.
delete() - Method in class org.mule.util.queue.QueueFileProvider
 
deleteAnchors() - Method in class org.mule.test.infrastructure.process.Controller
 
deleteDir(String) - Method in class org.mule.tck.util.ftp.FtpClient
Delete a directory
deleteDirectory(String) - Method in class org.mule.transport.sftp.SftpClient
 
DeleteException - Exception in org.mule.util.file
 
DeleteException() - Constructor for exception org.mule.util.file.DeleteException
 
DeleteException(File) - Constructor for exception org.mule.util.file.DeleteException
 
deleteFile(String) - Method in class org.mule.tck.util.ftp.FtpClient
Delete a single file.
deleteFile(String) - Method in class org.mule.transport.sftp.SftpClient
 
DeleteOnCloseFileInputStream - Class in org.mule.model.streaming
FileInputStream which deletes the underlying file when the stream is closed.
DeleteOnCloseFileInputStream(File) - Constructor for class org.mule.model.streaming.DeleteOnCloseFileInputStream
DeleteProcessorBeanDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
DeleteProcessorBeanDefinitionParser() - Constructor for class org.mule.module.db.internal.config.processor.DeleteProcessorBeanDefinitionParser
 
deleteProperties(MuleMessage) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
deleteStoreFile(File) - Method in class org.mule.util.store.PersistentObjectStorePartition
 
deleteStoreFile(File) - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
deleteTree(File) - Static method in class org.mule.util.FileUtils
Delete a file tree recursively.
deleteTree(File, String[]) - Static method in class org.mule.util.FileUtils
Delete a file tree recursively.
deleteUnacceptedMessages - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
DELIM - Static variable in class org.mule.config.converters.PropertiesConverter
 
DELIM - Static variable in class org.mule.config.converters.TransformerConverter
 
DELIM - Static variable in class org.mule.expression.ExpressionConstants
 
delist() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
delist() - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
 
delist() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
delist() - Method in class org.mule.transport.jms.xa.SessionInvocationHandler
 
DELIST_METHOD_NAME - Static variable in interface org.mule.transaction.XaTransaction.MuleXaObject
 
delistResource(XAResource, int) - Method in class org.mule.transaction.XaTransaction
 
delistResources() - Method in class org.mule.transaction.XaTransaction
 
deliver(Client, String, Object) - Method in class org.mule.transport.ajax.AjaxMessageDispatcher
 
DELTA - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter representing the variation of a counter
Delta - Class in org.mule.util.counters.impl
 
Delta(String, AbstractCounter) - Constructor for class org.mule.util.counters.impl.Delta
 
deploy(T) - Method in interface org.mule.module.launcher.ArtifactDeployer
Deploys an artifact.
deploy(Artifact) - Method in class org.mule.module.launcher.DefaultArtifactDeployer
 
deploy(URL) - Method in interface org.mule.module.launcher.DeploymentService
Deploys and application bundled as a zip from the given URL to the mule container
deploy(URL, Properties) - Method in interface org.mule.module.launcher.DeploymentService
Deploys an applications bundled as a zip from a given URL and sets the provided appProperties.
deploy(URL) - Method in class org.mule.module.launcher.MuleDeploymentService
 
deploy(URL, Properties) - Method in class org.mule.module.launcher.MuleDeploymentService
 
deploy(String) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
deploy(String, String) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
Deploys an application from a classpath resource
deploy(URL, String) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
Deploys an application from an URL
deploy(String) - Method in class org.mule.test.infrastructure.process.Controller
 
deploy(String) - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
DeployableMuleXmlContextListener - Class in org.mule.config.builders
This ServletContextListener should be used instead of MuleXmlBuilderContextListener when the webapp is contributing a configuration to an existing Mule instance configured and started at the server level rather than embedding a Mule instance in the webapp itself.
DeployableMuleXmlContextListener() - Constructor for class org.mule.config.builders.DeployableMuleXmlContextListener
 
deployAppFromClasspathFolder(String, String) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
Deploys an Application from a classpath folder
deployArtifact(T) - Method in interface org.mule.module.launcher.ArchiveDeployer
 
deployArtifact(T, Optional<Properties>) - Method in interface org.mule.module.launcher.ArchiveDeployer
 
deployArtifact(T) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
deployArtifact(T, Optional<Properties>) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
deployArtifact(Domain) - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
deployArtifact(Domain, Optional<Properties>) - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
deployDomain(URL) - Method in interface org.mule.module.launcher.DeploymentService
Deploys a domain bundled as a zip from the given URL to the mule container
deployDomain(URL, Properties) - Method in interface org.mule.module.launcher.DeploymentService
Deploys a domain bundled as a zip from the given URL to the mule container
deployDomain(URL) - Method in class org.mule.module.launcher.MuleDeploymentService
 
deployDomain(URL, Properties) - Method in class org.mule.module.launcher.MuleDeploymentService
 
deployDomain(String) - Method in class org.mule.test.infrastructure.process.Controller
 
deployDomain(String) - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
deployDomainFromClasspathFolder(String, String) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
Deploys a Domain from a classpath folder
deployExplodedApps(String[]) - Method in class org.mule.module.launcher.DeploymentDirectoryWatcher
 
deployExplodedApps(String[]) - Method in class org.mule.module.launcher.ParallelDeploymentDirectoryWatcher
 
deployExplodedArtifact(String) - Method in interface org.mule.module.launcher.ArchiveDeployer
 
deployExplodedArtifact(String) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
deployExplodedArtifact(String) - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
deployLogger - Variable in class org.mule.module.launcher.application.DefaultMuleApplication
 
deployLogger - Variable in class org.mule.module.launcher.domain.DefaultMuleDomain
 
Deployment - Class in org.mule.test.infrastructure.process.matchers
 
Deployment(String) - Constructor for class org.mule.test.infrastructure.process.matchers.Deployment
 
DEPLOYMENT_TIMEOUT - Static variable in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
deploymentClassLoader - Variable in class org.mule.module.launcher.application.DefaultMuleApplication
 
DeploymentDirectoryWatcher - Class in org.mule.module.launcher
It's in charge of the whole deployment process.
DeploymentDirectoryWatcher(ArchiveDeployer<Domain>, ArchiveDeployer<Application>, ObservableList<Domain>, ObservableList<Application>, ReentrantLock) - Constructor for class org.mule.module.launcher.DeploymentDirectoryWatcher
 
DeploymentException - Exception in org.mule.module.launcher
 
DeploymentException(Message) - Constructor for exception org.mule.module.launcher.DeploymentException
 
DeploymentException(Message, Throwable) - Constructor for exception org.mule.module.launcher.DeploymentException
 
DeploymentInitException - Exception in org.mule.module.launcher
 
DeploymentInitException(Message) - Constructor for exception org.mule.module.launcher.DeploymentInitException
 
DeploymentInitException(Message, Throwable) - Constructor for exception org.mule.module.launcher.DeploymentInitException
 
deploymentListener - Variable in class org.mule.module.launcher.application.DefaultApplicationFactory
 
deploymentListener - Variable in class org.mule.module.launcher.application.DefaultMuleApplication
 
DeploymentListener - Interface in org.mule.module.launcher
Defines a listener for deployment events for Mule applications.
deploymentListener - Variable in class org.mule.module.launcher.domain.DefaultDomainFactory
 
DeploymentListenerManager - Interface in org.mule.module.launcher
Manages which DeploymentListener are listening for deployment notifications.
DeploymentPropertiesUtils - Class in org.mule.module.launcher
Common logic to create and persist a file containing deployment properties for each app/domain deployed/redeployed.
DeploymentPropertiesUtils() - Constructor for class org.mule.module.launcher.DeploymentPropertiesUtils
 
DeploymentService - Interface in org.mule.module.launcher
Manages deploy of mule applications
deploymentService - Variable in class org.mule.module.launcher.MuleContainer
 
DeploymentServiceAware - Interface in org.mule.module.launcher
Enables DeploymentService injection.
DeploymentStartException - Exception in org.mule.module.launcher
 
DeploymentStartException(Message) - Constructor for exception org.mule.module.launcher.DeploymentStartException
 
DeploymentStartException(Message, Throwable) - Constructor for exception org.mule.module.launcher.DeploymentStartException
 
deploymentStates - Variable in class org.mule.module.launcher.ArtifactDeploymentStatusTracker
 
DeploymentStatusTracker - Class in org.mule.module.launcher
Keeps track of the deployment status of all artifact in the Mule instance.
DeploymentStatusTracker() - Constructor for class org.mule.module.launcher.DeploymentStatusTracker
 
DeploymentStopException - Exception in org.mule.module.launcher
 
DeploymentStopException(Message) - Constructor for exception org.mule.module.launcher.DeploymentStopException
 
DeploymentStopException(Message, Throwable) - Constructor for exception org.mule.module.launcher.DeploymentStopException
 
DeploymentTestUtils - Class in org.mule.test.infrastructure.deployment
 
DeploymentTestUtils() - Constructor for class org.mule.test.infrastructure.deployment.DeploymentTestUtils
 
deployPackagedArtifact(String, Optional<Properties>) - Method in interface org.mule.module.launcher.ArchiveDeployer
 
deployPackagedArtifact(String) - Method in interface org.mule.module.launcher.ArchiveDeployer
 
deployPackagedArtifact(URL, Optional<Properties>) - Method in interface org.mule.module.launcher.ArchiveDeployer
 
deployPackagedArtifact(String, Optional<Properties>) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
deployPackagedArtifact(URL, Optional<Properties>) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
deployPackagedArtifact(String) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
deployPackagedArtifact(String, Optional<Properties>) - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
deployPackagedArtifact(URL, Optional<Properties>) - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
deployPackagedArtifact(String) - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
deployPackedApps(String[]) - Method in class org.mule.module.launcher.DeploymentDirectoryWatcher
 
deployPackedApps(String[]) - Method in class org.mule.module.launcher.ParallelDeploymentDirectoryWatcher
 
deployProcess(String) - Method in interface org.mule.module.bpm.BPMS
Deploy (not start) a process to the BPMS based on a process definition file.
deployProcess(String) - Method in class org.mule.module.jbpm.Jbpm
 
deployProcessFromStream(String, InputStream) - Method in class org.mule.module.jbpm.Jbpm
 
DeprecatedBeanDefinitionParser - Class in org.mule.config.spring.parsers
Use this decorator to mark a BeanDefinitionParser as deprecated.
DeprecatedBeanDefinitionParser(BeanDefinitionParser, String) - Constructor for class org.mule.config.spring.parsers.DeprecatedBeanDefinitionParser
 
dequeue() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
DERBY_PROPERTIES_FILE - Static variable in class org.mule.tck.util.MuleDerbyTestDatabase
 
DerbyConfigResolverFactoryBean - Class in org.mule.module.db.internal.config.domain.database
Creates DbConfigResolver for Derby databases
DerbyConfigResolverFactoryBean() - Constructor for class org.mule.module.db.internal.config.domain.database.DerbyConfigResolverFactoryBean
 
DerbyDataSourceFactoryBean - Class in org.mule.transport.jdbc.config
 
DerbyDataSourceFactoryBean() - Constructor for class org.mule.transport.jdbc.config.DerbyDataSourceFactoryBean
 
desc - Variable in class org.mule.module.launcher.application.ApplicationMuleContextBuilder
 
DescendentDefinitionParser - Class in org.mule.config.spring.parsers.generic
An extension to ChildDefinitionParser which recurses up the DOM tree until it finds a named parent.
DescendentDefinitionParser(String, Class) - Constructor for class org.mule.config.spring.parsers.generic.DescendentDefinitionParser
 
describe() - Method in class org.mule.module.extension.DescriberSupport
 
describe() - Method in class org.mule.module.extension.internal.introspection.AnnotationsBasedDescriber
describe(Object) - Static method in class org.mule.util.BeanUtils
The Apache BeanUtils version of this converts all values to String, which is pretty useless, it also includes stuff not defined by the user
describeBean(Object) - Static method in class org.mule.util.BeanUtils
Similar to BeanUtils.describe(Object) except that it will only populate bean properties where there is a valid getter and setter method.
describeFailure() - Method in class org.mule.test.infrastructure.process.AppDeploymentProbe
 
describeFailure() - Method in class org.mule.test.infrastructure.process.MuleStatusProbe
 
DescriberSupport - Class in org.mule.module.extension
Utility class for easily building a Describer that is discoverable through SPI for an extension defined through annotations without coupling to mule's mechanism to actually parse those annotations.
DescriberSupport(Class<?>) - Constructor for class org.mule.module.extension.DescriberSupport
 
describeTo(Description) - Method in class org.mule.test.infrastructure.FileContainsInLine
 
describeTo(Description) - Method in class org.mule.test.infrastructure.HasRegex
 
describeTo(Description) - Method in class org.mule.test.infrastructure.process.matchers.Deployment
 
describeTo(Description) - Method in class org.mule.test.infrastructure.process.matchers.Running
 
describeTo(Description) - Method in class org.mule.test.infrastructure.process.VerifyLogWithMatcher
 
descriptor - Variable in class org.mule.module.launcher.application.DefaultMuleApplication
 
descriptorAlreadyExists(String) - Static method in class org.mule.config.i18n.CoreMessages
 
DescriptorParser - Interface in org.mule.module.launcher.descriptor
 
DeserializationPostInitialisable - Interface in org.mule.util.store
A marker interface used to trigger post-deserialization initialization of an object.
DeserializationPostInitialisable.Implementation - Class in org.mule.util.store
 
DeserializationPostInitialisable.Implementation() - Constructor for class org.mule.util.store.DeserializationPostInitialisable.Implementation
 
deserialize(byte[]) - Method in interface org.mule.api.serialization.ObjectSerializer
Deserializes the given bytes.
deserialize(byte[], ClassLoader) - Method in interface org.mule.api.serialization.ObjectSerializer
Deserializes the given bytes.
deserialize(InputStream) - Method in interface org.mule.api.serialization.ObjectSerializer
Deserializes the given stream of bytes.
deserialize(InputStream, ClassLoader) - Method in interface org.mule.api.serialization.ObjectSerializer
Deserializes the given stream of bytes.
deserialize(byte[]) - Method in class org.mule.serialization.internal.AbstractObjectSerializer
Deserializes the given bytes.
deserialize(byte[], ClassLoader) - Method in class org.mule.serialization.internal.AbstractObjectSerializer
Deserializes the given bytes.
deserialize(InputStream) - Method in class org.mule.serialization.internal.AbstractObjectSerializer
Deserializes the given stream of bytes.
deserialize(InputStream, ClassLoader) - Method in class org.mule.serialization.internal.AbstractObjectSerializer
Deserializes the given stream of bytes.
deserialize(MuleMessage, byte[]) - Method in class org.mule.session.AbstractSessionHandler
 
deserialize(DataInputStream) - Method in interface org.mule.util.journal.JournalEntrySerializer
 
deserialize(InputStream, MuleContext) - Static method in class org.mule.util.SerializationUtils
 
deserialize(byte[], MuleContext) - Static method in class org.mule.util.SerializationUtils
 
deserialize(InputStream, ClassLoader, MuleContext) - Static method in class org.mule.util.SerializationUtils
Deserializes an Object from the specified stream.
deserialize(InputStream, ClassLoader) - Static method in class org.mule.util.SerializationUtils
Deprecated.
Call deserialize(InputStream inputStream, MuleContext muleContext) instead
deserialize(byte[], ClassLoader) - Static method in class org.mule.util.SerializationUtils
Deprecated.
Call deserialize(byte[] objectData, MuleContext muleContext) instead
deserialize(File) - Method in class org.mule.util.store.PersistentObjectStorePartition
 
deserialize(File) - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
deserializeTxId(DataInputStream) - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
deserializeTxId(DataInputStream) - Method in class org.mule.util.journal.queue.LocalQueueTxJournalEntry
 
deserializeTxId(DataInputStream) - Method in class org.mule.util.journal.queue.XaQueueTxJournalEntry
 
desinstallArtifact(String) - Method in class org.mule.module.launcher.ArtifactArchiveInstaller
Desintalls an artifact from the mule container installation.
destroy(OutboundEndpoint, MessageDispatcher) - Method in interface org.mule.api.transport.MessageDispatcherFactory
destroy(InboundEndpoint, MessageRequester) - Method in interface org.mule.api.transport.MessageRequesterFactory
destroy() - Method in class org.mule.config.builders.MuleXmlBuilderContextListener
 
destroy() - Method in class org.mule.config.builders.MuleXmlBuilderContextServlet
 
destroy(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.AbstractMessageDispatcherFactory
 
destroy(InboundEndpoint, MessageRequester) - Method in class org.mule.transport.AbstractMessageRequesterFactory
 
destroy() - Method in class org.mule.transport.jdbc.config.DerbyDataSourceFactoryBean
 
destroy(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
destroy(InboundEndpoint, MessageRequester) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
destroy() - Method in class org.mule.transport.servlet.jetty.util.EmbeddedJettyServer
 
destroyAccessToken(String, OAuth2Adapter) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Destroy an access token
destroyAccessToken(String, C) - Method in interface org.mule.security.oauth.OAuth2Manager
Destroy an access token
destroyClient(ImmutableEndpoint, SftpClient) - Method in class org.mule.transport.sftp.SftpConnector
 
destroyFtp(ImmutableEndpoint, FTPClient) - Method in class org.mule.transport.ftp.FtpConnector
 
destroyInstance(CustomCachingConnectionFactory) - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
destroyObject(Object) - Method in class org.mule.module.xml.transformer.XQueryTransformer.PooledXQueryTransformerFactory
 
destroyObject(String, OAuth2Adapter) - Method in class org.mule.security.oauth.BaseOAuthClientFactory
If obj implements Stoppable or Disposable, the object is destroyed by invoking the corresponding methods
destroyObject(Object) - Method in class org.mule.transport.ftp.FtpConnectionFactory
 
destroyObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
destroyObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
destroyObject(Object, Object) - Method in class org.mule.transport.multicast.MulticastSocketFactory
 
destroyObject(Object) - Method in class org.mule.transport.sftp.SftpConnectionFactory
 
destroyObject(Object, Object) - Method in class org.mule.transport.tcp.AbstractTcpSocketFactory
 
destroyObject(Object, Object) - Method in class org.mule.transport.udp.UdpSocketFactory
 
destroyQuietly() - Method in class org.mule.test.infrastructure.process.TestProcess
 
destroyReceiver(MessageReceiver, ImmutableEndpoint) - Method in class org.mule.transport.AbstractConnector
 
destroySingleton(String) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
destroySingletons() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
destroySubcontext(Name) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
destroySubcontext(String) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
destroySubcontext(Name) - Method in class org.mule.jndi.SimpleContext
 
destroySubcontext(String) - Method in class org.mule.jndi.SimpleContext
 
destroySubcontext(Name) - Method in class org.mule.tck.jndi.InMemoryContext
 
destroySubcontext(String) - Method in class org.mule.tck.jndi.InMemoryContext
 
detectHttpMethod(MuleMessage) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
determineAutowireCandidate(Map<String, Object>, DependencyDescriptor) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Determine the autowire candidate in the given set of beans.
determineConfigBuilderClassNameForApplication(Application) - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
determineHighestPriorityCandidate(Map<String, Object>, Class<?>) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Determine the candidate with the highest priority in the given set of beans.
determineMimeType(String) - Method in class org.mule.transport.servlet.JarResourceServlet
 
determinePrimaryCandidate(Map<String, Object>, Class<?>) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Determine the primary candidate in the given set of beans.
DevkitBasedMessageProcessor - Class in org.mule.devkit.processor
 
DevkitBasedMessageProcessor(String) - Constructor for class org.mule.devkit.processor.DevkitBasedMessageProcessor
 
DIAGNOSABILITY_BEAN_NAME - Static variable in class org.mule.module.launcher.artifact.DefaultResourceReleaser
 
DIR_LIST_WILDCARD - Static variable in class org.mule.transport.sftp.SftpClient
 
directory - Variable in class org.mule.util.store.TextFileObjectStore
 
DirectoryResourceLocator - Class in org.mule.module.launcher
 
DirectoryResourceLocator(String...) - Constructor for class org.mule.module.launcher.DirectoryResourceLocator
 
DirectProtocol - Class in org.mule.transport.tcp.protocols
The DirectProtocol class is an application level tcp protocol that does nothing.
DirectProtocol() - Constructor for class org.mule.transport.tcp.protocols.DirectProtocol
 
DirectProtocol(boolean, int) - Constructor for class org.mule.transport.tcp.protocols.DirectProtocol
 
dirExists(String) - Method in class org.mule.tck.util.ftp.FtpClient
Check if a directory exists by trying to go to it
dirty - Variable in class org.mule.module.launcher.DeploymentDirectoryWatcher
 
dirty - Variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
dirty - Variable in class org.mule.util.xa.AbstractResourceManager
 
DISABLE_MEL_EXPRESSION_CACHE - Static variable in class org.mule.el.mvel.MVELExpressionExecutor
 
DISABLE_STALE_CONNECTION_CHECK_SYSTEM_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
 
DISABLE_SYSTEM_PROPERTIES_MAPPING_PROPERTY - Static variable in class org.mule.api.security.tls.TlsConfiguration
 
DISABLE_TEMP_DESTINATIONS_PROPERTY - Static variable in class org.mule.transport.jms.JmsConstants
 
disableAttribute(MuleDefinitionParser, String) - Static method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
disableAttributes(MuleDefinitionParser, String[][]) - Static method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
disableAttributes(MuleDefinitionParser, String[]) - Static method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
DISABLED_EVENT - Static variable in class org.mule.config.spring.parsers.specific.NotificationDisableDefinitionParser
 
DISABLED_INTERFACE - Static variable in class org.mule.config.spring.parsers.specific.NotificationDisableDefinitionParser
 
disableDebug() - Method in interface org.mule.api.debug.Debuggeable
Disables the debugging mode.
disableFollowsRedirect() - Method in class org.mule.module.http.api.client.HttpRequestOptionsBuilder
Configures the requester to not follow redirects
disableFollowsRedirect() - Method in interface org.mule.module.http.api.requester.HttpRequestOperationConfig
Configures the requester to not follow redirects
disableFollowsRedirect() - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
disableInterface(Class<? extends ServerNotificationListener>) - Method in class org.mule.context.notification.ServerNotificationManager
 
disableKeepAlive(boolean) - Method in class org.mule.transport.http.HttpResponse
 
disableNativeScheduling() - Method in class org.mule.transport.AbstractPollingMessageReceiver
 
disableParseResponse() - Method in class org.mule.module.http.api.client.HttpRequestOptionsBuilder
 
disableParseResponse() - Method in interface org.mule.module.http.api.requester.HttpRequestOperationConfig
Disables the http response parsing
disableParseResponse() - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
disableStatusCodeValidation() - Method in class org.mule.module.http.api.client.HttpRequestOptionsBuilder
Disables the status code validation for the response
disableStatusCodeValidation() - Method in interface org.mule.module.http.api.requester.HttpRequestOperationConfig
Disables the status code validation for the response
disableStatusCodeValidation() - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
disableTransportTransformer - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
disableType(Class<? extends ServerNotification>) - Method in class org.mule.context.notification.ServerNotificationManager
 
DISC_ON_CLUSTER_FAILURE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
DiscardedOptionalBeanPostProcessor - Class in org.mule.config.spring.processors
A InstantiationAwareBeanPostProcessor which suspends initialization and population of discarded objects and removes them from the registry
DiscardedOptionalBeanPostProcessor(OptionalObjectsController, DefaultListableBeanFactory) - Constructor for class org.mule.config.spring.processors.DiscardedOptionalBeanPostProcessor
 
discardEmptyContent - Variable in class org.mule.transport.http.PollingHttpMessageReceiver
 
discardInvalidMessage() - Method in interface org.mule.execution.ValidationPhaseTemplate
Discards the message because the validation failed
discardInvalidMessage() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
discardInvalidMessage() - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
discardMessageOnThrottlingExceeded() - Method in interface org.mule.execution.ThrottlingPhaseTemplate
Discards the message due to ThrottlingPolicy configured for the MessageSource is exceeded
discardMessageOnThrottlingExceeded() - Method in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
discardMessageOnThrottlingExceeded() - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
discardMessageOnThrottlingExceeded() - Method in class org.mule.transport.servlet.jetty.JettyContinuationsMessageProcessTemplate
 
discardMessageOnThrottlingExceeded() - Method in class org.mule.transport.servlet.jetty.JettyMessageProcessTemplate
 
discardOptionalObject(String) - Method in class org.mule.config.spring.CompositeOptionalObjectsController
 
discardOptionalObject(String) - Method in class org.mule.config.spring.DefaultOptionalObjectsController
 
discardOptionalObject(String) - Method in interface org.mule.config.spring.OptionalObjectsController
Registers the given key as a discarded object
disconnect() - Method in interface org.mule.api.transport.Connectable
Disconnect the from the underlying transport
disconnect() - Method in class org.mule.module.management.mbean.EndpointService
 
disconnect() - Method in interface org.mule.module.management.mbean.EndpointServiceMBean
 
disconnect() - Method in class org.mule.tck.util.ftp.FtpClient
Disconnect the ftp client
disconnect() - Method in class org.mule.transport.AbstractConnector
 
disconnect() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
disconnect(EndpointURI) - Method in class org.mule.transport.http.HttpConnector
 
disconnect() - Method in class org.mule.transport.sftp.SftpClient
 
disconnect() - Method in class org.mule.transport.sftp.SftpConnector
 
disconnect() - Method in class org.mule.transport.xmpp.AbstractXmppConversation
 
disconnect() - Method in interface org.mule.transport.xmpp.XmppConversation
Disconnect from the Jabber conversation, e.g.
discover() - Method in class org.mule.config.bootstrap.ClassPathRegistryBootstrapDiscoverer
Collects the Properties to be used in an ordered way.
discover() - Method in interface org.mule.config.bootstrap.RegistryBootstrapDiscoverer
Collects the Properties to be used in an ordered way.
discover(ClassLoader) - Method in interface org.mule.module.extension.internal.introspection.ExtensionDiscoverer
Performs a search for extensions according to the algorithm described in ExtensionManager.discoverExtensions(ClassLoader)
discover() - Method in class org.mule.module.launcher.coreextension.ClasspathMuleCoreExtensionDiscoverer
 
discover() - Method in interface org.mule.module.launcher.coreextension.MuleCoreExtensionDiscoverer
 
DiscoverableTransformer - Interface in org.mule.api.transformer
A interface to denote that a transformer is discoverable.
discoverer - Variable in class org.mule.config.bootstrap.AbstractRegistryBootstrap
 
discoverExtensions(ClassLoader) - Method in class org.mule.module.extension.internal.manager.DefaultExtensionManager
dispatch(String, Object, Map<String, Object>) - Method in interface org.mule.api.client.MuleClient
Deprecated.
use MuleClient.dispatch(String, org.mule.api.MuleMessage) instead Dispatches an event asynchronously to a endpointUri via a Mule server. The URL determines where to dispatch the event to.
dispatch(String, MuleMessage) - Method in interface org.mule.api.client.MuleClient
Dispatches an event asynchronously to a endpointUri via a Mule server.
dispatch(String, MuleMessage, OperationOptions) - Method in interface org.mule.api.client.MuleClient
Dispatches an event asynchronously to a endpointUri via a Mule server.
dispatch(MuleEvent) - Method in interface org.mule.api.transport.MessageDispatching
Dispatches an event from the endpoint to the external system
dispatch(String, Object, Map<String, Object>) - Method in class org.mule.client.DefaultLocalMuleClient
 
dispatch(String, MuleMessage) - Method in class org.mule.client.DefaultLocalMuleClient
 
dispatch(String, MuleMessage, OperationOptions) - Method in class org.mule.client.DefaultLocalMuleClient
 
dispatch(String, Object, Map<String, Object>) - Method in class org.mule.module.client.MuleClient
Dispatches an event asynchronously to a endpointUri via a Mule server.
dispatch(String, MuleMessage) - Method in class org.mule.module.client.MuleClient
Dispatches an event asynchronously to a endpointUri via a Mule server.
dispatch(String, Object, JobDataMap) - Method in class org.mule.transport.quartz.jobs.ScheduledDispatchJob
 
dispatch(Message) - Method in class org.mule.transport.xmpp.XmppChatConversation
 
dispatch(Message) - Method in interface org.mule.transport.xmpp.XmppConversation
Asynchronously dispatch message via the Jabber conversation.
dispatch(Message) - Method in class org.mule.transport.xmpp.XmppMessageConversation
 
dispatch(Message) - Method in class org.mule.transport.xmpp.XmppMultiUserChatConversation
 
dispatchAction(RemoteDispatcherNotification, boolean, int) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
dispatchDirect(String, Object, Map<String, Object>) - Method in class org.mule.module.client.MuleClient
Deprecated.
dispatchDirect(String, MuleMessage) - Method in class org.mule.module.client.MuleClient
Deprecated.
dispatcher(MuleContext, String) - Static method in class org.mule.util.concurrent.ThreadNameHelper
 
dispatcherFactory - Variable in class org.mule.transport.AbstractConnector
Factory used to create dispatchers for this connector
dispatcherPoolFactory - Variable in class org.mule.transport.AbstractConnector
A factory for creating the pool of dispatchers for this connector.
dispatchers - Variable in class org.mule.transport.AbstractConnector
A pool of dispatchers for this connector, keyed by endpoint
dispatcherSocketsPool - Variable in class org.mule.transport.udp.UdpConnector
 
DispatcherWorkManagerSource - Class in org.mule.transport
WorkManagerSource for connector dispatcher work manager
DispatcherWorkManagerSource(AbstractConnector) - Constructor for class org.mule.transport.DispatcherWorkManagerSource
 
dispatchEvent(MuleMessage) - Method in interface org.mule.api.MuleEventContext
Deprecated.
dispatchEvent(Object) - Method in interface org.mule.api.MuleEventContext
Deprecated.
dispatchEvent(MuleMessage, EndpointURI) - Method in interface org.mule.api.MuleEventContext
Deprecated.
dispatchEvent(MuleMessage, String) - Method in interface org.mule.api.MuleEventContext
Deprecated. 
dispatchEvent(MuleMessage, OutboundEndpoint) - Method in interface org.mule.api.MuleEventContext
Deprecated. 
dispatchEvent(MuleEvent) - Method in interface org.mule.api.service.Service
Deprecated. 
dispatchEvent(Object) - Method in class org.mule.DefaultMuleEventContext
This will dispatch an event asynchronously via the configured outbound endpoint on the service for this session
dispatchEvent(MuleMessage) - Method in class org.mule.DefaultMuleEventContext
This will dispatch an event asynchronously via the configured outbound endpoint on the service for this session
dispatchEvent(MuleMessage, EndpointURI) - Method in class org.mule.DefaultMuleEventContext
Depending on the session state this methods either Passes an event asynchronously to the next available Mule component in the pool or via the endpointUri configured for the event
dispatchEvent(MuleMessage, String) - Method in class org.mule.DefaultMuleEventContext
Depending on the session state this methods either Passes an event asynchronously to the next available Mule component in the pool or via the endpoint configured for the event
dispatchEvent(MuleMessage, OutboundEndpoint) - Method in class org.mule.DefaultMuleEventContext
Depending on the session state this methods either Passes an event asynchronously to the next available Mule component in the pool or via the endpoint configured for the event
dispatchEvent(MuleApplicationEvent) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
Will dispatch an application event through Mule
dispatchEvent(MuleEvent) - Method in class org.mule.service.AbstractService
Deprecated.
DispatchException - Exception in org.mule.api.transport
DispatchException is thrown when an endpoint dispatcher fails to send, dispatch or receive a message.
DispatchException(MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.transport.DispatchException
 
DispatchException(MuleEvent, MessageProcessor, Throwable) - Constructor for exception org.mule.api.transport.DispatchException
 
DispatchException(Message, MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.transport.DispatchException
 
DispatchException(Message, MuleEvent, MessageProcessor, Throwable) - Constructor for exception org.mule.api.transport.DispatchException
 
dispatchMuleMessage(Message, MuleEvent, OutboundEndpoint) - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
dispatchNotification(EndpointMessageNotification, MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundNotificationMessageProcessor
 
dispatchNotification(EndpointMessageNotification) - Method in class org.mule.endpoint.outbound.OutboundNotificationMessageProcessor
dispatchRemote(String, Object, Map) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
dispatchToRemoteComponent(String, Object, Map) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
Dispatcher an event asynchronously to a components on a remote Mule instance.
dispatchToSocket(MuleEvent) - Method in class org.mule.transport.tcp.LocalSocketTcpMessageDispatcher
 
Disposable - Interface in org.mule.api.lifecycle
Disposable is a lifecycle interface that gets called at the dispose lifecycle stage of the implementing service as the service is being destroyed.
DisposableClassLoader - Interface in org.mule.module.launcher
 
DisposableCloser - Class in org.guiceyfruit.mule.support
Disposes objects that implement Disposable in the current scope when the scope closes
DisposableCloser() - Constructor for class org.guiceyfruit.mule.support.DisposableCloser
 
dispose(DocumentBuilderFactory) - Method in class org.glassfish.jersey.message.internal.DocumentBuilderFactoryInjectionProvider
 
dispose(SAXParserFactory) - Method in class org.glassfish.jersey.message.internal.SaxParserFactoryInjectionProvider
 
dispose(XMLInputFactory) - Method in class org.glassfish.jersey.message.internal.XmlInputFactoryInjectionProvider
 
dispose() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
dispose() - Method in interface org.mule.api.lifecycle.Disposable
A lifecycle method where implementor should free up any resources.
dispose() - Method in class org.mule.component.AbstractComponent
 
dispose() - Method in class org.mule.component.DefaultComponentLifecycleAdapter
Propagates dispose() life-cycle to component object implementations if they implement the mule Disposable interface.
dispose() - Method in class org.mule.component.NullLifecycleAdapter
 
dispose() - Method in class org.mule.component.PooledJavaComponent.LifeCycleAdapterFactory
 
dispose() - Method in class org.mule.config.spring.factories.ConstantFactoryBean
 
dispose() - Method in class org.mule.config.spring.factories.FlowRefFactoryBean
 
dispose(SpringXmlConfigurationBuilder, MuleContext) - Method in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
dispose() - Method in class org.mule.config.spring.util.SpringBeanLookup
 
dispose() - Method in class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
 
dispose() - Method in class org.mule.construct.AbstractFlowConstruct
 
dispose() - Method in class org.mule.context.notification.MessageProcessingFlowTraceManager
 
dispose() - Method in class org.mule.context.notification.ServerNotificationManager
 
dispose() - Method in class org.mule.DefaultMuleContext
 
dispose() - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
 
dispose() - Method in class org.mule.endpoint.AbstractEndpoint
 
dispose() - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
dispose() - Method in class org.mule.interceptor.InterceptorStack
 
dispose() - Method in class org.mule.model.AbstractModel
Deprecated.
Destroys any current components
dispose() - Method in class org.mule.module.bpm.Process
 
dispose() - Method in class org.mule.module.bpm.Rules
 
dispose() - Method in class org.mule.module.client.MuleClient
Will dispose the MuleManager instance if a new instance was created for this client.
dispose() - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
dispose() - Method in class org.mule.module.client.remoting.RemoteDispatcherAgent
Deprecated.
 
dispose() - Method in class org.mule.module.cxf.config.FlowConfiguringMessageProcessor
 
dispose() - Method in class org.mule.module.cxf.CxfConfiguration
 
dispose() - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
dispose() - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
dispose() - Method in class org.mule.module.db.internal.domain.database.DataSourceFactory
 
dispose() - Method in class org.mule.module.db.internal.resolver.database.StaticDbConfigResolver
 
dispose() - Method in class org.mule.module.extension.internal.runtime.processor.OperationMessageProcessor
 
dispose() - Method in class org.mule.module.extension.internal.runtime.ReflectiveMethodOperationExecutor
 
dispose() - Method in interface org.mule.module.http.api.listener.HttpListener
Get rid of this listener.
dispose() - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
dispose() - Method in class org.mule.module.http.internal.listener.DefaultRequestHandlerManager
 
dispose() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyServerManager
 
dispose() - Method in class org.mule.module.http.internal.listener.HttpListenerConnectionManager
 
dispose() - Method in interface org.mule.module.http.internal.listener.HttpServerManager
Frees all the resource hold by the server manager.
dispose() - Method in interface org.mule.module.http.internal.listener.RequestHandlerManager
 
dispose() - Method in class org.mule.module.http.internal.request.client.HttpConnectorMessageProcessorProvider
 
dispose() - Method in class org.mule.module.jbpm.Jbpm
 
dispose() - Method in class org.mule.module.json.transformers.JsonTransformerResolver
 
dispose() - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
dispose() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
dispose() - Method in class org.mule.module.launcher.artifact.AbstractArtifactClassLoader
 
dispose() - Method in interface org.mule.module.launcher.artifact.Artifact
Dispose the artifact.
dispose() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
dispose() - Method in class org.mule.module.launcher.coreextension.DefaultMuleCoreExtensionManager
 
dispose() - Method in interface org.mule.module.launcher.DisposableClassLoader
Gets rid of the class loader resources.
dispose(DomainWrapper) - Method in class org.mule.module.launcher.domain.DefaultDomainFactory
 
dispose() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
dispose() - Method in class org.mule.module.launcher.domain.DomainWrapper
 
dispose() - Method in class org.mule.module.launcher.GoodCitizenClassLoader
Disposes the ClassLoader by closing all the resources opened by this ClassLoader.
dispose() - Method in class org.mule.module.launcher.log4j2.MuleLog4jContextFactory
 
dispose() - Method in class org.mule.module.management.agent.AbstractJmxAgent
A lifecycle method where implementor should free up any resources.
dispose() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
A lifecycle method where implementor should free up any resources.
dispose() - Method in class org.mule.module.management.agent.JdmkAgent
 
dispose() - Method in class org.mule.module.management.agent.JmxServerNotificationAgent
 
dispose() - Method in class org.mule.module.management.agent.Log4jAgent
Deprecated.
 
dispose() - Method in class org.mule.module.management.agent.Mx4jAgent
 
dispose() - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
dispose() - Method in class org.mule.module.management.agent.WrapperManagerAgent
 
dispose() - Method in class org.mule.module.management.agent.YourKitProfilerAgent
 
dispose() - Method in class org.mule.module.management.mbean.ConnectorService
 
dispose() - Method in interface org.mule.module.management.mbean.ConnectorServiceMBean
 
dispose() - Method in class org.mule.module.management.mbean.MuleService
 
dispose() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
dispose() - Method in class org.mule.module.management.mbean.ServiceService
 
dispose() - Method in interface org.mule.module.management.mbean.ServiceServiceMBean
Deprecated.
 
dispose() - Method in class org.mule.module.ognl.expression.OgnlExpressionEvaluator
 
dispose() - Method in class org.mule.module.scripting.expression.AbstractScriptExpressionEvaluator
A lifecycle method where implementor should free up any resources.
dispose() - Method in class org.mule.module.scripting.filter.ScriptFilter
 
dispose() - Method in class org.mule.module.scripting.transformer.ScriptTransformer
 
dispose() - Method in class org.mule.module.ws.consumer.WSConsumer
 
dispose() - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
A lifecycle method where implementor should free up any resources.
dispose() - Method in class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
A lifecycle method where implementor should free up any resources.
dispose() - Method in class org.mule.module.xml.transformer.jaxb.JAXBTransformerResolver
 
dispose() - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
dispose() - Method in class org.mule.modules.schedulers.cron.CronScheduler
 
dispose() - Method in class org.mule.object.AbstractObjectFactory
 
dispose() - Method in class org.mule.object.JndiObjectFactory
 
dispose() - Method in class org.mule.object.SingletonObjectFactory
 
dispose() - Method in class org.mule.processor.AbstractMuleObjectOwner
 
dispose() - Method in class org.mule.processor.AbstractRedeliveryPolicy
 
dispose() - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
dispose() - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
dispose() - Method in class org.mule.processor.ResponseMessageProcessorAdapter
 
dispose() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
dispose() - Method in class org.mule.processor.TransactionalInterceptingMessageProcessor
 
dispose() - Method in class org.mule.registry.AbstractRegistry
 
dispose() - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
dispose() - Method in class org.mule.registry.ExpressionEnricherProcessor
Deprecated.
A lifecycle method where implementor should free up any resources.
dispose() - Method in class org.mule.registry.ExpressionEvaluatorProcessor
Deprecated.
A lifecycle method where implementor should free up any resources.
dispose() - Method in class org.mule.registry.MuleRegistryHelper
A lifecycle method where implementor should free up any resources.
dispose() - Method in class org.mule.registry.TypeBasedTransformerResolver
 
dispose() - Method in class org.mule.routing.AbstractAggregator
 
dispose() - Method in class org.mule.routing.AbstractMatchingRouter
 
dispose() - Method in class org.mule.routing.AbstractSelectiveRouter
 
dispose() - Method in class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
 
dispose() - Method in class org.mule.routing.correlation.EventCorrelator
 
dispose() - Method in class org.mule.routing.IdempotentMessageFilter
 
dispose() - Method in class org.mule.routing.MessageFilter
 
dispose() - Method in class org.mule.routing.MessageProcessorFilterPair
 
dispose() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
dispose() - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
dispose() - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
dispose() - Method in class org.mule.routing.ScatterGatherRouter
 
dispose() - Method in class org.mule.security.oauth.BaseOAuth2Manager
dispose() - Method in class org.mule.service.AbstractService
Deprecated.
 
dispose() - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
dispose() - Method in class org.mule.source.ClusterizableMessageSourceWrapper
 
dispose() - Method in class org.mule.source.StartableCompositeMessageSource
 
dispose() - Method in class org.mule.tck.functional.FunctionalTestComponent
 
dispose() - Method in class org.mule.tck.testmodels.services.TestServiceComponent
A lifecycle method where implementor should free up any resources.
dispose() - Method in class org.mule.transformer.AbstractTransformer
Template method where deriving classes can do any clean up any resources or state before the object is disposed.
dispose() - Method in class org.mule.transformer.CompositeConverter
 
dispose() - Method in class org.mule.transport.AbstractConnector
 
dispose() - Method in class org.mule.transport.AbstractTransportMessageHandler
Template method to destroy any resources held by the Message Dispatcher
dispose() - Method in class org.mule.transport.ConcurrentWorkTracker
 
dispose() - Method in class org.mule.transport.jms.CustomCachingConnectionFactory
 
dispose() - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
dispose() - Method in class org.mule.transport.jms.jndi.SimpleJndiNameResolver
 
dispose() - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
dispose() - Method in class org.mule.transport.multicast.MulticastMessageReceiver.MulticastWorker
 
dispose() - Method in class org.mule.transport.polling.schedule.FixedFrequencyScheduler
Checks that the FixedFrequencyScheduler.executor is terminated and, if not, it terminates the scheduling abruptly
dispose() - Method in class org.mule.transport.quartz.jobs.PollEndpointJob
 
dispose() - Method in class org.mule.transport.servlet.jetty.JettyWebappServerAgent
 
dispose() - Method in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
dispose() - Method in class org.mule.transport.TrackingWorkManager
 
dispose() - Method in class org.mule.transport.udp.UdpMessageReceiver.UdpWorker
 
dispose() - Method in class org.mule.util.lock.InstanceLockGroup
 
dispose() - Method in class org.mule.util.lock.MuleLockFactory
 
dispose() - Method in class org.mule.util.monitor.ExpiryMonitor
 
dispose() - Method in class org.mule.util.pool.CommonsPoolObjectPool
 
dispose() - Method in class org.mule.util.queue.AbstractQueueManager
 
dispose() - Method in class org.mule.util.queue.DefaultQueueStore
 
dispose() - Method in class org.mule.util.queue.DefaultQueueStoreDelegate
 
dispose() - Method in class org.mule.util.queue.DelegateQueueManager
 
dispose() - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
Deletes the queue and it's content.
dispose() - Method in interface org.mule.util.queue.Queue
Disposes this queue by releasing it's storage and associated memory and storage.
dispose() - Method in interface org.mule.util.queue.QueueStore
 
dispose() - Method in interface org.mule.util.queue.QueueStoreDelegate
Deletes the queue and it's content.
dispose() - Method in class org.mule.util.queue.TransactionAwareQueueStore
 
dispose() - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
dispose() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
dispose() - Method in class org.mule.util.store.MuleObjectStoreManager
 
dispose() - Method in class org.mule.util.store.ProvidedObjectStoreWrapper
 
dispose() - Method in class org.mule.util.store.TextFileObjectStore
 
dispose() - Method in class org.mule.work.MuleWorkManager
 
dispose() - Method in class org.mule.work.SerialWorkManager
 
disposeAllIfNeeded(Collection<? extends Object>, Logger) - Static method in class org.mule.api.lifecycle.LifecycleUtils
For each item in the objects collection, it invokes Disposable.dispose() if it implements the Disposable interface.
disposeAndLogException() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
disposed - Variable in class org.mule.object.AbstractObjectFactory
 
DisposeException - Exception in org.mule.api.lifecycle
DisposeException TODO (document class)
DisposeException(Message, Disposable) - Constructor for exception org.mule.api.lifecycle.DisposeException
 
DisposeException(Message, Throwable, Disposable) - Constructor for exception org.mule.api.lifecycle.DisposeException
 
DisposeException(Throwable, Disposable) - Constructor for exception org.mule.api.lifecycle.DisposeException
 
disposeIfDisposable(Object) - Method in class org.mule.construct.AbstractFlowConstruct
 
disposeIfDisposable(Object) - Method in class org.mule.service.AbstractService
Deprecated.
 
disposeIfNeeded(Object, Logger) - Static method in class org.mule.api.lifecycle.LifecycleUtils
Invokes Disposable.dispose() on object if it implements the Disposable interface.
disposeMethod - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
disposeMuleContext(MuleContext) - Method in class org.mule.tck.junit4.DomainFunctionalTestCase
 
disposeMuleContexts() - Method in class org.mule.tck.junit4.DomainFunctionalTestCase
 
disposePartition(String) - Method in interface org.mule.api.store.PartitionableObjectStore
 
disposePartition(String) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
disposePartition(String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
disposePartition(String) - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
disposeQueue(Queue) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
disposeQueueStore(QueueStore) - Method in class org.mule.util.queue.AbstractQueueManager
 
disposeQueueStore(QueueStore) - Method in interface org.mule.util.queue.QueueStoreCacheListener
 
disposeReceivers() - Method in class org.mule.transport.AbstractConnector
 
disposeSession(Object) - Method in interface org.mule.module.bpm.RulesEngine
Dispose of a provider-specific session if necessary.
disposeSession(Object) - Method in class org.mule.module.drools.Drools
 
disposeStore(ObjectStore<? extends Serializable>) - Method in interface org.mule.api.store.ObjectStoreManager
Delete all objects from the partition
disposeStore(ObjectStore<? extends Serializable>) - Method in class org.mule.util.store.MuleObjectStoreManager
 
disposeWorkManagers() - Method in class org.mule.transport.AbstractConnector
 
disposing - Variable in class org.mule.transport.tcp.TcpMessageReceiver
 
disposing - Variable in class org.mule.transport.udp.UdpMessageReceiver
 
DISTINCT_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
DIVIDE - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter represening the division of two other counters
doAddAll(Collection<? extends Serializable>) - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
Adds all the items at the end of the queue
doAddAll(Collection<? extends Serializable>) - Method in class org.mule.util.queue.DefaultQueueStoreDelegate
 
doAddAll(Collection<? extends Serializable>) - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
doAllMethods(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
doBad(RequestLine) - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
doBad(RequestLine) - Method in class org.mule.transport.http.OldHttpMessageReceiver.HttpWorker
 
doBegin() - Method in class org.mule.module.db.internal.domain.transaction.DbTransaction
 
doBegin() - Method in class org.mule.module.spring.transaction.SpringTransactionFactory.SpringTransaction
 
doBegin() - Method in class org.mule.processor.DelegateTransaction
 
doBegin() - Method in class org.mule.transaction.AbstractTransaction
Really begin the transaction.
doBegin() - Method in class org.mule.transaction.ExternalXaTransaction
 
doBegin() - Method in class org.mule.transaction.XaTransaction
 
doBegin() - Method in class org.mule.transport.jdbc.JdbcTransaction
 
doBegin() - Method in class org.mule.transport.jms.JmsClientAcknowledgeTransaction
 
doBegin() - Method in class org.mule.transport.jms.JmsTransaction
 
doBegin() - Method in class org.mule.transport.vm.VMTransaction
 
doBegin(AbstractTransactionContext) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
doBegin(AbstractTransactionContext) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
doBegin(AbstractTransactionContext) - Method in class org.mule.util.queue.QueueXaResourceManager
 
doBegin(AbstractTransactionContext) - Method in class org.mule.util.xa.AbstractResourceManager
 
doBody() - Method in class org.mule.module.launcher.MuleContainerStartupSplashScreen
 
doBody(String) - Method in class org.mule.util.SplashScreen
 
doBuildContext() - Method in class org.mule.tck.junit4.ApplicationContextBuilder
 
doBuildInboundEndpoint() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
doBuildOutboundEndpoint() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
doBuildResponse(MuleEvent, HttpResponseBuilder, ResponseCompletionCallback) - Method in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
doCatchMessage(MuleEvent) - Method in class org.mule.routing.AbstractCatchAllStrategy
Deprecated.
 
doCatchMessage(MuleEvent) - Method in class org.mule.routing.ForwardingCatchAllStrategy
Deprecated.
 
doCatchMessage(MuleEvent) - Method in class org.mule.routing.LoggingCatchAllStrategy
Deprecated.
 
doCatchMessage(MuleEvent) - Method in class org.mule.routing.ServiceCatchAllStrategy
Deprecated.
 
doClear() - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
Removes all the items in the queue
doClear() - Method in class org.mule.util.queue.DefaultQueueStoreDelegate
 
doClear() - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
doClear(QueueInfo) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
doClientConnect() - Method in class org.mule.transport.http.HttpConnector
 
doCloseResource(boolean, XaTransactedJmsMessageReceiver.JmsThreadContext) - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
doCommit() - Method in class org.mule.module.db.internal.domain.transaction.DbTransaction
 
doCommit() - Method in class org.mule.module.spring.transaction.SpringTransactionFactory.SpringTransaction
 
doCommit() - Method in class org.mule.processor.DelegateTransaction
 
doCommit() - Method in class org.mule.transaction.AbstractTransaction
Commit the transaction on the underlying resource
doCommit() - Method in class org.mule.transaction.XaTransaction
 
doCommit() - Method in class org.mule.transport.jdbc.JdbcTransaction
 
doCommit() - Method in class org.mule.transport.jms.JmsClientAcknowledgeTransaction
 
doCommit() - Method in class org.mule.transport.jms.JmsTransaction
 
doCommit() - Method in class org.mule.transport.vm.VMTransaction
 
doCommit() - Method in interface org.mule.util.queue.LocalQueueTransactionContext
Commits the current transaction context operations
doCommit() - Method in class org.mule.util.queue.LocalTxQueueTransactionContext
 
doCommit() - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
doCommit(AbstractTransactionContext) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
doCommit(AbstractTransactionContext) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
doCommit() - Method in class org.mule.util.queue.objectstore.xa.AbstractTransactionContext
Deprecated.
 
doCommit() - Method in class org.mule.util.queue.PersistentQueueTransactionContext
 
doCommit() - Method in class org.mule.util.queue.PersistentXaTransactionContext
 
doCommit(AbstractTransactionContext) - Method in class org.mule.util.queue.QueueXaResourceManager
 
doCommit() - Method in class org.mule.util.queue.TransientQueueTransactionContext
 
doCommit() - Method in class org.mule.util.queue.TransientXaTransactionAdapter
 
doCommit() - Method in interface org.mule.util.queue.XaQueueTransactionContext
Commits the current transaction context operations
doCommit() - Method in class org.mule.util.queue.XaQueueTypeTransactionContextAdapter
 
doCommit(AbstractTransactionContext) - Method in class org.mule.util.xa.AbstractResourceManager
 
doCommit() - Method in class org.mule.util.xa.AbstractTransactionContext
 
doCompute() - Method in class org.mule.util.counters.impl.AggregateCounter
 
doCompute() - Method in class org.mule.util.counters.impl.Average
 
doCompute() - Method in class org.mule.util.counters.impl.Delta
 
doCompute() - Method in class org.mule.util.counters.impl.InstantRate
 
doCompute() - Method in class org.mule.util.counters.impl.Max
 
doCompute() - Method in class org.mule.util.counters.impl.Min
 
doCompute() - Method in class org.mule.util.counters.impl.Operator
 
doCompute() - Method in class org.mule.util.counters.impl.RatePerUnit
 
doCompute() - Method in class org.mule.util.counters.impl.Sum
 
doCompute() - Method in class org.mule.util.counters.impl.TimeAverage
 
doConfigure(MuleContext) - Method in class org.mule.config.AnnotationsConfigurationBuilder
 
doConfigure(MuleContext) - Method in class org.mule.config.builders.AbstractConfigurationBuilder
Will configure a MuleContext based on the configuration provided.
doConfigure(MuleContext) - Method in class org.mule.config.builders.AutoConfigurationBuilder
 
doConfigure(MuleContext) - Method in class org.mule.config.builders.DefaultsConfigurationBuilder
 
doConfigure(MuleContext) - Method in class org.mule.config.builders.ExtensionsManagerConfigurationBuilder
 
doConfigure(MuleContext) - Method in class org.mule.config.builders.SimpleConfigurationBuilder
 
doConfigure(MuleContext) - Method in class org.mule.config.builders.WebappMuleXmlConfigurationBuilder
 
doConfigure(MuleContext) - Method in class org.mule.config.spring.SpringConfigurationBuilder
 
doConfigure(MuleContext) - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
doConfigure(MuleContext) - Method in class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
doConfigure(MuleContext) - Method in class org.mule.module.scripting.builders.ScriptConfigurationBuilder
Deprecated.
 
doConfigureInboundEndpointBuilder(MuleContext, EndpointBuilder) - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundEndpointBuilder
 
doConfigureInboundEndpointBuilder(MuleContext, EndpointBuilder) - Method in class org.mule.construct.builder.BridgeBuilder
 
doConfigureOutboundEndpointBuilder(MuleContext, EndpointBuilder) - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundAndOutboundEndpointBuilder
 
doConfigureOutboundEndpointBuilder(MuleContext, EndpointBuilder) - Method in class org.mule.construct.builder.BridgeBuilder
 
doConfigureProxy(AsyncHttpClientConfig.Builder, ProxyConfig) - Method in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
doConfigureThread(Thread) - Method in class org.mule.util.concurrent.DaemonThreadFactory
 
doConfigureThread(Thread) - Method in class org.mule.util.concurrent.NamedThreadFactory
 
doConnect() - Method in class org.mule.endpoint.dynamic.NullConnector
 
doConnect() - Method in class org.mule.transport.AbstractConnector
Template method where any connections should be made for the connector
doConnect() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
doConnect() - Method in class org.mule.transport.email.AbstractMailConnector
 
doConnect() - Method in class org.mule.transport.email.RetrieveMessageReceiver
 
doConnect() - Method in class org.mule.transport.email.RetrieveMessageRequester
 
doConnect() - Method in class org.mule.transport.email.SmtpMessageDispatcher
 
doConnect() - Method in class org.mule.transport.file.FileConnector
 
doConnect() - Method in class org.mule.transport.file.FileMessageDispatcher
 
doConnect() - Method in class org.mule.transport.file.FileMessageReceiver
 
doConnect() - Method in class org.mule.transport.file.FileMessageRequester
 
doConnect() - Method in class org.mule.transport.ftp.FtpConnector
 
doConnect() - Method in class org.mule.transport.ftp.FtpMessageDispatcher
 
doConnect() - Method in class org.mule.transport.ftp.FtpMessageReceiver
 
doConnect() - Method in class org.mule.transport.ftp.FtpMessageRequester
 
doConnect() - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
doConnect() - Method in class org.mule.transport.http.HttpClientMessageRequester
 
doConnect() - Method in class org.mule.transport.http.HttpMessageReceiver
 
doConnect() - Method in class org.mule.transport.http.HttpsMessageReceiver
 
doConnect() - Method in class org.mule.transport.http.OldHttpMessageReceiver
 
doConnect() - Method in class org.mule.transport.http.OldHttpsMessageReceiver
 
doConnect() - Method in class org.mule.transport.http.PollingHttpMessageReceiver
 
doConnect() - Method in class org.mule.transport.jdbc.JdbcConnector
 
doConnect() - Method in class org.mule.transport.jdbc.JdbcMessageDispatcher
 
doConnect() - Method in class org.mule.transport.jdbc.JdbcMessageReceiver
 
doConnect() - Method in class org.mule.transport.jdbc.JdbcMessageRequester
 
doConnect() - Method in class org.mule.transport.jms.JmsConnector
 
doConnect() - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
doConnect() - Method in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
doConnect() - Method in class org.mule.transport.jms.JmsMessageRequester
 
doConnect() - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver
 
doConnect() - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.SubReceiver
 
doConnect() - Method in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
doConnect() - Method in class org.mule.transport.jms.websphere.WebsphereTransactedJmsMessageReceiver
 
doConnect() - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
doConnect() - Method in class org.mule.transport.polling.MessageProcessorPollingConnector
 
doConnect() - Method in class org.mule.transport.quartz.QuartzConnector
 
doConnect() - Method in class org.mule.transport.quartz.QuartzMessageDispatcher
 
doConnect() - Method in class org.mule.transport.quartz.QuartzMessageReceiver
 
doConnect() - Method in class org.mule.transport.rmi.RmiCallbackMessageReceiver
Initializes endpoint
doConnect() - Method in class org.mule.transport.rmi.RmiConnector
 
doConnect() - Method in class org.mule.transport.rmi.RmiMessageDispatcher
 
doConnect() - Method in class org.mule.transport.rmi.RmiMessageReceiver
 
doConnect() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
Template method where any connections should be made for the connector
doConnect() - Method in class org.mule.transport.servlet.ServletConnector
 
doConnect() - Method in class org.mule.transport.servlet.ServletMessageReceiver
 
doConnect() - Method in class org.mule.transport.sftp.SftpConnector
 
doConnect() - Method in class org.mule.transport.sftp.SftpMessageReceiver
 
doConnect() - Method in class org.mule.transport.soap.axis.AxisConnector
 
doConnect() - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
doConnect() - Method in class org.mule.transport.soap.axis.AxisMessageReceiver
 
doConnect() - Method in class org.mule.transport.soap.axis.AxisMessageRequester
 
doConnect() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
doConnect() - Method in class org.mule.transport.stdio.StdioMessageDispatcher
 
doConnect() - Method in class org.mule.transport.stdio.StdioMessageReceiver
 
doConnect() - Method in class org.mule.transport.tcp.TcpConnector
 
doConnect() - Method in class org.mule.transport.tcp.TcpMessageDispatcher
 
doConnect() - Method in class org.mule.transport.tcp.TcpMessageReceiver
 
doConnect() - Method in class org.mule.transport.tcp.TcpMessageRequester
 
doConnect() - Method in class org.mule.transport.udp.UdpConnector
 
doConnect() - Method in class org.mule.transport.udp.UdpMessageDispatcher
 
doConnect() - Method in class org.mule.transport.udp.UdpMessageReceiver
 
doConnect() - Method in class org.mule.transport.udp.UdpMessageRequester
 
doConnect() - Method in class org.mule.transport.UnsupportedMessageDispatcher
 
doConnect() - Method in class org.mule.transport.UnsupportedMessageRequester
 
doConnect() - Method in class org.mule.transport.vm.VMConnector
 
doConnect() - Method in class org.mule.transport.vm.VMMessageDispatcher
 
doConnect() - Method in class org.mule.transport.vm.VMMessageReceiver
 
doConnect() - Method in class org.mule.transport.vm.VMMessageRequester
 
doConnect() - Method in class org.mule.transport.xmpp.AbstractXmppConversation
Subclasses can override this method to create their conversation specific connection.
doConnect() - Method in class org.mule.transport.xmpp.XmppChatConversation
 
doConnect() - Method in class org.mule.transport.xmpp.XmppConnector
 
doConnect() - Method in class org.mule.transport.xmpp.XmppMessageDispatcher
 
doConnect() - Method in class org.mule.transport.xmpp.XmppMessageReceiver
 
doConnect() - Method in class org.mule.transport.xmpp.XmppMessageRequester
 
doConnect() - Method in class org.mule.transport.xmpp.XmppMultiUserChatConversation
 
doConnect() - Method in class org.mule.transport.xmpp.XmppPollingMessageReceiver
 
doConsume() - Method in class org.mule.streaming.AbstractConsumer
Implement this method to actually consume the producer without worrying about exception types or checking fo this consumer to be closed.
doConsume() - Method in class org.mule.streaming.ListConsumer
Implement this method to actually consume the producer without worrying about exception types or checking fo this consumer to be closed.
doConsume() - Method in class org.mule.streaming.SimpleConsumer
 
doContains(Serializable) - Method in class org.mule.util.store.AbstractObjectStore
 
doContains(Serializable) - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
doContains(Serializable) - Method in class org.mule.util.store.SimpleMemoryObjectStore
 
doCreate(String, T) - Method in class org.mule.api.schedule.SchedulerFactory
Template method to delegate the creation of the Scheduler.
doCreate(String, PollingReceiverWorker) - Method in class org.mule.modules.schedulers.cron.CronSchedulerFactory
 
doCreate(Object, MuleMessage, String, MuleContext) - Method in class org.mule.transport.AbstractMuleMessageFactory
 
doCreate(Object, MuleMessage, String, MuleContext) - Method in class org.mule.transport.http.HttpMultipartMuleMessageFactory
 
doCreate(String, T) - Method in class org.mule.transport.polling.schedule.FixedFrequencySchedulerFactory
 
doCreateApplicationContext(MuleContext, ConfigResource[], OptionalObjectsController) - Method in class org.mule.config.builders.WebappMuleXmlConfigurationBuilder
 
doCreateApplicationContext(MuleContext, ConfigResource[], OptionalObjectsController) - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
doCreateApplicationContext(MuleContext, ConfigResource[], OptionalObjectsController) - Method in class org.mule.config.spring.SpringXmlDomainConfigurationBuilder
 
doCreateConnection(DataSource) - Method in class org.mule.module.db.internal.domain.connection.AbstractConnectionFactory
 
doCreateConnection(DataSource) - Method in class org.mule.module.db.internal.domain.connection.RetryConnectionFactory
 
doCreateConnection(DataSource) - Method in class org.mule.module.db.internal.domain.connection.SimpleConnectionFactory
 
doCreateConnection() - Method in class org.mule.transport.jms.CustomCachingConnectionFactory
 
doCreateDbConfig(DataSource, DbTypeManager, DbConnectionFactory, String) - Method in class org.mule.module.db.internal.domain.database.GenericDbConfigFactory
 
doCreateDbConnection(Connection, TransactionalAction) - Method in class org.mule.module.db.internal.domain.connection.OracleTransactionalDbConnectionFactory
 
doCreateDbConnection(Connection, TransactionalAction) - Method in class org.mule.module.db.internal.domain.connection.TransactionalDbConnectionFactory
 
doCreateInstance() - Method in class org.mule.config.spring.factories.AnnotatedObjectFactoryBean
 
doCreateInstance() - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
doCreateMuleContext(MuleContextBuilder, DefaultMuleContextFactory.ContextConfigurator) - Method in class org.mule.context.DefaultMuleContextFactory
 
doCreateStatementResultIterator(DbConnection, Statement, QueryTemplate, AutoGeneratedKeyStrategy, ResultSetHandler) - Method in class org.mule.module.db.internal.result.statement.GenericStatementResultIteratorFactory
 
doCreateTypeManager() - Method in class org.mule.module.db.internal.domain.database.GenericDbConfigFactory
 
DOCUMENT_BUILDER_FACTORY - Static variable in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
DOCUMENT_BUILDER_PROPERTY - Static variable in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
DocumentBuilderFactoryInjectionProvider - Class in org.glassfish.jersey.message.internal
Thread-scoped injection provider of document builder factories.
DocumentBuilderFactoryInjectionProvider(Configuration) - Constructor for class org.glassfish.jersey.message.internal.DocumentBuilderFactoryInjectionProvider
Create new document builder factory provider.
doDecorate(ConnectionFactory, JmsConnector, MuleContext) - Method in class org.mule.transport.jms.AbstractConnectionFactoryDecorator
 
doDecorate(ConnectionFactory, JmsConnector, MuleContext) - Method in class org.mule.transport.jms.CachingConnectionFactoryDecorator
 
doDecorate(ConnectionFactory, JmsConnector, MuleContext) - Method in class org.mule.transport.jms.DefaultConnectionFactoryDecorator
 
doDelete(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
doDelete(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleRESTReceiverServlet
 
doDeserialize(InputStream, ClassLoader) - Method in class org.mule.serialization.internal.AbstractObjectSerializer
Deserializes the given inputStream using the provided classLoader.
doDeserialize(InputStream, ClassLoader) - Method in class org.mule.serialization.internal.JavaObjectSerializer
Deserializes the given inputStream using the provided classLoader.
doDestroyClient(ImmutableEndpoint, SftpClient) - Method in class org.mule.transport.sftp.SftpConnector
 
doDisconnect() - Method in class org.mule.endpoint.dynamic.NullConnector
 
doDisconnect() - Method in class org.mule.transport.AbstractConnector
Template method where any connected resources used by the connector should be disconnected
doDisconnect() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
doDisconnect() - Method in class org.mule.transport.email.AbstractMailConnector
 
doDisconnect() - Method in class org.mule.transport.email.RetrieveMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.email.RetrieveMessageRequester
 
doDisconnect() - Method in class org.mule.transport.email.SmtpMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.file.FileConnector
 
doDisconnect() - Method in class org.mule.transport.file.FileMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.file.FileMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.file.FileMessageRequester
 
doDisconnect() - Method in class org.mule.transport.ftp.FtpConnector
 
doDisconnect() - Method in class org.mule.transport.ftp.FtpMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.ftp.FtpMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.ftp.FtpMessageRequester
 
doDisconnect() - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.http.HttpClientMessageRequester
 
doDisconnect() - Method in class org.mule.transport.http.HttpMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.http.PollingHttpMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.jdbc.JdbcConnector
 
doDisconnect() - Method in class org.mule.transport.jdbc.JdbcMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.jdbc.JdbcMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.jdbc.JdbcMessageRequester
 
doDisconnect() - Method in class org.mule.transport.jms.activemq.ActiveMQJmsConnector
Will additionally try to cleanup the ActiveMq connection, otherwise there's a deadlock on shutdown.
doDisconnect() - Method in class org.mule.transport.jms.JmsConnector
 
doDisconnect() - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
doDisconnect() - Method in class org.mule.transport.jms.JmsMessageRequester
 
doDisconnect() - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.SubReceiver
 
doDisconnect() - Method in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.polling.MessageProcessorPollingConnector
 
doDisconnect() - Method in class org.mule.transport.quartz.QuartzConnector
 
doDisconnect() - Method in class org.mule.transport.quartz.QuartzMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.quartz.QuartzMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.rmi.RmiCallbackMessageReceiver
Unbinds Rmi class from registry
doDisconnect() - Method in class org.mule.transport.rmi.RmiConnector
 
doDisconnect() - Method in class org.mule.transport.rmi.RmiMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.rmi.RmiMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
Template method where any connected resources used by the connector should be disconnected
doDisconnect() - Method in class org.mule.transport.servlet.ServletConnector
 
doDisconnect() - Method in class org.mule.transport.servlet.ServletMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.sftp.SftpConnector
 
doDisconnect() - Method in class org.mule.transport.sftp.SftpMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.sftp.SftpMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.soap.axis.AxisConnector
 
doDisconnect() - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.soap.axis.AxisMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.soap.axis.AxisMessageRequester
 
doDisconnect() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
doDisconnect() - Method in class org.mule.transport.stdio.StdioMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.stdio.StdioMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.tcp.TcpConnector
 
doDisconnect() - Method in class org.mule.transport.tcp.TcpMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.tcp.TcpMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.tcp.TcpMessageRequester
 
doDisconnect() - Method in class org.mule.transport.udp.UdpConnector
 
doDisconnect() - Method in class org.mule.transport.udp.UdpMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.udp.UdpMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.udp.UdpMessageRequester
 
doDisconnect() - Method in class org.mule.transport.UnsupportedMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.UnsupportedMessageRequester
 
doDisconnect() - Method in class org.mule.transport.vm.VMConnector
 
doDisconnect() - Method in class org.mule.transport.vm.VMMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.vm.VMMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.vm.VMMessageRequester
 
doDisconnect() - Method in class org.mule.transport.xmpp.AbstractXmppConversation
Subclasses can override this method to perform custom disconnect actions.
doDisconnect() - Method in class org.mule.transport.xmpp.XmppChatConversation
 
doDisconnect() - Method in class org.mule.transport.xmpp.XmppConnector
 
doDisconnect() - Method in class org.mule.transport.xmpp.XmppMessageDispatcher
 
doDisconnect() - Method in class org.mule.transport.xmpp.XmppMessageReceiver
 
doDisconnect() - Method in class org.mule.transport.xmpp.XmppMessageRequester
 
doDisconnect() - Method in class org.mule.transport.xmpp.XmppMultiUserChatConversation
 
doDisconnect() - Method in class org.mule.transport.xmpp.XmppPollingMessageReceiver
 
doDispatch(MuleEvent) - Method in class org.mule.transport.AbstractMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.ajax.AjaxMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.email.RetrieveMessageRequester
 
doDispatch(MuleEvent) - Method in class org.mule.transport.email.SmtpMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.file.FileMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.ftp.FtpMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.jdbc.JdbcMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.quartz.QuartzMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.rmi.RmiMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.sftp.SftpMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.stdio.StdioMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.tcp.LocalSocketTcpMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.tcp.TcpMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.udp.UdpMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.UnsupportedMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.vm.VMMessageDispatcher
 
doDispatch(MuleEvent) - Method in class org.mule.transport.xmpp.XmppMessageDispatcher
 
doDispose() - Method in class org.mule.component.AbstractComponent
 
doDispose() - Method in class org.mule.component.AbstractJavaComponent
 
doDispose() - Method in class org.mule.component.DefaultJavaComponent
 
doDispose() - Method in class org.mule.component.SimpleCallableJavaComponent
 
doDispose() - Method in class org.mule.config.spring.SpringRegistry
 
doDispose() - Method in class org.mule.construct.AbstractFlowConstruct
 
doDispose() - Method in class org.mule.construct.AbstractPipeline
 
doDispose() - Method in class org.mule.endpoint.dynamic.NullConnector
 
doDispose() - Method in class org.mule.module.bpm.ProcessComponent
 
doDispose() - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
doDispose() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
doDispose() - Method in class org.mule.module.scripting.component.ScriptComponent
 
doDispose() - Method in class org.mule.registry.AbstractRegistry
 
doDispose() - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
doDispose() - Method in class org.mule.service.AbstractService
Deprecated.
 
doDispose() - Method in class org.mule.transport.AbstractConnector
Template method to perform any work when destroying the connectoe
doDispose() - Method in class org.mule.transport.AbstractMessageReceiver
 
doDispose() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
doDispose() - Method in class org.mule.transport.ajax.AjaxMessageDispatcher
 
doDispose() - Method in class org.mule.transport.email.AbstractMailConnector
 
doDispose() - Method in class org.mule.transport.email.RetrieveMessageReceiver
 
doDispose() - Method in class org.mule.transport.email.RetrieveMessageRequester
 
doDispose() - Method in class org.mule.transport.email.SmtpMessageDispatcher
 
doDispose() - Method in class org.mule.transport.file.FileConnector
 
doDispose() - Method in class org.mule.transport.file.FileMessageDispatcher
 
doDispose() - Method in class org.mule.transport.file.FileMessageReceiver
 
doDispose() - Method in class org.mule.transport.file.FileMessageRequester
 
doDispose() - Method in class org.mule.transport.ftp.FtpConnector
 
doDispose() - Method in class org.mule.transport.ftp.FtpMessageDispatcher
 
doDispose() - Method in class org.mule.transport.ftp.FtpMessageReceiver
 
doDispose() - Method in class org.mule.transport.ftp.FtpMessageRequester
 
doDispose() - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
doDispose() - Method in class org.mule.transport.http.HttpClientMessageRequester
 
doDispose() - Method in class org.mule.transport.http.HttpConnector
 
doDispose() - Method in class org.mule.transport.http.PollingHttpMessageReceiver
 
doDispose() - Method in class org.mule.transport.jdbc.JdbcConnector
 
doDispose() - Method in class org.mule.transport.jdbc.JdbcMessageDispatcher
 
doDispose() - Method in class org.mule.transport.jdbc.JdbcMessageReceiver
 
doDispose() - Method in class org.mule.transport.jdbc.JdbcMessageRequester
 
doDispose() - Method in class org.mule.transport.jms.JmsConnector
 
doDispose() - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
doDispose() - Method in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
doDispose() - Method in class org.mule.transport.jms.JmsMessageRequester
 
doDispose() - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver
 
doDispose() - Method in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
doDispose() - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
doDispose() - Method in class org.mule.transport.multicast.MulticastMessageReceiver
 
doDispose() - Method in class org.mule.transport.polling.MessageProcessorPollingConnector
 
doDispose() - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
 
doDispose() - Method in class org.mule.transport.quartz.QuartzConnector
 
doDispose() - Method in class org.mule.transport.quartz.QuartzMessageDispatcher
 
doDispose() - Method in class org.mule.transport.quartz.QuartzMessageReceiver
 
doDispose() - Method in class org.mule.transport.rmi.RmiCallbackMessageReceiver
 
doDispose() - Method in class org.mule.transport.rmi.RmiConnector
 
doDispose() - Method in class org.mule.transport.rmi.RmiMessageDispatcher
 
doDispose() - Method in class org.mule.transport.rmi.RmiMessageReceiver
 
doDispose() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
Template method to dispose any resources associated with this receiver.
doDispose() - Method in class org.mule.transport.servlet.ServletConnector
 
doDispose() - Method in class org.mule.transport.servlet.ServletMessageReceiver
 
doDispose() - Method in class org.mule.transport.sftp.SftpConnector
 
doDispose() - Method in class org.mule.transport.sftp.SftpMessageDispatcher
 
doDispose() - Method in class org.mule.transport.sftp.SftpMessageReceiver
 
doDispose() - Method in class org.mule.transport.soap.axis.AxisConnector
 
doDispose() - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
doDispose() - Method in class org.mule.transport.soap.axis.AxisMessageReceiver
 
doDispose() - Method in class org.mule.transport.soap.axis.AxisMessageRequester
 
doDispose() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
doDispose() - Method in class org.mule.transport.stdio.StdioConnector
 
doDispose() - Method in class org.mule.transport.stdio.StdioMessageDispatcher
 
doDispose() - Method in class org.mule.transport.stdio.StdioMessageReceiver
 
doDispose() - Method in class org.mule.transport.tcp.TcpConnector
 
doDispose() - Method in class org.mule.transport.tcp.TcpMessageDispatcher
 
doDispose() - Method in class org.mule.transport.tcp.TcpMessageReceiver
 
doDispose() - Method in class org.mule.transport.tcp.TcpMessageRequester
 
doDispose() - Method in class org.mule.transport.udp.UdpConnector
 
doDispose() - Method in class org.mule.transport.udp.UdpMessageDispatcher
 
doDispose() - Method in class org.mule.transport.udp.UdpMessageReceiver
 
doDispose() - Method in class org.mule.transport.udp.UdpMessageRequester
 
doDispose() - Method in class org.mule.transport.UnsupportedMessageDispatcher
 
doDispose() - Method in class org.mule.transport.UnsupportedMessageRequester
 
doDispose() - Method in class org.mule.transport.vm.VMConnector
 
doDispose() - Method in class org.mule.transport.vm.VMMessageDispatcher
 
doDispose() - Method in class org.mule.transport.vm.VMMessageReceiver
 
doDispose() - Method in class org.mule.transport.vm.VMMessageRequester
 
doDispose() - Method in class org.mule.transport.xmpp.XmppConnector
 
doDispose() - Method in class org.mule.transport.xmpp.XmppMessageDispatcher
 
doDispose() - Method in class org.mule.transport.xmpp.XmppMessageReceiver
 
doDispose() - Method in class org.mule.transport.xmpp.XmppMessageRequester
 
doDispose() - Method in class org.mule.transport.xmpp.XmppPollingMessageReceiver
 
doDispose() - Method in class org.mule.util.queue.AbstractQueueManager
Dispose resources allocated by the implementations.
doDispose() - Method in class org.mule.util.queue.TransactionalQueueManager
 
doExecute(WorkerContext, Executor) - Method in interface org.mule.api.work.WorkExecutor
This method must be implemented by sub-classes in order to provide the relevant synchronization policy.
doExecute(JobExecutionContext) - Method in class org.mule.transport.quartz.jobs.AbstractJob
Execute the job.
doExecute(JobExecutionContext) - Method in class org.mule.transport.quartz.jobs.CustomJob
 
doExecute(JobExecutionContext) - Method in class org.mule.transport.quartz.jobs.EndpointPollingJob
 
doExecute(JobExecutionContext) - Method in class org.mule.transport.quartz.jobs.EventGeneratorJob
 
doExecute(JobExecutionContext) - Method in class org.mule.transport.quartz.jobs.PollEndpointJob
 
doExecute(JobExecutionContext) - Method in class org.mule.transport.quartz.jobs.ScheduledDispatchJob
 
doExecute(WorkerContext, Executor) - Method in class org.mule.work.ScheduleWorkExecutor
 
doExecute(WorkerContext, Executor) - Method in class org.mule.work.StartWorkExecutor
 
doExecute(WorkerContext, Executor) - Method in class org.mule.work.SyncWorkExecutor
 
doExecuteQuery(DbConnection, Statement, Query) - Method in class org.mule.module.db.internal.domain.executor.AbstractSingleQueryExecutor
 
doExecuteQuery(DbConnection, Statement, Query, AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.domain.executor.AbstractSingleQueryExecutor
 
doExecuteQuery(DbConnection, Statement, Query) - Method in class org.mule.module.db.internal.domain.executor.SelectExecutor
 
doExecuteQuery(DbConnection, Statement, Query, AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.domain.executor.SelectExecutor
 
doExecuteQuery(DbConnection, Statement, Query) - Method in class org.mule.module.db.internal.domain.executor.StoredProcedureExecutor
 
doExecuteQuery(DbConnection, Statement, Query, AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.domain.executor.StoredProcedureExecutor
 
doExecuteQuery(DbConnection, Statement, Query) - Method in class org.mule.module.db.internal.domain.executor.UpdateExecutor
 
doExecuteQuery(DbConnection, Statement, Query, AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.domain.executor.UpdateExecutor
 
doExecuteQuery(DbConnection, Query) - Method in class org.mule.module.db.internal.processor.AbstractSingleQueryDbMessageProcessor
 
doExecuteQuery(DbConnection, Query) - Method in class org.mule.module.db.internal.processor.ExecuteDdlMessageProcessor
 
doExecuteQuery(DbConnection, Query) - Method in class org.mule.module.db.internal.processor.SelectMessageProcessor
 
doExecuteQuery(DbConnection, Query) - Method in class org.mule.module.db.internal.processor.StoredProcedureMessageProcessor
 
doExecuteQuery(DbConnection, Query) - Method in class org.mule.module.db.internal.processor.UpdateMessageProcessor
 
doExecution(DefaultExecutor, CommandLine, Map<Object, Object>) - Method in class org.mule.test.infrastructure.process.Controller
 
doFilter(MuleEvent) - Method in interface org.mule.api.security.SecurityFilter
 
doFilter(MuleEvent) - Method in class org.mule.module.spring.security.AuthorizationFilter
 
doFilter(MuleEvent) - Method in class org.mule.security.AbstractAuthenticationFilter
 
doFilter(MuleEvent) - Method in class org.mule.security.AbstractEndpointSecurityFilter
Deprecated.
 
doFilter(MuleEvent) - Method in class org.mule.security.AbstractSecurityFilter
 
doFooter(MuleContext) - Method in class org.mule.module.launcher.MuleContainerStartupSplashScreen
 
doFooter(MuleContext) - Method in class org.mule.util.ApplicationStartupSplashScreen
 
doFooter(MuleContext) - Method in class org.mule.util.ServerStartupSplashScreen
 
doFooter(MuleContext) - Method in class org.mule.util.SplashScreen
 
doForceStop() - Method in class org.mule.service.AbstractService
Deprecated.
 
doGet(String) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.JarResourceServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleRESTReceiverServlet
 
doGet(MuleEventContext, AxisStringWriter) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
doGetArtifact(Element, XmlConfigurationCallback, boolean) - Method in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
doGetObject() - Method in class org.mule.config.spring.factories.AbstractEndpointFactoryBean
 
doGetObject() - Method in class org.mule.config.spring.factories.InboundEndpointFactoryBean
 
doGetObject() - Method in class org.mule.config.spring.factories.OutboundEndpointFactoryBean
 
doGetObject() - Method in class org.mule.config.spring.factories.PollInboundEndpointFactoryBean
 
doGetObject() - Method in class org.mule.config.spring.factories.PollingMessageSourceFactoryBean
 
doHandleException(Exception, MuleEvent) - Method in class org.mule.exception.AbstractMessagingExceptionStrategy
 
doHandleException(Exception, MuleEvent) - Method in class org.mule.module.cxf.CxfComponentExceptionStrategy
Deprecated.
 
doHandleException(Exception, MuleEvent) - Method in class org.mule.tck.functional.QuietExceptionStrategy
 
doHandshake(MuleEventContext) - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
doHead(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
doHeader(MuleContext) - Method in class org.mule.util.ApplicationShutdownSplashScreen
 
doHeader(MuleContext) - Method in class org.mule.util.ApplicationStartupSplashScreen
 
doHeader(MuleContext) - Method in class org.mule.util.ServerShutdownSplashScreen
 
doHeader(MuleContext) - Method in class org.mule.util.ServerStartupSplashScreen
 
doHeader(MuleContext) - Method in class org.mule.util.SplashScreen
 
doInit() - Method in class org.mule.transport.servlet.AbstractReceiverServlet
 
doInit() - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
doInitialise() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
doInitialise() - Method in class org.mule.agent.EndpointNotificationLoggerAgent
 
doInitialise() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
doInitialise() - Method in class org.mule.component.AbstractComponent
 
doInitialise() - Method in class org.mule.component.AbstractJavaComponent
 
doInitialise() - Method in class org.mule.component.DefaultJavaComponent
 
doInitialise() - Method in class org.mule.config.spring.SpringRegistry
 
doInitialise() - Method in class org.mule.construct.AbstractFlowConstruct
 
doInitialise() - Method in class org.mule.construct.AbstractPipeline
 
doInitialise() - Method in class org.mule.construct.Flow
 
doInitialise() - Method in class org.mule.construct.Validator
 
doInitialise() - Method in class org.mule.endpoint.dynamic.NullConnector
 
doInitialise(MuleContext) - Method in class org.mule.exception.AbstractExceptionListener
 
doInitialise(MuleContext) - Method in class org.mule.exception.RollbackMessagingExceptionStrategy
 
doInitialise(MuleContext) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
doInitialise() - Method in class org.mule.model.seda.SedaService
Deprecated.
Initialise the service.
doInitialise() - Method in class org.mule.module.bpm.ProcessComponent
 
doInitialise() - Method in class org.mule.module.bpm.RulesComponent
 
doInitialise() - Method in class org.mule.module.cxf.component.AbstractWebServiceWrapperComponent
 
doInitialise() - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
doInitialise() - Method in class org.mule.module.jaas.filters.JaasSecurityFilter
 
doInitialise() - Method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider
The initialise method checks whether a jaas configuration file exists.
doInitialise() - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
doInitialise() - Method in class org.mule.module.management.agent.JmxServerNotificationAgent
 
doInitialise() - Method in class org.mule.module.pgp.filters.PGPSecurityFilter
 
doInitialise() - Method in class org.mule.module.pgp.PGPSecurityProvider
 
doInitialise() - Method in class org.mule.module.scripting.component.ScriptComponent
 
doInitialise() - Method in class org.mule.module.spring.security.SpringProviderAdapter
 
doInitialise() - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
doInitialise() - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
doInitialise() - Method in class org.mule.module.xml.transformer.XsltTransformer
 
doInitialise() - Method in class org.mule.registry.AbstractRegistry
 
doInitialise() - Method in class org.mule.registry.SimpleRegistry
 
doInitialise() - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
doInitialise() - Method in class org.mule.security.AbstractSecurityFilter
 
doInitialise() - Method in class org.mule.security.AbstractSecurityProvider
 
doInitialise() - Method in class org.mule.security.filters.MuleEncryptionEndpointSecurityFilter
 
doInitialise() - Method in class org.mule.service.AbstractService
Deprecated.
 
doInitialise() - Method in class org.mule.tck.security.TestMultiuserSecurityProvider
 
doInitialise() - Method in class org.mule.transport.AbstractConnector
 
doInitialise() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
doInitialise() - Method in class org.mule.transport.ajax.AjaxMessageDispatcher
 
doInitialise() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
doInitialise() - Method in class org.mule.transport.email.AbstractMailConnector
 
doInitialise() - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
doInitialise() - Method in class org.mule.transport.email.SmtpsConnector
 
doInitialise() - Method in class org.mule.transport.file.FileConnector
 
doInitialise() - Method in class org.mule.transport.file.FileMessageReceiver
 
doInitialise() - Method in class org.mule.transport.ftp.FtpConnector
 
doInitialise() - Method in class org.mule.transport.ftp.FtpMessageReceiver
 
doInitialise() - Method in class org.mule.transport.http.components.RestServiceWrapper
 
doInitialise() - Method in class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
 
doInitialise() - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
doInitialise() - Method in class org.mule.transport.http.HttpConnector
 
doInitialise() - Method in class org.mule.transport.http.HttpsConnector
 
doInitialise() - Method in class org.mule.transport.jdbc.JdbcConnector
 
doInitialise() - Method in class org.mule.transport.jms.JmsConnector
 
doInitialise() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
doInitialise() - Method in class org.mule.transport.multicast.MulticastConnector
 
doInitialise() - Method in class org.mule.transport.polling.MessageProcessorPollingConnector
 
doInitialise() - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
On the Initialization phase it.
doInitialise() - Method in class org.mule.transport.quartz.QuartzConnector
 
doInitialise() - Method in class org.mule.transport.rmi.RmiConnector
 
doInitialise() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
doInitialise() - Method in class org.mule.transport.servlet.jetty.JettyHttpMessageReceiver
 
doInitialise() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
doInitialise() - Method in class org.mule.transport.servlet.ServletConnector
 
doInitialise() - Method in class org.mule.transport.sftp.SftpConnector
 
doInitialise() - Method in class org.mule.transport.sftp.SftpMessageReceiver
 
doInitialise() - Method in class org.mule.transport.soap.axis.AxisConnector
 
doInitialise() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
doInitialise() - Method in class org.mule.transport.tcp.TcpConnector
 
doInitialise() - Method in class org.mule.transport.udp.UdpConnector
 
doInitialise() - Method in class org.mule.transport.UnsupportedMessageDispatcher
 
doInitialise() - Method in class org.mule.transport.UnsupportedMessageRequester
 
doInitialise() - Method in class org.mule.transport.vm.VMConnector
 
doInitialise() - Method in class org.mule.transport.xmpp.XmppConnector
 
doInTransaction() - Method in interface org.mule.api.transaction.TransactionCallback
 
doInvoke(MuleEvent) - Method in class org.mule.component.AbstractComponent
 
doInvoke(MuleEvent) - Method in class org.mule.component.AbstractJavaComponent
 
doInvoke(MuleEvent) - Method in class org.mule.component.simple.PassThroughComponent
Deprecated.
 
doInvoke(MuleEvent) - Method in class org.mule.module.bpm.ProcessComponent
 
doInvoke(MuleEvent) - Method in class org.mule.module.bpm.RulesComponent
 
doInvoke(MuleEvent) - Method in class org.mule.module.cxf.component.WebServiceWrapperComponent
Deprecated.
 
doInvoke(MuleEvent) - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
doInvoke(MuleEvent) - Method in class org.mule.module.scripting.component.ScriptComponent
 
doInvoke(MuleEvent) - Method in class org.mule.transport.http.components.RestServiceWrapper
 
doInvoke(MuleEvent) - Method in class org.mule.transport.soap.axis.component.WebServiceWrapperComponent
 
doLoad(QueueInfo, Serializable) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
doLogException(Throwable) - Method in class org.mule.exception.AbstractExceptionListener
 
doLogException(Throwable) - Method in class org.mule.tck.functional.QuietExceptionStrategy
 
Domain - Interface in org.mule.module.launcher.domain
A domain is a deployable Artifact that contains shared resources for Application

A domain can just consist of a set of jar libraries to share between the domain applications or it can also contain shared resources such as connectors or other mule components.

DOMAIN_BUNDLE_APPS_FOLDER - Static variable in class org.mule.module.launcher.DomainArchiveDeployer
 
DOMAIN_CONFIG_FILE_LOCATION - Static variable in interface org.mule.module.launcher.domain.Domain
Domain configuration file name
DOMAIN_LIBRARY_FOLDER - Static variable in class org.mule.module.launcher.MuleSharedDomainClassLoader
 
DOMAIN_ROOT_ELEMENT - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
DomainArchiveDeployer - Class in org.mule.module.launcher
Archive deployer for domains.
DomainArchiveDeployer(ArchiveDeployer<Domain>, ArchiveDeployer<Application>, DeploymentService) - Constructor for class org.mule.module.launcher.DomainArchiveDeployer
 
DomainClassLoaderRepository - Interface in org.mule.module.launcher.domain
Repository for domain class loaders.
domainContext - Variable in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
DomainContextBuilder - Class in org.mule.tck.junit4
 
DomainContextBuilder() - Constructor for class org.mule.tck.junit4.DomainContextBuilder
 
DomainDeploymentListenerManager - Interface in org.mule.module.launcher
Manages which DeploymentListener are listening for domain deployment notifications.
DomainDeploymentTemplate - Class in org.mule.module.launcher
Utility to hook callbacks just before and after a domain zip is redeployed in Mule.
DomainDeploymentTemplate(DefaultArchiveDeployer<Application>, DeploymentService) - Constructor for class org.mule.module.launcher.DomainDeploymentTemplate
 
DomainDescriptor - Class in org.mule.module.launcher.descriptor
Represents the description of a domain.
DomainDescriptor() - Constructor for class org.mule.module.launcher.descriptor.DomainDescriptor
 
DomainDescriptorParser - Class in org.mule.module.launcher.descriptor
Descriptor parser exclusive for domains.
DomainDescriptorParser() - Constructor for class org.mule.module.launcher.descriptor.DomainDescriptorParser
 
DomainElementsValidator - Class in org.mule.config.spring.parsers.specific
A PreProcessor that validates that no mule element is used inside a <spring:beans> element.
DomainElementsValidator() - Constructor for class org.mule.config.spring.parsers.specific.DomainElementsValidator
 
DomainFactory - Interface in org.mule.module.launcher.domain
Factory for Domain artifact creation
DomainFunctionalTestCase - Class in org.mule.tck.junit4
 
DomainFunctionalTestCase() - Constructor for class org.mule.tck.junit4.DomainFunctionalTestCase
 
DomainFunctionalTestCase.ApplicationConfig - Class in org.mule.tck.junit4
 
DomainFunctionalTestCase.ApplicationConfig(String, String[]) - Constructor for class org.mule.tck.junit4.DomainFunctionalTestCase.ApplicationConfig
 
DomainMuleContextAwareConfigurationBuilder - Interface in org.mule.api.config
Configuration builders that implements this interface will receive a reference to the context of the domain they belong to.
DomainMuleContextBuilder - Class in org.mule.module.launcher.domain
Builder for domain MuleContext instance.
DomainMuleContextBuilder(String) - Constructor for class org.mule.module.launcher.domain.DomainMuleContextBuilder
 
DOMAINS_FOLDER - Static variable in class org.mule.module.launcher.MuleFoldersUtil
 
domainsDir - Variable in class org.mule.test.infrastructure.process.Controller
 
DomainStartedSplashScreen - Class in org.mule.module.launcher.domain
Splash screen specific for Domain startup.
DomainStartedSplashScreen() - Constructor for class org.mule.module.launcher.domain.DomainStartedSplashScreen
 
DomainWrapper - Class in org.mule.module.launcher.domain
Domain wrapper used to notify domain factory that a domain has been disposed or started.
DomainWrapper(Domain, DefaultDomainFactory) - Constructor for class org.mule.module.launcher.domain.DomainWrapper
 
DomDocumentToXml - Class in org.mule.module.xml.transformer
DomDocumentToXml Transform a org.w3c.dom.Document to XML String
DomDocumentToXml() - Constructor for class org.mule.module.xml.transformer.DomDocumentToXml
 
domToString(Element) - Method in class org.mule.module.xml.config.XsltTextDefinitionParser
 
domTypeNotSupported(Class) - Static method in class org.mule.module.xml.i18n.XmlMessages
 
DONT_BREAK_LINES - Static variable in class org.mule.util.Base64
Don't break lines when encoding (violates strict Base64 specification)
doOnConnectException(ConnectException) - Method in class org.mule.lifecycle.MuleContextLifecycleManager
 
doOnConnectException(ConnectException) - Method in class org.mule.lifecycle.RegistryLifecycleManager
 
doOptions(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
doOtherValid(RequestLine, String) - Method in class org.mule.transport.http.OldHttpMessageReceiver.HttpWorker
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.AbstractChildDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
Parse the supplied Element and populate the supplied BeanDefinitionBuilder as required.
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.collection.OrphanMapDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.ConfigurationDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.FlowDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.ServiceDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.SimpleServiceDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.domain.param.InOutParamDefinitionDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.domain.param.InputParamDefinitionDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.domain.param.InputParamValueBeanDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.domain.param.OutputParamDefinitionDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.domain.query.QueryTemplateBeanDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.SingleUpdateProcessorDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.StoredProcedureProcessorBeanDefinitionParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.xml.config.NamespaceManagerDefinitionParser
Parse the supplied Element and populate the supplied BeanDefinitionBuilder as required.
doParseElement(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
doParseElement(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.AbstractResultSetHandlerProcessorDefinitionParser
 
doParseElement(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.AbstractSingleQueryProcessorDefinitionParser
 
doParseElement(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.BulkExecuteProcessorBeanDefinitionParser
 
doParseElement(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.PreparedBulkUpdateProcessorBeanDefinitionParser
 
doPause() - Method in class org.mule.model.seda.SedaService
Deprecated.
 
doPause() - Method in class org.mule.service.AbstractService
Deprecated.
Custom components can execute code necessary to put the service in a paused state here.
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleRESTReceiverServlet
 
doPost(MuleEventContext, AxisStringWriter) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
doPrepare(AbstractTransactionContext) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
doPrepare(AbstractTransactionContext) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
doPrepare() - Method in class org.mule.util.queue.PersistentXaTransactionContext
 
doPrepare(AbstractXaTransactionContext) - Method in class org.mule.util.queue.QueueXaResourceManager
 
doPrepare() - Method in class org.mule.util.queue.TransientXaTransactionAdapter
 
doPrepare() - Method in interface org.mule.util.queue.XaQueueTransactionContext
Prepares the current transaction context for a commit
doPrepare() - Method in class org.mule.util.queue.XaQueueTypeTransactionContextAdapter
 
doPrepare(T) - Method in class org.mule.util.xa.AbstractXAResourceManager
 
doPrepare() - Method in class org.mule.util.xa.AbstractXaTransactionContext
Two phase commit prepare phase
doProcess(MuleEvent) - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
Implementors of this class need to implement this method in order to perform actual processing
doProcess(MuleEvent) - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
doProcess(MuleEvent) - Method in class org.mule.processor.chain.DefaultMessageProcessorChain
 
doProcess(MuleEvent) - Method in class org.mule.processor.chain.InterceptingChainLifecycleWrapper
 
doProcess(MuleEvent) - Method in class org.mule.processor.chain.SimpleMessageProcessorChain
 
doProcess(MuleEvent) - Method in class org.mule.routing.Foreach
 
doProcess(MuleEvent) - Method in class org.mule.security.oauth.processor.AbstractListeningMessageProcessor
Not valid for this class or its extensions
doProcess(MuleEvent) - Method in class org.mule.security.oauth.processor.BaseOAuth1AuthorizeMessageProcessor
Starts the OAuth authorization process
doProcess(MuleEvent) - Method in class org.mule.security.oauth.processor.BaseOAuth1UnauthorizeMessageProcessor
Unauthorize the connector
doProcess(MuleEvent) - Method in class org.mule.security.oauth.processor.BaseOAuth2AuthorizeMessageProcessor
Starts the OAuth authorization process
doProcess(MuleEvent) - Method in class org.mule.security.oauth.processor.BaseOAuth2UnauthorizeMessageProcessor
Unauthorize the connector
doProcess(MuleEvent) - Method in class org.mule.security.oauth.processor.OAuth1FetchAccessTokenMessageProcessor
Implementors of this class need to implement this method in order to perform actual processing
doProcess(MuleEvent) - Method in class org.mule.security.oauth.processor.OAuth2FetchAccessTokenMessageProcessor
Implementors of this class need to implement this method in order to perform actual processing
doProcess(MuleEvent) - Method in class org.mule.streaming.processor.AbstractDevkitBasedPageableMessageProcessor
This method sets the message payload to an instance of ConsumerIterator configured accordingly to the configured outputUnit and the PagingDelegate obtained by invoking AbstractDevkitBasedPageableMessageProcessor.getPagingDelegate(org.mule.api.MuleEvent, org.mule.streaming.PagingConfiguration)
doProcessOutputParam(OutputQueryParam, Object) - Method in class org.mule.module.db.internal.result.statement.StatementResultIterator
 
doProcessParameters(PreparedStatement, QueryTemplate, List<QueryParamValue>, SingleQueryLogger) - Method in class org.mule.module.db.internal.domain.executor.AbstractExecutor
 
doProcessResultSet(String, ResultSet) - Method in class org.mule.module.db.internal.result.statement.StatementResultIterator
 
doProcessRoute(MessageProcessor, MuleEvent) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
doProcessUpdateCount(String, int) - Method in class org.mule.module.db.internal.result.statement.StatementResultIterator
 
doPropagate(MuleMessage, TypedValue, ASTNode) - Method in class org.mule.el.mvel.datatype.AbstractEnricherDataTypePropagator
 
doPropagate(MuleMessage, TypedValue, ASTNode) - Method in class org.mule.el.mvel.datatype.AbstractVariableEnricherDataTypePropagator
 
doPropagate(MuleMessage, TypedValue, ASTNode) - Method in class org.mule.el.mvel.datatype.PayloadEnricherDataTypePropagator
 
doPropagate(MuleMessage, TypedValue, ASTNode) - Method in class org.mule.el.mvel.datatype.PropertyEnricherDataTypePropagator
 
doPut(String, Object) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
doPut(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
doPut(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleRESTReceiverServlet
 
doRefreshToken(MuleEvent, ResourceOwnerOAuthContext) - Method in class org.mule.module.oauth2.internal.authorizationcode.AbstractAuthorizationCodeTokenRequestHandler
ThreadSafe refresh token operation to be implemented by subclasses
doRefreshToken(MuleEvent, ResourceOwnerOAuthContext) - Method in class org.mule.module.oauth2.internal.authorizationcode.AutoAuthorizationCodeTokenRequestHandler
Executes a refresh token for a particular user.
doRegisterObject(String, String, boolean) - Method in class org.mule.config.bootstrap.AbstractRegistryBootstrap
 
doRegisterObject(String, String, boolean) - Method in class org.mule.config.bootstrap.SimpleRegistryBootstrap
Deprecated.
 
doRegisterObject(String, String, boolean) - Method in class org.mule.config.spring.SpringRegistryBootstrap
 
doRegisterObject(String, Object, Object) - Method in class org.mule.registry.SimpleRegistry
 
doRegisterObject(String, Object, Object) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
doRegisterTransformer(String, Class<?>, Class<? extends Transformer>, String, boolean) - Method in class org.mule.config.bootstrap.AbstractRegistryBootstrap
 
doRegisterTransformer(String, Class<?>, Class<? extends Transformer>, String, boolean) - Method in class org.mule.config.bootstrap.SimpleRegistryBootstrap
Deprecated.
 
doRegisterTransformer(String, Class<?>, Class<? extends Transformer>, String, boolean) - Method in class org.mule.config.spring.SpringRegistryBootstrap
 
doRemove(QueueInfo, Serializable) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
doRemove(Serializable) - Method in class org.mule.util.store.AbstractObjectStore
 
doRemove(Serializable) - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
doRemove(Serializable) - Method in class org.mule.util.store.SimpleMemoryObjectStore
 
doRequest(long) - Method in class org.mule.transport.AbstractMessageRequester
Make a specific request to the underlying transport
doRequest(long) - Method in class org.mule.transport.email.RetrieveMessageRequester
Make a specific request to the underlying transport.
doRequest(long) - Method in class org.mule.transport.file.FileMessageRequester
Will attempt to do a receive from a directory, if the endpointUri resolves to a file name the file will be returned, otherwise the first file in the directory according to the filename filter configured on the connector.
doRequest(long) - Method in class org.mule.transport.ftp.FtpMessageRequester
Make a specific request to the underlying transport
doRequest(long) - Method in class org.mule.transport.http.HttpClientMessageRequester
Make a specific request to the underlying transport
doRequest(HttpRequest) - Method in class org.mule.transport.http.OldHttpMessageReceiver.HttpWorker
 
doRequest(long) - Method in class org.mule.transport.jdbc.JdbcMessageRequester
Make a specific request to the underlying transport
doRequest(long, MuleEvent) - Method in class org.mule.transport.jdbc.JdbcMessageRequester
Make a specific request to the underlying transport Special case: The event is need when doReceive was called from doSend
doRequest(long) - Method in class org.mule.transport.jms.JmsMessageRequester
Make a specific request to the underlying transport
doRequest(long) - Method in class org.mule.transport.sftp.SftpMessageRequester
 
doRequest(long) - Method in class org.mule.transport.soap.axis.AxisMessageRequester
Make a specific request to the underlying transport
doRequest(long) - Method in class org.mule.transport.tcp.TcpMessageRequester
Make a specific request to the underlying transport
doRequest(long) - Method in class org.mule.transport.udp.UdpMessageRequester
Make a specific request to the underlying transport
doRequest(long) - Method in class org.mule.transport.UnsupportedMessageRequester
 
doRequest(long) - Method in class org.mule.transport.vm.VMMessageRequester
Make a specific request to the underlying transport
doRequest(long) - Method in class org.mule.transport.xmpp.XmppMessageRequester
 
doResolveDependency(DependencyDescriptor, String, Set<String>, TypeConverter) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
doResume() - Method in class org.mule.model.seda.SedaService
Deprecated.
 
doResume() - Method in class org.mule.service.AbstractService
Deprecated.
Custom components can execute code necessary to resume a service once it has been paused If a developer overloads this method the doPause() method MUST also be overloaded to avoid inconsistent state in the service
doRetrieve(Serializable) - Method in class org.mule.util.store.AbstractObjectStore
 
doRetrieve(Serializable) - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
doRetrieve(Serializable) - Method in class org.mule.util.store.SimpleMemoryObjectStore
 
doRollback() - Method in class org.mule.module.db.internal.domain.transaction.DbTransaction
 
doRollback() - Method in class org.mule.module.spring.transaction.SpringTransactionFactory.SpringTransaction
 
doRollback() - Method in class org.mule.processor.DelegateTransaction
 
doRollback() - Method in class org.mule.transaction.AbstractTransaction
Rollback the transaction on the underlying resource
doRollback() - Method in class org.mule.transaction.XaTransaction
 
doRollback() - Method in class org.mule.transport.jdbc.JdbcTransaction
 
doRollback() - Method in class org.mule.transport.jms.JmsClientAcknowledgeTransaction
 
doRollback() - Method in class org.mule.transport.jms.JmsTransaction
 
doRollback() - Method in class org.mule.transport.vm.VMTransaction
 
doRollback() - Method in interface org.mule.util.queue.LocalQueueTransactionContext
Rollbacks the current transaction context operations
doRollback() - Method in class org.mule.util.queue.LocalTxQueueTransactionContext
 
doRollback() - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
doRollback(AbstractTransactionContext) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
doRollback(AbstractTransactionContext) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
doRollback() - Method in class org.mule.util.queue.objectstore.xa.AbstractTransactionContext
Deprecated.
 
doRollback() - Method in class org.mule.util.queue.PersistentQueueTransactionContext
 
doRollback() - Method in class org.mule.util.queue.PersistentXaTransactionContext
 
doRollback(AbstractTransactionContext) - Method in class org.mule.util.queue.QueueXaResourceManager
 
doRollback() - Method in class org.mule.util.queue.TransientQueueTransactionContext
 
doRollback() - Method in class org.mule.util.queue.TransientXaTransactionAdapter
 
doRollback() - Method in interface org.mule.util.queue.XaQueueTransactionContext
Rollbacks the current transaction context operations
doRollback() - Method in class org.mule.util.queue.XaQueueTypeTransactionContextAdapter
 
doRollback(AbstractTransactionContext) - Method in class org.mule.util.xa.AbstractResourceManager
 
doRollback() - Method in class org.mule.util.xa.AbstractTransactionContext
 
doRoute(MuleEvent) - Method in class org.mule.routing.AbstractUntilSuccessfulProcessingStrategy
 
doRoute(MuleEvent) - Method in class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
 
doRoute(MuleEvent) - Method in class org.mule.routing.SynchronousUntilSuccessfulProcessingStrategy
 
doRun() - Method in class org.mule.routing.EventProcessingThread
Detect and process events
doRun() - Method in class org.mule.tck.concurrency.TestingThread
 
doRun() - Method in class org.mule.transport.AbstractReceiverResourceWorker
 
doRun() - Method in class org.mule.transport.AbstractReceiverWorker
 
doRun() - Method in class org.mule.work.AbstractMuleEventWork
 
doRun() - Method in class org.mule.work.ProcessingMuleEventWork
doSend(MuleEvent) - Method in class org.mule.transport.AbstractMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.ajax.AjaxMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.email.RetrieveMessageRequester
 
doSend(MuleEvent) - Method in class org.mule.transport.email.SmtpMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.file.FileMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.ftp.FtpMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.jdbc.JdbcMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.quartz.QuartzMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.rmi.RmiMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.sftp.SftpMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.stdio.StdioMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.tcp.LocalSocketTcpMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.tcp.TcpMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.udp.UdpMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.UnsupportedMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.vm.VMMessageDispatcher
 
doSend(MuleEvent) - Method in class org.mule.transport.xmpp.XmppMessageDispatcher
 
doSendNonBlocking(MuleEvent, CompletionHandler<MuleMessage, Exception>) - Method in class org.mule.transport.AbstractMessageDispatcher
 
doSendNonBlocking(MuleEvent, CompletionHandler<MuleMessage, Exception>) - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
doSendWithClient(MuleEvent) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
doSendWithProxy(MuleEvent) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
doSerialize(Object) - Method in class org.mule.serialization.internal.AbstractObjectSerializer
Serializes the given object.
doSerialize(Object) - Method in class org.mule.serialization.internal.JavaObjectSerializer
Serializes the given object.
doSetUp() - Method in class org.mule.tck.AbstractServiceAndFlowTestCase
Deprecated.
 
doSetUp() - Method in class org.mule.tck.DynamicPortTestCase
Deprecated.
 
doSetUpBeforeMuleContextCreation() - Method in class org.mule.tck.junit4.ExtensionsFunctionalTestCase
Performs all the logic inherited from the super class, plus invokes ExtensionsFunctionalTestCase.createExtensionsManager()
doSetUpForFlow() - Method in class org.mule.tck.AbstractServiceAndFlowTestCase
Deprecated.
 
doSetUpForService() - Method in class org.mule.tck.AbstractServiceAndFlowTestCase
Deprecated.
 
doShutdown() - Method in class org.mule.module.launcher.MuleContainer
 
doShutdown() - Method in class org.mule.MuleServer
 
doSingleBean(int, MuleDefinitionParser, Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.AbstractFirstResultSerialDefinitionParser
 
doSingleBean(int, MuleDefinitionParser, Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
doSingleBean(int, MuleDefinitionParser, Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.AbstractSingleParentFamilyDefinitionParser
 
doStart() - Method in class org.mule.component.AbstractComponent
 
doStart() - Method in class org.mule.component.AbstractJavaComponent
 
doStart() - Method in class org.mule.component.DefaultJavaComponent
 
doStart() - Method in class org.mule.component.PooledJavaComponent
 
doStart() - Method in class org.mule.component.SimpleCallableJavaComponent
 
doStart() - Method in class org.mule.construct.AbstractFlowConstruct
 
doStart() - Method in class org.mule.construct.AbstractPipeline
 
doStart() - Method in class org.mule.construct.Flow
 
doStart() - Method in class org.mule.endpoint.dynamic.NullConnector
 
doStart() - Method in class org.mule.module.tomcat.MuleTomcatListener
 
doStart() - Method in class org.mule.service.AbstractService
Deprecated.
 
doStart() - Method in class org.mule.transport.AbstractConnector
Template method to perform any work when starting the connectoe
doStart() - Method in class org.mule.transport.AbstractPollingMessageReceiver
 
doStart() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
doStart() - Method in class org.mule.transport.ajax.AjaxMessageReceiver
 
doStart() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
doStart() - Method in class org.mule.transport.email.AbstractMailConnector
 
doStart() - Method in class org.mule.transport.email.RetrieveMessageReceiver
 
doStart() - Method in class org.mule.transport.file.FileConnector
 
doStart() - Method in class org.mule.transport.ftp.FtpConnector
 
doStart() - Method in class org.mule.transport.http.HttpConnector
 
doStart() - Method in class org.mule.transport.jdbc.JdbcConnector
 
doStart() - Method in class org.mule.transport.jms.JmsConnector
 
doStart() - Method in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
doStart() - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver
 
doStart() - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.SubReceiver
 
doStart() - Method in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
doStart() - Method in class org.mule.transport.polling.MessageProcessorPollingConnector
 
doStart() - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
 
doStart() - Method in class org.mule.transport.quartz.QuartzConnector
 
doStart() - Method in class org.mule.transport.quartz.QuartzMessageReceiver
 
doStart() - Method in class org.mule.transport.rmi.RmiCallbackMessageReceiver
 
doStart() - Method in class org.mule.transport.rmi.RmiConnector
 
doStart() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
doStart() - Method in class org.mule.transport.servlet.ServletConnector
 
doStart() - Method in class org.mule.transport.servlet.ServletMessageReceiver
 
doStart() - Method in class org.mule.transport.sftp.SftpConnector
 
doStart() - Method in class org.mule.transport.soap.axis.AxisConnector
Template method to perform any work when starting the connectoe
doStart() - Method in class org.mule.transport.soap.axis.AxisMessageReceiver
 
doStart() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
doStart() - Method in class org.mule.transport.stdio.StdioConnector
 
doStart() - Method in class org.mule.transport.tcp.TcpConnector
 
doStart() - Method in class org.mule.transport.tcp.TcpMessageReceiver
 
doStart() - Method in class org.mule.transport.TransactedPollingMessageReceiver
 
doStart() - Method in class org.mule.transport.udp.UdpConnector
 
doStart() - Method in class org.mule.transport.udp.UdpMessageReceiver
 
doStart() - Method in class org.mule.transport.UnsupportedMessageDispatcher
 
doStart() - Method in class org.mule.transport.UnsupportedMessageRequester
 
doStart() - Method in class org.mule.transport.vm.VMConnector
 
doStart() - Method in class org.mule.transport.xmpp.XmppConnector
 
doStart() - Method in class org.mule.transport.xmpp.XmppMessageReceiver
 
doStart() - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
doStart() - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
doStart() - Method in class org.mule.util.xa.AbstractResourceManager
 
doStartHandler() - Method in class org.mule.transport.AbstractMessageReceiver
 
doStartHandler() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
doStop() - Method in class org.mule.component.AbstractComponent
 
doStop() - Method in class org.mule.component.DefaultJavaComponent
 
doStop() - Method in class org.mule.component.PooledJavaComponent
 
doStop() - Method in class org.mule.component.SimpleCallableJavaComponent
 
doStop() - Method in class org.mule.construct.AbstractFlowConstruct
 
doStop() - Method in class org.mule.construct.AbstractPipeline
 
doStop() - Method in class org.mule.construct.Flow
 
doStop() - Method in class org.mule.endpoint.dynamic.NullConnector
 
doStop() - Method in class org.mule.module.tomcat.MuleTomcatListener
 
doStop() - Method in class org.mule.service.AbstractService
Deprecated.
 
doStop() - Method in class org.mule.transport.AbstractConnector
Template method to perform any work when stopping the connectoe
doStop() - Method in class org.mule.transport.AbstractMessageReceiver
 
doStop() - Method in class org.mule.transport.AbstractPollingMessageReceiver
 
doStop() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
doStop() - Method in class org.mule.transport.email.AbstractMailConnector
 
doStop() - Method in class org.mule.transport.email.RetrieveMessageReceiver
 
doStop() - Method in class org.mule.transport.file.FileConnector
 
doStop() - Method in class org.mule.transport.ftp.FtpConnector
 
doStop() - Method in class org.mule.transport.http.HttpConnector
 
doStop() - Method in class org.mule.transport.jdbc.JdbcConnector
 
doStop() - Method in class org.mule.transport.jms.JmsConnector
 
doStop() - Method in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
doStop() - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver
 
doStop(boolean) - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.SubReceiver
Stop the subreceiver.
doStop() - Method in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
doStop() - Method in class org.mule.transport.polling.MessageProcessorPollingConnector
 
doStop() - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
 
doStop() - Method in class org.mule.transport.quartz.QuartzConnector
 
doStop() - Method in class org.mule.transport.quartz.QuartzMessageReceiver
 
doStop() - Method in class org.mule.transport.rmi.RmiConnector
 
doStop() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
doStop() - Method in class org.mule.transport.servlet.ServletConnector
 
doStop() - Method in class org.mule.transport.sftp.SftpConnector
 
doStop() - Method in class org.mule.transport.soap.axis.AxisConnector
Template method to perform any work when stopping the connectoe
doStop() - Method in class org.mule.transport.soap.axis.AxisMessageReceiver
 
doStop() - Method in class org.mule.transport.stdio.StdioConnector
 
doStop() - Method in class org.mule.transport.tcp.TcpConnector
 
doStop() - Method in class org.mule.transport.tcp.TcpMessageReceiver
 
doStop() - Method in class org.mule.transport.udp.UdpConnector
 
doStop() - Method in class org.mule.transport.UnsupportedMessageDispatcher
 
doStop() - Method in class org.mule.transport.UnsupportedMessageRequester
 
doStop() - Method in class org.mule.transport.vm.VMConnector
 
doStop() - Method in class org.mule.transport.xmpp.XmppConnector
 
doStop() - Method in class org.mule.transport.xmpp.XmppMessageReceiver
 
doStore(QueueInfo, Serializable) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
doStore(Serializable, T) - Method in class org.mule.util.store.AbstractObjectStore
 
doStore(Serializable, T) - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
doStore(Serializable, T) - Method in class org.mule.util.store.SimpleMemoryObjectStore
 
doTearDown() - Method in class org.mule.tck.DynamicPortTestCase
Deprecated.
 
doThreading - Variable in class org.mule.processor.AsyncInterceptingMessageProcessor
 
doToRemote(String, Object, Map, boolean, int) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
doToRemoteComponent(String, Object, Map, boolean) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
doTrace(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
doTransform(Object, String) - Method in class org.mule.module.atom.transformers.BaseToOutputHandler
 
doTransform(Object, String) - Method in class org.mule.module.atom.transformers.ObjectToFeed
 
doTransform(Object, String) - Method in class org.mule.module.json.transformers.JsonToXml
Use Staxon to convert JSON to an XML string
doTransform(Object, String) - Method in class org.mule.module.json.transformers.XmlToJson
Use Staxon to convert XML to a JSON string
doTransform(Object, String) - Method in class org.mule.module.rss.transformers.ObjectToRssFeed
 
doTransform(Object, String) - Method in class org.mule.module.spring.remoting.ObjectToRemoteInvocationResultTransformer
 
doTransform(Object, String) - Method in class org.mule.module.spring.remoting.ObjectToRemoteInvocationTransformer
 
doTransform(Object, String) - Method in class org.mule.module.xml.transformer.jaxb.JAXBMarshallerTransformer
 
doTransform(Object, String) - Method in class org.mule.module.xml.transformer.jaxb.JAXBUnmarshallerTransformer
 
doTransform(Object, String) - Method in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
Evaluate the expression in the context of the given object and returns the result.
doTransform(Object, String) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
doTransform(Object, String) - Method in class org.mule.module.xml.transformer.XPathExtractor
 
doTransform(MuleMessage, String, Source, Result) - Method in class org.mule.module.xml.transformer.XsltTransformer
 
doTransform(Object, String) - Method in class org.mule.tck.transformer.NoActionTransformer
Deprecated.
 
doTransform(Object, String) - Method in class org.mule.tck.transformer.ValidateResponse
 
doTransform(Object, String) - Method in class org.mule.transformer.AbstractMessageTransformer
Perform a non-message aware transform.
doTransform(Object, String) - Method in class org.mule.transformer.AbstractTransformer
 
doTransform(Object, String) - Method in class org.mule.transformer.codec.Base64Decoder
 
doTransform(Object, String) - Method in class org.mule.transformer.codec.Base64Encoder
 
doTransform(Object, String) - Method in class org.mule.transformer.codec.XmlEntityDecoder
 
doTransform(Object, String) - Method in class org.mule.transformer.codec.XmlEntityEncoder
 
doTransform(Object, String) - Method in class org.mule.transformer.compression.GZipCompressTransformer
 
doTransform(Object, String) - Method in class org.mule.transformer.compression.GZipUncompressTransformer
 
doTransform(Object, String) - Method in class org.mule.transformer.encryption.AbstractEncryptionTransformer
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.BeanToMap
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.ByteArrayToHexString
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.ByteArrayToObject
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.ByteArrayToSerializable
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.DataHandlerToInputStreamTransformer
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.GetBeanProperty
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.HexStringToByteArray
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.MapLookup
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.MapToBean
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.NumberToString
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.ObjectArrayToString
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.ObjectToByteArray
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.ObjectToInputStream
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.ObjectToOutputHandler
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.ObjectToString
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.PropertyEditorTextToValueTransformer
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.PropertyEditorValueToTextTransformer
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.SerializableToByteArray
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.StringAppendTransformer
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.StringToBoolean
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.StringToNumber
 
doTransform(Object, String) - Method in class org.mule.transformer.simple.StringToObjectArray
 
doTransform(MuleMessage) - Method in class org.mule.transformer.TransformerTemplate.OverwitePayloadCallback
 
doTransform(MuleMessage) - Method in interface org.mule.transformer.TransformerTemplate.TransformerCallback
 
doTransform(Object, String) - Method in class org.mule.transport.email.transformers.EmailMessageToString
 
doTransform(Object, String) - Method in class org.mule.transport.email.transformers.MimeMessageToRfc822ByteArray
 
doTransform(Object, String) - Method in class org.mule.transport.email.transformers.Rfc822ByteArraytoMimeMessage
 
doTransform(Object, String) - Method in class org.mule.transport.file.transformers.FileToByteArray
 
doTransform(Object, String) - Method in class org.mule.transport.file.transformers.FileToString
Simple implementation which relies on FileToByteArray to get a byte[] from the file beeing parsed and then transform it to a String with the correct encoding.
doTransform(MuleMessage) - Method in class org.mule.transport.http.construct.support.CopyInboundToOutboundPropertiesTransformerCallback
 
doTransform(Object, String) - Method in class org.mule.transport.http.transformers.HttpClientMethodResponseToObject
 
doTransform(Object, String) - Method in class org.mule.transport.http.transformers.HttpResponseToString
Perform the transformation to always return a String object
doTransform(Object, String) - Method in class org.mule.transport.http.transformers.ServletRequestToOutputHandler
 
doTransform(Object, String) - Method in class org.mule.transport.servlet.transformers.HttpRequestToByteArray
 
doTransform(Object, String) - Method in class org.mule.transport.servlet.transformers.HttpRequestToInputStream
 
doTransform(Object, String) - Method in class org.mule.transport.sftp.transformers.InputStreamToByteArray
 
doTrimAndExpire() - Method in class org.mule.util.store.InMemoryObjectStore
 
DOUBLE_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
DOUBLE_ERROR - Static variable in class org.mule.util.NumberUtils
 
doUnregisterListener(FlowConstruct, InboundEndpoint, MessageReceiver) - Method in class org.mule.transport.AbstractConnector
 
doUnregisterObject(String) - Method in class org.mule.config.spring.SpringRegistry
 
doUnregisterObject(String) - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
doUnregisterObject(String) - Method in class org.mule.registry.AbstractRegistry
Template method for the logic to actually unregister the key without applying any lifecycle to it.
doUnregisterObject(String) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
doWork(RetryContext) - Method in interface org.mule.api.retry.RetryCallback
 
doWork(Work) - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
doWork(Work, long, ExecutionContext, WorkListener) - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
doWork(Work) - Method in class org.mule.transport.TrackingWorkManager
 
doWork(Work, long, ExecutionContext, WorkListener) - Method in class org.mule.transport.TrackingWorkManager
 
doWork(Work) - Method in class org.mule.work.MuleWorkManager
 
doWork(Work, long, ExecutionContext, WorkListener) - Method in class org.mule.work.MuleWorkManager
 
doWork(Work) - Method in class org.mule.work.SerialWorkManager
 
doWork(Work, long, ExecutionContext, WorkListener) - Method in class org.mule.work.SerialWorkManager
 
DRIVER_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
driverClassName - Variable in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
Drools - Class in org.mule.module.drools
 
Drools() - Constructor for class org.mule.module.drools.Drools
 
DROOLS_WRAPPER_CLASS - Static variable in class org.mule.module.bpm.config.BpmNamespaceHandler
Allows simple configuration of Drools from the generic "bpm" namespace.
DroolsSessionData - Class in org.mule.module.drools
A simple data structure which contains the KnowledgeSession plus any other stateful information.
DroolsSessionData(StatefulKnowledgeSession, KnowledgeRuntimeLogger) - Constructor for class org.mule.module.drools.DroolsSessionData
 
dropRef(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
DualRandomAccessFileQueueStoreDelegate - Class in org.mule.util.queue
TransactionalQueueStoreDelegate implementation using two files for storing the queue data.
DualRandomAccessFileQueueStoreDelegate(String, String, MuleContext, int) - Constructor for class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
dumpAll() - Method in class org.mule.module.extension.internal.resources.AbstractResourcesGenerator
dumpProperties(String, Properties, boolean) - Method in class org.mule.transport.email.AbstractMailConnector
 
DUPLICATE_COLUMN_LABEL_ERROR - Static variable in class org.mule.module.db.internal.metadata.SelectMetadataProvider
 
duplicateHandling(String, String, String) - Method in class org.mule.transport.sftp.SftpClient
 
DURABLE_NAME_PROPERTY - Static variable in class org.mule.transport.jms.JmsConstants
 
DURABLE_PROPERTY - Static variable in class org.mule.transport.jms.JmsConstants
 
DYLIB_EXTENSION - Static variable in class org.mule.module.launcher.nativelib.PerAppNativeLibraryFinder
 
DYNAMIC_QUERY - Static variable in class org.mule.module.db.internal.config.domain.query.QueryDefinitionParser
 
DYNAMIC_QUERY - Static variable in class org.mule.module.db.internal.config.domain.query.QueryTemplateBeanDefinitionParser
 
DynamicAll - Class in org.mule.routing
Routes a message through a set of routes that will be obtained dynamically (per message) using a DynamicRouteResolver.
DynamicAll() - Constructor for class org.mule.routing.DynamicAll
 
DynamicAttributeDefinitionParser - Interface in org.mule.config.spring.parsers.collection
 
DynamicBulkQueryResolver - Class in org.mule.module.db.internal.resolver.query
Resolves a bulk query evaluating expression using a given event
DynamicBulkQueryResolver(String, QueryTemplateParser, ExpressionManager) - Constructor for class org.mule.module.db.internal.resolver.query.DynamicBulkQueryResolver
 
DynamicBulkUpdateMessageProcessor - Class in org.mule.module.db.internal.processor
Executes an update dynamic query in bulk mode on a database *

A dynamic update query can be update, insert or delete query or a stored procedure taking input parameters only and returning an update count.

DynamicBulkUpdateMessageProcessor(DbConfigResolver, QueryResolver, BulkQueryExecutorFactory, TransactionalAction, List<QueryType>) - Constructor for class org.mule.module.db.internal.processor.DynamicBulkUpdateMessageProcessor
 
DynamicConfigurationInstanceProvider<T> - Class in org.mule.module.extension.internal.runtime
A ConfigurationInstanceProvider which continuously evaluates the same ResolverSet and then uses the resulting ResolverSetResult to build an instance of a given type.
DynamicConfigurationInstanceProvider(ConfigurationObjectBuilder, ResolverSet) - Constructor for class org.mule.module.extension.internal.runtime.DynamicConfigurationInstanceProvider
Creates a new instance
DynamicDataTypeConversionResolver - Class in org.mule
Resolves data type conversion finding an appropriate converter that is able to execute the required transformation.
DynamicDataTypeConversionResolver(MuleContext) - Constructor for class org.mule.DynamicDataTypeConversionResolver
 
DynamicDbConfigResolver - Class in org.mule.module.db.internal.resolver.database
Resolves a DbConfig from a dynamic DataSourceConfig.
DynamicDbConfigResolver(String, DbConfigFactory, DataSourceFactory, DataSourceConfig) - Constructor for class org.mule.module.db.internal.resolver.database.DynamicDbConfigResolver
 
DynamicDbType - Class in org.mule.module.db.internal.domain.type
Defines a type that is dynamically resolved
DynamicDbType(String) - Constructor for class org.mule.module.db.internal.domain.type.DynamicDbType
 
dynamicEndpointsMustSpecifyAScheme() - Static method in class org.mule.config.i18n.CoreMessages
 
dynamicEndpointURIsCannotBeUsedOnInbound() - Static method in class org.mule.config.i18n.CoreMessages
 
DynamicFirstSuccessful - Class in org.mule.routing
Routes a message through a set of routes that will be obtained dynamically (per message) using a DynamicRouteResolver.
DynamicFirstSuccessful() - Constructor for class org.mule.routing.DynamicFirstSuccessful
 
DynamicFlowFactory - Class in org.mule.module.oauth2.internal
 
DynamicFlowFactory() - Constructor for class org.mule.module.oauth2.internal.DynamicFlowFactory
 
DynamicMessageProcessorContainer - Interface in org.mule.processor.chain
Specific case of a MessageProcessorContainer when its inner processors are dynamic (for instance, with a dynamically referenced subflow).
dynamicName - Variable in class org.mule.config.spring.parsers.collection.OrphanMapDefinitionParser
 
DynamicOutboundEndpoint - Class in org.mule.endpoint
An Outbound endpoint who's URI is a template used to created new non dynamic endpoints based on the current message.
DynamicOutboundEndpoint(EndpointBuilder, DynamicURIBuilder) - Constructor for class org.mule.endpoint.DynamicOutboundEndpoint
 
DynamicParamValueResolver - Class in org.mule.module.db.internal.resolver.param
Resolves query parameters evaluating expression using a given event
DynamicParamValueResolver(ExpressionManager) - Constructor for class org.mule.module.db.internal.resolver.param.DynamicParamValueResolver
 
DynamicPipeline - Interface in org.mule.api.processor
Adds to a pipeline the ability to dynamically inject a sequence of message processors after initialization.
dynamicPipeline(String) - Method in interface org.mule.api.processor.DynamicPipeline
Provide access to a DynamicPipelineBuilder that allows modifying the dynamic pipeline injecting message processors and resetting the pipeline
dynamicPipeline(String) - Method in class org.mule.construct.DynamicPipelineMessageProcessor
 
dynamicPipeline(String) - Method in class org.mule.construct.Flow
 
DynamicPipelineBuilder - Interface in org.mule.api.processor
Updates a dynamic pipeline by ways of injecting message processor before and after the static chain.
DynamicPipelineException - Exception in org.mule.api.processor
 
DynamicPipelineException(Message, Throwable) - Constructor for exception org.mule.api.processor.DynamicPipelineException
 
DynamicPipelineException(Message) - Constructor for exception org.mule.api.processor.DynamicPipelineException
 
DynamicPipelineException(Throwable) - Constructor for exception org.mule.api.processor.DynamicPipelineException
 
DynamicPipelineMessageProcessor - Class in org.mule.construct
Experimental implementation that supports a single dynamic pipeline due to restrictions imposed by intercepting message processors and their lifecycle.
DynamicPipelineMessageProcessor(Flow) - Constructor for class org.mule.construct.DynamicPipelineMessageProcessor
 
DynamicPortTestCase - Class in org.mule.tck
Deprecated.
DynamicPortTestCase() - Constructor for class org.mule.tck.DynamicPortTestCase
Deprecated.
 
DynamicQueryResolver - Class in org.mule.module.db.internal.resolver.query
Resolves a dynamic query evaluating expressions using a given event
DynamicQueryResolver(Query, QueryTemplateParser, ExpressionManager) - Constructor for class org.mule.module.db.internal.resolver.query.DynamicQueryResolver
 
DynamicQueryTemplateFactoryBean - Class in org.mule.module.db.internal.config.domain.query
Creates a QueryTemplate for a dynamic query
DynamicQueryTemplateFactoryBean(String) - Constructor for class org.mule.module.db.internal.config.domain.query.DynamicQueryTemplateFactoryBean
 
DynamicRoundRobin - Class in org.mule.routing
RoundRobin divides the messages it receives among its target routes in round-robin fashion.
DynamicRoundRobin() - Constructor for class org.mule.routing.DynamicRoundRobin
 
DynamicRouteResolver - Interface in org.mule.routing
SPI for dynamic route resolvers
DynamicRouteResolverAdapter - Class in org.mule.routing
 
DynamicRouteResolverAdapter(DynamicRouteResolver) - Constructor for class org.mule.routing.DynamicRouteResolverAdapter
 
DynamicRouteResolverAdapter(DynamicRouteResolver, String) - Constructor for class org.mule.routing.DynamicRouteResolverAdapter
 
DynamicURIBuilder - Class in org.mule.endpoint
Builds dynamic string URI from a template URIBuilder
DynamicURIBuilder(URIBuilder) - Constructor for class org.mule.endpoint.DynamicURIBuilder
 
DynamicURIInboundEndpoint - Class in org.mule.endpoint
Allow's EndpointURI to be set and changed dynamically by wrapping up an immutable endpoint instance.
DynamicURIInboundEndpoint(InboundEndpoint) - Constructor for class org.mule.endpoint.DynamicURIInboundEndpoint
 
DynamicURIInboundEndpoint(InboundEndpoint, EndpointURI) - Constructor for class org.mule.endpoint.DynamicURIInboundEndpoint
 
DynamicURIOutboundEndpoint - Class in org.mule.endpoint
Allows EndpointURI to be set and changed dynamically by wrapping up an immutable endpoint instance.
DynamicURIOutboundEndpoint(OutboundEndpoint) - Constructor for class org.mule.endpoint.DynamicURIOutboundEndpoint
 
DynamicURIOutboundEndpoint(OutboundEndpoint, EndpointURI) - Constructor for class org.mule.endpoint.DynamicURIOutboundEndpoint
 

E

EagerStatementResultHandler - Class in org.mule.module.db.internal.result.statement
Processes Statement eagerly fetching all results from any returned ResultSet and then closes the statement.
EagerStatementResultHandler(ResultSetHandler) - Constructor for class org.mule.module.db.internal.result.statement.EagerStatementResultHandler
 
echo(String) - Method in interface org.mule.api.component.simple.EchoService
 
echo(String) - Method in class org.mule.component.simple.EchoComponent
 
echo(InputStream) - Method in class org.mule.tck.functional.FunctionalStreamingEchoComponent
 
echo(String) - Method in class org.mule.tck.testmodels.services.TestServiceComponent
 
EchoComponent - Class in org.mule.component.simple
EchoComponent will log the message and return the payload back as the result.
EchoComponent() - Constructor for class org.mule.component.simple.EchoComponent
 
EchoService - Interface in org.mule.api.component.simple
 
EJB - Static variable in class org.mule.transport.ejb.EjbConnector
 
EJB_SERVICECLASS_INVOCATION_FAILED - Static variable in class org.mule.transport.ejb.EjbConnector
 
EjbConnector - Class in org.mule.transport.ejb
Provides Connection configurstion for EJB endpoints
EjbConnector(MuleContext) - Constructor for class org.mule.transport.ejb.EjbConnector
 
ejbKeyRefNotValid(Object) - Static method in class org.mule.transport.ejb.i18n.EjbMessages
 
EjbMessageDispatcher - Class in org.mule.transport.ejb
Invokes a method on an EJB object stored in Jndi.
EjbMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.ejb.EjbMessageDispatcher
 
EjbMessageDispatcherFactory - Class in org.mule.transport.ejb
EjbMessageDispatcherFactory creates a dispatcher for marshalling requests to an EJB MuleSession bean
EjbMessageDispatcherFactory() - Constructor for class org.mule.transport.ejb.EjbMessageDispatcherFactory
 
EjbMessageReceiver - Class in org.mule.transport.ejb
Will repeatedly call a method on an EJB object.
EjbMessageReceiver(Connector, FlowConstruct, InboundEndpoint, long) - Constructor for class org.mule.transport.ejb.EjbMessageReceiver
 
EjbMessages - Class in org.mule.transport.ejb.i18n
 
EjbMessages() - Constructor for class org.mule.transport.ejb.i18n.EjbMessages
 
EjbNamespaceHandler - Class in org.mule.transport.ejb.config
 
EjbNamespaceHandler() - Constructor for class org.mule.transport.ejb.config.EjbNamespaceHandler
 
ejbObjectMissingCreate(Object) - Static method in class org.mule.transport.ejb.i18n.EjbMessages
 
ElementAddedEvent - Class in org.mule.module.launcher.util
 
ElementAddedEvent(Object, Object, int) - Constructor for class org.mule.module.launcher.util.ElementAddedEvent
 
ElementEvent<E> - Class in org.mule.module.launcher.util
 
ElementEvent(Object, Object, Object, int, int) - Constructor for class org.mule.module.launcher.util.ElementEvent
 
ElementInNestedMapDefinitionParser - Class in org.mule.config.spring.parsers.specific.properties
This constructs a nested map - keyed by "mapKey" - and then adds an entry in that named from the attribute "keyAttribute".
ElementInNestedMapDefinitionParser(String, String, String) - Constructor for class org.mule.config.spring.parsers.specific.properties.ElementInNestedMapDefinitionParser
 
ElementRemovedEvent - Class in org.mule.module.launcher.util
 
ElementRemovedEvent(Object, Object, int) - Constructor for class org.mule.module.launcher.util.ElementRemovedEvent
 
ElementsClearedEvent - Class in org.mule.module.launcher.util
 
ElementsClearedEvent(Object, List<?>) - Constructor for class org.mule.module.launcher.util.ElementsClearedEvent
 
elementToString(Element) - Static method in class org.mule.util.XMLUtils
 
ElementUpdatedEvent - Class in org.mule.module.launcher.util
 
ElementUpdatedEvent(Object, Object, Object, int) - Constructor for class org.mule.module.launcher.util.ElementUpdatedEvent
 
ElementValidator - Interface in org.mule.config.spring
Allows validating an Element prior to parsing it.
EmailMessages - Class in org.mule.transport.email.i18n
 
EmailMessages() - Constructor for class org.mule.transport.email.i18n.EmailMessages
 
EmailMessageToString - Class in org.mule.transport.email.transformers
EmailMessageToString extracts the text body of java mail Message and returns a string.
EmailMessageToString() - Constructor for class org.mule.transport.email.transformers.EmailMessageToString
 
EmailNamespaceHandler - Class in org.mule.transport.email.config
 
EmailNamespaceHandler() - Constructor for class org.mule.transport.email.config.EmailNamespaceHandler
 
EmbeddedJettyServer - Class in org.mule.transport.servlet.jetty.util
A simple helper class for Mule testing that creates an embedded Jetty Server
EmbeddedJettyServer(int, String, String, Servlet, MuleContext) - Constructor for class org.mule.transport.servlet.jetty.util.EmbeddedJettyServer
 
EMPTY_EVENTS_ARRAY - Static variable in class org.mule.routing.EventGroup
 
EmptyApplicationDescriptor - Class in org.mule.module.launcher.descriptor
Encapsulates defaults when no explicit descriptor provided with an app.
EmptyApplicationDescriptor(String) - Constructor for class org.mule.module.launcher.descriptor.EmptyApplicationDescriptor
 
EmptyDomainDescriptor - Class in org.mule.module.launcher.descriptor
Represents the description of a domain when none is given
EmptyDomainDescriptor(String) - Constructor for class org.mule.module.launcher.descriptor.EmptyDomainDescriptor
 
EmptyHttpEntity - Class in org.mule.module.http.internal.domain
Represents a http empty body
EmptyHttpEntity() - Constructor for class org.mule.module.http.internal.domain.EmptyHttpEntity
 
emptyInstance(MuleContext) - Static method in class org.mule.module.http.internal.listener.HttpResponseBuilder
 
EmptyLifecycleCallback<O> - Class in org.mule.lifecycle
A lifecycle callback that does nothing.
EmptyLifecycleCallback() - Constructor for class org.mule.lifecycle.EmptyLifecycleCallback
 
emptyTestTable() - Method in class org.mule.tck.util.MuleDerbyTestDatabase
Remove all the rows from TEST table.
emptyToNull(String) - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
ENABLE_MULE_SOAP_HEADERS - Static variable in class org.mule.module.cxf.CxfConstants
 
ENABLE_MULTIPLEXED_CONNECTIONS - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
ENABLE_SHARED_DURABLE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
enableAttribute(MuleDefinitionParser, String) - Static method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
enableAttributes(MuleDefinitionParser, String[], boolean) - Static method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
A utility class for selecting certain attributes.
enableAttributes(MuleDefinitionParser, String[][]) - Static method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
enableAttributes(MuleDefinitionParser, String[]) - Static method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
enableCorrelation - Variable in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
enableCorrelation - Variable in class org.mule.routing.outbound.AbstractOutboundRouter
Determines if Mule stamps outgoing message with a correlation ID or not.
enabled - Variable in class org.mule.management.stats.AbstractFlowConstructStatistics
 
enableDebug(DebuggerCallback) - Method in interface org.mule.api.debug.Debuggeable
Enables the debug mode for this message processor and returns a new debugging session.
enableFollowsRedirect() - Method in class org.mule.module.http.api.client.HttpRequestOptionsBuilder
Configures the requester to follows redirects
enableFollowsRedirect() - Method in interface org.mule.module.http.api.requester.HttpRequestOperationConfig
Configures the requester to follows redirects
enableFollowsRedirect() - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
enableMuleSoapHeaders - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
enableNotifications - Variable in class org.mule.exception.AbstractExceptionListener
 
ENCODE - Static variable in class org.mule.util.Base64
Specify encoding.
encodeBytes(byte[]) - Static method in class org.mule.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int) - Static method in class org.mule.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int) - Static method in class org.mule.util.Base64
Encodes a byte array into Base64 notation.
encodeBytes(byte[], int, int, int) - Static method in class org.mule.util.Base64
Encodes a byte array into Base64 notation.
encodeFromFile(String) - Static method in class org.mule.util.Base64
Convenience method for reading a binary file and base64-encoding it.
encodeHeader(String) - Static method in class org.mule.transport.jms.JmsMessageUtils
Encode a String so that is is a valid JMS header name
encodeObject(Serializable) - Static method in class org.mule.util.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encodeObject(Serializable, int) - Static method in class org.mule.util.Base64
Serializes an object and returns the Base64-encoded version of that serialized object.
encodeOnCompleteRedirectToInState(String) - Method in class org.mule.module.oauth2.internal.StateEncoder
Creates and state value with the redirect url to send the user when the oauth dance is complete
encodeQueryString(Map) - Static method in class org.mule.module.http.internal.HttpParser
 
encodeRedirectURL(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
encodeRedirectUrl(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
encodeResourceOwnerIdInState(String) - Method in class org.mule.module.oauth2.internal.StateEncoder
Creates an state value with the resource owner id encoded in it.
encodeSpaces(String) - Static method in class org.mule.module.http.internal.HttpParser
Encodes spaces in a path, replacing them by %20.
encodeString(String, Map) - Static method in class org.mule.module.http.internal.HttpParser
 
encodeString(String) - Static method in class org.mule.util.XMLEntityCodec
 
encodeToFile(byte[], String) - Static method in class org.mule.util.Base64
Convenience method for encoding data to a file.
encodeURL(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
encodeUrl(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
encodeVendorSpecificID(String) - Method in class org.mule.transport.jms.JmsMessageDispatcher
By default, no encoding is performed.
encoding - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
encoding - Variable in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
encoding - Variable in class org.mule.transformer.AbstractTransformer
 
encoding - Variable in class org.mule.transformer.types.SimpleDataType
 
encoding - Variable in class org.mule.util.store.TextFileObjectStore
 
encrypt(InputStream, Object) - Method in interface org.mule.api.EncryptionStrategy
 
encrypt(byte[], Object) - Method in interface org.mule.api.EncryptionStrategy
 
encrypt(InputStream, Object) - Method in class org.mule.module.pgp.KeyBasedEncryptionStrategy
 
encrypt(InputStream, Object) - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
encrypt(byte[], Object) - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
encrypt(byte[], Object) - Method in class org.mule.security.AbstractNamedEncryptionStrategy
 
encrypt(byte[], Object) - Method in class org.mule.tck.security.MockEncryptionStrategy
 
encrypt(InputStream, Object) - Method in class org.mule.tck.security.MockEncryptionStrategy
 
encryptCipher - Variable in class org.mule.security.AbstractJCEEncryptionStrategy
 
EncryptionAlgorithm - Enum in org.mule.module.pgp
 
EncryptionNotSupportedException - Exception in org.mule.api.security
EncryptionNotSupportedException is thrown if an algorithm is set in the MULE_USER header but it doesn't match the algorithm set on the security filter
EncryptionNotSupportedException(Message, MuleEvent) - Constructor for exception org.mule.api.security.EncryptionNotSupportedException
 
EncryptionNotSupportedException(Message, MuleEvent, Throwable, MessageProcessor) - Constructor for exception org.mule.api.security.EncryptionNotSupportedException
 
EncryptionStrategy - Interface in org.mule.api
EncryptionStrategy can be used to provide different types of Encryption strategy objects.
EncryptionStrategyNotFoundException - Exception in org.mule.api.security
EncryptionStrategyNotFoundException is thrown by the SecurityManager when an encryption scheme is set in a property or header that has not been registered witrh the manager
EncryptionStrategyNotFoundException(String) - Constructor for exception org.mule.api.security.EncryptionStrategyNotFoundException
 
EncryptionStrategyNotFoundException(String, Throwable) - Constructor for exception org.mule.api.security.EncryptionStrategyNotFoundException
 
encryptionStrategyNotSet() - Static method in class org.mule.config.i18n.CoreMessages
 
encryptionStrategyNotSet() - Static method in class org.mule.module.pgp.i18n.PGPMessages
 
EncryptionTransformer - Class in org.mule.transformer.encryption
EncryptionTransformer will transform an array of bytes or string into an encrypted array of bytes
EncryptionTransformer() - Constructor for class org.mule.transformer.encryption.EncryptionTransformer
 
EncryptStreamTransformer - Class in org.mule.module.pgp
 
EncryptStreamTransformer(PGPPublicKey, Provider, int, PGPOutputMode) - Constructor for class org.mule.module.pgp.EncryptStreamTransformer
 
end(Xid, int) - Method in class org.mule.transport.jms.xa.XAResourceWrapper
 
end(Xid, int) - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
end(Xid, int) - Method in class org.mule.util.queue.TransactionalQueueSession
 
end(Xid, int) - Method in class org.mule.util.xa.DefaultXASession
 
EndedProcess - Class in org.mule.module.jbpm
Placeholder used to get status for a process in a uniform way, even if it has ended.
EndedProcess(String) - Constructor for class org.mule.module.jbpm.EndedProcess
 
EndElementEventX - Class in org.mule.module.xml.stax
 
EndElementEventX(QName, List<Namespace>) - Constructor for class org.mule.module.xml.stax.EndElementEventX
 
EndPhaseTemplate - Interface in org.mule.execution
Phase were the MessageProcessTemplate is notified that the message processing has ended
endpoint - Variable in class org.mule.endpoint.DynamicURIInboundEndpoint
 
endpoint - Variable in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
endpoint - Variable in class org.mule.endpoint.EndpointMessageProcessorChainBuilder
 
endpoint - Variable in class org.mule.endpoint.inbound.InboundLoggingMessageProcessor
 
endpoint - Variable in class org.mule.endpoint.inbound.InboundNotificationMessageProcessor
 
endpoint - Variable in class org.mule.endpoint.OutboundEndpointMessageProcessorChainBuilder
 
endpoint - Variable in class org.mule.routing.ForwardingCatchAllStrategy
Deprecated.
 
endpoint - Variable in class org.mule.security.AbstractEndpointSecurityFilter
Deprecated.
 
endpoint - Variable in class org.mule.transformer.AbstractTransformer
The endpoint that this transformer instance is configured on
endpoint - Variable in class org.mule.transport.AbstractReceiverWorker
 
endpoint - Variable in class org.mule.transport.AbstractTransportMessageHandler
 
ENDPOINT_BUILDER_POSTFIX - Static variable in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
ENDPOINT_PREFIX - Static variable in class org.mule.util.ObjectNameHelper
 
ENDPOINT_PROPERTIES_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.endpoint.EndpointPropertyElementDefinitionParser
 
ENDPOINT_PROPERTY_PREFIX - Static variable in class org.mule.api.config.MuleProperties
The prefix for endpoint properties that should not be propagated to messages
ENDPOINT_REF_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
ENDPOINT_REGISTRY_PREFIX - Static variable in class org.mule.endpoint.DefaultEndpointFactory
 
EndpointAnnotationParser - Interface in org.mule.api
An SPI interface that will process an Endpoint annotation.
EndpointAware - Interface in org.mule.endpoint
Interface used by objects that allow an endpoint instance to be set.
EndpointBuilder - Interface in org.mule.api.endpoint
Constructs endpoints.
EndpointCache - Interface in org.mule.api.endpoint
Cache endpoints in order to prevent memory leaks.
endpointDispatchers - Variable in class org.mule.transport.http.HttpConnector
 
endpointDispatchers - Variable in class org.mule.transport.jdbc.JdbcConnector
 
EndpointException - Exception in org.mule.api.endpoint
EndpointException is an abstract exception extended by endpoint specific exceptions.
EndpointException(Message) - Constructor for exception org.mule.api.endpoint.EndpointException
 
EndpointException(Message, Throwable) - Constructor for exception org.mule.api.endpoint.EndpointException
 
EndpointException(Throwable) - Constructor for exception org.mule.api.endpoint.EndpointException
 
EndpointFactory - Interface in org.mule.api.endpoint
Endpoint factory creates immutable instances of ImmutableEndpoint.
EndpointInfoExpressionEvaluator - Class in org.mule.expression
Looks up information about a global endpoint
EndpointInfoExpressionEvaluator() - Constructor for class org.mule.expression.EndpointInfoExpressionEvaluator
 
endpointIsMalformed(String) - Static method in class org.mule.config.i18n.CoreMessages
 
endpointIsNullForListener() - Static method in class org.mule.config.i18n.CoreMessages
 
EndpointMessageNotification - Class in org.mule.context.notification
These notifications are fired when either a message is either: received by an endpoint, sent or dispatched from an endpoint or requested from an endpoint.
EndpointMessageNotification(MuleMessage, ImmutableEndpoint, FlowConstruct, int) - Constructor for class org.mule.context.notification.EndpointMessageNotification
 
EndpointMessageNotificationListener<T extends EndpointMessageNotification> - Interface in org.mule.api.context.notification
EndpointMessageNotificationListener is an observer interface that objects can use to receive notifications about messages being sent and received from endpoints
EndpointMessageProcessorChainBuilder - Class in org.mule.endpoint
 
EndpointMessageProcessorChainBuilder(ImmutableEndpoint, FlowConstruct) - Constructor for class org.mule.endpoint.EndpointMessageProcessorChainBuilder
 
EndpointMessageProcessorChainBuilder(ImmutableEndpoint) - Constructor for class org.mule.endpoint.EndpointMessageProcessorChainBuilder
 
EndpointMessageProcessorChainFactory - Interface in org.mule.api.endpoint
 
endpointName - Variable in class org.mule.endpoint.AbstractEndpointURIBuilder
 
endpointNotFound(String) - Static method in class org.mule.config.i18n.CoreMessages
 
EndpointNotFoundException - Exception in org.mule.api.endpoint
EndpointNotFoundException is thrown when an endpoint name or protocol is specified but a matching endpoint is not registered with the Mule server
EndpointNotFoundException(String) - Constructor for exception org.mule.api.endpoint.EndpointNotFoundException
 
EndpointNotFoundException(Message) - Constructor for exception org.mule.api.endpoint.EndpointNotFoundException
 
EndpointNotFoundException(Message, Throwable) - Constructor for exception org.mule.api.endpoint.EndpointNotFoundException
 
EndpointNotFoundException(Throwable) - Constructor for exception org.mule.api.endpoint.EndpointNotFoundException
 
EndpointNotificationLoggerAgent - Class in org.mule.agent
EndpointAbstractEventLoggerAgent will forward server notifications to a configurered endpoint uri.
EndpointNotificationLoggerAgent() - Constructor for class org.mule.agent.EndpointNotificationLoggerAgent
 
EndpointPollingJob - Class in org.mule.transport.quartz.jobs
Will receive on an endpoint and dispatch it to the component set via the Receiver information.
EndpointPollingJob() - Constructor for class org.mule.transport.quartz.jobs.EndpointPollingJob
 
EndpointPollingJobConfig - Class in org.mule.transport.quartz.jobs
Configuration for the EndpointPollingJob job.
EndpointPollingJobConfig() - Constructor for class org.mule.transport.quartz.jobs.EndpointPollingJobConfig
 
EndpointPropertyElementDefinitionParser - Class in org.mule.config.spring.parsers.specific.endpoint
This parser parses nested endpoint elements adding the resulting beans to the map of properties on the EndpointBuilder rather than attempting to inject them on the EndpointBuilder itself.
EndpointPropertyElementDefinitionParser(String, Class) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.EndpointPropertyElementDefinitionParser
 
EndpointRefParser - Class in org.mule.config.spring.parsers.specific.endpoint
Configures a reference to an endpoint on a parent bean.
EndpointRefParser(String) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.EndpointRefParser
 
endpoints - Variable in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
endpointsCache - Variable in class org.mule.transport.soap.axis.extensions.UniversalSender
 
EndpointSecurityFilter - Interface in org.mule.api.security
Deprecated.
EndpointSelector - Class in org.mule.routing.outbound
Deprecated.
EndpointSelector() - Constructor for class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
EndpointService - Class in org.mule.module.management.mbean
The EndpointServiceMBean allows you to check the confiugration of an endpoint and conect/disconnect endpoints manually.
EndpointService(ImmutableEndpoint) - Constructor for class org.mule.module.management.mbean.EndpointService
 
EndpointService(MessageReceiver) - Constructor for class org.mule.module.management.mbean.EndpointService
 
EndpointServiceMBean - Interface in org.mule.module.management.mbean
The EndpointServiceMBean allows you to check the confiugration of an endpoint and conect/disconnect endpoints manually.
EndpointTransactionalInterceptingMessageProcessor - Class in org.mule.processor
Wraps the invocation of the next MessageProcessor with a transaction.
EndpointTransactionalInterceptingMessageProcessor(TransactionConfig) - Constructor for class org.mule.processor.EndpointTransactionalInterceptingMessageProcessor
 
EndpointURI - Interface in org.mule.api.endpoint
EndpointURI is used to determine how a message is sent or received.
EndpointURIBuilder - Interface in org.mule.api.endpoint
EndpointBuilder determines how a uri is translated to a MuleEndpointURI Connectors can override the default behaviour to suit their needs
EndpointURIEndpointBuilder - Class in org.mule.endpoint
 
EndpointURIEndpointBuilder() - Constructor for class org.mule.endpoint.EndpointURIEndpointBuilder
 
EndpointURIEndpointBuilder(EndpointURIEndpointBuilder) - Constructor for class org.mule.endpoint.EndpointURIEndpointBuilder
Called from Spring
EndpointURIEndpointBuilder(URIBuilder) - Constructor for class org.mule.endpoint.EndpointURIEndpointBuilder
 
EndpointURIEndpointBuilder(String, MuleContext) - Constructor for class org.mule.endpoint.EndpointURIEndpointBuilder
 
EndpointURIEndpointBuilder(EndpointURI) - Constructor for class org.mule.endpoint.EndpointURIEndpointBuilder
 
EndpointURIEndpointBuilder(ImmutableEndpoint) - Constructor for class org.mule.endpoint.EndpointURIEndpointBuilder
 
EndpointURIPropertyEditor - Class in org.mule.config.spring.editors
Translates a connector name property into the corresponding Connector instance.
EndpointURIPropertyEditor(MuleContext) - Constructor for class org.mule.config.spring.editors.EndpointURIPropertyEditor
 
EndpointUtils - Class in org.mule.config.spring.parsers.specific.endpoint.support
Routines and constants common to the two endpoint definition parsers.
EndpointUtils() - Constructor for class org.mule.config.spring.parsers.specific.endpoint.support.EndpointUtils
 
EndProcessPhase - Class in org.mule.execution
This phase notifies to the MessageProcessTemplate that the message processing has ended.
EndProcessPhase() - Constructor for class org.mule.execution.EndProcessPhase
 
EnforcerPortRule - Class in org.apache.maven.enforcer.rule
 
EnforcerPortRule() - Constructor for class org.apache.maven.enforcer.rule.EnforcerPortRule
 
enlist() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
enlist() - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
 
enlist() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
enlist() - Method in class org.mule.transport.jms.xa.SessionInvocationHandler
 
ENLIST_METHOD_NAME - Static variable in interface org.mule.transaction.XaTransaction.MuleXaObject
 
enlistResource(XAResource) - Method in class org.mule.transaction.XaTransaction
 
enqueue(MuleEvent) - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
enrich(String, MuleMessage, TypedValue) - Method in interface org.mule.api.el.ExpressionLanguage
Enriches a message
enrich(String, MuleMessage, Object) - Method in interface org.mule.api.expression.ExpressionEnricher
Enriches the message with the object
enrich(String, MuleMessage, Object) - Method in interface org.mule.api.expression.ExpressionManager
Deprecated.
enrich(String, MuleEvent, Object) - Method in interface org.mule.api.expression.ExpressionManager
 
enrich(String, String, MuleMessage, Object) - Method in interface org.mule.api.expression.ExpressionManager
Enriches the current message
enrich(String, MuleMessage, TypedValue) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
enrich(MuleMessage, MuleMessage, String, String, ExpressionManager) - Method in class org.mule.enricher.MessageEnricher
 
enrich(String, MuleMessage, Object) - Method in class org.mule.expression.AttachmentExpressionEnricher
 
enrich(String, MuleMessage, Object) - Method in class org.mule.expression.DefaultExpressionManager
 
enrich(String, MuleEvent, Object) - Method in class org.mule.expression.DefaultExpressionManager
 
enrich(String, String, MuleMessage, Object) - Method in class org.mule.expression.DefaultExpressionManager
 
enrich(String, MuleMessage, Object) - Method in class org.mule.expression.MessageHeaderExpressionEnricher
 
enrich(String, MuleMessage, Object) - Method in class org.mule.expression.VariableExpressionEnricher
 
EnricherDataTypePropagator - Interface in org.mule.el.mvel.datatype
Propagates DataType from the right to the left side of an assignment expression if possible
enrichTyped(String, MuleMessage, TypedValue) - Method in interface org.mule.api.expression.ExpressionManager
Enriches the current message using a typed value
enrichTyped(String, MuleMessage, TypedValue) - Method in class org.mule.expression.DefaultExpressionManager
 
ensure(TestAppender.Expectation...) - Method in class org.mule.tck.logging.TestAppender
 
ensure(Set<TestAppender.Expectation>) - Method in class org.mule.tck.logging.TestAppender
 
ensureFolderIsOpen(Folder) - Method in class org.mule.transport.email.RetrieveMessageRequester
 
ensurePartIndexMatchListIndex(MessageContentsList, List<MessagePartInfo>) - Method in class org.mule.module.cxf.support.OutputPayloadInterceptor
Ensures that each part's content is in the right place in the content list.
ensureSerializable(MuleMessage) - Method in class org.mule.routing.AbstractUntilSuccessfulProcessingStrategy
 
ensureSerializable(MuleMessage) - Method in class org.mule.routing.SynchronousUntilSuccessfulProcessingStrategy
 
ensureSize(Object, int) - Static method in class org.mule.transport.http.multipart.LazyList
Ensure the capcity of the underlying list.
ensureStoreDirectoryExists(File) - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
ensureUniqueConnector(String) - Method in class org.mule.util.ObjectNameHelper
 
ensureUniqueEndpoint(String) - Method in class org.mule.util.ObjectNameHelper
 
ensureUniqueId(Element, String) - Static method in class org.mule.config.spring.parsers.generic.AutoIdUtils
 
enterActiveOrPassiveMode(FTPClient, ImmutableEndpoint) - Method in class org.mule.transport.ftp.FtpConnector
Passive mode is OFF by default.
entityFormat - Variable in class org.mule.module.http.internal.listener.ErrorRequestHandler
 
entityName(int) - Static method in class org.mule.util.XMLEntityCodec
Returns the name of the entity identified by the specified value.
entityValue(String) - Static method in class org.mule.util.XMLEntityCodec
Returns the value of the entity identified by the specified name.
EntryLastUpdatedFilter - Class in org.mule.module.atom.routing
Will filter entries in an atom feed based on the lasted Edited date, falling back to the published date if the edit date was not set
EntryLastUpdatedFilter() - Constructor for class org.mule.module.atom.routing.EntryLastUpdatedFilter
 
EntryLastUpdatedFilter(Date) - Constructor for class org.mule.module.atom.routing.EntryLastUpdatedFilter
 
EntryLastUpdatedFilter - Class in org.mule.module.rss.routing
Will filter a feed who's update date has changed since the last time it was read.
EntryLastUpdatedFilter() - Constructor for class org.mule.module.rss.routing.EntryLastUpdatedFilter
 
EntryLastUpdatedFilter(Date) - Constructor for class org.mule.module.rss.routing.EntryLastUpdatedFilter
 
EntryPoint - Interface in org.mule.api.model
EntryPoint defines the current entry method on a service.
EntryPointNotFoundException - Exception in org.mule.model.resolvers
Tis exception gets thrown by the DefaultEntryPointResolverSet if after trying all entrypointResolvers it cannot fin the entrypoint on the service service
EntryPointNotFoundException(String) - Constructor for exception org.mule.model.resolvers.EntryPointNotFoundException
 
EntryPointResolver - Interface in org.mule.api.model
EntryPointResolver resolves a method to call on the given Component when an event is received for the service.
entryPointResolver - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
EntryPointResolverSet - Interface in org.mule.api.model
EntryPointResolver resolves a method to call on the given service object when an event is received.
entryPointResolverSet - Variable in class org.mule.component.AbstractJavaComponent
 
entrySet() - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
entrySet() - Method in class org.mule.el.context.AbstractMapContext
 
entrySet() - Method in class org.mule.expression.InboundAttachmentsMap
 
entrySet() - Method in class org.mule.expression.OutboundAttachmentsMap
 
entrySet() - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
entrySet() - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
entrySet() - Method in class org.mule.module.http.internal.ParameterMap
 
entrySet() - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
entrySet() - Method in class org.mule.registry.TransientRegistry.RegistryMap
Deprecated.
 
entrySet() - Method in class org.mule.transport.http.multipart.MultiMap
 
entrySet() - Method in class org.mule.util.CaseInsensitiveMapWrapper
 
entrySet() - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
entrySet() - Method in class org.mule.util.MapCombiner
 
entrySet() - Method in class org.mule.util.OrderedProperties
 
entrySet() - Method in class org.mule.util.store.ObjectStoreToMapAdapter
This method is not supported for performance reasons
entryTTL - Variable in class org.mule.util.store.AbstractMonitoredObjectStore
The time-to-live for each message ID, specified in milliseconds, or -1 for entries that should never expire.
entryTTL - Variable in class org.mule.util.store.MonitoredObjectStoreWrapper
The time-to-live for each message ID, specified in milliseconds, or -1 for entries that should never expire.
EnumerationAdapter<T> - Class in org.mule.module.launcher.application
Creates an Enumeration containing all the items in a Collection
EnumerationAdapter(Collection<T>) - Constructor for class org.mule.module.launcher.application.EnumerationAdapter
 
ENV_REQUEST_HEADERS - Static variable in class org.mule.module.cxf.MuleSoapHeaders
 
environment - Variable in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
EOF - Static variable in class org.mule.transport.tcp.protocols.AbstractByteProtocol
 
EOFProtocol - Class in org.mule.transport.tcp.protocols
The EOFProtocol class is an application level tcp protocol that does nothing.
EOFProtocol() - Constructor for class org.mule.transport.tcp.protocols.EOFProtocol
 
equal(Object, Object) - Static method in class org.mule.endpoint.AbstractEndpoint
 
equal(Object, Object) - Static method in class org.mule.endpoint.AbstractEndpointBuilder
 
equal(Object, Object) - Static method in class org.mule.endpoint.URIBuilder
 
equal(Object, Object) - Static method in class org.mule.util.ClassUtils
Simple helper for writing object equalities.
equals(Object) - Method in exception org.mule.api.MuleException
 
equals(Object) - Method in class org.mule.api.registry.AbstractServiceDescriptor.Key
 
equals(Object) - Method in class org.mule.api.security.tls.TlsConfiguration
 
equals(Object) - Method in class org.mule.api.security.tls.TlsProperties
 
equals(Object) - Method in class org.mule.api.transport.PropertyScope
 
equals(Object) - Method in class org.mule.client.SimpleOptions
 
equals(Object) - Method in class org.mule.config.ConfigResource
 
equals(Object) - Method in class org.mule.config.DefaultMuleConfiguration
 
equals(Object) - Method in class org.mule.config.transformer.AnnotatedTransformerProxy
 
equals(Object) - Method in class org.mule.context.notification.ListenerSubscriptionPair
 
equals(Object) - Method in class org.mule.DefaultMuleEvent
 
equals(Object) - Method in class org.mule.DefaultMuleMessage
 
equals(Object) - Method in class org.mule.el.datetime.AbstractInstant
 
equals(Object) - Method in class org.mule.endpoint.AbstractEndpoint
 
equals(Object) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
equals(Object) - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
equals(Object) - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
equals(Object) - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
equals(Object) - Method in class org.mule.endpoint.MuleEndpointURI
 
equals(Object) - Method in class org.mule.endpoint.URIBuilder
 
equals(Object) - Method in class org.mule.interceptor.InterceptorStack
 
equals(Object) - Method in class org.mule.module.cxf.support.DelegatingOutputStream
 
equals(Object) - Method in class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
equals(Object) - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
equals(Object) - Method in class org.mule.module.db.internal.domain.type.AbstractDbType
 
equals(Object) - Method in class org.mule.module.extension.internal.runtime.resolver.ResolverSetResult
Defines equivalence by comparing the values in both objects.
equals(Object) - Method in class org.mule.module.http.internal.listener.ServerAddress
 
equals(Object) - Method in class org.mule.module.http.internal.ParameterMap
 
equals(Object) - Method in class org.mule.module.http.internal.request.client.DefaultHttpRequestOptions
 
equals(Object) - Method in class org.mule.module.http.internal.request.client.HttpRequestCacheKey
 
equals(Object) - Method in class org.mule.module.json.JsonData
 
equals(Object) - Method in class org.mule.module.launcher.util.ObservableList
 
equals(Object) - Method in class org.mule.module.ognl.filters.OGNLFilter
 
equals(Object) - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
equals(Object) - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
equals(Object) - Method in class org.mule.module.sxc.SxcFilter
 
equals(Object) - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
equals(Object) - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
equals(Object) - Method in class org.mule.module.xml.filters.XPathFilter
 
equals(Object) - Method in class org.mule.routing.EventGroup
Compares two EventGroups for equality.
equals(Object) - Method in class org.mule.routing.filters.ExpressionFilter
 
equals(Object) - Method in class org.mule.routing.filters.logic.AbstractFilterCollection
 
equals(Object) - Method in class org.mule.routing.filters.logic.NotFilter
 
equals(Object) - Method in class org.mule.routing.filters.MessagePropertyFilter
 
equals(Object) - Method in class org.mule.routing.filters.PayloadTypeFilter
 
equals(Object) - Method in class org.mule.routing.filters.RegExFilter
 
equals(Object) - Method in class org.mule.routing.filters.WildcardFilter
 
equals(Object) - Method in class org.mule.tck.logging.TestAppender.Expectation
 
equals(Object) - Method in class org.mule.transaction.MuleTransactionConfig
 
equals(Object) - Method in class org.mule.transformer.TransformerWeighting
 
equals(Object) - Method in class org.mule.transformer.types.CollectionDataType
 
equals(Object) - Method in class org.mule.transformer.types.SimpleDataType
 
equals(Object) - Method in class org.mule.transport.email.filters.MailSubjectRegExFilter
 
equals(Object) - Method in class org.mule.transport.http.multipart.MultiMap
 
equals(Object) - Method in class org.mule.transport.jms.filters.JmsPropertyFilter
 
equals(Object) - Method in class org.mule.transport.jms.filters.JmsSelectorFilter
 
equals(Object) - Method in class org.mule.transport.NullPayload
 
equals(Object) - Method in class org.mule.transport.tcp.TcpSocketKey
 
equals(Object) - Method in class org.mule.transport.xmpp.filters.XmppAndFilter
 
equals(Object) - Method in class org.mule.transport.xmpp.filters.XmppFromContainsFilter
 
equals(Object) - Method in class org.mule.transport.xmpp.filters.XmppNotFilter
 
equals(Object) - Method in class org.mule.transport.xmpp.filters.XmppPacketTypeFilter
 
equals(Object) - Method in class org.mule.util.annotation.AnnotationMetaData
 
equals(Object) - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
equals(Object) - Method in class org.mule.util.concurrent.WaitableBoolean
 
equals(Object) - Method in class org.mule.util.JdkVersionUtils.JdkVersion
 
equals(Object) - Method in class org.mule.util.MapCombiner
 
equals(Object) - Method in class org.mule.util.queue.DefaultQueueConfiguration
 
equals(Object) - Method in class org.mule.util.queue.DefaultQueueStore
 
equals(Object) - Method in class org.mule.util.queue.objectstore.QueueConfiguration
Deprecated.
 
equals(Object) - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
equals(Object) - Method in class org.mule.util.queue.objectstore.QueueKey
Deprecated.
 
equals(Object) - Method in class org.mule.util.scan.annotations.AnnotationInfo
Deprecated.
 
equals(Object) - Method in class org.mule.util.scan.annotations.AnnotationInfo.NameValue
Deprecated.
 
equals(Object) - Method in class org.mule.util.store.InMemoryObjectStore.StoredObject
 
equals(Object) - Method in class org.mule.util.xa.MuleXid
 
equals(Object) - Method in class org.mule.util.xmlsecurity.XMLFactoryConfig
 
equals(Object) - Method in class org.mule.VoidResult
 
EqualsFilter - Class in org.mule.routing.filters
EqualsFilter is a filter for comparing two objects using the equals() method.
EqualsFilter() - Constructor for class org.mule.routing.filters.EqualsFilter
 
EqualsFilter(Object) - Constructor for class org.mule.routing.filters.EqualsFilter
 
error(TransformerException) - Method in class org.mule.module.xml.transformer.XsltTransformer.DefaultErrorListener
 
error(Object) - Method in class org.mule.util.MuleLogger
 
error(Object, Throwable) - Method in class org.mule.util.MuleLogger
 
ERROR_CODE_PROPERTY - Static variable in class org.mule.config.ExceptionHelper
This is the property to set the error code to no the message it is the property name the Transport provider uses set the set the error code on the underlying message
ERROR_STATUS_CODE_RANGE_START - Static variable in class org.mule.transport.http.HttpClientMessageDispatcher
Range start for http error status codes.
errorCreatingConnectionFactory() - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
errorExpression - Variable in class org.mule.construct.builder.ValidatorBuilder
 
errorExpression(String) - Method in class org.mule.construct.builder.ValidatorBuilder
 
ErrorFieldDebugInfo - Class in org.mule.api.debug
Provides debug information for a field when there was an error obtaining the field's information.
ErrorHandlingExecutionTemplate - Class in org.mule.execution
ExecutionTemplate created by this method should be used on the beginning of the execution of a chain of MessageProcessor that should manage exceptions.
errorInitializingJndi() - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
errorInvokingMessageProcessorAsynchronously(MessageProcessor) - Static method in class org.mule.config.i18n.CoreMessages
 
errorInvokingMessageProcessorWithinTransaction(MessageProcessor, TransactionConfig) - Static method in class org.mule.config.i18n.CoreMessages
 
errorMuleMqJmsSpecification() - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
ErrorOccurredDecorator - Interface in org.mule.transport.sftp
Decorator for the ErrorOccured method
errorReadingStream() - Static method in class org.mule.config.i18n.CoreMessages
 
ErrorRequestHandler - Class in org.mule.module.http.internal.listener
 
ErrorRequestHandler(int, String, String) - Constructor for class org.mule.module.http.internal.listener.ErrorRequestHandler
 
errorSchedulingMessageProcessorForAsyncInvocation(MessageProcessor) - Static method in class org.mule.config.i18n.CoreMessages
 
errorVerifySignature() - Static method in class org.mule.module.pgp.i18n.PGPMessages
 
errorWhileListingFiles() - Static method in class org.mule.transport.file.i18n.FileMessages
 
escape(String) - Method in class org.mule.module.management.support.JmxLegacySupport
Uses simpler rules for escaping non-JMX compliant chars.
escape(String) - Method in class org.mule.module.management.support.JmxModernSupport
Uses JMX 1.2 and higher standard escape method and semantics.
escape(String) - Method in interface org.mule.module.management.support.JmxSupport
Uses JMX 1.2 and higher standard escape method and semantics.
escapeStatement(String) - Method in class org.mule.transport.jdbc.sqlstrategy.CallableSqlStatementStrategy
 
escapeStatement(String) - Method in class org.mule.transport.jdbc.sqlstrategy.SimpleUpdateSqlStatementStrategy
 
ETAG - Static variable in class org.mule.module.http.api.HttpHeaders.Names
etag - Variable in class org.mule.transport.http.PollingHttpMessageReceiver
 
eval(String) - Method in interface org.mule.api.debug.ScriptEvaluator
Evaluates the script and returns the information of the result
evaluate() - Method in interface org.mule.api.debug.FieldDebugInfoFactory.FieldEvaluator
Provides the value for a field
evaluate(String) - Method in interface org.mule.api.el.ExpressionLanguage
Execute the expression returning the result.
evaluate(String, Map<String, Object>) - Method in interface org.mule.api.el.ExpressionLanguage
Execute the expression returning the result.
evaluate(String, MuleEvent) - Method in interface org.mule.api.el.ExpressionLanguage
Execute the expression returning the result.
evaluate(String, MuleEvent, Map<String, Object>) - Method in interface org.mule.api.el.ExpressionLanguage
Execute the expression returning the result.
evaluate(String, MuleMessage) - Method in interface org.mule.api.el.ExpressionLanguage
Deprecated.
evaluate(String, MuleMessage, Map<String, Object>) - Method in interface org.mule.api.el.ExpressionLanguage
Deprecated.
evaluate(String, MuleMessage) - Method in interface org.mule.api.expression.ExpressionEvaluator
Extracts a single property from the message
evaluate(String, MuleMessage) - Method in interface org.mule.api.expression.ExpressionManager
Deprecated.
evaluate(String, MuleEvent) - Method in interface org.mule.api.expression.ExpressionManager
 
evaluate(String, MuleMessage, boolean) - Method in interface org.mule.api.expression.ExpressionManager
Deprecated.
evaluate(String, MuleEvent, boolean) - Method in interface org.mule.api.expression.ExpressionManager
 
evaluate(String, String, MuleMessage, boolean) - Method in interface org.mule.api.expression.ExpressionManager
Evaluates the given expression.
evaluate(Throwable) - Method in interface org.mule.config.ExceptionHelper.ExceptionEvaluator
 
evaluate(TemplateParser.PatternInfo, ExpressionManager, MuleMessage, Object) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
 
evaluate(String) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
evaluate(String, Map<String, Object>) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
evaluate(String, MuleEvent) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
evaluate(String, MuleEvent, Map<String, Object>) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
evaluate(String, MuleMessage) - Method in class org.mule.el.mvel.MVELExpressionLanguage
Deprecated.
evaluate(String, MuleMessage, Map<String, Object>) - Method in class org.mule.el.mvel.MVELExpressionLanguage
Deprecated.
evaluate(String, MuleMessage) - Method in class org.mule.expression.BaseAttachmentExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.DefaultExpressionManager
Evaluates the given expression.
evaluate(String, MuleEvent) - Method in class org.mule.expression.DefaultExpressionManager
 
evaluate(String, MuleEvent, boolean) - Method in class org.mule.expression.DefaultExpressionManager
Evaluates the given expression.
evaluate(String, MuleMessage, boolean) - Method in class org.mule.expression.DefaultExpressionManager
 
evaluate(String, String, MuleMessage, boolean) - Method in class org.mule.expression.DefaultExpressionManager
Evaluates the given expression.
evaluate(String, MuleMessage) - Method in class org.mule.expression.EndpointInfoExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.FunctionExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.IllegalExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.MapPayloadExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.MessageAttachmentsExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.MessageAttachmentsListExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.MessageExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.MessageHeaderExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.MessageHeadersExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.MessageHeadersListExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.MessagePayloadExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.MessageProcessorExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.MuleContextExpressionEvaluator
Extracts a single property from the message
evaluate(String, MuleMessage) - Method in class org.mule.expression.MuleExpressionEvaluator
Deprecated.
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.OutboundAttachmentsExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.RegistryExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.expression.StringExpressionEvaluator
 
evaluate(MuleMessage) - Method in class org.mule.expression.transformers.ExpressionArgument
Evaluates this Expression against the passed in Message.
evaluate(String, MuleMessage) - Method in class org.mule.expression.VariableExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.module.json.JsonExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.module.ognl.expression.OgnlExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.module.scripting.expression.AbstractScriptExpressionEvaluator
Extracts a single property from the message
evaluate(String, MuleMessage) - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
Extracts a single property from the message
evaluate(String, MuleMessage) - Method in class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
Extracts a single property from the message
evaluate(String, MuleMessage) - Method in class org.mule.module.xml.expression.JXPathExpressionEvaluator
Deprecated.
 
evaluate(String, Node, MuleEvent) - Method in class org.mule.module.xml.xpath.JaxpXPathEvaluator
Evaluates the xpathExpression over the input and returns the evaluation as a String.
evaluate(String, Node, XPathReturnType, MuleEvent) - Method in class org.mule.module.xml.xpath.JaxpXPathEvaluator
Evaluates the xpathExpression over the input and returns the evaluation as a type in concordance with returnType.
evaluate(String, Node, MuleEvent) - Method in interface org.mule.module.xml.xpath.XPathEvaluator
Evaluates the xpathExpression over the input and returns the evaluation as a String.
evaluate(String, Node, XPathReturnType, MuleEvent) - Method in interface org.mule.module.xml.xpath.XPathEvaluator
Evaluates the xpathExpression over the input and returns the evaluation as a type in concordance with returnType.
evaluate(String, MuleMessage) - Method in class org.mule.routing.correlation.CorrelationPropertiesExpressionEvaluator
 
evaluate(String, MuleMessage) - Method in class org.mule.transport.email.transformers.StringToEmailMessage
 
evaluate(String, MuleEvent) - Static method in class org.mule.transport.polling.watermark.WatermarkUtils
Evaluates a mel expression.
evaluate(T) - Method in interface org.mule.util.Predicate
 
evaluateAndTransform(MuleContext, MuleEvent, Type, String, Object) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
 
evaluateAndTransform(MuleContext, MuleMessage, Type, String, Object) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
 
evaluateArguments(MuleEvent, List<?>) - Method in class org.mule.processor.InvokerMessageProcessor
 
evaluateBoolean(String, String, MuleMessage) - Method in interface org.mule.api.expression.ExpressionManager
Evaluates the given expression resolving the result of the evaluation to a boolean.
evaluateBoolean(String, MuleMessage) - Method in interface org.mule.api.expression.ExpressionManager
Deprecated.
evaluateBoolean(String, MuleEvent) - Method in interface org.mule.api.expression.ExpressionManager
 
evaluateBoolean(String, String, MuleMessage, boolean, boolean) - Method in interface org.mule.api.expression.ExpressionManager
Evaluates the given expression resolving the result of the evaluation to a boolean.
evaluateBoolean(String, MuleMessage, boolean, boolean) - Method in interface org.mule.api.expression.ExpressionManager
Deprecated.
evaluateBoolean(String, MuleEvent, boolean, boolean) - Method in interface org.mule.api.expression.ExpressionManager
 
evaluateBoolean(String, String, MuleMessage) - Method in class org.mule.expression.DefaultExpressionManager
 
evaluateBoolean(String, MuleMessage) - Method in class org.mule.expression.DefaultExpressionManager
 
evaluateBoolean(String, String, MuleMessage, boolean, boolean) - Method in class org.mule.expression.DefaultExpressionManager
 
evaluateBoolean(String, MuleMessage, boolean, boolean) - Method in class org.mule.expression.DefaultExpressionManager
 
evaluateBoolean(String, MuleEvent, boolean, boolean) - Method in class org.mule.expression.DefaultExpressionManager
 
evaluateBoolean(String, MuleEvent) - Method in class org.mule.expression.DefaultExpressionManager
 
evaluateExpressionCandidate(Object, MuleMessage) - Method in class org.mule.processor.InvokerMessageProcessor
 
evaluateInternal(String, MVELExpressionLanguageContext) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
evaluateProcessorArgument(MuleMessage, String) - Method in class org.mule.expression.MessageProcessorExpressionEvaluator
 
evaluateTransformParameter(String, Object, MuleMessage) - Method in class org.mule.module.xml.transformer.XQueryTransformer
Returns the value to be set for the parameter.
evaluateTransformParameter(String, Object, MuleMessage) - Method in class org.mule.module.xml.transformer.XsltTransformer
Returns the value to be set for the parameter.
evaluateTyped(String, MuleMessage) - Method in interface org.mule.api.el.ExpressionLanguage
 
evaluateTyped(String, MuleMessage) - Method in interface org.mule.api.expression.ExpressionEvaluator
Extracts a single typed property from the message
evaluateTyped(String, String, MuleMessage, boolean) - Method in interface org.mule.api.expression.ExpressionManager
Evaluates the given expression propagating dataType.
evaluateTyped(String, MuleMessage) - Method in interface org.mule.api.expression.ExpressionManager
 
evaluateTyped(String, MuleMessage) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
evaluateTyped(String, MuleMessage) - Method in class org.mule.expression.AbstractExpressionEvaluator
 
evaluateTyped(String, String, MuleMessage, boolean) - Method in class org.mule.expression.DefaultExpressionManager
 
evaluateTyped(String, MuleMessage) - Method in class org.mule.expression.DefaultExpressionManager
 
evaluateTyped(String, MuleMessage) - Method in class org.mule.expression.IllegalExpressionEvaluator
 
evaluateTyped(String, MuleMessage) - Method in class org.mule.expression.MessageExpressionEvaluator
 
evaluateTyped(String, MuleMessage) - Method in class org.mule.expression.MessageHeaderExpressionEvaluator
 
evaluateTyped(String, MuleMessage) - Method in class org.mule.expression.MessagePayloadExpressionEvaluator
 
evaluateTyped(String, MuleMessage) - Method in class org.mule.expression.MuleExpressionEvaluator
Deprecated.
 
evaluateTyped(String, MuleMessage) - Method in class org.mule.expression.VariableExpressionEvaluator
 
Evaluator - Annotation Type in org.mule.api.annotations.meta
 
event - Variable in exception org.mule.api.MessagingException
The MuleEvent being processed when the error occurred
EVENT - Static variable in class org.mule.config.spring.parsers.specific.NotificationDefinitionParser
 
event - Variable in class org.mule.processor.BlockingProcessorExecutor
 
event - Variable in class org.mule.work.AbstractMuleEventWork
 
EVENT_ATTRIBUTES - Static variable in class org.mule.config.spring.parsers.specific.NotificationDefinitionParser
 
EVENT_CLASS - Static variable in class org.mule.config.spring.parsers.specific.NotificationDefinitionParser
 
EVENT_CONTEXT - Static variable in class org.mule.module.atom.AbderaServiceComponent
 
EVENT_MAP - Static variable in class org.mule.config.spring.parsers.specific.NotificationDefinitionParser
 
EVENT_MULTICASTER_DESCRIPTOR_NAME - Static variable in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
 
EVENT_NAME - Variable in class org.mule.api.context.notification.ServerNotification
 
EVENT_RECEIVED - Static variable in class org.mule.tck.functional.FunctionalTestNotification
 
EventArgumentResolver - Class in org.mule.module.extension.internal.runtime.resolver
An implementation of ArgumentResolver which returns the MuleEvent associated with a given OperationContext.
EventCallback - Interface in org.mule.tck.functional
The scope of the MuleEvent Callback is to be able to get a the message currently being processed by the FunctionalTestComponent and make assertions on the message payload, headers or attachments or to make changes required for the test.
eventComparator - Variable in class org.mule.routing.correlation.ResequenceCorrelatorCallback
 
eventComparator - Variable in class org.mule.routing.correlation.ResequenceMessagesCorrelatorCallback
 
eventComparator - Variable in class org.mule.routing.MessageChunkAggregator
 
eventComparator - Variable in class org.mule.routing.Resequencer
 
eventCorrelator - Variable in class org.mule.routing.AbstractAggregator
 
EventCorrelator - Class in org.mule.routing.correlation
 
EventCorrelator(EventCorrelatorCallback, MessageProcessor, MessageInfoMapping, MuleContext, FlowConstruct, PartitionableObjectStore, String, ObjectStore<Long>) - Constructor for class org.mule.routing.correlation.EventCorrelator
 
EventCorrelatorCallback - Interface in org.mule.routing.correlation
A callback used to allow pluggable behaviour when correlating events
EventGeneratorJob - Class in org.mule.transport.quartz.jobs
Will generate a new event based o the scheduled time.
EventGeneratorJob() - Constructor for class org.mule.transport.quartz.jobs.EventGeneratorJob
 
EventGeneratorJobConfig - Class in org.mule.transport.quartz.jobs
The configuration for the EventGeneratorJob job.
EventGeneratorJobConfig() - Constructor for class org.mule.transport.quartz.jobs.EventGeneratorJobConfig
 
EventGroup - Class in org.mule.routing
EventGroup is a holder over events grouped by a common group Id.
EventGroup(Object, MuleContext) - Constructor for class org.mule.routing.EventGroup
 
EventGroup(Object, MuleContext, int, String) - Constructor for class org.mule.routing.EventGroup
 
EventGroup.ArrivalOrderEventComparator - Class in org.mule.routing
 
EventGroup.ArrivalOrderEventComparator() - Constructor for class org.mule.routing.EventGroup.ArrivalOrderEventComparator
 
EventGroup.ArrivalOrderMessageComparator - Class in org.mule.routing
 
EventGroup.ArrivalOrderMessageComparator() - Constructor for class org.mule.routing.EventGroup.ArrivalOrderMessageComparator
 
EventListener - Interface in org.mule.api.lifecycle
EventListener is a marker interface that is implemented by objects wishing to receive Mule events in managed environments, such as an EJB container.
eventLogger - Variable in class org.mule.agent.Log4jNotificationLoggerAgent
 
eventProcessingFailedFor(String) - Static method in class org.mule.config.i18n.CoreMessages
 
EventProcessingThread - Class in org.mule.routing
A thread that detects and processes events.
EventProcessingThread(String, long) - Constructor for class org.mule.routing.EventProcessingThread
 
eventPropertyNotSetCannotProcessRequest(String) - Static method in class org.mule.transport.http.i18n.HttpMessages
 
eventReceived(MuleEventContext, Object) - Method in class org.mule.tck.functional.CountdownCallback
 
eventReceived(MuleEventContext, Object) - Method in class org.mule.tck.functional.CounterCallback
 
eventReceived(MuleEventContext, Object) - Method in interface org.mule.tck.functional.EventCallback
 
eventReceived(MuleEventContext, Object) - Method in class org.mule.tck.functional.ResponseWriterCallback
 
EVENTS_STORE_REGISTRY_KEY_PREFIX - Static variable in class org.mule.routing.AbstractAggregator
 
eventsObjectStoreKey - Variable in class org.mule.routing.AbstractAggregator
 
EventTimerTask - Class in org.mule.util.timer
EventTimerTask is a task that causes TimeEvent to be fired to listening objects when a specific number of milliseconds have passed.
EventTimerTask(TimeEventListener) - Constructor for class org.mule.util.timer.EventTimerTask
Constructs a EventTimeTask and registers a listener with it
EventTimerTask(TimeEventListener, String) - Constructor for class org.mule.util.timer.EventTimerTask
Constructs a EventTimeTask and registers a listener with it
EventToMessageSequenceSplittingStrategy - Class in org.mule.util.collection
 
EventToMessageSequenceSplittingStrategy() - Constructor for class org.mule.util.collection.EventToMessageSequenceSplittingStrategy
 
eventTypeNotRecognised(String) - Static method in class org.mule.config.i18n.CoreMessages
 
EventVariableResolverFactory - Class in org.mule.el.mvel
 
EventVariableResolverFactory(ParserConfiguration, MuleContext, MuleEvent) - Constructor for class org.mule.el.mvel.EventVariableResolverFactory
 
EventVariableResolverFactory(ParserConfiguration, MuleContext, MuleEvent, VariableResolverFactory) - Constructor for class org.mule.el.mvel.EventVariableResolverFactory
Convenience constructor to allow for more concise creation of VariableResolverFactory chains without and performance overhead incurred by using a builder.
EventVariableResolverFactory.FlowContext - Class in org.mule.el.mvel
 
EventVariableResolverFactory.FlowContext(FlowConstruct) - Constructor for class org.mule.el.mvel.EventVariableResolverFactory.FlowContext
 
exactTransformerCache - Variable in class org.mule.registry.MuleRegistryHelper
We cache transformer searches so that we only search once
exactTransformerCache - Variable in class org.mule.registry.TypeBasedTransformerResolver
 
exception - Variable in class org.mule.context.notification.AsyncMessageNotification
 
exception - Variable in class org.mule.context.notification.PipelineMessageNotification
 
EXCEPTION_ACTION - Static variable in class org.mule.context.notification.ExceptionNotification
 
EXCEPTION_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
EXCEPTION_MESSAGE - Static variable in exception org.mule.tck.exceptions.FunctionalTestException
 
EXCEPTION_MESSAGE - Static variable in class org.mule.tck.testmodels.services.TestComponent
 
EXCEPTION_STRATEGY_MESSAGE_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
ExceptionBasedRouter - Class in org.mule.routing.outbound
Deprecated.
ExceptionBasedRouter() - Constructor for class org.mule.routing.outbound.ExceptionBasedRouter
Deprecated.
 
ExceptionContextProvider - Interface in org.mule.api.execution
Provides a callback to add info entries to an exception just before logging/handling it.
ExceptionHandler - Interface in org.mule.api.exception
 
ExceptionHandlingMessageProcessor - Class in org.mule.processor
 
ExceptionHandlingMessageProcessor() - Constructor for class org.mule.processor.ExceptionHandlingMessageProcessor
 
ExceptionHandlingReplyToHandlerDecorator - Class in org.mule.api.transport
ReplyToHandler implementation that uses a .MessagingExceptionHandler to handle errors before delegating to the delegate ReplyToHandler instance.
ExceptionHandlingReplyToHandlerDecorator(ReplyToHandler, MessagingExceptionHandler) - Constructor for class org.mule.api.transport.ExceptionHandlingReplyToHandlerDecorator
 
ExceptionHelper - Class in org.mule.config
ExceptionHelper provides a number of helper functions that can be useful for dealing with Mule exceptions.
ExceptionHelper.ExceptionEvaluator<T> - Interface in org.mule.config
 
ExceptionHolder - Class in org.mule.util
TODO
ExceptionHolder() - Constructor for class org.mule.util.ExceptionHolder
 
exceptionListener - Variable in class org.mule.config.spring.factories.TransactionalMessageProcessorsFactoryBean
 
exceptionListener - Variable in class org.mule.construct.AbstractFlowConstruct
 
exceptionListener - Variable in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
exceptionListener - Variable in class org.mule.DefaultMuleContext
Global exception handler which handles "system" exceptions (i.e., when no message is involved).
exceptionListener - Variable in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
Used to store parsed endpoints
exceptionListener - Variable in class org.mule.processor.TransactionalInterceptingMessageProcessor
 
exceptionListener - Variable in class org.mule.service.AbstractService
Deprecated.
The exception strategy used by the service.
ExceptionListener - Class in org.mule.tck.listener
Listener for exception thrown by a message source or flow.
ExceptionListener(MuleContext) - Constructor for class org.mule.tck.listener.ExceptionListener
Constructor for creating a listener for any exception thrown within a flow or message source.
exceptionListenerMustUseOutboundEndpoint(AbstractExceptionListener, ImmutableEndpoint) - Static method in class org.mule.config.i18n.CoreMessages
 
ExceptionMessage - Class in org.mule.message
ExceptionMessage is used by the DefaultServiceExceptionStrategy for wrapping an exception with a message to send via an endpointUri.
ExceptionMessage(MuleEvent, Throwable, String, URI) - Constructor for class org.mule.message.ExceptionMessage
 
ExceptionNotification - Class in org.mule.context.notification
This class is from Mule 2.2.5.
ExceptionNotification(Throwable) - Constructor for class org.mule.context.notification.ExceptionNotification
 
ExceptionNotificationListener<T extends ExceptionNotification> - Interface in org.mule.api.context.notification
ExceptionNotificationListener is an observer interface that objects can implement and then register themselves with the Mule manager to be notified when a Exception event occurs.
exceptionOccurred(FilterChainContext, Throwable) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
 
exceptionOnConnectorNoExceptionListener(String) - Static method in class org.mule.config.i18n.CoreMessages
 
ExceptionPayload - Interface in org.mule.api
ExceptionPayload is a message payload that contains exception information that occurred during message processing.
exceptionPayloadAvailable(MuleMessage) - Method in class org.mule.routing.outbound.ExceptionBasedRouter
Deprecated.
 
ExceptionReader - Interface in org.mule.api.config
Provides a strategy interface for reading information from an exception in a consistent way.
ExceptionReturnTcpMessageReceiver - Class in org.mule.transport.tcp
Extends TcpMessageReceiver providing managing of protocol error conditions.
ExceptionReturnTcpMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.tcp.ExceptionReturnTcpMessageReceiver
 
ExceptionReturnTcpMessageReceiver.TcpWorker - Class in org.mule.transport.tcp
 
ExceptionReturnTcpMessageReceiver.TcpWorker(Socket, AbstractMessageReceiver) - Constructor for class org.mule.transport.tcp.ExceptionReturnTcpMessageReceiver.TcpWorker
 
exceptionStackIs() - Static method in class org.mule.config.i18n.CoreMessages
 
exceptionStrategy(MessagingExceptionHandler) - Method in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
ExceptionStrategyDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
ExceptionStrategyDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.ExceptionStrategyDefinitionParser
 
ExceptionStrategyNotification - Class in org.mule.context.notification
 
ExceptionStrategyNotification(Object, int) - Constructor for class org.mule.context.notification.ExceptionStrategyNotification
 
ExceptionStrategyNotificationListener<T extends ExceptionStrategyNotification> - Interface in org.mule.api.context.notification
 
exceptionThrown(Exception) - Method in class org.mule.util.ExceptionHolder
 
ExceptionToMessagingExceptionExecutionInterceptor - Class in org.mule.execution
Replace any exception thrown with a MessagingException
ExceptionToMessagingExceptionExecutionInterceptor() - Constructor for class org.mule.execution.ExceptionToMessagingExceptionExecutionInterceptor
 
ExceptionTXFilterDefinitionParser - Class in org.mule.config.spring.parsers.specific
TODO
ExceptionTXFilterDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.specific.ExceptionTXFilterDefinitionParser
The class will be inferred from the class attribute
ExceptionTypeExpressionEvaluator - Class in org.mule.expression
 
ExceptionTypeExpressionEvaluator() - Constructor for class org.mule.expression.ExceptionTypeExpressionEvaluator
 
ExceptionTypeFilter - Class in org.mule.routing.filters
A filter that accepts messages that have an exception payload.
ExceptionTypeFilter() - Constructor for class org.mule.routing.filters.ExceptionTypeFilter
 
ExceptionTypeFilter(String) - Constructor for class org.mule.routing.filters.ExceptionTypeFilter
 
ExceptionTypeFilter(Class) - Constructor for class org.mule.routing.filters.ExceptionTypeFilter
 
ExceptionUtils - Class in org.mule.util
Mule exception utilities.
ExceptionUtils() - Constructor for class org.mule.util.ExceptionUtils
 
exceptionWhileProcessing(String, String) - Static method in class org.mule.transport.file.i18n.FileMessages
 
EXCHANGE_PATTERN - Static variable in class org.mule.api.config.MuleProperties
 
EXCHANGE_PATTERN_CAMEL_CASE - Static variable in class org.mule.api.config.MuleProperties
 
exchangePattern - Variable in class org.mule.construct.builder.BridgeBuilder
 
exchangePattern(MessageExchangePattern) - Method in class org.mule.construct.builder.BridgeBuilder
 
exchangePatternForEndpointNotSupported(MessageExchangePattern, String, EndpointURI) - Static method in class org.mule.config.i18n.CoreMessages
 
execSqlQuery(String) - Method in class org.mule.tck.util.MuleDerbyTestDatabase
Executes a query against the database.
execSqlUpdate(String) - Method in class org.mule.tck.util.MuleDerbyTestDatabase
Executes an SQL statement against the database.
execute(EnforcerRuleHelper) - Method in class org.apache.maven.enforcer.rule.EnforcerPortRule
 
execute() - Method in class org.apache.maven.plugin.archetype.BobberArchetypeMojo
 
execute(ProcessCallback<T, O>, O, MessageProcessor, MuleEvent) - Method in interface org.mule.api.devkit.ProcessInterceptor
 
execute(ProcessCallback<T, O>, O, Filter, MuleMessage) - Method in interface org.mule.api.devkit.ProcessInterceptor
 
execute(ProcessCallback<T, O>, MessageProcessor, MuleEvent) - Method in interface org.mule.api.devkit.ProcessTemplate
 
execute(ProcessCallback<T, O>, Filter, MuleMessage) - Method in interface org.mule.api.devkit.ProcessTemplate
 
execute(String, T) - Method in interface org.mule.api.el.ExpressionExecutor
Execute an expression using using the provided context.
execute(ExecutionCallback<T>) - Method in interface org.mule.api.execution.ExecutionTemplate
 
execute() - Method in class org.mule.api.FutureMessageResult
Start asynchronous execution of this task
execute() - Method in interface org.mule.api.processor.ProcessorExecutor
Executes a list of MessageProcessors.
execute(RetryCallback, WorkManager) - Method in interface org.mule.api.retry.RetryPolicyTemplate
 
execute(String, MVELExpressionLanguageContext) - Method in class org.mule.el.mvel.MVELExpressionExecutor
 
execute(ExecutionCallback<MuleEvent>) - Method in class org.mule.execution.ErrorHandlingExecutionTemplate
 
execute(MessageProcessor, MuleEvent) - Method in class org.mule.execution.ExceptionToMessagingExceptionExecutionInterceptor
 
execute(ExecutionCallback<T>, ExecutionContext) - Method in class org.mule.execution.IsolateCurrentTransactionInterceptor
 
execute(MessageProcessor, MuleEvent) - Method in interface org.mule.execution.MessageProcessorExecutionInterceptor
 
execute(MessageProcessor, MuleEvent) - Method in class org.mule.execution.MessageProcessorExecutionTemplate
 
execute(ExecutionCallback<T>, ExecutionContext) - Method in class org.mule.execution.SuspendXaTransactionInterceptor
 
execute(ExecutionCallback<MuleEvent>) - Method in class org.mule.execution.TransactionalErrorHandlingExecutionTemplate
 
execute(ExecutionCallback<T>) - Method in class org.mule.execution.TransactionalExecutionTemplate
 
execute(Statement, QueryTemplate) - Method in interface org.mule.module.db.internal.domain.autogeneratedkey.AutoGeneratedKeyStrategy
Executes a query that can return multiple results
execute(Statement, QueryTemplate) - Method in class org.mule.module.db.internal.domain.autogeneratedkey.ColumnIndexAutoGeneratedKeyStrategy
 
execute(Statement, QueryTemplate) - Method in class org.mule.module.db.internal.domain.autogeneratedkey.ColumnNameAutoGeneratedKeyStrategy
 
execute(Statement, QueryTemplate) - Method in class org.mule.module.db.internal.domain.autogeneratedkey.DefaultAutoGeneratedKeyStrategy
 
execute(Statement, QueryTemplate) - Method in class org.mule.module.db.internal.domain.autogeneratedkey.NoAutoGeneratedKeyStrategy
 
execute(DbConnection, Query) - Method in class org.mule.module.db.internal.domain.executor.AbstractSingleQueryExecutor
 
execute(DbConnection, Query, AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.domain.executor.AbstractSingleQueryExecutor
 
execute(DbConnection, BulkQuery) - Method in interface org.mule.module.db.internal.domain.executor.BulkExecutor
Executes a bulk query
execute(DbConnection, Query, List<List<QueryParamValue>>) - Method in interface org.mule.module.db.internal.domain.executor.BulkExecutor
Executes a parameterized query using a bulk of parameter sets
execute(DbConnection, BulkQuery) - Method in class org.mule.module.db.internal.domain.executor.BulkUpdateExecutor
 
execute(DbConnection, Query, List<List<QueryParamValue>>) - Method in class org.mule.module.db.internal.domain.executor.BulkUpdateExecutor
 
execute(DbConnection, Query) - Method in interface org.mule.module.db.internal.domain.executor.QueryExecutor
Executes a query
execute(DbConnection, Query, AutoGeneratedKeyStrategy) - Method in interface org.mule.module.db.internal.domain.executor.QueryExecutor
 
execute(OperationContext) - Method in class org.mule.module.extension.internal.runtime.ReflectiveMethodOperationExecutor
execute(ExecutionImpl) - Method in class org.mule.module.jbpm.MuleReceiveActivity
 
execute(ActivityExecution) - Method in class org.mule.module.jbpm.MuleSendActivity
 
execute() - Method in interface org.mule.module.launcher.artifact.ShutdownListener
 
execute(JobExecutionContext) - Method in class org.mule.modules.schedulers.cron.CronJob
 
execute() - Method in class org.mule.processor.BlockingProcessorExecutor
 
execute(RetryCallback, WorkManager) - Method in class org.mule.retry.async.AsynchronousRetryTemplate
 
execute(RetryCallback, WorkManager) - Method in class org.mule.retry.policies.AbstractPolicyTemplate
 
execute(ProcessCallback<T, OAuth2Adapter>, OAuth2Adapter, MessageProcessor, MuleEvent) - Method in class org.mule.security.oauth.process.ManagedAccessTokenProcessInterceptor
 
execute(ProcessCallback<T, OAuth2Adapter>, OAuth2Adapter, Filter, MuleMessage) - Method in class org.mule.security.oauth.process.ManagedAccessTokenProcessInterceptor
 
execute(ProcessCallback<P, OAuth2Adapter>, MessageProcessor, MuleEvent) - Method in class org.mule.security.oauth.process.ManagedAccessTokenProcessTemplate
 
execute(ProcessCallback<P, OAuth2Adapter>, Filter, MuleMessage) - Method in class org.mule.security.oauth.process.ManagedAccessTokenProcessTemplate
 
execute(ProcessCallback<P, Capabilities>, MessageProcessor, MuleEvent) - Method in class org.mule.security.oauth.process.OAuthProcessTemplate
 
execute(ProcessCallback<P, Capabilities>, Filter, MuleMessage) - Method in class org.mule.security.oauth.process.OAuthProcessTemplate
 
execute(ProcessCallback<T, O>, O, MessageProcessor, MuleEvent) - Method in class org.mule.security.oauth.process.ProcessCallbackProcessInterceptor
 
execute(ProcessCallback<T, O>, O, Filter, MuleMessage) - Method in class org.mule.security.oauth.process.ProcessCallbackProcessInterceptor
 
execute(ProcessCallback<T, OAuth2Adapter>, OAuth2Adapter, MessageProcessor, MuleEvent) - Method in class org.mule.security.oauth.process.RefreshTokenProcessInterceptor
 
execute(ProcessCallback<T, OAuth2Adapter>, OAuth2Adapter, Filter, MuleMessage) - Method in class org.mule.security.oauth.process.RefreshTokenProcessInterceptor
 
execute(ProcessCallback<T, O>, O, MessageProcessor, MuleEvent) - Method in class org.mule.security.oauth.process.RetryProcessInterceptor
 
execute(ProcessCallback<T, O>, O, Filter, MuleMessage) - Method in class org.mule.security.oauth.process.RetryProcessInterceptor
 
execute(T) - Method in interface org.mule.tck.listener.Callback
 
execute() - Method in class org.mule.tools.anttasks.MuleDeploy
install the application file
execute() - Method in class org.mule.tools.maven.archetype.ConfigurationPatternArchetypeMojo
 
execute() - Method in class org.mule.tools.maven.archetype.ModuleArchetypeMojo
 
execute() - Method in class org.mule.tools.maven.archetype.ProjectArchetypeMojo
 
execute() - Method in class org.mule.tools.maven.archetype.TransportArchetypeMojo
 
execute(MuleEvent, HttpMethod) - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
execute(SqlStatementStrategy, JdbcConnector, ImmutableEndpoint, MuleEvent, long, Connection) - Method in class org.mule.transport.jdbc.sqlstrategy.SqlStatementStrategyExecutor
 
execute(Runnable) - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
execute(JobExecutionContext) - Method in class org.mule.transport.quartz.jobs.AbstractJob
 
execute(Runnable) - Method in class org.mule.transport.TrackingWorkManager
 
execute(Runnable) - Method in class org.mule.util.concurrent.AbstractSynchronizedVariable
 
execute(Runnable) - Method in class org.mule.work.MuleWorkManager
 
execute(Runnable) - Method in class org.mule.work.SerialWorkManager
 
executeAckStatement(Connection, MuleMessage) - Method in class org.mule.transport.jdbc.JdbcMessageReceiver
Executes the acknowledge SQL statement for a given message.
executeBatchAckStatement(Connection, List<MuleMessage>) - Method in class org.mule.transport.jdbc.JdbcMessageReceiver
Executes the acknowledge SQL statement for a list of messages.
executeCommand(String, String...) - Static method in class org.mule.test.infrastructure.process.MuleUtils
 
ExecuteDdlMessageProcessor - Class in org.mule.module.db.internal.processor
Executes a DDL query on a database

Both database and bulk query are resolved, if required, using the MuleEvent being processed.

ExecuteDdlMessageProcessor(DbConfigResolver, QueryResolver, QueryExecutorFactory, TransactionalAction) - Constructor for class org.mule.module.db.internal.processor.ExecuteDdlMessageProcessor
 
ExecuteDdlProcessorBeanDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
ExecuteDdlProcessorBeanDefinitionParser() - Constructor for class org.mule.module.db.internal.config.processor.ExecuteDdlProcessorBeanDefinitionParser
 
executeIoEvent(Connection, IOEvent, boolean) - Method in class org.mule.module.http.internal.listener.grizzly.ExecutorPerServerAddressIOStrategy
 
executeNext() - Method in class org.mule.processor.BlockingProcessorExecutor
 
executeNext() - Method in class org.mule.service.processor.ServiceProcessorExecutor
 
executeQuery(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
executeQuery(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.processor.AbstractSingleQueryDbMessageProcessor
 
executeQuery(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.processor.BulkExecuteMessageProcessor
 
executeQuery(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.processor.DynamicBulkUpdateMessageProcessor
 
executeQuery(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.processor.PreparedBulkUpdateMessageProcessor
 
executeReadStatement(Connection) - Method in class org.mule.transport.jdbc.JdbcMessageReceiver
Executes the read SQL statement to get data from the database.
executeStatement(JdbcConnector, ImmutableEndpoint, MuleEvent, long, Connection) - Method in class org.mule.transport.jdbc.sqlstrategy.SelectSqlStatementStrategy
 
executeStatement(JdbcConnector, ImmutableEndpoint, MuleEvent, long, Connection) - Method in class org.mule.transport.jdbc.sqlstrategy.SimpleUpdateSqlStatementStrategy
 
executeStatement(JdbcConnector, ImmutableEndpoint, MuleEvent, long, Connection) - Method in interface org.mule.transport.jdbc.sqlstrategy.SqlStatementStrategy
 
executeUpdate(Statement, QueryTemplate) - Method in interface org.mule.module.db.internal.domain.autogeneratedkey.AutoGeneratedKeyStrategy
Executes an update query
executeUpdate(Statement, QueryTemplate) - Method in class org.mule.module.db.internal.domain.autogeneratedkey.ColumnIndexAutoGeneratedKeyStrategy
 
executeUpdate(Statement, QueryTemplate) - Method in class org.mule.module.db.internal.domain.autogeneratedkey.ColumnNameAutoGeneratedKeyStrategy
 
executeUpdate(Statement, QueryTemplate) - Method in class org.mule.module.db.internal.domain.autogeneratedkey.DefaultAutoGeneratedKeyStrategy
 
executeUpdate(Statement, QueryTemplate) - Method in class org.mule.module.db.internal.domain.autogeneratedkey.NoAutoGeneratedKeyStrategy
 
executingPhase - Variable in class org.mule.lifecycle.AbstractLifecycleManager
 
EXECUTION_FOLDER - Static variable in class org.mule.module.launcher.MuleFoldersUtil
 
ExecutionCallback<T> - Interface in org.mule.api.execution
Callback with logic to execute within a controlled environment provided by ExecutionTemplate
executionClassLoader - Variable in class org.mule.work.WorkerContext
 
ExecutionContext - Class in org.mule.execution
Provides information about the current execution of an ExecutionTemplate
ExecutionContext() - Constructor for class org.mule.execution.ExecutionContext
 
ExecutionManager - Interface in org.mule.api.debug
Handles the execution of the underlying debugging engine.
ExecutionTemplate<T> - Interface in org.mule.api.execution
ExecutionTemplate provides an execution context for message processing.
EXECUTOR_REJECTED_ATTRIBUTE - Static variable in class org.mule.module.http.internal.listener.grizzly.ExecutorPerServerAddressIOStrategy
 
ExecutorPerServerAddressIOStrategy - Class in org.mule.module.http.internal.listener.grizzly
Grizzly IO Strategy that will handle each work to an specific Executor based on the ServerAddress of a Connection.
ExecutorPerServerAddressIOStrategy(ExecutorProvider) - Constructor for class org.mule.module.http.internal.listener.grizzly.ExecutorPerServerAddressIOStrategy
 
ExecutorProvider - Interface in org.mule.module.http.internal.listener.grizzly
 
EXPAND_ENTITIES_PROPERTY - Static variable in class org.mule.util.xmlsecurity.XMLSecureFactories
 
expandEntities - Variable in class org.mule.util.xmlsecurity.XMLFactoryConfig
 
expandTemplates(byte[], String) - Method in class org.mule.transport.servlet.JarResourceServlet
 
EXPECT - Static variable in class org.mule.module.http.api.HttpHeaders.Names
expectedSize() - Method in class org.mule.routing.EventGroup
Returns the number of events that this EventGroup is expecting before correlation can proceed.
expectFileCount(String, int, long) - Method in class org.mule.tck.util.ftp.FtpClient
Verify that a number of files exist on the ftp server
Expirable - Interface in org.mule.util.monitor
Expirable implementing classes can be notified when they expire
ExpirableObjectStore<T extends Serializable> - Interface in org.mule.api.store
 
EXPIRATION_TIME_EXPRESSION - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
expirationInterval - Variable in class org.mule.util.store.AbstractMonitoredObjectStore
The interval for periodic bounded size enforcement and entry expiration, specified in milliseconds.
expirationInterval - Variable in class org.mule.util.store.MonitoredObjectStoreWrapper
The interval for periodic bounded size enforcement and entry expiration, specified in milliseconds.
expire(int, int) - Method in interface org.mule.api.store.ExpirableObjectStore
 
expire(int, int, String) - Method in interface org.mule.api.store.PartitionableExpirableObjectStore
 
expire() - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
expire() - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
expire() - Method in class org.mule.util.store.InMemoryObjectStore
 
expire() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
expire(int, int) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
expire(int, int, String) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
expire(int, int) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
expire(int, int, String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
expire(int, int) - Method in class org.mule.util.store.PersistentObjectStorePartition
 
expire() - Method in class org.mule.util.store.TextFileObjectStore
 
EXPIRE_PATTERN - Static variable in class org.mule.transport.http.CookieHelper
 
expireAggregation(String) - Method in interface org.mule.api.routing.Aggregator
 
expireAggregation(String) - Method in class org.mule.routing.AbstractAggregator
 
expireAggregation(String) - Method in class org.mule.service.ServiceAsyncReplyCompositeMessageSource
Deprecated.
 
expireAndCount() - Method in class org.mule.util.store.InMemoryObjectStore
 
expired() - Method in class org.mule.transport.http.HttpRequestDispatcherWork
 
expired() - Method in class org.mule.transport.http.OldHttpMessageReceiver.HttpWorker
 
expired() - Method in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
expired() - Method in interface org.mule.util.monitor.Expirable
 
EXPIRES - Static variable in class org.mule.module.http.api.HttpHeaders.Names
EXPIRES_IN_PARAMETER - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
ExpiryMonitor - Class in org.mule.util.monitor
ExpiryMonitor can monitor objects beased on an expiry time and can invoke a callback method once the object time has expired.
ExpiryMonitor(MuleContext, boolean) - Constructor for class org.mule.util.monitor.ExpiryMonitor
 
ExpiryMonitor(String, MuleContext, boolean) - Constructor for class org.mule.util.monitor.ExpiryMonitor
 
ExpiryMonitor(String, int, MuleContext, boolean) - Constructor for class org.mule.util.monitor.ExpiryMonitor
 
ExpiryMonitor(String, int, ClassLoader, MuleContext, boolean) - Constructor for class org.mule.util.monitor.ExpiryMonitor
 
ExpiryMonitor(String, int, ScheduledThreadPoolExecutor, MuleContext, boolean) - Constructor for class org.mule.util.monitor.ExpiryMonitor
 
ExplicitMethodEntryPointResolver - Class in org.mule.model.resolvers
An Entry-point resolver that allows the user to set one or more acceptable method names to look for.
ExplicitMethodEntryPointResolver() - Constructor for class org.mule.model.resolvers.ExplicitMethodEntryPointResolver
 
Expr - Annotation Type in org.mule.api.annotations.expressions
Allows method parameters to be configured with result of one or more Mule expressions public Object save(Object foo, @Expr("#[header:X-User]-#[function:UUID]") String id)
ExprAnnotationParser - Class in org.mule.config.expression
Used to parse Expr parameter annotations
ExprAnnotationParser() - Constructor for class org.mule.config.expression.ExprAnnotationParser
 
expression - Variable in class org.mule.el.ExpressionLanguageComponent
 
expression - Variable in class org.mule.tck.functional.AssertionMessageProcessor
 
EXPRESSION_SEPARATOR - Static variable in class org.mule.expression.ExpressionConfig
 
ExpressionAnnotationParser - Interface in org.mule.api.expression
TODO
ExpressionAnnotationsHelper - Class in org.mule.config.expression
TODO
ExpressionAnnotationsHelper() - Constructor for class org.mule.config.expression.ExpressionAnnotationsHelper
 
ExpressionArgument - Class in org.mule.expression.transformers
TODO
ExpressionArgument() - Constructor for class org.mule.expression.transformers.ExpressionArgument
 
ExpressionArgument(String, ExpressionConfig, boolean) - Constructor for class org.mule.expression.transformers.ExpressionArgument
 
ExpressionArgument(String, ExpressionConfig, boolean, Class<?>) - Constructor for class org.mule.expression.transformers.ExpressionArgument
 
ExpressionComponentDefintionParser - Class in org.mule.config.spring.parsers.specific
 
ExpressionComponentDefintionParser(String, Class<?>) - Constructor for class org.mule.config.spring.parsers.specific.ExpressionComponentDefintionParser
 
ExpressionConfig - Class in org.mule.expression
A simple configuration object for holding the common Expression evaluator configuration.
ExpressionConfig() - Constructor for class org.mule.expression.ExpressionConfig
 
ExpressionConfig(String, String, String) - Constructor for class org.mule.expression.ExpressionConfig
 
ExpressionConfig(String, String, String, String, String) - Constructor for class org.mule.expression.ExpressionConfig
 
expressionConfig - Variable in class org.mule.routing.outbound.ExpressionRecipientList
 
ExpressionConstants - Class in org.mule.expression
Constnts for Headers and Attachment processing shared by a number of the Expression evaluators
ExpressionDataTypeResolver - Interface in org.mule.el.mvel.datatype
Resolves DataType from a compiled MEL expression
ExpressionEnricher - Interface in org.mule.api.expression
ExpressionEnricher enriches a message using the extensible mule expression framework allowing the contribution of additional enrichers.
expressionEnricherNotRegistered(String) - Static method in class org.mule.config.i18n.CoreMessages
 
ExpressionEnricherPostProcessor - Class in org.mule.config.spring.processors
A BeanPostProcessor which registers ExpressionEnrichers in the ExpressionManager
ExpressionEnricherPostProcessor(MuleContext) - Constructor for class org.mule.config.spring.processors.ExpressionEnricherPostProcessor
 
ExpressionEnricherProcessor - Class in org.mule.registry
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)
ExpressionEnricherProcessor(MuleContext) - Constructor for class org.mule.registry.ExpressionEnricherProcessor
Deprecated.
 
expressionEvaluationClassLoader - Variable in class org.mule.expression.transformers.ExpressionArgument
 
expressionEvaluationFailed(String) - Static method in class org.mule.config.i18n.CoreMessages
 
ExpressionEvaluator - Interface in org.mule.api.expression
ExpressionEvaluator extracts a property from the message in a generic way.
expressionEvaluatorNotRegistered(String) - Static method in class org.mule.config.i18n.CoreMessages
 
ExpressionEvaluatorPostProcessor - Class in org.mule.config.spring
Registers custom declarative expression evaluators configured via Spring config.
ExpressionEvaluatorPostProcessor(MuleContext) - Constructor for class org.mule.config.spring.ExpressionEvaluatorPostProcessor
 
ExpressionEvaluatorProcessor - Class in org.mule.registry
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)
ExpressionEvaluatorProcessor(MuleContext) - Constructor for class org.mule.registry.ExpressionEvaluatorProcessor
Deprecated.
 
expressionEvaluatorReturnedNull(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
ExpressionEvaluatorSupport - Class in org.mule.devkit.processor
 
ExpressionEvaluatorSupport() - Constructor for class org.mule.devkit.processor.ExpressionEvaluatorSupport
 
ExpressionExecutor<T extends ExpressionLanguageContext> - Interface in org.mule.api.el
Wraps an expression language engine.
expressionExecutor - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
expressionFailed() - Method in class org.mule.tck.functional.AssertionMessageProcessor
 
expressionFile - Variable in class org.mule.el.ExpressionLanguageComponent
 
ExpressionFilenameParser - Class in org.mule.transport.file
ExpressionFilenameParser can use any expression language supported by Mule to construct a file name for the current message.
ExpressionFilenameParser() - Constructor for class org.mule.transport.file.ExpressionFilenameParser
 
ExpressionFilter - Class in org.mule.routing.filters
Allows boolean expressions to be executed on a message.
ExpressionFilter(String, String, String) - Constructor for class org.mule.routing.filters.ExpressionFilter
 
ExpressionFilter(String, String) - Constructor for class org.mule.routing.filters.ExpressionFilter
 
ExpressionFilter(String) - Constructor for class org.mule.routing.filters.ExpressionFilter
 
ExpressionFilter() - Constructor for class org.mule.routing.filters.ExpressionFilter
 
ExpressionFilterParser - Class in org.mule.config.expression
Will create a filter from one of more expression filters.
ExpressionFilterParser() - Constructor for class org.mule.config.expression.ExpressionFilterParser
 
expressionFinalVariableCannotBeAssignedValue(String) - Static method in class org.mule.config.i18n.CoreMessages
 
expressionInvalidForProperty(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
ExpressionLanguage - Interface in org.mule.api.el
Allows for the execution of expressions within Mule using an expression language.
ExpressionLanguageComponent - Class in org.mule.el
 
ExpressionLanguageComponent() - Constructor for class org.mule.el.ExpressionLanguageComponent
 
ExpressionLanguageContext - Interface in org.mule.api.el
 
ExpressionLanguageDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
ExpressionLanguageDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.ExpressionLanguageDefinitionParser
 
ExpressionLanguageExtension - Interface in org.mule.api.el
Interface used to implement extensions to be used with a Mule Expression Language implementation.
ExpressionLanguageFunction - Interface in org.mule.api.el
 
expressionMalformed(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
ExpressionManager - Interface in org.mule.api.expression
Provides universal access for evaluating expressions embedded in Mule configurations, such as Xml, Java, scripting and annotations.
expressionManager - Variable in class org.mule.api.processor.LoggerMessageProcessor
 
expressionManager - Variable in class org.mule.processor.InvokerMessageProcessor
 
expressionManager - Variable in class org.mule.routing.ExpressionSplitter
 
expressionManager - Variable in class org.mule.routing.outbound.FilteringOutboundRouter
 
expressionManager - Variable in class org.mule.tck.functional.AssertionMessageProcessor
 
ExpressionMessageInfoMapping - Class in org.mule.routing
TODO
ExpressionMessageInfoMapping() - Constructor for class org.mule.routing.ExpressionMessageInfoMapping
 
ExpressionMessageSplitter - Class in org.mule.routing.outbound
Deprecated.
ExpressionMessageSplitter() - Constructor for class org.mule.routing.outbound.ExpressionMessageSplitter
Deprecated.
 
ExpressionMessageSplitter(ExpressionConfig) - Constructor for class org.mule.routing.outbound.ExpressionMessageSplitter
Deprecated.
 
ExpressionMuleEventKeyGenerator - Class in org.mule.keygenerator
Implements MuleEventKeyGenerator using the Mule expression language to generate the cache keys.
ExpressionMuleEventKeyGenerator() - Constructor for class org.mule.keygenerator.ExpressionMuleEventKeyGenerator
 
ExpressionRecipientList - Class in org.mule.routing.outbound
 
ExpressionRecipientList() - Constructor for class org.mule.routing.outbound.ExpressionRecipientList
 
expressionResultWasNull(String) - Static method in class org.mule.config.i18n.CoreMessages
 
ExpressionRuntimeException - Exception in org.mule.api.expression
If thrown by the DefaultExpressionManager if an expression returns null and failIfNull was set when ExpressionManager.evaluate(String,org.mule.api.MuleMessage,boolean) was called.
ExpressionRuntimeException(Message) - Constructor for exception org.mule.api.expression.ExpressionRuntimeException
 
ExpressionRuntimeException(Message, Throwable) - Constructor for exception org.mule.api.expression.ExpressionRuntimeException
 
ExpressionSplitter - Class in org.mule.routing
Splits a message using the expression provided invoking the next message processor one for each split part.
ExpressionSplitter() - Constructor for class org.mule.routing.ExpressionSplitter
 
ExpressionSplitter(ExpressionConfig) - Constructor for class org.mule.routing.ExpressionSplitter
 
ExpressionTransformer - 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.
ExpressionTransformer() - Constructor for class org.mule.expression.transformers.ExpressionTransformer
 
ExpressionTransformerDefinitionParser - Class in org.mule.config.spring.parsers.specific
This allows a message processor to be defined globally, or embedded within an endpoint.
ExpressionTransformerDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.ExpressionTransformerDefinitionParser
 
ExpressionUtils - Class in org.mule.expression
Used by the different header expression evaluators to read message properties, honuouring scope and return type
extendBean(Attr) - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
Add a property defined by an attribute to the bean we are constructing.
extendBean(String, Object, boolean) - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
Allow direct access to bean for more complex cases
extendBean(Attr) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
Add a property defined by an attribute to the bean we are constructing.
extendBean(String, Object, boolean) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
Allow direct access to bean for major hacks
ExtendedQueryRunner - Class in org.mule.transport.jdbc
An extended version of the Query runner that supports query timeouts
ExtendedQueryRunner(DataSource, int) - Constructor for class org.mule.transport.jdbc.ExtendedQueryRunner
 
ExtendingOperationCapability<T> - Class in org.mule.module.extension.internal.capability.metadata
A metadata capability which marks that an operation is augmenting the functionality of an Extension which is defined in a type annotated with Extensible.
ExtendingOperationCapability(Class<T>) - Constructor for class org.mule.module.extension.internal.capability.metadata.ExtendingOperationCapability
Creates a new instance pointing to a type annotated with IllegalArgumentException
extendProblemDetails(Problem) - Method in class org.mule.config.spring.MissingParserProblemReporter
 
extendPropertiesForSession(Properties, Properties, URLName) - Method in class org.mule.transport.email.AbstractMailConnector
Subclasses should extend this to add further properties.
extendPropertiesForSession(Properties, Properties, URLName) - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
extendPropertiesForSession(Properties, Properties, URLName) - Method in class org.mule.transport.email.GmailSmtpConnector
 
extendPropertiesForSession(Properties, Properties, URLName) - Method in class org.mule.transport.email.SmtpsConnector
 
extendTarget(Attr) - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
Add a property defined by an attribute to the parent of the bean we are constructing.
extendTarget(String, Object, boolean) - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
Allow direct access to target for more complex cases
extendTarget(String, String, Object) - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
 
extendTarget(Attr) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
Add a property defined by an attribute to the parent of the bean we are constructing.
extendTarget(String, Object, boolean) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
Allow direct access to target for major hacks
extendTarget(String, String, Object) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
ExtendTarget - Class in org.mule.config.spring.parsers.processors
 
ExtendTarget(String, String) - Constructor for class org.mule.config.spring.parsers.processors.ExtendTarget
 
ExtensionDiscoverer - Interface in org.mule.module.extension.internal.introspection
A component capable of searching the classpath for extensions according to the algorithm described in ExtensionManager.discoverExtensions(ClassLoader)
ExtensionManagerAdapter - Interface in org.mule.module.extension.internal.manager
An adapter interface which expands the contract of ExtensionManager with functionality that is internal to this implementation of the extensions API and that extensions themselves shouldn't be able to access
ExtensionManagerFactoryBean - Class in org.mule.config.spring.factories
A FactoryBean which returns the ExtensionManager obtained through MuleContext.getExtensionManager().
ExtensionManagerFactoryBean(MuleContext) - Constructor for class org.mule.config.spring.factories.ExtensionManagerFactoryBean
 
ExtensionsFunctionalTestCase - Class in org.mule.tck.junit4
Base test class for FunctionalTestCases that make use of components generated through the extensions API.
ExtensionsFunctionalTestCase() - Constructor for class org.mule.tck.junit4.ExtensionsFunctionalTestCase
 
ExtensionsManagerConfigurationBuilder - Class in org.mule.config.builders
Implementation of ConfigurationBuilder that register a ExtensionManager if it's present in the classpath
ExtensionsManagerConfigurationBuilder() - Constructor for class org.mule.config.builders.ExtensionsManagerConfigurationBuilder
 
EXTERNAL_ENTITIES_PROPERTY - Static variable in class org.mule.util.xmlsecurity.XMLSecureFactories
 
EXTERNAL_REDIRECT_URL_PROPERTY - Static variable in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
externalEntities - Variable in class org.mule.util.xmlsecurity.XMLFactoryConfig
 
ExternalTransactionAwareTransactionFactory - Interface in org.mule.api.transaction
ExternalTransactionAwareTransactionFactory creates a transaction, possibly representing a transaction started outside Mule.
ExternalXaTransaction - Class in org.mule.transaction
ExternalXaTransaction represents an external XA transaction in Mule.
ExternalXaTransaction(MuleContext) - Constructor for class org.mule.transaction.ExternalXaTransaction
 
extra - Variable in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
extractAccessCode(Pattern, String) - Method in class org.mule.security.oauth.util.DefaultOAuthResponseParser
 
extractAccessCode(Pattern, String) - Method in interface org.mule.security.oauth.util.OAuthResponseParser
 
ExtractAuthorizationCodeMessageProcessor - Class in org.mule.security.oauth.processor
 
ExtractAuthorizationCodeMessageProcessor(Pattern) - Constructor for class org.mule.security.oauth.processor.ExtractAuthorizationCodeMessageProcessor
 
extractCapability(DeclarationDescriptor, Class<?>) - Method in interface org.mule.module.extension.CapabilityExtractor
Looks for a specific capability in the given extensionType and returns it.
extractCredentials(InboundEndpoint) - Method in class org.mule.DefaultMuleEvent
 
extractExpirationTime(Pattern, String) - Method in class org.mule.security.oauth.util.DefaultOAuthResponseParser
extractExpirationTime(Pattern, String) - Method in interface org.mule.security.oauth.util.OAuthResponseParser
 
extractMuleMessage(MuleEvent) - Method in exception org.mule.api.MessagingException
 
extractPath(String) - Static method in class org.mule.module.http.internal.HttpParser
 
extractPayload(Message) - Method in class org.mule.module.cxf.MuleInvoker
 
extractPayload(Object, String) - Method in class org.mule.transport.AbstractMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.ajax.AjaxMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.DefaultMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.email.MailMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.file.FileContentsMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.file.FileMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.ftp.FtpMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.rmi.RmiMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.soap.axis.AxisMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.udp.UdpMuleMessageFactory
 
extractPayload(Object, String) - Method in class org.mule.transport.xmpp.XmppMuleMessageFactory
 
extractPayloadFromHttpMethod(HttpMethod) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
extractPayloadFromHttpRequest(HttpRequest) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
extractPayloadFromHttpRequest(HttpRequest) - Method in class org.mule.transport.http.HttpMultipartMuleMessageFactory
 
extractPayloadFromPostRequest(HttpServletRequest) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
extractQueryParams(String) - Static method in class org.mule.module.http.internal.HttpParser
 
extractRefreshToken(Pattern, String) - Method in class org.mule.security.oauth.util.DefaultOAuthResponseParser
extractRefreshToken(Pattern, String) - Method in interface org.mule.security.oauth.util.OAuthResponseParser
 
extractResources(String, Class, File, boolean) - Static method in class org.mule.util.FileUtils
Extract the specified resource to the given directory for remain all directory struct
extractResultFromNode(JsonNode) - Method in class org.mule.module.json.JsonExpressionEvaluator
 
extractResultFromNode(JsonNode) - Method in class org.mule.module.json.JsonNodeExpressionEvaluator
 
extractResultFromNode(Object) - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
extractResultFromNode(Object) - Method in class org.mule.module.xml.expression.BeanPayloadExpressionEvaluator
Deprecated.
 
extractResultFromNode(Object) - Method in class org.mule.module.xml.expression.XPathBranchExpressionEvaluator
Deprecated.
 
extractResultFromNode(Object) - Method in class org.mule.module.xml.expression.XPathExpressionEvaluator
Deprecated.
 
extractResultFromNode(Object) - Method in class org.mule.module.xml.expression.XPathNodeExpressionEvaluator
Deprecated.
 
extractResultsFromNodes(List<?>) - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
extractW3CElement(Object) - Method in class org.mule.module.xml.expression.XPathNodeExpressionEvaluator
Deprecated.
 

F

FACTORY - Static variable in class org.mule.config.spring.parsers.specific.TransactionDefinitionParser
 
factory - Variable in class org.mule.transport.jms.xa.DefaultXAConnectionFactoryWrapper
 
FACTORY_CLASS - Static variable in class org.mule.config.spring.parsers.specific.TransactionDefinitionParser
 
FACTORY_REF - Static variable in class org.mule.config.spring.parsers.specific.TransactionDefinitionParser
 
factoryDelegate - Static variable in class org.mule.transport.vm.VMTransactionFactory
 
factoryName - Variable in class org.mule.util.xmlsecurity.XMLFactoryConfig
 
failed(Throwable) - Method in class org.mule.module.http.internal.listener.grizzly.BaseResponseCompletionHandler
 
failed(Throwable) - Method in class org.mule.module.http.internal.listener.grizzly.ResponseCompletionHandler
The method will be called, if http message transferring was failed.
failed(Throwable) - Method in class org.mule.module.http.internal.listener.grizzly.ResponseStreamingCompletionHandler
The method will be called, if file transferring was failed.
FAILED_DISPATCHER - Static variable in interface org.mule.api.retry.RetryContext
 
FAILED_RECEIVER - Static variable in interface org.mule.api.retry.RetryContext
 
FAILED_REQUESTER - Static variable in interface org.mule.api.retry.RetryContext
 
failedToBind(URI) - Static method in class org.mule.transport.udp.i18n.UdpMessages
 
failedToBindToUri(URI) - Static method in class org.mule.transport.tcp.i18n.TcpMessages
 
failedToBuildMessage() - Static method in class org.mule.config.i18n.CoreMessages
 
failedToClone(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToCloseSocket() - Static method in class org.mule.transport.tcp.i18n.TcpMessages
 
failedToConnect(URI) - Static method in class org.mule.transport.http.i18n.HttpMessages
 
failedToConvertStringUsingEncoding(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToCreate(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToCreateAndDispatchResponse(Object) - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
failedToCreateConnectorFromUri(EndpointURI) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToCreateDocumentBuilder() - Static method in class org.mule.module.xml.i18n.XmlMessages
 
failedToCreateEndpointFromLocation(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToCreateManagerInstance(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToCreateObjectWith(String, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToCreateProxyFor(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToDeleteFile(File) - Static method in class org.mule.transport.file.i18n.FileMessages
 
failedToDeserializeHandshakeFromServer() - Static method in class org.mule.module.client.i18n.ClientMessages
Deprecated.
failedToDispatchActionNoResponseFromServer(String, int) - Static method in class org.mule.module.client.i18n.ClientMessages
Deprecated.
failedToDispatchClientEvent() - Static method in class org.mule.module.client.i18n.ClientMessages
Deprecated.
failedToDispatchToReplyto(ImmutableEndpoint) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToDispose(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToFindEntrypointForComponent(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToGetOutputStream() - Static method in class org.mule.config.i18n.CoreMessages
 
failedToGetPooledObject() - Static method in class org.mule.config.i18n.CoreMessages
 
failedToInitMessageReader() - Static method in class org.mule.transport.tcp.i18n.TcpMessages
 
failedToInitSecurityProvider(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToInvoke(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToInvokeLifecycle(String, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToInvokeReplyMethod(String) - Static method in class org.mule.config.i18n.AnnotationsMessages
 
failedToInvokeRestService(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToLoad(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToLoadTransformer(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToLocateHost(URI) - Static method in class org.mule.transport.udp.i18n.UdpMessages
 
failedToMoveFile(String, String) - Static method in class org.mule.transport.file.i18n.FileMessages
 
failedToParseConfigResource(String) - Static method in class org.mule.config.builders.i18n.BuildersMessages
 
failedToProcessExtractorFunction(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToProcessRequest() - Static method in class org.mule.transport.servlet.i18n.ServletMessages
 
failedToProcessXPath(String) - Static method in class org.mule.module.xml.i18n.XmlMessages
 
FailedToQueueEventException - Exception in org.mule.api.service
FailedToQueueEventException is thrown when an event cannot be put on an internal service queue.
FailedToQueueEventException(Message, MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.service.FailedToQueueEventException
 
FailedToQueueEventException(Message, MuleEvent, Throwable, MessageProcessor) - Constructor for exception org.mule.api.service.FailedToQueueEventException
 
failedToReadAttachment(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToReadFromStore(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToReadPayload() - Static method in class org.mule.config.i18n.CoreMessages
 
failedToReadPayload(String) - Static method in class org.mule.transport.servlet.i18n.ServletMessages
 
failedToRecevieWithTimeout(Object, long) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToRegisterNamespace(String, String) - Static method in class org.mule.module.xml.i18n.XmlMessages
 
failedToRegisterOBjectWithMule(Class) - Static method in class org.mule.module.guice.i18n.GuiceMessages
 
failedtoRegisterOnEndpoint(String, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToReinitMule() - Static method in class org.mule.module.spring.i18n.SpringMessages
 
failedToRouterViaEndpoint(MessageProcessor) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToScheduleWork() - Static method in class org.mule.config.i18n.CoreMessages
 
failedToSetPropertiesOn(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToSetProxyOnService(Object, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToStart(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToStartAjaxServlet() - Static method in class org.mule.transport.ajax.i18n.AjaxMessages
 
failedToStartInboundEndpoint(InboundEndpoint) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToStop(String) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToStopInboundEndpoint(InboundEndpoint) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToUnregister(String, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
failedToWriteMessageToStore(Object, String) - Static method in class org.mule.config.i18n.CoreMessages
 
failOnTimeout - Variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
failOnTimeout - Variable in class org.mule.service.ServiceAsyncReplyCompositeMessageSource
Deprecated.
 
FAILURE_PROCESSING_REDIRECT_URL_REQUEST_STATUS - Static variable in class org.mule.module.oauth2.internal.authorizationcode.AutoAuthorizationCodeTokenRequestHandler
 
failureExpression - Variable in class org.mule.routing.FirstSuccessful
 
failureExpressionFilter - Variable in class org.mule.routing.FirstSuccessfulRoutingStrategy
 
FailureStatusCodeValidator - Class in org.mule.module.http.internal.request
 
FailureStatusCodeValidator() - Constructor for class org.mule.module.http.internal.request.FailureStatusCodeValidator
 
FAKE_SERVER_DISABLE_LOG_REPOSITORY_SELECTOR - Static variable in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
FakeLock - Class in org.mule.tck.util
 
FakeLock() - Constructor for class org.mule.tck.util.FakeLock
 
FakeMuleServer - Class in org.mule.test.infrastructure.deployment
 
FakeMuleServer(String) - Constructor for class org.mule.test.infrastructure.deployment.FakeMuleServer
 
FakeMuleServer(String, List<MuleCoreExtension>) - Constructor for class org.mule.test.infrastructure.deployment.FakeMuleServer
 
FakeObjectStore<T extends Serializable> - Class in org.mule.tck.util
 
FakeObjectStore() - Constructor for class org.mule.tck.util.FakeObjectStore
 
FallbackErrorMapper - Class in org.mule.module.jersey.exception
A default ResponseErrorMapper to be used when no other error mapper has been configured by the user
FallbackErrorMapper() - Constructor for class org.mule.module.jersey.exception.FallbackErrorMapper
 
fatal(Problem) - Method in class org.mule.config.spring.MissingParserProblemReporter
 
fatal(Object) - Method in class org.mule.util.MuleLogger
 
fatal(Object, Throwable) - Method in class org.mule.util.MuleLogger
 
fatalError(TransformerException) - Method in class org.mule.module.xml.transformer.XsltTransformer.DefaultErrorListener
 
fatalErrorInShutdown() - Static method in class org.mule.config.i18n.CoreMessages
 
fatalErrorWhileRunning() - Static method in class org.mule.config.i18n.CoreMessages
 
FatalException - Exception in org.mule.api.lifecycle
FatalException can be thrown during initialisation or during execution to indicate that something fatal has occurred and the MuleManager must shutdown.
FatalException(Message, Object) - Constructor for exception org.mule.api.lifecycle.FatalException
 
FatalException(Message, Throwable, Object) - Constructor for exception org.mule.api.lifecycle.FatalException
 
FatalException(Throwable, Object) - Constructor for exception org.mule.api.lifecycle.FatalException
 
features - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
FEATURES - Static variable in class org.mule.module.cxf.CxfConstants
 
FEED_PROPERTY - Static variable in class org.mule.module.atom.routing.FeedSplitter
 
FEED_PROPERTY - Static variable in class org.mule.module.rss.routing.FeedSplitter
 
feedback - Variable in class org.mule.transport.servlet.AbstractReceiverServlet
 
FEEDBACK_PROPERTY - Static variable in class org.mule.transport.servlet.AbstractReceiverServlet
 
FeedLastUpdatedFilter - Class in org.mule.module.atom.routing
Will filter a feed who's update date has changed since the last time it was read.
FeedLastUpdatedFilter() - Constructor for class org.mule.module.atom.routing.FeedLastUpdatedFilter
 
FeedLastUpdatedFilter(Date) - Constructor for class org.mule.module.atom.routing.FeedLastUpdatedFilter
 
FeedLastUpdatedFilter - Class in org.mule.module.rss.routing
Will filter a feed who's update date has changed since the last time it was read.
FeedLastUpdatedFilter() - Constructor for class org.mule.module.rss.routing.FeedLastUpdatedFilter
 
FeedLastUpdatedFilter(Date) - Constructor for class org.mule.module.rss.routing.FeedLastUpdatedFilter
 
FeedSplitter - Class in org.mule.module.atom.routing
An inbound router that will split a Feed into entries.
FeedSplitter() - Constructor for class org.mule.module.atom.routing.FeedSplitter
 
FeedSplitter - Class in org.mule.module.rss.routing
Will split the feed into entries.
FeedSplitter() - Constructor for class org.mule.module.rss.routing.FeedSplitter
 
fetch(String) - Method in interface org.mule.module.launcher.AppBloodhound
Sniff around and get me the app descriptor!
fetch(String) - Method in class org.mule.module.launcher.DefaultAppBloodhound
 
FETCH_SIZE - Static variable in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
fetchAccessToken(OAuth1Adapter, String, String, String, String) - Method in class org.mule.security.oauth.BaseOAuth1Manager
Retrieves the access token for the given adapter with the given parameters.
fetchAccessToken(OAuth2Adapter, String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Makes an http call to the adapter's accessTokenUrl and extracts the access token, which is then set into the adapter
fetchAccessToken(String, String, String, String) - Method in interface org.mule.security.oauth.OAuth1Adapter
Fetches an access token and stores it into this adapter
fetchAccessToken(OAuth1Adapter, String, String, String, String) - Method in interface org.mule.security.oauth.OAuth1Manager
Retrieves the access token for the given adapter with the given parameters.
fetchAccessToken(String) - Method in interface org.mule.security.oauth.OAuth2Adapter
Acquire access token and secret
fetchAccessToken(OAuth2Adapter, String) - Method in interface org.mule.security.oauth.OAuth2Manager
Makes an http call to the adapter's accessTokenUrl and extracts the access token, which is then set into the adapter
FetchAccessTokenMessageProcessor - Class in org.mule.security.oauth.processor
 
FetchAccessTokenMessageProcessor() - Constructor for class org.mule.security.oauth.processor.FetchAccessTokenMessageProcessor
 
fetchApplicationDescriptor(ArtifactClassLoader) - Method in class org.mule.module.launcher.log4j2.MuleLoggerContextFactory
 
fetchCallbackParameters(OAuth2Adapter, String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Extracts any custom parameters from the OAuth response and sets them accordingly on the adapter
FieldDebugInfo<T> - Class in org.mule.api.debug
Provides debug information for an object field.
FieldDebugInfoFactory - Class in org.mule.api.debug
Creates instances of FieldDebugInfo
FieldDebugInfoFactory.FieldEvaluator - Interface in org.mule.api.debug
Evaluates a field to provide its value
FILE - Static variable in class org.mule.transport.file.FileConnector
 
FILE_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.query.QueryTemplateBeanDefinitionParser
 
FileBulkQueryResolver - Class in org.mule.module.db.internal.resolver.query
Resolves a bulk query reading the queries from a file
FileBulkQueryResolver(String, QueryTemplateParser, FileReader) - Constructor for class org.mule.module.db.internal.resolver.query.FileBulkQueryResolver
 
fileChanged(File) - Method in interface org.mule.util.monitor.FileListener
Called when one of the monitored files are created, deleted or modified.
FileChecker - Class in org.mule.tools.anttasks
Check file parameters to Ant tasks
FileChecker(Location) - Constructor for class org.mule.tools.anttasks.FileChecker
Create a FileChecker
fileClose(File) - Method in interface org.mule.transport.file.InputStreamCloseListener
Call when a file input stream gets closed
FileConnector - Class in org.mule.transport.file
FileConnector is used for setting up listeners on a directory and for writing files to a directory.
FileConnector(MuleContext) - Constructor for class org.mule.transport.file.FileConnector
 
FileContainsInLine - Class in org.mule.test.infrastructure
 
FileContentsMuleMessageFactory - Class in org.mule.transport.file
FileContentsMuleMessageFactory converts the InputStream's content into a byte[] as payload for the MuleMessage.
FileContentsMuleMessageFactory() - Constructor for class org.mule.transport.file.FileContentsMuleMessageFactory
 
fileDoesNotExist(String) - Static method in class org.mule.transport.file.i18n.FileMessages
 
FileEndpointURIBuilder - Class in org.mule.transport.file
FileEndpointBuilder File uris need some special processing because the uri path can be any length, and the default resolver relies on a particular path format.
FileEndpointURIBuilder() - Constructor for class org.mule.transport.file.FileEndpointURIBuilder
 
fileExists(String) - Method in class org.mule.tck.util.ftp.FtpClient
Check if a file exists on the ftp server
FileListener - Interface in org.mule.util.monitor
Interface for listening to disk file changes.
FileMessageDispatcher - Class in org.mule.transport.file
FileMessageDispatcher is used to read/write files to the filesystem
FileMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.file.FileMessageDispatcher
 
FileMessageDispatcherFactory - Class in org.mule.transport.file
FileMessageDispatcherFactory creaes a dispatcher responsible for writing files to disk
FileMessageDispatcherFactory() - Constructor for class org.mule.transport.file.FileMessageDispatcherFactory
 
FileMessageReceiver - Class in org.mule.transport.file
FileMessageReceiver is a polling listener that reads files from a directory.
FileMessageReceiver(Connector, FlowConstruct, InboundEndpoint, String, String, String, long) - Constructor for class org.mule.transport.file.FileMessageReceiver
 
FileMessageRequester - Class in org.mule.transport.file
FileMessageRequester is used to read/write files to the filesystem
FileMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.file.FileMessageRequester
 
FileMessageRequesterFactory - Class in org.mule.transport.file
Creates a requester responsible for reading files from disk
FileMessageRequesterFactory() - Constructor for class org.mule.transport.file.FileMessageRequesterFactory
 
FileMessages - Class in org.mule.transport.file.i18n
 
FileMessages() - Constructor for class org.mule.transport.file.i18n.FileMessages
 
FileMonitor - Class in org.mule.util.monitor
Class for monitoring changes in disk files.
FileMonitor(long) - Constructor for class org.mule.util.monitor.FileMonitor
Create a file monitor instance with specified polling interval.
FileMonitor.FileMonitorNotifier - Class in org.mule.util.monitor
This is the timer thread which is executed every n milliseconds according to the setting of the file monitor.
FileMonitor.FileMonitorNotifier() - Constructor for class org.mule.util.monitor.FileMonitor.FileMonitorNotifier
 
FileMonitor.FileMonitorNotifier(ExceptionListener) - Constructor for class org.mule.util.monitor.FileMonitor.FileMonitorNotifier
 
fileMoveCompleted() - Method in interface org.mule.tck.util.ftp.MuleFtplet.Callback
 
FileMuleMessageFactory - Class in org.mule.transport.file
FileMuleMessageFactory creates a new MuleMessage with a File or InputStream payload.
FileMuleMessageFactory() - Constructor for class org.mule.transport.file.FileMuleMessageFactory
 
filenameFilter - Variable in class org.mule.transport.ftp.FtpMessageReceiver
 
filenameParser - Variable in class org.mule.transport.file.FileConnector
 
FilenameParser - Interface in org.mule.transport.file
FilenameParser is a simple expression parser interface for processing filenames
FilenameRegexFilter - Class in org.mule.transport.file.filters
FilenameRegexFilter filters incoming files from a directory, based on a regular expression.
FilenameRegexFilter() - Constructor for class org.mule.transport.file.filters.FilenameRegexFilter
 
FileNamespaceHandler - Class in org.mule.transport.file.config
Reigsters a Bean Definition Parser for handling elements.
FileNamespaceHandler() - Constructor for class org.mule.transport.file.config.FileNamespaceHandler
 
FilenameUtils - Class in org.mule.util
 
FilenameWildcardFilter - Class in org.mule.transport.file.filters
FilenameWildcardFilter filters incoming files from a directory, based on file patterns.
FilenameWildcardFilter() - Constructor for class org.mule.transport.file.filters.FilenameWildcardFilter
 
FilenameWildcardFilter(String) - Constructor for class org.mule.transport.file.filters.FilenameWildcardFilter
 
fileNotFound(String) - Static method in class org.mule.transport.http.i18n.HttpMessages
 
FileQueueStoreFactoryBean - Class in org.mule.config.spring.factories
 
FileQueueStoreFactoryBean() - Constructor for class org.mule.config.spring.factories.FileQueueStoreFactoryBean
 
FileReader - Interface in org.mule.module.db.internal.util
Abstracts file reading operations
fileStore - Variable in class org.mule.util.store.TextFileObjectStore
 
FileToByteArray - Class in org.mule.transport.file.transformers
FileToByteArray reads the contents of a file as a byte array.
FileToByteArray() - Constructor for class org.mule.transport.file.transformers.FileToByteArray
 
FileToString - Class in org.mule.transport.file.transformers
FileToString reads file contents into a string.
FileToString() - Constructor for class org.mule.transport.file.transformers.FileToString
 
fileUploadCompleted() - Method in interface org.mule.tck.util.ftp.MuleFtplet.Callback
 
FileUtils - Class in org.mule.util
FileUtils contains useful methods for dealing with files & directories.
FileUtils() - Constructor for class org.mule.util.FileUtils
 
fileWithPathComponents(String[]) - Static method in class org.mule.util.FilenameUtils
 
fillProperties(InboundEndpoint) - Method in class org.mule.DefaultMuleEvent
 
Filter - Interface in org.mule.api.routing.filter
The Filter interface allows MuleMessage filtering.
FILTER - Static variable in class org.mule.config.spring.parsers.specific.FilterDefinitionParser
 
FILTER - Static variable in class org.mule.config.spring.parsers.specific.FilterRefDefinitionParser
 
filter - Variable in class org.mule.model.resolvers.ReflectionEntryPointResolver
 
filter(FilterContext) - Method in class org.mule.module.http.internal.request.grizzly.CustomTimeoutThrottleRequestFilter
 
filter - Variable in class org.mule.routing.MessageFilter
 
filter - Variable in class org.mule.routing.WireTap
 
filter(List<Converter>, DataType<?>, DataType<?>) - Method in class org.mule.transformer.graph.CompositeConverterFilter
 
filter(List<Converter>, DataType<?>, DataType<?>) - Method in interface org.mule.transformer.graph.ConverterFilter
Filters a list of converters
filter(List<Converter>, DataType<?>, DataType<?>) - Method in class org.mule.transformer.graph.NameConverterFilter
 
filter(List<Converter>, DataType<?>, DataType<?>) - Method in class org.mule.transformer.graph.PriorityWeightingConverterFilter
 
filter(List<Converter>, DataType<?>, DataType<?>) - Method in class org.mule.transformer.graph.TransformationLengthConverterFilter
 
filter - Variable in class org.mule.transport.ajax.AjaxMuleMessageFactory
 
FilterConverter - Class in org.mule.config.converters
Converts an Expression sting into a Filter object.
FilterConverter() - Constructor for class org.mule.config.converters.FilterConverter
 
FilterDefinitionParser - Class in org.mule.config.spring.parsers.specific
This allows a filter to be defined globally, or embedded within an endpoint.
FilterDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.FilterDefinitionParser
 
FilterDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.FilterDefinitionParser
 
filteredTap - Variable in class org.mule.routing.WireTap
 
FilterEventHandler - Class in org.mule.module.sxc
 
FilterEventHandler(SxcFilteringOutboundRouter, SxcFilter) - Constructor for class org.mule.module.sxc.FilterEventHandler
 
filterFailureException(MuleEvent, Exception) - Method in class org.mule.processor.AbstractFilteringMessageProcessor
 
filterFailureException(MuleEvent, Exception) - Method in class org.mule.routing.MessageFilter
 
FilteringOutboundRouter - Class in org.mule.routing.outbound
FilteringRouter is a router that accepts events based on a filter set.
FilteringOutboundRouter() - Constructor for class org.mule.routing.outbound.FilteringOutboundRouter
 
filterParamsByValue(String, String) - Method in class org.mule.util.UriParamFilter
 
FilterRefDefinitionParser - Class in org.mule.config.spring.parsers.specific
This allows a filter to be defined globally, or embedded within an endpoint.
FilterRefDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.FilterRefDefinitionParser
 
FilterUnacceptedException - Exception in org.mule.api.routing.filter
 
FilterUnacceptedException(Message, MuleEvent, Filter, MessageProcessor) - Constructor for exception org.mule.api.routing.filter.FilterUnacceptedException
 
FilterUnacceptedException(Message, MuleEvent, Filter, Throwable) - Constructor for exception org.mule.api.routing.filter.FilterUnacceptedException
 
FilterUnacceptedException(Message, MuleEvent, Throwable) - Constructor for exception org.mule.api.routing.filter.FilterUnacceptedException
 
FilterUnacceptedException(Message, MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.routing.filter.FilterUnacceptedException
 
filterUnacceptedException(MuleEvent) - Method in class org.mule.processor.AbstractFilteringMessageProcessor
 
filterUnacceptedException(MuleEvent) - Method in class org.mule.routing.MessageFilter
 
finalCleanUp() - Method in class org.mule.util.queue.objectstore.xa.AbstractTransactionContext
Deprecated.
 
finalCleanUp() - Method in class org.mule.util.xa.AbstractTransactionContext
 
finalize() - Method in class org.hibernate.connection.SimpleConnectionProvider
 
findActiveActivityNames() - Method in class org.mule.module.jbpm.EndedProcess
 
findActiveExecutionIn(String) - Method in class org.mule.module.jbpm.EndedProcess
 
findAllListableObjectStores() - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
findAllQueueStores() - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
findAnnotation(Class) - Method in class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
 
findAnnotationOnBean(String, Class<A>) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Find a Annotation of annotationType on the specified bean, traversing its interfaces and super classes if no annotation can be found on the given class itself, as well as checking its raw bean class if not found on the exposed bean reference (e.g.
findApplication(String) - Method in interface org.mule.module.launcher.DeploymentService
Finds an active application by name.
findApplication(String) - Method in class org.mule.module.launcher.MuleDeploymentService
 
findApplication(String) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
Finds deployed application by name.
findArtifact(String, ObservableList<T>) - Method in class org.mule.module.launcher.DeploymentDirectoryWatcher
 
findAttributeReaders(Class) - Static method in class org.mule.util.ClassReader
 
findAutowireCandidates(String, Class<?>, DependencyDescriptor) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Find bean instances that match the required type.
findClass(String) - Method in class org.mule.module.launcher.FineGrainedControlClassLoader
 
findClass(String) - Method in class org.mule.module.launcher.MuleApplicationClassLoader
 
findConnector() - Method in class org.mule.transport.DefaultReplyToHandler
 
findConnectorClass(Class, String) - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
See if there's a preferred connector class
findCounter(String) - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
findDependencies(MuleCoreExtension) - Method in interface org.mule.module.launcher.coreextension.MuleCoreExtensionDependencyDiscoverer
Finds dependencies defined in a given MuleCoreExtension
findDependencies(MuleCoreExtension) - Method in class org.mule.module.launcher.coreextension.ReflectionMuleCoreExtensionDependencyDiscoverer
 
findDisposeMethod(Object) - Method in class org.mule.component.DefaultComponentLifecycleAdapter
 
findDomain(String) - Method in interface org.mule.module.launcher.DeploymentService
 
findDomain(String) - Method in class org.mule.module.launcher.MuleDeploymentService
 
findDomainApplications(String) - Method in interface org.mule.module.launcher.DeploymentService
 
findDomainApplications(String) - Method in class org.mule.module.launcher.MuleDeploymentService
 
findFileByName(File, String, boolean) - Static method in class org.mule.util.FileUtils
 
findFiles(File, IOFileFilter, boolean) - Static method in class org.mule.util.FileUtils
 
findFileToProcess(FTPClient) - Method in class org.mule.transport.ftp.FtpMessageRequester
 
findInitMethod(Object) - Method in class org.mule.component.DefaultComponentLifecycleAdapter
 
findLibrary(String) - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
findLibrary(String, ClassLoader) - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
findLibrary(String) - Method in class org.mule.module.launcher.MuleApplicationClassLoader
 
findLibrary(String, String) - Method in interface org.mule.module.launcher.nativelib.NativeLibraryFinder
Finds a native library for the given name
findLibrary(String, String) - Method in class org.mule.module.launcher.nativelib.PerAppCopyNativeLibraryFinder
 
findLibrary(String, String) - Method in class org.mule.module.launcher.nativelib.PerAppNativeLibraryFinder
 
findLibraryLocally(String) - Method in class org.mule.module.launcher.nativelib.PerAppNativeLibraryFinder
 
findLocalResource(String) - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
findLocalResource(String) - Method in class org.mule.module.launcher.artifact.AbstractArtifactClassLoader
 
findLocalResource(String) - Method in class org.mule.module.launcher.DirectoryResourceLocator
 
findLocalResource(String) - Method in interface org.mule.module.launcher.LocalResourceLocator
This method finds a resource in the local environment for this artifact, if the resource is not found and the artifact has a parent artifact then the operation is resolved by that parent, if there is no parent, the resources is searched in the global environment.
findOrCreate(Class<?>, boolean, MuleEvent) - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
Obtains the expression manager from the Mule context and initialises the connector.
findParentClass(String) - Method in class org.mule.module.launcher.FineGrainedControlClassLoader
 
findPropertyInAnyScope(String, T) - Method in interface org.mule.api.MuleMessage
This method was added with the introduction of Property scopes.
findPropertyInAnyScope(String, T) - Method in class org.mule.DefaultMuleMessage
 
findPropertyInSpecifiedScopes(String, PropertyScope...) - Method in class org.mule.DefaultMuleMessage
Find property in one of the specified scopes, in order
findReceiverByStem(Map<Object, MessageReceiver>, String) - Static method in class org.mule.transport.http.HttpConnector
 
findReceiverByStem(Map<Object, MessageReceiver>, String) - Static method in class org.mule.transport.http.OldHttpMessageReceiver
 
findReceiverByStemConsideringMatchingHost(Map<Object, MessageReceiver>, String) - Static method in class org.mule.transport.http.HttpConnector
 
findRequestHandler(HttpRequest) - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.ServerAddressRequestHandlerRegistry
 
findResource(String) - Method in interface org.mule.module.launcher.application.ApplicationClassLoader
 
findResource(String) - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
findResource(String) - Method in interface org.mule.module.launcher.artifact.ArtifactClassLoader
 
findResource(String) - Method in class org.mule.module.launcher.MuleSharedDomainClassLoader
 
findService(String, ServiceDescriptor, Properties) - Method in interface org.mule.api.registry.ServiceFinder
 
findService(String, ServiceDescriptor, Properties) - Method in class org.mule.transport.soap.axis.SoapServiceFinder
Deprecated.
We can use a more intelligent strategy for locating the service using the OSGi registry.
findServiceDescriptor(ServiceType, String) - Static method in class org.mule.util.SpiUtils
 
findServiceDescriptor(String, String, Class) - Static method in class org.mule.util.SpiUtils
 
findServiceDescriptor(String, String, Class, boolean) - Static method in class org.mule.util.SpiUtils
 
findServiceDescriptors(String, String, Class) - Static method in class org.mule.util.SpiUtils
Find all resources of the given name and merge them
findVariable(String, List) - Method in class com.javaforge.bobber.plugin.archetype.BobberArchetype
Find the variable.
FineGrainedControlClassLoader - Class in org.mule.module.launcher
TODO document overrides, blocked, systemPackages and syntax for specifying those.
FineGrainedControlClassLoader(URL[], ClassLoader) - Constructor for class org.mule.module.launcher.FineGrainedControlClassLoader
 
FineGrainedControlClassLoader(URL[], ClassLoader, Set<String>) - Constructor for class org.mule.module.launcher.FineGrainedControlClassLoader
 
finished - Variable in class org.mule.util.queue.objectstore.xa.AbstractTransactionContext
Deprecated.
 
finished - Variable in class org.mule.util.xa.AbstractTransactionContext
 
FIPS_SECURITY_MODEL - Static variable in class org.mule.api.security.tls.TlsConfiguration
 
fireAsyncScheduledNotification(MuleEvent) - Method in class org.mule.processor.AsyncInterceptingMessageProcessor
 
fireComponentNotification(MuleMessage, int) - Method in class org.mule.component.AbstractComponent
 
fireConnectNotification(int, String, RetryContext) - Method in class org.mule.retry.notifiers.ConnectNotifier
 
fireDisposePhase(LifecycleCallback<Component>) - Method in class org.mule.component.ComponentLifecycleManager
 
fireDisposePhase(LifecycleCallback<FlowConstruct>) - Method in class org.mule.construct.FlowConstructLifecycleManager
 
fireDisposePhase(LifecycleCallback<T>) - Method in class org.mule.lifecycle.DefaultLifecycleManager
 
fireDisposePhase(LifecycleCallback<AbstractRegistryBroker>) - Method in class org.mule.lifecycle.RegistryBrokerLifecycleManager
Deprecated.
 
fireDisposePhase(LifecycleCallback<O>) - Method in class org.mule.lifecycle.SimpleLifecycleManager
 
fireDisposePhase(LifecycleCallback<AbstractModel>) - Method in class org.mule.model.ModelLifecycleManager
Deprecated.
 
fireDisposePhase(LifecycleCallback<SedaStageInterceptingMessageProcessor>) - Method in class org.mule.processor.SedaStageLifecycleManager
 
fireDisposePhase(LifecycleCallback<FlowConstruct>) - Method in class org.mule.service.ServiceLifecycleManager
Deprecated.
 
fireDisposePhase(LifecycleCallback<O>) - Method in class org.mule.transport.ConnectableLifecycleManager
 
fireDisposePhase(LifecycleCallback<Connector>) - Method in class org.mule.transport.ConnectorLifecycleManager
 
fireInitialisationCallbacks(Object) - Method in class org.mule.object.AbstractObjectFactory
 
fireInitialisePhase(LifecycleCallback<Component>) - Method in class org.mule.component.ComponentLifecycleManager
 
fireInitialisePhase(LifecycleCallback<FlowConstruct>) - Method in class org.mule.construct.FlowConstructLifecycleManager
 
fireInitialisePhase(LifecycleCallback<T>) - Method in class org.mule.lifecycle.DefaultLifecycleManager
 
fireInitialisePhase(LifecycleCallback<AbstractRegistryBroker>) - Method in class org.mule.lifecycle.RegistryBrokerLifecycleManager
Deprecated.
 
fireInitialisePhase(LifecycleCallback<O>) - Method in class org.mule.lifecycle.SimpleLifecycleManager
 
fireInitialisePhase(LifecycleCallback<AbstractModel>) - Method in class org.mule.model.ModelLifecycleManager
Deprecated.
 
fireInitialisePhase(LifecycleCallback<SedaStageInterceptingMessageProcessor>) - Method in class org.mule.processor.SedaStageLifecycleManager
 
fireInitialisePhase(LifecycleCallback<FlowConstruct>) - Method in class org.mule.service.ServiceLifecycleManager
Deprecated.
 
fireInitialisePhase(LifecycleCallback<O>) - Method in class org.mule.transport.ConnectableLifecycleManager
 
fireInitialisePhase(LifecycleCallback<Connector>) - Method in class org.mule.transport.ConnectorLifecycleManager
 
fireLifecycle(String) - Method in interface org.mule.api.lifecycle.LifecycleManager
Applies lifecycle phase to a collection of objects.
fireLifecycle(String) - Method in interface org.mule.api.registry.Registry
 
fireLifecycle(String) - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
fireLifecycle(String) - Method in class org.mule.lifecycle.MuleContextLifecycleManager
 
fireLifecycle(String) - Method in class org.mule.lifecycle.RegistryLifecycleManager
 
fireLifecycle(String) - Method in class org.mule.lifecycle.SimpleLifecycleManager
 
fireLifecycle(String) - Method in class org.mule.registry.AbstractRegistry
 
fireLifecycle(String) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
fireLifecycle(String) - Method in class org.mule.registry.MuleRegistryHelper
 
fireNotification(ServerNotification) - Method in interface org.mule.api.context.notification.ServerNotificationHandler
 
fireNotification(ServerNotification) - Method in interface org.mule.api.MuleContext
Fires a server notification to all regiistered listeners
fireNotification(int) - Method in class org.mule.construct.FlowConstructLifecycleManager
 
fireNotification(MuleMessage, String, FlowConstruct, int) - Method in class org.mule.context.notification.NotificationHelper
fireNotification(MuleEvent, String, FlowConstruct, int) - Method in class org.mule.context.notification.NotificationHelper
Fires a ConnectorMessageNotification for the given arguments using the ServerNotificationHandler associated to the given event
fireNotification(ServerNotification) - Method in class org.mule.context.notification.NotificationHelper
Fires the given notification using the NotificationHelper.defaultNotificationHandler.
fireNotification(ServerNotification, MuleEvent) - Method in class org.mule.context.notification.NotificationHelper
Fires the given notification using the ServerNotificationHandler that corresponds to the given event
fireNotification(ServerNotification) - Method in class org.mule.context.notification.OptimisedNotificationHandler
 
fireNotification(ServerNotification) - Method in class org.mule.context.notification.ServerNotificationManager
 
fireNotification(ServerNotification) - Method in class org.mule.DefaultMuleContext
Fires a server notification to all registered CustomNotificationListener notificationManager.
fireNotification(Exception) - Method in class org.mule.exception.AbstractExceptionListener
 
fireNotification(ServerNotification) - Method in class org.mule.exception.AbstractExceptionListener
Fires a server notification to all registered ExceptionNotificationListener eventManager.
fireNotification(MuleEvent, int) - Method in class org.mule.execution.NotificationFiringProcessingPhase
 
fireNotification(int) - Method in class org.mule.service.ServiceLifecycleManager
Deprecated.
 
fireNotification(TransactionNotification) - Method in class org.mule.transaction.AbstractTransaction
Fires a server notification to all registered TransactionNotificationListeners.
fireNotification(ServerNotification) - Method in class org.mule.transport.AbstractConnector
Fires a server notification to all registered listeners
fireNotification(ServerNotification, MuleEvent) - Method in class org.mule.transport.AbstractConnector
Fires a server notification to all registered listeners on the MuleContext of the given event
fireNotification(int) - Method in class org.mule.transport.ConnectorLifecycleManager
 
firePausePhase(LifecycleCallback<FlowConstruct>) - Method in class org.mule.construct.FlowConstructLifecycleManager
 
firePausePhase(LifecycleCallback<SedaStageInterceptingMessageProcessor>) - Method in class org.mule.processor.SedaStageLifecycleManager
 
firePausePhase(LifecycleCallback<FlowConstruct>) - Method in class org.mule.service.ServiceLifecycleManager
Deprecated.
 
firePipelineNotification(MuleEvent, MessagingException) - Method in class org.mule.processor.AsyncInterceptingMessageProcessor
 
firePostNotification(MuleContext) - Method in class org.mule.lifecycle.LifecycleObject
 
firePostNotification(MuleContext) - Method in class org.mule.lifecycle.NotificationLifecycleObject
 
firePreNotification(MuleContext) - Method in class org.mule.lifecycle.LifecycleObject
 
firePreNotification(MuleContext) - Method in class org.mule.lifecycle.NotificationLifecycleObject
 
fireResumePhase(LifecycleCallback<FlowConstruct>) - Method in class org.mule.construct.FlowConstructLifecycleManager
 
fireResumePhase(LifecycleCallback<SedaStageInterceptingMessageProcessor>) - Method in class org.mule.processor.SedaStageLifecycleManager
 
fireResumePhase(LifecycleCallback<FlowConstruct>) - Method in class org.mule.service.ServiceLifecycleManager
Deprecated.
 
fireStartPhase(LifecycleCallback<Component>) - Method in class org.mule.component.ComponentLifecycleManager
 
fireStartPhase(LifecycleCallback<FlowConstruct>) - Method in class org.mule.construct.FlowConstructLifecycleManager
 
fireStartPhase(LifecycleCallback<T>) - Method in class org.mule.lifecycle.DefaultLifecycleManager
 
fireStartPhase(LifecycleCallback<O>) - Method in class org.mule.lifecycle.SimpleLifecycleManager
 
fireStartPhase(LifecycleCallback<AbstractModel>) - Method in class org.mule.model.ModelLifecycleManager
Deprecated.
 
fireStartPhase(LifecycleCallback<SedaStageInterceptingMessageProcessor>) - Method in class org.mule.processor.SedaStageLifecycleManager
 
fireStartPhase(LifecycleCallback<FlowConstruct>) - Method in class org.mule.service.ServiceLifecycleManager
Deprecated.
 
fireStartPhase(LifecycleCallback<O>) - Method in class org.mule.transport.ConnectableLifecycleManager
 
fireStartPhase(LifecycleCallback<Connector>) - Method in class org.mule.transport.ConnectorLifecycleManager
 
fireStopPhase(LifecycleCallback<Component>) - Method in class org.mule.component.ComponentLifecycleManager
 
fireStopPhase(LifecycleCallback<FlowConstruct>) - Method in class org.mule.construct.FlowConstructLifecycleManager
 
fireStopPhase(LifecycleCallback<T>) - Method in class org.mule.lifecycle.DefaultLifecycleManager
 
fireStopPhase(LifecycleCallback<O>) - Method in class org.mule.lifecycle.SimpleLifecycleManager
 
fireStopPhase(LifecycleCallback<AbstractModel>) - Method in class org.mule.model.ModelLifecycleManager
Deprecated.
 
fireStopPhase(LifecycleCallback<SedaStageInterceptingMessageProcessor>) - Method in class org.mule.processor.SedaStageLifecycleManager
 
fireStopPhase(LifecycleCallback<FlowConstruct>) - Method in class org.mule.service.ServiceLifecycleManager
Deprecated.
 
fireStopPhase(LifecycleCallback<O>) - Method in class org.mule.transport.ConnectableLifecycleManager
 
fireStopPhase(LifecycleCallback<Connector>) - Method in class org.mule.transport.ConnectorLifecycleManager
 
fireTimerEvent(TimeEvent) - Method in class org.mule.util.timer.EventTimerTask
 
firstDefinition - Variable in class org.mule.config.spring.parsers.delegate.AbstractFirstResultSerialDefinitionParser
 
FirstItemWatermarkSelector - Class in org.mule.transport.polling.watermark.selector
Implementation of WatermarkSelector that selects the first value of the set.
FirstItemWatermarkSelector() - Constructor for class org.mule.transport.polling.watermark.selector.FirstItemWatermarkSelector
 
firstOrNull(List<Transformer>) - Static method in class org.mule.transformer.TransformerUtils
 
FirstSuccessful - Class in org.mule.routing
FirstSuccessful routes an event to the first target route that can accept it without throwing or returning an exception.
FirstSuccessful() - Constructor for class org.mule.routing.FirstSuccessful
 
FirstSuccessfulRoutingStrategy - Class in org.mule.routing
Routing strategy that routes the message through a list of MessageProcessor until one is successfully executed.
FirstSuccessfulRoutingStrategy(MuleContext, String, FirstSuccessfulRoutingStrategy.RouteProcessor) - Constructor for class org.mule.routing.FirstSuccessfulRoutingStrategy
 
FixedFrequencyScheduler<T extends Runnable> - Class in org.mule.transport.polling.schedule
Scheduler that runs a task giving a fixed period of time.
FixedFrequencyScheduler(String, long, long, T, TimeUnit) - Constructor for class org.mule.transport.polling.schedule.FixedFrequencyScheduler
 
FixedFrequencySchedulerFactory<T extends Runnable> - Class in org.mule.transport.polling.schedule
Implementation of SchedulerFactory for a FixedFrequencyScheduler.
FixedFrequencySchedulerFactory() - Constructor for class org.mule.transport.polling.schedule.FixedFrequencySchedulerFactory
 
FixedHostRmiClientSocketFactory - Class in org.mule.module.management.agent
Deprecated.
For multi-homed hosts support set the Java system property java.rmi.server.hostname
FixedHostRmiClientSocketFactory() - Constructor for class org.mule.module.management.agent.FixedHostRmiClientSocketFactory
Deprecated.
Default constructor.
FixedHostRmiClientSocketFactory(String) - Constructor for class org.mule.module.management.agent.FixedHostRmiClientSocketFactory
Deprecated.
Create a new instance.
flagMessage(Message) - Method in class org.mule.transport.email.RetrieveMessageRequester
There seems to be some variation on pop3 implementation so it may be preferrable to mark messages as seen here and also overload the getMessages method to grab only new messages
FLOAT_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
FLOAT_ERROR - Static variable in class org.mule.util.NumberUtils
 
FloridaSunnyOrangeFactory - Class in org.mule.tck.testmodels.fruit
A simple object factory for unit testing.
FloridaSunnyOrangeFactory() - Constructor for class org.mule.tck.testmodels.fruit.FloridaSunnyOrangeFactory
 
FloridaSunnyOrangeFactoryBean - Class in org.mule.tck.testmodels.fruit
A Spring FactoryBean implementation for unit testing.
FloridaSunnyOrangeFactoryBean() - Constructor for class org.mule.tck.testmodels.fruit.FloridaSunnyOrangeFactoryBean
 
Flow - Class in org.mule.construct
This implementation of AbstractPipeline adds the following functionality: Rejects inbound events when Flow is not started Gathers statistics and processing time data Implements MessagePorcessor allowing direct invocation of the pipeline Supports the optional configuration of a ProcessingStrategy that determines how message processors are processed.
Flow(String, MuleContext) - Constructor for class org.mule.construct.Flow
 
flow(MuleContext, String) - Static method in class org.mule.util.concurrent.ThreadNameHelper
 
FLOW_CONSTRUCT_DISPOSED - Static variable in class org.mule.context.notification.FlowConstructNotification
 
FLOW_CONSTRUCT_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
FLOW_CONSTRUCT_INITIALISED - Static variable in class org.mule.context.notification.FlowConstructNotification
 
FLOW_CONSTRUCT_PAUSED - Static variable in class org.mule.context.notification.FlowConstructNotification
 
FLOW_CONSTRUCT_RESUMED - Static variable in class org.mule.context.notification.FlowConstructNotification
 
FLOW_CONSTRUCT_STARTED - Static variable in class org.mule.context.notification.FlowConstructNotification
 
FLOW_CONSTRUCT_STOPPED - Static variable in class org.mule.context.notification.FlowConstructNotification
 
FLOW_STACK_INFO_KEY - Static variable in class org.mule.context.notification.MessageProcessingFlowTraceManager
 
FLOW_VARS - Static variable in class org.mule.el.mvel.MessageVariableResolverFactory
 
FlowAssert - Class in org.mule.tck.functional
 
FlowAssert() - Constructor for class org.mule.tck.functional.FlowAssert
 
FlowCallStack - Interface in org.mule.api.context.notification
Keeps context information about the executing flows and its callers in order to provide augmented troubleshooting information for an application developer.
FlowConfiguringMessageProcessor - Class in org.mule.module.cxf.config
Wraps a MessageProcessorBuilder and configures it lazily so it can be injected with the FlowConstruct.
FlowConfiguringMessageProcessor(MessageProcessorBuilder) - Constructor for class org.mule.module.cxf.config.FlowConfiguringMessageProcessor
 
FlowConstruct - Interface in org.mule.api.construct
A uniquely identified FlowConstruct that once implemented and configured defines a construct through which messages are processed using MessageSource and MessageProcessor building blocks.
flowConstruct - Variable in class org.mule.component.AbstractComponent
 
flowConstruct - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
flowConstruct - Variable in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
flowConstruct - Variable in class org.mule.construct.processor.FlowConstructStatisticsMessageProcessor
 
flowConstruct - Variable in class org.mule.context.notification.ComponentMessageNotification
 
flowConstruct - Variable in class org.mule.devkit.processor.DevkitBasedMessageProcessor
Flow Construct
flowConstruct - Variable in class org.mule.interceptor.AbstractEnvelopeInterceptor
 
flowConstruct - Variable in class org.mule.object.AbstractObjectFactory
 
flowConstruct - Variable in class org.mule.processor.AbstractMuleObjectOwner
 
flowConstruct - Variable in class org.mule.processor.AbstractRedeliveryPolicy
 
flowConstruct - Variable in class org.mule.processor.chain.AbstractMessageProcessorChain
 
flowConstruct - Variable in class org.mule.processor.chain.AbstractMessageProcessorChainBuilder
 
flowConstruct - Variable in class org.mule.processor.ResponseMessageProcessorAdapter
 
flowConstruct - Variable in class org.mule.routing.AbstractAggregator
 
flowConstruct - Variable in class org.mule.routing.IdempotentMessageFilter
 
flowConstruct - Variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
flowConstruct - Variable in class org.mule.security.oauth.BaseOAuth2Manager
Flow Construct
flowConstruct - Variable in class org.mule.source.StartableCompositeMessageSource
 
flowConstruct - Variable in class org.mule.tck.functional.AssertionMessageProcessor
 
flowConstruct - Variable in class org.mule.transport.AbstractMessageReceiver
The Service with which this receiver is associated with
FlowConstructAware - Interface in org.mule.api.construct
Implemented by objects that require the FlowConstruct to be injected.
FlowConstructInvalidException - Exception in org.mule.api.construct
 
FlowConstructInvalidException(Message, Throwable) - Constructor for exception org.mule.api.construct.FlowConstructInvalidException
 
FlowConstructInvalidException(Message) - Constructor for exception org.mule.api.construct.FlowConstructInvalidException
 
FlowConstructInvalidException(Message, FlowConstruct) - Constructor for exception org.mule.api.construct.FlowConstructInvalidException
 
FlowConstructInvalidException(Throwable) - Constructor for exception org.mule.api.construct.FlowConstructInvalidException
 
FlowConstructLifecycleManager - Class in org.mule.construct
The lifecycle manager responsible for managing lifecycle transitions for a Mule service.
FlowConstructLifecycleManager(FlowConstruct, MuleContext) - Constructor for class org.mule.construct.FlowConstructLifecycleManager
 
FlowConstructNotification - Class in org.mule.context.notification
FlowConstructNotification is fired when an event such as the flow construct starting occurs.
FlowConstructNotification(FlowConstruct, int) - Constructor for class org.mule.context.notification.FlowConstructNotification
 
flowConstructPollingSchedulers(String) - Static method in class org.mule.api.schedule.Schedulers
 
FlowConstructService - Class in org.mule.module.management.mbean
FlowConstructService exposes service information about a Mule Managed flow construct.
FlowConstructService(String, String, MuleContext, FlowConstructStatistics) - Constructor for class org.mule.module.management.mbean.FlowConstructService
 
FlowConstructService(String, String, MuleContext) - Constructor for class org.mule.module.management.mbean.FlowConstructService
 
FlowConstructServiceMBean - Interface in org.mule.module.management.mbean
FlowConstructServiceMBean defines the management interface for a mule managed flow construct.
FlowConstructStatistics - Class in org.mule.management.stats
 
FlowConstructStatistics(String, String, ProcessingStrategy) - Constructor for class org.mule.management.stats.FlowConstructStatistics
 
FlowConstructStatistics(String, String, int) - Constructor for class org.mule.management.stats.FlowConstructStatistics
 
FlowConstructStatistics(String, String) - Constructor for class org.mule.management.stats.FlowConstructStatistics
 
FlowConstructStatisticsMessageProcessor - Class in org.mule.construct.processor
 
FlowConstructStatisticsMessageProcessor() - Constructor for class org.mule.construct.processor.FlowConstructStatisticsMessageProcessor
 
FlowConstructStats - Class in org.mule.module.management.mbean
A concrete class that holds management information for a Mule managed flow.
FlowConstructStats(FlowConstructStatistics) - Constructor for class org.mule.module.management.mbean.FlowConstructStats
 
FlowConstructStatsMBean - Interface in org.mule.module.management.mbean
FlowConstructStatsMBean defines the management interface for a mule managed flow.
flowConstructType - Variable in class org.mule.management.stats.AbstractFlowConstructStatistics
 
FlowDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
FlowDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.FlowDefinitionParser
 
FlowExecutionListener - Class in org.mule.tck.listener
Listener for flow execution complete action.
FlowExecutionListener(MuleContext) - Constructor for class org.mule.tck.listener.FlowExecutionListener
Constructor for releasing latch when any flow execution completes
FlowExecutionListener(String, MuleContext) - Constructor for class org.mule.tck.listener.FlowExecutionListener
Constructor for releasing latch when flow with name flowName completes
FlowNotificationTextDebugger - Class in org.mule.context.notification
Listener for PipelineMessageNotification that delegates notifications to NotificationTextDebugger
FlowNotificationTextDebugger(MessageProcessingFlowTraceManager) - Constructor for class org.mule.context.notification.FlowNotificationTextDebugger
 
FlowProcessingPhase - Class in org.mule.execution
This phase routes the message through the flow.
FlowProcessingPhase() - Constructor for class org.mule.execution.FlowProcessingPhase
 
FlowProcessingPhaseTemplate - Interface in org.mule.execution
Template methods for MessageSource specific behavior during flow execution.
FlowRefDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
FlowRefDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.FlowRefDefinitionParser
 
FlowRefFactoryBean - Class in org.mule.config.spring.factories
 
FlowRefFactoryBean() - Constructor for class org.mule.config.spring.factories.FlowRefFactoryBean
 
FlowStackElement - Class in org.mule.api.context.notification
Keeps context information about the processors that a flow executed.
FlowStackElement(String, String) - Constructor for class org.mule.api.context.notification.FlowStackElement
 
flowStatistics - Variable in class org.mule.management.stats.FlowConstructStatistics
 
flowTrace - Static variable in class org.mule.config.DefaultMuleConfiguration
When true, each event will keep trace information of the flows and components it traverses to be shown as part of an exception message if an exception occurs.
FlowTraceManager - Interface in org.mule.api.context.notification
Provides callbacks for notifying when a flow call from another flow is started or completed.
FlowTraceUtils - Class in org.mule.tck.util
 
FlowTraceUtils() - Constructor for class org.mule.tck.util.FlowTraceUtils
 
FlowTraceUtils.FlowStackAsserter - Class in org.mule.tck.util
 
FlowTraceUtils.FlowStackAsserter() - Constructor for class org.mule.tck.util.FlowTraceUtils.FlowStackAsserter
 
FlowTraceUtils.FlowStackAsyncAsserter - Class in org.mule.tck.util
 
FlowTraceUtils.FlowStackAsyncAsserter() - Constructor for class org.mule.tck.util.FlowTraceUtils.FlowStackAsyncAsserter
 
FlowVarEnricherDataTypePropagator - Class in org.mule.el.mvel.datatype
Propagates data type for flow vars used for enrichment target
FlowVarEnricherDataTypePropagator() - Constructor for class org.mule.el.mvel.datatype.FlowVarEnricherDataTypePropagator
 
FlowVarExpressionDataTypeResolver - Class in org.mule.el.mvel.datatype
Resolves data type for flow var when flowVars['x'] syntax is used
FlowVarExpressionDataTypeResolver() - Constructor for class org.mule.el.mvel.datatype.FlowVarExpressionDataTypeResolver
 
flush() - Method in class org.mule.module.cxf.support.DelegatingOutputStream
 
flush() - Method in class org.mule.transport.http.ResponseWriter
 
flush() - Method in class org.mule.transport.soap.axis.AxisStringWriter
 
flush() - Method in class org.mule.transport.tcp.protocols.ProtocolStream
 
flushBase64() - Method in class org.mule.util.Base64.OutputStream
Method added by PHIL.
flushBuffer() - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
flushRequestOutputStream() - Method in class org.apache.commons.httpclient.HttpConnection
Flushes the output request stream.
footer - Variable in class org.mule.util.SplashScreen
 
forceGC(long[]) - Static method in class org.mule.module.management.i18n.ManagementMessages
 
forceGC() - Method in class org.mule.module.management.mbean.YourKitProfilerService
Force GC
forceGC() - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
Force GC
forceGroupExpiry(String) - Method in class org.mule.routing.correlation.EventCorrelator
 
forceOldHttpTransport(boolean) - Method in interface org.mule.api.callback.HttpCallbackFactory
 
forceOldHttpTransport(boolean) - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackFactory
 
forceParent(BeanDefinition) - Method in class org.mule.config.spring.parsers.AbstractHierarchicalDefinitionParser
 
forceParent(BeanDefinition) - Method in interface org.mule.config.spring.parsers.collection.DynamicAttributeDefinitionParser
This is implemented in AbstractHierarchicalDefinitionParser and allows us to "fake" a parent when processing the same element.
forceParent(BeanDefinition) - Method in class org.mule.config.spring.parsers.delegate.AbstractSingleParentFamilyChildDefinitionParser
 
forceParent(BeanDefinition) - Method in class org.mule.config.spring.parsers.delegate.MapDefinitionParserMutator
 
forceParent(BeanDefinition) - Method in interface org.mule.config.spring.parsers.MuleChildDefinitionParser
 
forceProperty(String, String) - Static method in class org.mule.transport.jdbc.i18n.JdbcMessages
 
forcePropertyNoTransaction(String, String) - Static method in class org.mule.transport.jdbc.i18n.JdbcMessages
 
forceStop() - Method in class org.mule.module.management.mbean.ServiceService
 
forceStop() - Method in interface org.mule.module.management.mbean.ServiceServiceMBean
Deprecated.
Causes the service to stop without processing its event queue first
forceStop() - Method in class org.mule.service.AbstractService
Deprecated.
 
forceUniqueId(Element, String) - Static method in class org.mule.config.spring.parsers.generic.AutoIdUtils
 
Foreach - Class in org.mule.routing
` * The Foreach MessageProcessor allows iterating over a collection payload, or any collection obtained by an expression, generating a message for each element.
Foreach() - Constructor for class org.mule.routing.Foreach
 
forget(Xid) - Method in class org.mule.transport.jms.xa.XAResourceWrapper
 
forget(Xid) - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
forget(Xid) - Method in class org.mule.util.queue.TransactionalQueueSession
 
forget(Xid) - Method in class org.mule.util.xa.DefaultXASession
 
FORM_URLENCODED_CONTENT_TYPE - Static variable in class org.mule.transport.http.HttpConstants
 
format() - Method in interface org.mule.api.el.datetime.Instant
 
format(String) - Method in interface org.mule.api.el.datetime.Instant
 
format() - Method in class org.mule.el.datetime.AbstractInstant
 
format(String) - Method in class org.mule.el.datetime.AbstractInstant
 
formatCookieForASetCookieHeader(Cookie) - Static method in class org.mule.transport.http.CookieHelper
This method formats the cookie so it can be send from server to client in a "Set-Cookie" header.
formatDate(StringBuilder, Calendar, boolean) - Static method in class org.mule.transport.http.servlet.MuleHttpServletResponse
Format HTTP date "EEE, dd MMM yyyy HH:mm:ss 'GMT'" or "EEE, dd-MMM-yy HH:mm:ss 'GMT'"for cookies
formatDate(long) - Static method in class org.mule.transport.http.transformers.MuleMessageToHttpResponse
 
formatInvalidCrlAlgorithm(String) - Static method in class org.mule.api.security.tls.TlsConfiguration
 
formatTimeStamp(Date, String) - Static method in class org.mule.util.DateUtils
 
formatUsingFilenameParser(String, String, String) - Method in class org.mule.transport.file.FileMessageRequester
 
formatXmlPayload(String) - Static method in class org.mule.module.cxf.feature.PrettyLoggingFeature
Takes the log output from the standard CXF LoggingInterceptor, disassembles it, pretty-prints the XML payload, then puts it all back together again.
forMethodOrConstructor(Object, int) - Static method in class org.mule.util.generics.MethodParameter
Create a new MethodParameter for the given method or constructor.
FormTransformer - Class in org.mule.transport.http.transformers
Converts HTML forms POSTs into a Map of parameters.
FormTransformer() - Constructor for class org.mule.transport.http.transformers.FormTransformer
 
ForwardingCatchAllStrategy - Class in org.mule.routing
Deprecated.
ForwardingCatchAllStrategy() - Constructor for class org.mule.routing.ForwardingCatchAllStrategy
Deprecated.
 
ForwardingConsumer - Class in org.mule.service
Deprecated. 
ForwardingConsumer() - Constructor for class org.mule.service.ForwardingConsumer
Deprecated.
 
freezeConfiguration() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
frequency - Variable in class org.mule.config.spring.factories.PollingMessageSourceFactoryBean
 
frequency - Variable in class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
FROM - Static variable in class org.mule.module.http.api.HttpHeaders.Names
from(File) - Static method in class org.mule.module.launcher.plugin.PluginClasspath
 
from(MessageProcessor) - Static method in class org.mule.processor.chain.DefaultMessageProcessorChain
 
from(MessageProcessor...) - Static method in class org.mule.processor.chain.DefaultMessageProcessorChain
 
from(List<MessageProcessor>) - Static method in class org.mule.processor.chain.DefaultMessageProcessorChain
 
FROM_ADDRESS_PROPERTY - Static variable in interface org.mule.transport.email.MailProperties
 
fromString(String) - Static method in enum org.mule.construct.SimpleService.Type
 
fromString(String) - Static method in enum org.mule.MessageExchangePattern
 
fromSyncFlag(boolean) - Static method in enum org.mule.MessageExchangePattern
 
FTP - Static variable in class org.mule.transport.ftp.FtpConnector
 
FTP_SERVER_BASE_DIR - Static variable in class org.mule.tck.util.ftp.FtpServer
 
FtpClient - Class in org.mule.tck.util.ftp
Ftp client wrapper for working with an FTP server.
FtpClient(String, int, String, String) - Constructor for class org.mule.tck.util.ftp.FtpClient
 
FtpConnectionFactory - Class in org.mule.transport.ftp
 
FtpConnectionFactory(EndpointURI) - Constructor for class org.mule.transport.ftp.FtpConnectionFactory
 
FtpConnector - Class in org.mule.transport.ftp
 
FtpConnector(MuleContext) - Constructor for class org.mule.transport.ftp.FtpConnector
 
FtpMessageDispatcher - Class in org.mule.transport.ftp
 
FtpMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.ftp.FtpMessageDispatcher
 
FtpMessageDispatcherFactory - Class in org.mule.transport.ftp
 
FtpMessageDispatcherFactory() - Constructor for class org.mule.transport.ftp.FtpMessageDispatcherFactory
 
FtpMessageReceiver - Class in org.mule.transport.ftp
 
FtpMessageReceiver(Connector, FlowConstruct, InboundEndpoint, long) - Constructor for class org.mule.transport.ftp.FtpMessageReceiver
 
FtpMessageRequester - Class in org.mule.transport.ftp
 
FtpMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.ftp.FtpMessageRequester
 
FtpMessageRequesterFactory - Class in org.mule.transport.ftp
 
FtpMessageRequesterFactory() - Constructor for class org.mule.transport.ftp.FtpMessageRequesterFactory
 
FtpMuleMessageFactory - Class in org.mule.transport.ftp
 
FtpMuleMessageFactory() - Constructor for class org.mule.transport.ftp.FtpMuleMessageFactory
 
FtpNamespaceHandler - Class in org.mule.transport.ftp.config
Reigsters a Bean Definition Parser for handling elements.
FtpNamespaceHandler() - Constructor for class org.mule.transport.ftp.config.FtpNamespaceHandler
 
FtpServer - Class in org.mule.tck.util.ftp
 
FtpServer(String, int, String, String) - Constructor for class org.mule.tck.util.ftp.FtpServer
 
fullStackTraces - Static variable in class org.mule.config.DefaultMuleConfiguration
When false (default), some internal Mule entries are removed from exception stacktraces for readability.
Function - Annotation Type in org.mule.api.annotations.expressions
This evaluator allows for predefined functions to be called and returns a result.
FunctionalStreamingEchoComponent - Class in org.mule.tck.functional
 
FunctionalStreamingEchoComponent() - Constructor for class org.mule.tck.functional.FunctionalStreamingEchoComponent
 
FunctionalStreamingTestComponent - Class in org.mule.tck.functional
A service that can be used by streaming functional tests.
FunctionalStreamingTestComponent() - Constructor for class org.mule.tck.functional.FunctionalStreamingTestComponent
 
FunctionalTestCase - Class in org.mule.tck
Deprecated.
FunctionalTestCase() - Constructor for class org.mule.tck.FunctionalTestCase
Deprecated.
 
FunctionalTestCase - Class in org.mule.tck.junit4
A base test case for tests that initialize Mule using a configuration file.
FunctionalTestCase() - Constructor for class org.mule.tck.junit4.FunctionalTestCase
 
FunctionalTestComponent - Class in org.mule.tck.functional
FunctionalTestComponent is a service that can be used by functional tests.
FunctionalTestComponent() - Constructor for class org.mule.tck.functional.FunctionalTestComponent
 
FunctionalTestComponent.LifecycleCallback - Interface in org.mule.tck.functional
 
FunctionalTestException - Exception in org.mule.tck.exceptions
 
FunctionalTestException() - Constructor for exception org.mule.tck.exceptions.FunctionalTestException
 
FunctionalTestException(String) - Constructor for exception org.mule.tck.exceptions.FunctionalTestException
 
FunctionalTestNotification - Class in org.mule.tck.functional
A FunctionlTestNotification is fired by the FunctionalTestComponent when it receives an event.
FunctionalTestNotification(Object, int) - Constructor for class org.mule.tck.functional.FunctionalTestNotification
 
FunctionalTestNotification(MuleEventContext, Object, int) - Constructor for class org.mule.tck.functional.FunctionalTestNotification
 
FunctionalTestNotificationListener - Interface in org.mule.tck.functional
By implementing this listener interface and registering the object with the MuleContext.registerListener(ServerNotificationListener) You can receive FunctionalTestNotifications from the FunctionalTestComponent.
FunctionAnnotationParser - Class in org.mule.config.expression
Used to parse Function annotations
FunctionAnnotationParser() - Constructor for class org.mule.config.expression.FunctionAnnotationParser
 
FunctionExpressionEvaluator - Class in org.mule.expression
This property extractor doesn't actually extract a property from the message, instead it allows for certain functions to be called and returns a result.
FunctionExpressionEvaluator() - Constructor for class org.mule.expression.FunctionExpressionEvaluator
 
FutureMessageResult - Class in org.mule.api
FutureMessageResult is an MuleMessage result of a remote invocation on a Mule Server.
FutureMessageResult(Callable, MuleContext) - Constructor for class org.mule.api.FutureMessageResult
 
FutureRetryContext - Class in org.mule.retry.async
An implementation of RetryContext to be used when a RetryPolicyTemplate is executed in a separate thread via the AsynchronousRetryTemplate.
FutureRetryContext() - Constructor for class org.mule.retry.async.FutureRetryContext
 

G

GENERAL_AND_ENTITY_HEADER_NAMES - Static variable in class org.mule.transport.http.HttpConstants
 
generateChildBeanName(Element) - Method in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
generateChildBeanName(Element) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
generateEventId(MuleContext) - Method in class org.mule.DefaultMuleEvent
 
generateFor(Extension) - Method in class org.mule.module.extension.internal.resources.AbstractResourcesGenerator
generateId(MuleContext) - Static method in class org.mule.api.context.notification.ServerNotification
 
generateKey(MuleEvent) - Method in interface org.mule.api.MuleEventKeyGenerator
Generates a key for an event.
generateKey(MuleEvent) - Method in class org.mule.keygenerator.ExpressionMuleEventKeyGenerator
 
generateKey(MuleEvent) - Method in class org.mule.keygenerator.MD5MuleEventKeyGenerator
Deprecated.
 
generateKey(MuleEvent) - Method in class org.mule.keygenerator.SHA256MuleEventKeyGenerator
 
generateMessage(Message) - Method in exception org.mule.api.MessagingException
 
generateMessage(String, Object, Map, MessageExchangePattern) - Method in interface org.mule.module.bpm.MessageService
 
generateMessage(String, Object, Map, MessageExchangePattern) - Method in class org.mule.module.bpm.Process
 
generateMessage(String, Object, Map, MessageExchangePattern) - Method in class org.mule.module.bpm.Rules
 
generateMessage(String, Object, Map, MessageExchangePattern) - Method in class org.mule.module.jbpm.MuleMessageService
 
generateMessage(Message) - Method in exception org.mule.routing.CompositeRoutingException
 
generateRequestBody(BindingOperation) - Method in class org.mule.module.ws.consumer.RequestBodyGenerator
Checks if the operation requires input parameters (if the XML required in the body is just one constant element).
generateTransformerName() - Method in class org.mule.transformer.AbstractTransformer
 
generateTransformerName() - Method in class org.mule.transformer.TransformerChain
 
generateTransformerName(Class<? extends Transformer>, DataType) - Static method in class org.mule.transformer.TransformerUtils
 
generateWSDLOrXSD(MuleEvent, String) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
GenericChildMapDefinitionParser - Class in org.mule.config.spring.parsers.collection
Creates a single Map and processes standard Spring sub elements.
GenericChildMapDefinitionParser(String, String, String, String) - Constructor for class org.mule.config.spring.parsers.collection.GenericChildMapDefinitionParser
 
GenericDbConfig - Class in org.mule.module.db.internal.domain.database
Defines a database configuration that is not customized for any particular database vendor
GenericDbConfig(DataSource, String, DbTypeManager, DbConnectionFactory) - Constructor for class org.mule.module.db.internal.domain.database.GenericDbConfig
 
GenericDbConfigFactory - Class in org.mule.module.db.internal.domain.database
Creates DbConfig for generic data bases
GenericDbConfigFactory() - Constructor for class org.mule.module.db.internal.domain.database.GenericDbConfigFactory
 
GenericGlobalEndpointDefinitionParser - Class in org.mule.config.spring.parsers.specific.endpoint
 
GenericGlobalEndpointDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.endpoint.GenericGlobalEndpointDefinitionParser
 
GenericParamTypeResolverFactory - Class in org.mule.module.db.internal.resolver.param
Creates ParamTypeResolver for generic databases
GenericParamTypeResolverFactory(DbTypeManager) - Constructor for class org.mule.module.db.internal.resolver.param.GenericParamTypeResolverFactory
 
GenericStatementResultIteratorFactory - Class in org.mule.module.db.internal.result.statement
Creates StatementResultIterator for generic database configurations
GenericStatementResultIteratorFactory(ResultSetHandler) - Constructor for class org.mule.module.db.internal.result.statement.GenericStatementResultIteratorFactory
 
GenericsUtils - Class in org.mule.util.generics
Helper class for determining element types of collections and maps.
GenericsUtils() - Constructor for class org.mule.util.generics.GenericsUtils
 
GenericTransactionManagerLookupFactory - Class in org.mule.transaction.lookup
A factory performing a JNDI lookup for TransactionManager.
GenericTransactionManagerLookupFactory() - Constructor for class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
GenericTypeResolver - Class in org.mule.util.generics
Helper class for resolving generic types against type variables.
get(String) - Method in interface org.mule.api.registry.Registry
Alias method performing the lookup, here to simplify syntax when called from dynamic languages.
get(String) - Static method in class org.mule.api.transport.PropertyScope
 
get(Object) - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
get() - Static method in class org.mule.config.StartupContext
 
get(Object) - Method in class org.mule.el.context.InboundAttachmentMapContext
 
get(Object) - Method in class org.mule.el.context.MessagePropertyMapContext
 
get(Object) - Method in class org.mule.el.context.OutboundAttachmentMapContext
 
get(Object) - Method in class org.mule.expression.InboundAttachmentsMap
 
get(Object) - Method in class org.mule.expression.OutboundAttachmentsMap
 
get(Object) - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
get(Object) - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
get(String) - Method in class org.mule.module.extension.internal.resources.AbstractResourcesGenerator
get(OperationContext) - Method in class org.mule.module.extension.internal.runtime.DynamicConfigurationInstanceProvider
Evaluates DynamicConfigurationInstanceProvider.resolverSet using the given event and returns an instance produced with the result.
get(Parameter) - Method in class org.mule.module.extension.internal.runtime.resolver.ResolverSetResult
Returns the value associated with the given parameter
get(String) - Method in class org.mule.module.extension.internal.runtime.resolver.ResolverSetResult
Returns the value associated with the Parameter of the given parameterName
get(OperationContext) - Method in class org.mule.module.extension.internal.runtime.StaticConfigurationInstanceProvider
get(Object) - Method in interface org.mule.module.http.api.HttpParameters
 
get(Object) - Method in class org.mule.module.http.internal.listener.ServerAddressMap
 
get(Object) - Method in class org.mule.module.http.internal.ParameterMap
 
get(int) - Method in class org.mule.module.json.JsonData
 
get(String) - Method in class org.mule.module.json.JsonData
 
get(int) - Method in class org.mule.module.launcher.util.ObservableList
 
get(Object) - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
get(String) - Method in class org.mule.registry.AbstractRegistry
 
get(String) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
get(String) - Method in class org.mule.registry.MuleRegistryHelper
 
get(Object) - Method in class org.mule.registry.RegistryMap
 
get(String) - Method in class org.mule.registry.TransientRegistry.RegistryMap
Deprecated.
 
GET - Static variable in class org.mule.transport.http.components.RestServiceWrapper
 
get(Object, int) - Static method in class org.mule.transport.http.multipart.LazyList
Get item from the list
get(Object) - Method in class org.mule.transport.http.multipart.MultiMap
 
get(String) - Method in class org.mule.transport.soap.axis.extensions.AxisMuleSession
 
get(Object) - Method in class org.mule.util.CaseInsensitiveMapWrapper
 
get() - Method in class org.mule.util.concurrent.WaitableBoolean
 
get(Object) - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
get(Object) - Method in class org.mule.util.MapCombiner
 
get(Object) - Method in class org.mule.util.store.ObjectStoreToMapAdapter
 
get() - Method in class org.mule.util.ValueHolder
Returns the given value
GET_TARGET_OBJECT_METHOD_NAME - Static variable in interface org.mule.transaction.XaTransaction.MuleXaObject
 
getAbsolutePath(String) - Method in class org.mule.transport.sftp.SftpClient
Converts a relative path to an absolute path according to http://tools.ietf.org/html/draft-ietf-secsh-scp-sftp-ssh-uri-04.
getAbsoluteResourcePaths() - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
getAcceptedTime() - Method in class org.mule.work.WorkerContext
System.currentTimeMillis() when the Work has been accepted.
getAcceptors() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
Get the number of "acceptor" threads Jetty should use
getAccessCodePattern() - Method in interface org.mule.security.oauth.OAuth2Adapter
Returns a compiled Pattern which can be used to extract the access code from a String
getAccessToken() - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
getAccessToken() - Method in class org.mule.module.oauth2.internal.authorizationcode.TokenResponseConfiguration
 
getAccessToken() - Method in class org.mule.module.oauth2.internal.TokenResponseProcessor
 
getAccessToken() - Method in class org.mule.security.oauth.callback.DefaultRestoreAccessTokenCallback
 
getAccessToken() - Method in interface org.mule.security.oauth.callback.RestoreAccessTokenCallback
Retrieve the just restored access token
getAccessToken() - Method in interface org.mule.security.oauth.OAuth1Connector
 
getAccessToken() - Method in interface org.mule.security.oauth.OAuth2Adapter
Retrieve access token
getAccessToken() - Method in interface org.mule.security.oauth.OAuth2Connector
 
getAccessTokenId() - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
 
getAccessTokenId(MuleEvent, MessageProcessor, OAuth2Manager<?>) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
 
getAccessTokenId() - Method in class org.mule.security.oauth.callback.ProcessCallback
 
getAccessTokenObjectStore() - Method in class org.mule.security.oauth.BaseOAuth2Manager
Retrieves accessTokenObjectStore
getAccessTokenPoolFactory() - Method in class org.mule.security.oauth.BaseOAuth2Manager
Retrieves accessTokenPoolFactory
getAccessTokenPoolFactory() - Method in interface org.mule.security.oauth.OAuth2Manager
Retrieves accessTokenPoolFactory
getAccessTokenRegex() - Method in interface org.mule.security.oauth.OAuth2Connector
 
getAccessTokenSecret() - Method in class org.mule.security.oauth.callback.DefaultRestoreAccessTokenCallback
 
getAccessTokenSecret() - Method in interface org.mule.security.oauth.callback.RestoreAccessTokenCallback
Retrieve the access token secret
getAccessTokenSecret() - Method in interface org.mule.security.oauth.OAuth1Adapter
Retrieves the accessTokenSecret
getAccessTokenUrl() - Method in interface org.mule.security.oauth.OAuth1Connector
 
getAccessTokenUrl() - Method in interface org.mule.security.oauth.OAuth2Connector
 
getAccessTokenUrl() - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
Retrieves accessTokenUrl
getAccessTokenUrl() - Method in class org.mule.security.oauth.processor.FetchAccessTokenMessageProcessor
Retrieves accessTokenUrl
getAccumulator() - Method in class org.mule.management.stats.ProcessingTime
 
getAckExpression() - Method in class org.mule.routing.UntilSuccessful
 
getAckExpression() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
getAcknowledgementMode() - Method in class org.mule.transport.jms.JmsConnector
 
getAcknowledgeMode() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
getAcknowledgeMode() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
getAcknowledgeMode() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
getAcquireIncrement() - Method in class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
getAction() - Method in class org.mule.api.context.notification.ServerNotification
 
getAction() - Method in interface org.mule.api.transaction.TransactionConfig
 
getAction() - Method in class org.mule.transaction.MuleTransactionConfig
 
getActionAsString() - Method in class org.mule.transaction.MuleTransactionConfig
 
getActionId(String) - Static method in class org.mule.api.context.notification.ServerNotification
 
getActionName() - Method in class org.mule.api.context.notification.ServerNotification
 
getActionName(int) - Static method in class org.mule.api.context.notification.ServerNotification
 
getActionNames() - Method in class org.mule.context.notification.CustomNotification
 
getAdapter() - Method in class org.mule.security.oauth.processor.BaseOAuth1AuthorizeMessageProcessor
 
getAdapter() - Method in class org.mule.security.oauth.processor.BaseOAuth1UnauthorizeMessageProcessor
 
getAdapterClass() - Method in class org.mule.security.oauth.BaseOAuthClientFactory
Returns the class of the concrete implementation of OAuth2Adapter that this factory is supposed to generate
getAdapterClass() - Method in class org.mule.security.oauth.processor.BaseOAuth1AuthorizeMessageProcessor
 
getAdapterClass() - Method in class org.mule.security.oauth.processor.BaseOAuth1UnauthorizeMessageProcessor
 
getAddDefaultEntities() - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Returns the state of the "add default entities" flag.
getAddProperties() - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
getAddress() - Method in interface org.mule.api.endpoint.EndpointURI
 
getAddress() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
This returns the address of the endpoint.
getAddress() - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
getAddress() - Method in class org.mule.endpoint.AbstractEndpoint
 
getAddress() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getAddress() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getAddress() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getAddress() - Method in class org.mule.endpoint.MuleEndpointURI
 
getAddress() - Method in class org.mule.endpoint.URIBuilder
 
getAddress() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getAddress() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getAddress() - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
getAddress() - Method in class org.mule.module.cxf.component.AbstractWebServiceWrapperComponent
 
getAddress() - Method in class org.mule.module.management.mbean.EndpointService
 
getAddress() - Method in interface org.mule.module.management.mbean.EndpointServiceMBean
 
getAddress() - Method in class org.mule.tck.testmodels.services.Address
 
getAddress() - Method in class org.mule.tck.testmodels.services.Person
 
getAddress() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getAgents() - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
Use lookupAgent() instead
getAgents() - Method in class org.mule.registry.MuleRegistryHelper
getAlgorithm() - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
getAlias(Field) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
getAlias() - Method in class org.mule.module.ws.security.WssEncryptSecurityStrategy
 
getAliases() - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
getAliases() - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
getAll(String) - Method in interface org.mule.module.http.api.HttpParameters
Utility method to retrieve all the values for a certain parameter.
getAll(String) - Method in class org.mule.module.http.internal.ParameterMap
 
getAllAnnotations() - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
getAllDeployedServices() - Method in class org.mule.transport.soap.axis.extensions.MuleConfigProvider
 
getAllFieldAnnotations(Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
getAllLogEntries() - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
 
getAllLogEntries() - Method in class org.mule.util.journal.TransactionJournal
 
getAllMethodAnnotations(Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
getAllOptionalKeys() - Method in class org.mule.config.spring.CompositeOptionalObjectsController
 
getAllOptionalKeys() - Method in class org.mule.config.spring.DefaultOptionalObjectsController
 
getAllOptionalKeys() - Method in interface org.mule.config.spring.OptionalObjectsController
 
getAllowedMethods() - Method in interface org.mule.module.http.api.listener.HttpListener
 
getAllowedMethods() - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
getAllPaths() - Method in class org.mule.util.NotificationUtils.FlowMap
 
getAllServices(Definition) - Method in class org.mule.module.cxf.support.ProxyServiceConfiguration
This method returns a list of all the services defined in the definition.
getAnnotatedExtensionClasses() - Method in class org.mule.tck.junit4.ExtensionsFunctionalTestCase
Implement this method to limit the amount of extensions initialised by providing the annotated classes which define the extensions that you actually want to use for this test.
getAnnotation(QName) - Method in class org.mule.AbstractAnnotatedObject
 
getAnnotation(QName) - Method in interface org.mule.api.AnnotatedObject
Gets the value of specified annotation.
getAnnotation() - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
getAnnotation(QName) - Method in class org.mule.config.spring.factories.AnnotatedObjectFactoryBean
 
getAnnotation(QName) - Method in class org.mule.config.spring.factories.WatermarkFactoryBean
 
getAnnotation(QName) - Method in class org.mule.processor.AbstractMessageProcessorOwner
 
getAnnotation() - Method in class org.mule.util.annotation.AnnotationMetaData
 
getAnnotationClassName(String) - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
getAnnotations() - Method in class org.mule.AbstractAnnotatedObject
 
getAnnotations() - Method in interface org.mule.api.AnnotatedObject
Gets all annotations.
getAnnotations() - Method in class org.mule.config.spring.factories.AnnotatedObjectFactoryBean
 
getAnnotations() - Method in class org.mule.config.spring.factories.WatermarkFactoryBean
 
getAnnotations() - Method in class org.mule.processor.AbstractMessageProcessorOwner
 
getAnnotationsPackageName() - Method in class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
This resolver scans a class for annotations in this package.
getAnnotationsPackageName() - Method in class org.mule.module.json.transformers.JsonMapperResolver
This resolver scans a class for annotations in this package.
getAnnotationsPackageName() - Method in class org.mule.module.xml.transformer.jaxb.JAXBContextResolver
 
getApiConfiguration() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getAppBuilder(String[]) - Method in class org.mule.tck.junit4.ApplicationContextBuilder
 
getAppConfigurationEntry(String) - Method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider.JaasConfig
Gets the configuration entries using the application Name
getAppDescriptor() - Method in class org.mule.module.launcher.plugin.PluginDescriptor
 
getAppDescriptor() - Method in class org.mule.module.launcher.plugin.PluginDescriptorParser
 
getAppDir() - Method in class org.mule.module.launcher.plugin.PluginDescriptorParser
 
getAppendString() - Method in class org.mule.tck.functional.FunctionalTestComponent
 
getAppExecutionFolder(String) - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getAppFolder(String) - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getAppLibFolder(String) - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getApplicationContext() - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
getApplicationContext() - Method in class org.mule.module.spring.events.MuleApplicationEvent
Deprecated.
 
getApplicationDeploymentStatusTracker() - Method in class org.mule.module.launcher.DeploymentStatusTracker
 
getApplicationName() - Method in class org.mule.context.notification.TransactionNotification
 
getApplicationName() - Method in class org.mule.security.oauth.BaseOAuth2Manager
Retrieves applicationName
getApplications() - Method in interface org.mule.module.launcher.DeploymentService
Lists all applications that are deployed, starting or failed to start
getApplications() - Method in class org.mule.module.launcher.MuleDeploymentService
 
getApplicationStatistics() - Method in class org.mule.management.stats.AllStatistics
 
getApplicationStatus(String) - Static method in class org.mule.module.launcher.application.ApplicationStatusMapper
 
getAppName() - Method in interface org.mule.module.launcher.application.ApplicationClassLoader
Deprecated.
use ArtifactClassLoader.getArtifactName instead.
getAppName() - Method in class org.mule.module.launcher.application.ApplicationWrapper
 
getAppName() - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
getAppName() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
getAppName() - Method in class org.mule.module.launcher.MuleApplicationClassLoader
 
getAppPluginsFolder(String) - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getAppProperties() - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
getAppsDir() - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
getAppsFolder() - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getAppSharedPluginLibsFolder(String) - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getAppTempFolder(String) - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getArchiveDir() - Method in class org.mule.transport.sftp.SftpConnector
 
getArchiveDir() - Method in class org.mule.transport.sftp.SftpUtil
 
getArchiveTempReceivingDir() - Method in class org.mule.transport.sftp.SftpConnector
 
getArchiveTempReceivingDir() - Method in class org.mule.transport.sftp.SftpUtil
 
getArchiveTempSendingDir() - Method in class org.mule.transport.sftp.SftpConnector
 
getArchiveTempSendingDir() - Method in class org.mule.transport.sftp.SftpUtil
 
getArgs() - Method in class org.mule.config.i18n.Message
 
getArgs(MuleEvent) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
getArgTypes(Object, MuleEvent) - Method in class org.mule.transport.rmi.RmiConnector
 
getArgumentClass() - Method in class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
The object type that this resolver will discover or create
getArgumentClass() - Method in class org.mule.module.json.transformers.JsonMapperResolver
The object type that this resolver will discover or create
getArgumentClass() - Method in class org.mule.module.xml.transformer.jaxb.JAXBContextResolver
 
getArguments() - Method in class org.mule.expression.transformers.AbstractExpressionTransformer
 
getArtifact(Element, XmlConfigurationCallback) - Method in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
getArtifactClassLoader() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
getArtifactClassLoader() - Method in interface org.mule.module.launcher.artifact.Artifact
 
getArtifactClassLoader() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
getArtifactClassLoader() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
getArtifactDir() - Method in class org.mule.module.launcher.application.DefaultApplicationFactory
 
getArtifactDir() - Method in interface org.mule.module.launcher.artifact.ArtifactFactory
 
getArtifactDir() - Method in class org.mule.module.launcher.domain.DefaultDomainFactory
 
getArtifactForMessageProcessor(Element, XmlConfigurationCallback) - Method in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
getArtifactMuleConfig(String, Element, XmlConfigurationCallback, boolean) - Method in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
getArtifactName() - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
getArtifactName() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
getArtifactName() - Method in interface org.mule.module.launcher.artifact.Artifact
 
getArtifactName() - Method in interface org.mule.module.launcher.artifact.ArtifactClassLoader
 
getArtifactName() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
getArtifactName() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
getArtifactName() - Method in class org.mule.module.launcher.MuleApplicationClassLoader
 
getArtifactName() - Method in class org.mule.module.launcher.MuleSharedDomainClassLoader
 
getArtifactsZombieMap() - Method in interface org.mule.module.launcher.ArchiveDeployer
 
getArtifactsZombieMap() - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
getArtifactsZombieMap() - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
getArtifactType() - Method in interface org.mule.api.MuleContext
The ArtifactType indicating if this configuration object is for an application or a domain.
getArtifactType() - Method in class org.mule.DefaultMuleContext
 
getAsString() - Method in enum org.mule.config.bootstrap.ArtifactType
 
getAsString(String) - Method in class org.mule.module.json.JsonData
 
getAsText() - Method in class org.mule.config.spring.editors.DatePropertyEditor
Format the Date as String, using the specified DateFormat.
getAsync() - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
Retrieves async
getAsync() - Method in interface org.mule.security.oauth.callback.HttpCallbackAdapter
Retrieves async
getAsyncContext() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getAsyncEventsReceived() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
 
getAsyncEventsReceived() - Method in class org.mule.management.stats.ApplicationStatistics
 
getAsyncEventsReceived() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getAsyncEventsReceived() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
getAsyncEventsReceived() - Method in interface org.mule.module.management.mbean.FlowConstructStatsMBean
 
getAsyncEventsReceived() - Method in class org.mule.module.management.mbean.ServiceService
 
getAsyncEventsSent() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
getAsyncEventsSent() - Method in class org.mule.module.management.mbean.ServiceService
 
getAsyncEventsSent() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getAsyncEventsSent() - Method in interface org.mule.module.management.mbean.ServiceStatsMBean
Deprecated.
 
getAsyncReplyCorrelationId(MuleEvent) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
getAsyncReplyMessageSource() - Method in interface org.mule.api.service.Service
Deprecated.
 
getAsyncReplyMessageSource() - Method in class org.mule.service.AbstractService
Deprecated.
 
getAsyncReplyTimeout() - Method in class org.mule.service.AbstractService
Deprecated.
 
getAsyncStageNameSource() - Method in interface org.mule.api.processor.StageNameSourceProvider
Provides a StageNameSource
getAsyncStageNameSource(String) - Method in interface org.mule.api.processor.StageNameSourceProvider
Returns a StageNameSource that takes the given paramter into consideration when generating the name
getAsyncStageNameSource() - Method in class org.mule.construct.Flow
Provides a StageNameSource
getAsyncStageNameSource(String) - Method in class org.mule.construct.Flow
Returns a StageNameSource that takes the given paramter into consideration when generating the name
getAttachment(String) - Method in interface org.mule.api.MuleMessage
getAttachment(String) - Method in class org.mule.DefaultMuleMessage
Deprecated.
getAttachment(MuleMessage, String) - Method in class org.mule.expression.BaseAttachmentExpressionEvaluator
 
getAttachment(MuleMessage, String) - Method in class org.mule.expression.MessageAttachmentExpressionEvaluator
 
getAttachmentName(String, Map<String, Part>) - Static method in class org.mule.transport.email.MailUtils
Check whether an attachment with the same name already exists, using a counter for override protection.
getAttachmentNames() - Method in interface org.mule.api.MuleMessage
getAttachmentNames() - Method in class org.mule.DefaultMuleMessage
Deprecated.
getAttachments(Multipart, Map<String, Part>) - Static method in class org.mule.transport.email.MailUtils
 
getAttribute(RequestContext.Scope, String) - Method in class org.mule.module.atom.server.MuleRequestContext
 
getAttribute(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getAttributeAlias(String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
getAttributeAlias(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
getAttributeAlias(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
getAttributeAlias(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
getAttributeCount() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getAttributeCount() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getAttributeList() - Method in class org.mule.module.xml.stax.StartElementEventX
 
getAttributeLocalName(int) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getAttributeLocalName(int) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getAttributeMapping(String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
getAttributeMapping(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
getAttributeMapping(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
getAttributeMapping(String, String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
getAttributeMapping(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
getAttributeMapping(String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
getAttributeName(int) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getAttributeName(int) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getAttributeNames(RequestContext.Scope) - Method in class org.mule.module.atom.server.MuleRequestContext
 
getAttributeNames() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getAttributeNamespace(int) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getAttributeNamespace(int) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getAttributePrefix(int) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getAttributePrefix(int) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getAttributes() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
Get the attributes associated with the given START_ELEMENT or ATTRIBUTE StAXevent.
getAttributeType(int) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getAttributeType(int) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getAttributeValue(int) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getAttributeValue(String, String) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getAttributeValue(int) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getAttributeValue(String, String) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getAttributeValue(Element, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
getAuthCodeRegex() - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
getAuthentication() - Method in interface org.mule.api.security.SecurityContext
 
getAuthentication() - Method in interface org.mule.module.http.api.requester.HttpRequesterConfig
 
getAuthentication() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getAuthentication() - Method in class org.mule.module.pgp.PGPSecurityContext
 
getAuthentication(Authentication) - Method in class org.mule.module.spring.security.PreAuthenticatedAuthenticationProvider
Provides a spring authentication according to mule's authentication
getAuthentication(Authentication) - Method in interface org.mule.module.spring.security.SpringAuthenticationProvider
Provides a spring authentication according to mule's authentication
getAuthentication() - Method in class org.mule.module.spring.security.SpringSecurityContext
 
getAuthentication(Authentication) - Method in class org.mule.module.spring.security.UserAndPasswordAuthenticationProvider
Provides a spring authentication according to mule's authentication
getAuthentication() - Method in class org.mule.security.DefaultSecurityContext
 
getAuthenticationMethod() - Method in class org.mule.module.management.agent.Mx4jAgent
 
getAuthenticationProvider() - Method in class org.mule.module.spring.security.SpringProviderAdapter
 
getAuthenticationToken(MuleEvent) - Method in class org.mule.security.UsernamePasswordAuthenticationFilter
 
getAuthenticator() - Method in class org.mule.transport.email.AbstractMailConnector
 
getAuthorities() - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
getAuthority() - Method in interface org.mule.api.endpoint.EndpointURI
 
getAuthority() - Method in class org.mule.endpoint.MuleEndpointURI
 
getAuthorizationParameters() - Method in interface org.mule.security.oauth.OAuth2Connector
 
getAuthorizationUrl() - Method in interface org.mule.security.oauth.OAuth1Connector
 
getAuthorizationUrl() - Method in interface org.mule.security.oauth.OAuth2Connector
 
getAuthorizationUrl() - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
Retrieves authorizationUrl
getAuthorizationUrl() - Method in class org.mule.security.oauth.processor.OAuth1FetchAccessTokenMessageProcessor
Retrieves authorizationUrl
getAuthType() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getAutoAckCount() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getAutoCommit() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
getAutoCommit() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getAutoCommit() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getAutoGeneratedKeyStrategy() - Method in class org.mule.module.db.internal.processor.UpdateMessageProcessor
 
getAutowireCandidateResolver() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Return the autowire candidate resolver for this BeanFactory (never null).
getAvailableFiles(boolean) - Method in class org.mule.transport.sftp.SftpReceiverRequesterUtil
 
getAverageExecutionTime() - Method in class org.mule.management.stats.ComponentStatistics
Returns the average execution time, rounded downwards.
getAverageExecutionTime() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
getAverageExecutionTime() - Method in class org.mule.module.management.mbean.ServiceService
 
getAverageExecutionTime() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getAverageExecutionTime() - Method in interface org.mule.module.management.mbean.ServiceStatsMBean
Deprecated.
 
getAverageProcessingTime() - Method in class org.mule.management.stats.ApplicationStatistics
 
getAverageProcessingTime() - Method in class org.mule.management.stats.FlowConstructStatistics
 
getAverageProcessingTime() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getAverageProcessingTime() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
getAverageProcessingTime() - Method in interface org.mule.module.management.mbean.FlowConstructStatsMBean
 
getAverageQueueSize() - Method in class org.mule.management.stats.FlowConstructStatistics
 
getAverageQueueSize() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
getAverageQueueSize() - Method in class org.mule.module.management.mbean.ServiceService
 
getAverageQueueSize() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getAverageQueueSize() - Method in interface org.mule.module.management.mbean.ServiceStatsMBean
Deprecated.
 
getAxis() - Method in class org.mule.transport.soap.axis.AxisConnector
 
getAxis() - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
getAxisDeployedServices() - Method in class org.mule.transport.soap.axis.extensions.MuleConfigProvider
 
getAxisTransportProtocols() - Method in class org.mule.transport.soap.axis.AxisConnector
 
getBacklog() - Method in class org.mule.transport.tcp.TcpConnector
Deprecated.
getBackupFolder() - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
getBase() - Method in class org.mule.util.counters.impl.AggregateCounter
 
getBaseInputSource() - Method in class org.mule.module.ws.consumer.MuleWSDLLocator
 
getBasePath(MuleMessage) - Static method in class org.mule.module.cxf.HttpRequestPropertyManager
 
getBasePath() - Method in interface org.mule.module.http.api.requester.HttpRequesterConfig
 
getBasePath() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getBasePath(String) - Static method in class org.mule.module.ws.consumer.WSDLUtils
 
getBasepath() - Method in class org.mule.transport.servlet.JarResourceServlet
 
getBaseProtocol() - Method in class org.mule.transport.email.AbstractMailConnector
Some protocols (eg secure extensions) extend a "base" protocol.
getBaseProtocol() - Method in class org.mule.transport.email.ImapsConnector
 
getBaseProtocol() - Method in class org.mule.transport.email.Pop3sConnector
 
getBaseProtocol() - Method in class org.mule.transport.email.SmtpsConnector
 
getBaseStore() - Method in class org.mule.util.store.ObjectStorePartition
 
getBaseStore() - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
 
getBaseURI() - Method in class org.mule.module.ws.consumer.MuleWSDLLocator
 
getBaseURI() - Method in class org.mule.module.ws.consumer.MuleWSDLLocatorConfig
 
getBaseURI() - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
getBatchSize() - Method in class org.mule.transaction.constraints.BatchConstraint
 
getBatchSize(int) - Method in class org.mule.transport.AbstractPollingMessageReceiver
The preferred number of messages to process in the current batch.
getBayeux() - Method in class org.mule.transport.ajax.AjaxMessageDispatcher
 
getBayeux() - Method in class org.mule.transport.ajax.AjaxMessageReceiver
 
getBayeux() - Method in interface org.mule.transport.ajax.BayeuxAware
 
getBayeux() - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
getBayeux() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
getBccAddresses() - Method in class org.mule.transport.email.SmtpConnector
 
getBean() - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
 
getBean() - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
getBean() - Method in class org.mule.config.spring.util.SpringBeanLookup
 
getBean(Class<T>) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
getBean(Class<T>, Object...) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
getBeanAssembler(Element, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.AbstractHierarchicalDefinitionParser
The bean assembler gives more reliable/automatic processing of collections, maps, etc.
getBeanAssembler(Element, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
Restricted use - does not include a target.
getBeanAssemblerFactory() - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.factories.AggregationStrategyDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
Determine the bean class corresponding to the supplied Element.
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.collection.AttributeListEntryDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.collection.AttributeMapDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.collection.ChildListDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.collection.ChildMapDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.collection.ChildPropertiesDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.collection.GenericChildMapDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.collection.OrphanMapDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.generic.ChildDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.generic.OrphanDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.generic.ParentDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.specific.BridgeDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.specific.ConfigurationDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.specific.ExpressionLanguageDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.specific.GlobalPropertyDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.specific.InvokerMessageProcessorDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.specific.ObjectFactoryDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.specific.properties.ListPropertyDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.specific.SimpleServiceDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.config.spring.parsers.specific.ValidatorDefinitionParser
 
getBeanClass() - Method in class org.mule.expression.transformers.BeanBuilderTransformer
 
getBeanClass(Element) - Method in class org.mule.module.cxf.config.WsCustomValidatorDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.db.internal.config.domain.connection.PoolingProfileBeanDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.db.internal.config.domain.param.InOutParamDefinitionDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.db.internal.config.domain.param.InputParamDefinitionDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.db.internal.config.domain.param.InputParamValueBeanDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.db.internal.config.domain.param.OutputParamDefinitionDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.db.internal.config.domain.query.QueryTemplateBeanDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.db.internal.config.processor.BulkExecuteProcessorBeanDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.db.internal.config.processor.ExecuteDdlProcessorBeanDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.db.internal.config.processor.PreparedBulkUpdateProcessorBeanDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.db.internal.config.processor.SelectProcessorDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.db.internal.config.processor.SingleUpdateProcessorDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.db.internal.config.processor.StoredProcedureProcessorBeanDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.management.config.JmxAgentDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.module.scripting.config.GroovyRefreshableBeanBuilderParser
 
getBeanClass(Element) - Method in class org.mule.module.ws.config.spring.parsers.specific.WSProxyDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.transport.http.builder.HttpResponseDefinitionParser
 
getBeanClass(Element) - Method in class org.mule.transport.http.config.spring.parsers.specific.HttpProxyDefinitionParser
 
getBeanClassFromAttribute(Element) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
Determine the bean class corresponding to the supplied Element based on an explicit "class" attribute.
getBeanConfig() - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
getBeanDefinition(String) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
getBeanDefinitionCount() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
getBeanDefinitionDocumentReaderClass() - Method in class org.mule.config.spring.MuleArtifactContext
 
getBeanDefinitionNames() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
getBeanFactory() - Method in class org.mule.expression.transformers.BeanBuilderTransformer
 
getBeanName(Element) - Method in class org.mule.config.spring.parsers.AbstractChildDefinitionParser
 
getBeanName(Element) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
getBeanName(Element) - Method in class org.mule.config.spring.parsers.collection.ChildMapEntryDefinitionParser
 
getBeanName(Element) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
getBeanName(Element) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
getBeanName(Element) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParser
 
getBeanName(Element) - Method in class org.mule.config.spring.parsers.specific.endpoint.support.ChildEndpointDefinitionParser
 
getBeanName(Element) - Method in class org.mule.config.spring.parsers.specific.FlowRefDefinitionParser
 
getBeanName(Element) - Method in class org.mule.module.db.internal.config.domain.param.AbstractParamDefinitionDefinitionParser
 
getBeanName(Element) - Method in class org.mule.module.db.internal.config.domain.param.InputParamValueBeanDefinitionParser
 
getBeanName(Element) - Method in class org.mule.module.xml.config.NamespaceManagerDefinitionParser
 
getBeanName(Element) - Method in class org.mule.transport.http.builder.HttpCookiesDefinitionParser
 
getBeanNamesForAnnotation(Class<? extends Annotation>) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
getBeanNamesForType(Class<?>) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
getBeanNamesForType(Class<?>, boolean, boolean) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
getBeanNamesIterator() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
GetBeanProperty - Class in org.mule.transformer.simple
Looks up a property from a JavaBean using PropertyUtils.getProperty().
GetBeanProperty() - Constructor for class org.mule.transformer.simple.GetBeanProperty
 
getBeansOfType(Class<T>) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
getBeansOfType(Class<T>, boolean, boolean) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
getBeansWithAnnotation(Class<? extends Annotation>) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
getBeanTypes() - Method in class org.mule.transport.soap.axis.AxisConnector
 
getBindingId() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getBindingIdForSoapVersion(String) - Static method in class org.mule.module.cxf.support.CxfUtils
 
getBindingOperationFromEndpoint(Endpoint, String) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
getBit() - Method in enum org.mule.api.devkit.capability.ModuleCapability
 
getBody() - Method in class org.mule.transport.http.HttpRequest
 
getBody() - Method in class org.mule.transport.http.HttpResponse
 
getBodyAsString() - Method in class org.mule.transport.http.HttpResponse
 
getBodyBytes() - Method in class org.mule.transport.http.HttpRequest
 
getBodyParameterName(MuleMessage) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
getBodyPartForAttachment(DataHandler, String) - Method in class org.mule.transport.email.transformers.ObjectToMimeMessage
 
getBodyString() - Method in class org.mule.transport.http.HttpRequest
 
getBoilerPlate(String) - Static method in class org.mule.util.StringMessageUtils
 
getBoilerPlate(String, char, int) - Static method in class org.mule.util.StringMessageUtils
 
getBoilerPlate(List<String>, char, int) - Static method in class org.mule.util.StringMessageUtils
 
getBoolean(String, Map) - Static method in class org.hibernate.connection.SimpleConnectionProvider
Get the config value as a boolean (default of false)
getBoolean(String, Map, boolean) - Static method in class org.hibernate.connection.SimpleConnectionProvider
Get the config value as a boolean.
getBoolean(Object, Boolean) - Static method in class org.mule.util.ObjectUtils
Gets a boolean from a value in a null-safe manner.
getBooleanProperty(String, boolean) - Method in interface org.mule.api.MuleMessage
getBooleanProperty(String, boolean) - Method in class org.mule.DefaultMuleMessage
Deprecated.
getBooleanProperty(String, boolean) - Method in class org.mule.MessagePropertiesContext
 
getBooleanValue(String, String, XmlPullParser) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method getBooleanValue.
getBooleanValue(String, String, XmlPullParser, String) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method getBooleanValue.
getBoundary() - Method in class org.mule.transport.http.multipart.MultiPartOutputStream
 
getBpms() - Method in class org.mule.module.bpm.Process
 
getBpms() - Method in class org.mule.module.bpm.ProcessComponent
 
getBranchQualifier() - Method in class org.mule.util.xa.MuleXid
 
getBreakpointManager() - Method in interface org.mule.api.debug.DebuggingSession
Returns the breakpoint manager for this session
getBrokerURL() - Method in class org.mule.transport.jms.activemq.ActiveMQJmsConnector
 
getBufferOutput() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getBufferSize() - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
getBufferSize() - Method in class org.mule.transport.stdio.StdioMessageReceiver
 
getBufferSize() - Method in class org.mule.transport.tcp.TcpConnector
getBuildDate() - Static method in class org.mule.config.MuleManifest
 
getBuildDate() - Method in class org.mule.module.management.mbean.MuleService
Deprecated.
use getBuildNumber() instead
getBuildDate() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getBuilder() - Method in class org.mule.tck.FunctionalTestCase
Deprecated.
 
getBuilder() - Method in class org.mule.tck.junit4.FunctionalTestCase
 
getBuilderInstance() - Method in class org.mule.config.spring.factories.MessageProcessorChainFactoryBean
 
getBuilderInstance() - Method in class org.mule.config.spring.factories.SubflowMessageProcessorChainFactoryBean
 
getBuildNumber() - Static method in class org.mule.config.MuleManifest
 
getBuildNumber() - Method in class org.mule.module.management.mbean.MuleService
 
getBuildNumber() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getBundle(String) - Method in class org.mule.config.i18n.MessageFactory
 
getBundlePath(String) - Static method in class org.mule.config.i18n.MessageFactory
Computes the bundle's full path (META-INF/services/org/mule/i18n/<bundleName>-messages.properties) from bundleName.
getBus() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getBus() - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
getBus() - Method in class org.mule.module.cxf.transport.MuleUniversalTransport
 
getByte(Object, Byte) - Static method in class org.mule.util.ObjectUtils
Gets a byte from a value in a null-safe manner.
getByteProperty(String, byte) - Method in class org.mule.MessagePropertiesContext
 
getBytes(Class) - Static method in class org.mule.util.ClassReader
load the bytecode for a given class, by using the class's defining classloader and assuming that for a class named P.C, the bytecodes are in a resource named /P/C.class.
getBytes(String) - Static method in class org.mule.util.StringMessageUtils
 
getByteStream() - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
getCacheId() - Method in class org.apache.maven.enforcer.rule.EnforcerPortRule
If your rule is cacheable, you must return a unique id when parameters or conditions change that would cause the result to be different.
getCacheKeyForPayload(Object, Object[]) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
getCall(MuleEvent, Object[]) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
getCallbackCount() - Method in class org.mule.tck.functional.CounterCallback
 
getCallbackResponse() - Method in exception org.mule.security.oauth.exception.AuthorizationCodeNotFoundException
 
getCanonicalURI(EndpointURI) - Method in interface org.mule.api.transport.Connector
Returns a canonical representation of the given EndpointURI
getCanonicalURI(EndpointURI) - Method in class org.mule.transport.AbstractConnector
Returns a canonical representation of the given EndpointURI
getCanonicalURI(EndpointURI) - Method in class org.mule.transport.vm.VMConnector
This implementation returns the default canonical representation with an added query param specifying the connector name
getCapabilities(Class<T>) - Method in class org.mule.module.extension.internal.introspection.ParameterGroup
getCapabilities(Set<?>, Class<T>) - Static method in class org.mule.module.extension.internal.util.CapabilityUtils
Returns the items in capabilities which are instances of capabilityType
getCapability(Class<T>) - Method in class org.mule.config.spring.DefaultMuleArtifact
 
getCapacity() - Method in class org.mule.util.queue.DefaultQueueConfiguration
 
getCapacity() - Method in class org.mule.util.queue.DefaultQueueStore
 
getCapacity() - Method in class org.mule.util.queue.objectstore.QueueConfiguration
Deprecated.
 
getCapacity() - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
getCapacity() - Method in interface org.mule.util.queue.QueueConfiguration
 
getCapacity() - Method in interface org.mule.util.queue.QueueStore
 
getCatalog() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
getCatalog() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getCatalog() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getCatchAllCurrentPathMap() - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.PathMap
 
getCatchAllPathMap() - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.PathMap
 
getCatchAllStrategy() - Method in interface org.mule.api.routing.OutboundRouterCollection
Deprecated.
 
getCatchAllStrategy() - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
getCatchAllStrategy() - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
getCaughtMessages() - Method in class org.mule.management.stats.RouterStatistics
 
getCaughtMessages() - Method in class org.mule.module.management.mbean.RouterStats
 
getCaughtMessages() - Method in interface org.mule.module.management.mbean.RouterStatsMBean
 
getCause(Throwable) - Method in interface org.mule.api.config.ExceptionReader
 
getCause(Throwable) - Method in class org.mule.config.DefaultExceptionReader
 
getCause(Throwable) - Method in class org.mule.config.MuleExceptionReader
 
getCause(Throwable) - Method in class org.mule.config.NamingExceptionReader
 
getCause(Throwable) - Method in class org.mule.transport.jdbc.SQLExceptionReader
 
getCause(Throwable) - Method in class org.mule.transport.jms.JmsExceptionReader
 
getCause(Throwable) - Method in class org.mule.transport.soap.axis.AxisFaultExceptionReader
 
getCauseException() - Method in exception org.mule.api.MessagingException
 
getCcAddresses() - Method in class org.mule.transport.email.SmtpConnector
 
getCertifiedText() - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
getChainsawHost() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
getChainsawPort() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
getChannelSftp() - Method in class org.mule.transport.sftp.SftpClient
 
getCharacterEncoding() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getCharacterEncoding() - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
getCharacterEncodingScheme() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getCharacterStream() - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
getCharacterValue(String, String, XmlPullParser) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method getCharacterValue.
getCharset() - Method in class org.mule.transport.http.HttpRequest
 
getCharset() - Method in class org.mule.transport.http.HttpResponse
 
getCheckedParameter(String, Class<T>) - Method in class org.mule.module.extension.internal.DefaultDescribingContext
getCheckFileAge() - Method in class org.mule.transport.file.FileConnector
 
getCheckFileAge() - Method in class org.mule.transport.sftp.SftpConnector
 
getCheckFrequency() - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
getChildDelegate() - Method in class org.mule.config.spring.parsers.delegate.MapDefinitionParserMutator
 
getChildPathMap(String, String) - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.PathMap
 
getChildren() - Method in class org.mule.api.processor.DefaultMessageProcessorPathElement
 
getChildren() - Method in interface org.mule.api.processor.MessageProcessorPathElement
 
getCipherSuite() - Method in class org.mule.module.http.internal.listener.properties.SSLSessionProperties
 
getClass(String) - Method in class org.mule.config.bootstrap.AbstractRegistryBootstrap
 
getClassAndMethodAnnotations(Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
getClassAnnotationForInterfaces(Class<?>, List<AnnotationMetaData>) - Static method in class org.mule.util.annotation.AnnotationUtils
 
getClassAnnotationForSuperClasses(Class<? extends Annotation>, Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
 
getClassAnnotationForSuperClasses(Class<?>, List<AnnotationMetaData>) - Static method in class org.mule.util.annotation.AnnotationUtils
 
getClassAnnotationInHeirarchy(Class<? extends Annotation>, Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
use getClassAnnotationInHierarchy(Class, Class)
getClassAnnotationInHeirarchy(Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
use getClassAnnotationInHierarchy(Class)
getClassAnnotationInHierarchy(Class<? extends Annotation>, Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
getClassAnnotationInHierarchy(Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
getClassAnnotations() - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
getClassConstraint() - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
getClassInternal(Element) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
getClassLoader() - Method in class org.mule.config.i18n.MessageFactory
Override this method to return the classloader for the bundle/module which contains the needed resource files.
getClassLoader() - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
getClassLoader() - Method in interface org.mule.module.launcher.artifact.ArtifactClassLoader
ClassLoader is an abstract class.
getClassLoader() - Method in class org.mule.module.launcher.MuleApplicationClassLoader
 
getClassLoader() - Method in class org.mule.module.launcher.MuleSharedDomainClassLoader
 
getClassLoader() - Method in class org.mule.transport.tcp.protocols.CustomClassLoadingLengthProtocol
 
getClassLoader() - Method in class org.springframework.asm.ClassWriter
 
getClassName(Class) - Static method in class org.mule.util.ClassUtils
 
getClassName() - Method in class org.mule.util.scan.annotations.AnnotationInfo
Deprecated.
 
getClassName() - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
getClassName() - Method in interface org.mule.util.scan.ClassScanner
Deprecated.
 
getClassName() - Method in class org.mule.util.scan.ImplementationClassScanner
Deprecated.
 
getClassName() - Method in class org.mule.util.scan.InterfaceClassScanner
Deprecated.
 
getClasspath() - Method in class org.mule.module.launcher.plugin.PluginDescriptor
 
getClassPathRoot(Class) - Static method in class org.mule.util.ClassUtils
 
getClassTypes(Object) - Static method in class org.mule.util.ClassUtils
Used for creating an array of class types for an array or single object
getClassURL(String) - Method in class org.mule.util.scan.annotations.MetaAnnotationTypeFilter
Deprecated.
 
getClassURL(String) - Method in class org.mule.util.scan.ImplementationClassScanner
Deprecated.
 
getClassURL(String) - Method in class org.mule.util.scan.InterfaceClassScanner
Deprecated.
 
getClazz() - Method in class org.mule.util.annotation.AnnotationMetaData
 
getClearQuery() - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
getClearQueryKey() - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
getClient() - Method in interface org.mule.api.MuleContext
 
getClient() - Method in class org.mule.DefaultMuleContext
 
getClient() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getClient() - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
getClient() - Method in class org.mule.transport.ajax.AjaxMessageDispatcher
 
getClientCertificate() - Method in class org.mule.module.http.internal.domain.request.ClientConnection
 
getClientClass() - Method in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
getClientConfig() - Method in class org.mule.transport.soap.axis.AxisConnector
 
getClientConfig(ImmutableEndpoint) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
getClientConfig(ImmutableEndpoint) - Method in class org.mule.transport.soap.axis.AxisMessageRequester
 
getClientConnection() - Method in class org.mule.module.http.internal.domain.request.HttpRequestContext
 
getClientConnectionManager() - Method in class org.mule.transport.http.HttpConnector
 
getClientId() - Method in interface org.mule.module.oauth2.internal.ApplicationCredentials
 
getClientId() - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
getClientId() - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
getClientId() - Method in class org.mule.transport.jms.JmsConnector
 
getClientInfo(String) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
getClientInfo() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
getClientInfo() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getClientInfo(String) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getClientInfo() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getClientInfo(String) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getClientKeyStore() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getClientKeyStore() - Method in interface org.mule.api.security.TlsIndirectKeyStore
 
getClientKeyStore() - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
getClientKeyStore() - Method in class org.mule.transport.email.SmtpsConnector
 
getClientKeyStore() - Method in class org.mule.transport.http.HttpsConnector
 
getClientKeyStore() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getClientKeyStorePassword() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getClientKeyStorePassword() - Method in interface org.mule.api.security.TlsIndirectKeyStore
 
getClientKeyStorePassword() - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
getClientKeyStorePassword() - Method in class org.mule.transport.email.SmtpsConnector
 
getClientKeyStorePassword() - Method in class org.mule.transport.http.HttpsConnector
 
getClientKeyStorePassword() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getClientKeyStoreType() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getClientKeyStoreType() - Method in interface org.mule.api.security.TlsIndirectKeyStore
 
getClientKeyStoreType() - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
getClientKeyStoreType() - Method in class org.mule.transport.email.SmtpsConnector
 
getClientKeyStoreType() - Method in class org.mule.transport.http.HttpsConnector
 
getClientKeyStoreType() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getClientPool(ImmutableEndpoint) - Method in class org.mule.transport.sftp.SftpConnector
 
getClientProvider() - Method in class org.mule.transport.soap.axis.AxisConnector
 
getClientSecret() - Method in interface org.mule.module.oauth2.internal.ApplicationCredentials
 
getClientSecret() - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
getClientSecret() - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
getClientSocketProperties() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getClientSocketProperties() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getClientSoTimeout() - Method in class org.mule.transport.tcp.TcpConnector
 
getClusterId() - Method in interface org.mule.api.MuleContext
 
getClusterId() - Method in interface org.mule.config.ClusterConfiguration
 
getClusterId() - Method in class org.mule.config.NullClusterConfiguration
 
getClusterId() - Method in class org.mule.context.notification.MuleContextNotification
 
getClusterId() - Method in class org.mule.DefaultMuleContext
 
getClusterId() - Method in class org.mule.el.context.MuleInstanceContext
 
getClusterNodeId() - Method in interface org.mule.api.MuleContext
 
getClusterNodeId() - Method in interface org.mule.config.ClusterConfiguration
 
getClusterNodeId() - Method in class org.mule.config.NullClusterConfiguration
 
getClusterNodeId() - Method in class org.mule.DefaultMuleContext
 
getCode() - Method in exception org.mule.api.ConnectionException
Get a code for what went wrong
getCode() - Method in interface org.mule.api.ExceptionPayload
 
getCode() - Method in class org.mule.config.i18n.Message
 
getCode() - Method in class org.mule.message.DefaultExceptionPayload
 
getCollectionFieldType(Field) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic element type of the given Collection field.
getCollectionFieldType(Field, int) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic element type of the given Collection field.
getCollectionParameterType(MethodParameter) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic element type of the given Collection parameter.
getCollectionReturnType(Method) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic element type of the given Collection return type.
getCollectionReturnType(Method, int) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic element type of the given Collection return type.
getCollectionType(Class<? extends Collection<?>>) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic element type of the given Collection class (if it declares one through a generic superclass or generic interface).
getColumn(FlowConstructStatistics, String[]) - Method in class org.mule.management.stats.printers.AbstractTablePrinter
 
getCommandLineOption(String, String[], String[][]) - Static method in class org.mule.util.SystemUtils
Returns the value corresponding to the given option from the command line, for example if the options are "-config mule-config.xml" getCommandLineOption("config") would return "mule-config.xml"
getCommandLineOptions(String[], String[][]) - Static method in class org.mule.util.SystemUtils
Returns a Map of all options in the command line.
getCommitTxFilter() - Method in class org.mule.exception.AbstractExceptionListener
 
getCommonRootId() - Method in class org.mule.routing.EventGroup
 
getCommonSuperClass(String, String) - Method in class org.springframework.asm.ClassWriter
Returns the common super type of the two given types.
getComparator() - Method in class org.mule.transport.file.FileMessageReceiver
 
getCompiledExpression(String) - Method in class org.mule.el.mvel.MVELExpressionExecutor
Compile an expression.
getCompiledScript() - Method in class org.mule.module.scripting.component.Scriptable
 
getComponent() - Method in exception org.mule.api.lifecycle.LifecycleException
 
getComponent() - Method in interface org.mule.api.service.Service
Deprecated.
Returns the Component that is a invoked by a Service for each incoming MuleEvent routed on by the inbound routers.
getComponent() - Method in exception org.mule.component.ComponentException
 
getComponent() - Method in class org.mule.construct.SimpleService
 
getComponent() - Method in class org.mule.context.notification.ComponentMessageNotification
 
getComponent() - Method in class org.mule.service.AbstractService
Deprecated.
 
getComponent(String) - Method in class org.mule.tck.FunctionalTestCase
Deprecated.
Returns an instance of the service's component object.
getComponent(FlowConstruct) - Method in class org.mule.tck.FunctionalTestCase
Deprecated.
Returns an instance of the service's component object.
getComponent(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
Returns an instance of the service's component object.
getComponent(FlowConstruct) - Method in class org.mule.tck.junit4.FunctionalTestCase
Returns an instance of the service's component object.
getComponentName() - Method in class org.mule.message.ExceptionMessage
 
getComponentName() - Method in class org.mule.module.management.mbean.EndpointService
 
getComponentName() - Method in interface org.mule.module.management.mbean.EndpointServiceMBean
 
getComponentPoolAbsoluteMaxSize() - Method in class org.mule.management.stats.SedaServiceStatistics
Deprecated.
 
getComponentPoolMaxSize() - Method in class org.mule.management.stats.SedaServiceStatistics
Deprecated.
 
getComponentPoolSize() - Method in class org.mule.management.stats.SedaServiceStatistics
Deprecated.
 
getComponents() - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
getComponentStat() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
getComponentStatistics() - Method in class org.mule.management.stats.AllStatistics
Deprecated.
use #getServiceStatistics
getComponentStatistics() - Method in class org.mule.module.management.mbean.StatisticsService
Deprecated.
use #getServiceStatistics
getCondition() - Method in class org.mule.api.debug.Breakpoint
Return the condition expression for this breakpoint if any.
getConditionalMessageProcessors() - Method in class org.mule.routing.AbstractSelectiveRouter
 
getConduit(EndpointInfo) - Method in class org.mule.module.cxf.transport.MuleUniversalTransport
 
getConduit(EndpointInfo, EndpointReferenceType) - Method in class org.mule.module.cxf.transport.MuleUniversalTransport
 
getConfig() - Method in interface org.mule.module.http.api.listener.HttpListener
 
getConfig() - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
getConfig() - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
getConfig() - Method in class org.mule.module.ws.consumer.WSConsumer
 
getConfigBuilderClassName() - Method in class org.mule.module.management.mbean.MuleService
 
getConfigBuilderClassName() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
Contains value of option -builder
getConfigBuilderClassName() - Static method in class org.mule.MuleServer
Returns the class name of the configuration builder used to create this MuleServer.
getConfigFile() - Method in class org.mule.tck.AbstractServiceAndFlowTestCase
Deprecated.
 
getConfigFile() - Method in class org.mule.tck.junit4.FunctionalTestCase
 
getConfigFile() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
getConfigFiles() - Method in class org.mule.tck.AbstractServiceAndFlowTestCase
Deprecated.
 
getConfigFiles() - Method in class org.mule.tck.junit4.FunctionalTestCase
 
getConfigNamespaces() - Method in class org.mule.module.xml.util.NamespaceManager
 
getConfigOAuthContext() - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
getConfigOAuthContext() - Method in class org.mule.module.oauth2.internal.tokenmanager.TokenManagerConfig
 
getConfigProperties() - Method in class org.mule.module.cxf.config.WsConfig
 
getConfigProperties() - Method in class org.mule.module.cxf.config.WsSecurity
 
getConfigResources() - Method in class org.mule.config.spring.MuleArtifactContext
 
getConfigResources() - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
getConfigResources() - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
getConfigResources() - Method in class org.mule.tck.FunctionalTestCase
Deprecated.
 
getConfigResources() - Method in class org.mule.tck.junit4.DomainFunctionalTestCase
 
getConfigResources() - Method in class org.mule.tck.junit4.FunctionalTestCase
Deprecated.
use getConfigFile instead.
getConfigResourcesFile() - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
getConfiguration() - Method in interface org.mule.api.MuleContext
 
getConfiguration() - Method in class org.mule.DefaultMuleContext
 
getConfiguration() - Method in class org.mule.module.bpm.Rules
 
getConfiguration() - Method in class org.mule.module.client.MuleClient
 
getConfiguration() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getConfiguration() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getConfiguration(MuleContext) - Static method in class org.mule.module.cxf.CxfConfiguration
 
getConfiguration() - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
getConfigurationAnnotations() - Method in interface org.mule.api.MuleContext
Return all annotations seen in the configuration
getConfigurationAnnotations() - Method in class org.mule.DefaultMuleContext
 
getConfigurationBuilder() - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
Config builder name.
getConfigurationInstance(Extension, String, OperationContext) - Method in class org.mule.module.extension.internal.manager.DefaultExtensionManager
Returns a configuration instance obtained through a ConfigurationInstanceProvider previously registered using the ExtensionManager.registerConfigurationInstanceProvider(Extension, String, ConfigurationInstanceProvider) under the given configurationInstanceProviderName.
getConfigurationInstance(Extension, OperationContext) - Method in class org.mule.module.extension.internal.manager.DefaultExtensionManager
getConfigurationInstance(Extension, String, OperationContext) - Method in interface org.mule.module.extension.internal.manager.ExtensionManagerAdapter
Returns a configuration instance obtained through a ConfigurationInstanceProvider previously registered using the ExtensionManager.registerConfigurationInstanceProvider(Extension, String, ConfigurationInstanceProvider) under the given configurationInstanceProviderName.
getConfigurationInstance(Extension, OperationContext) - Method in interface org.mule.module.extension.internal.manager.ExtensionManagerAdapter
 
getConfigurationInstance() - Method in class org.mule.module.extension.internal.runtime.DefaultOperationContext
 
getConfigurationLocation() - Method in class org.mule.module.cxf.CxfConfiguration
 
getConfigurationResource() - Method in class org.mule.module.jbpm.Jbpm
 
getConfigurationResources() - Method in class org.mule.MuleServer
Getter for property messengerURL.
getConfiguredSecretKey() - Method in interface org.mule.module.pgp.PGPKeyRing
 
getConfiguredSecretKey() - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
getConnectEventId() - Method in class org.mule.transport.AbstractConnector
The resource id used when firing ConnectEvents from this connector
getConnectEventId() - Method in class org.mule.transport.AbstractMessageReceiver
 
getConnectEventId(ImmutableEndpoint) - Method in class org.mule.transport.AbstractTransportMessageHandler
 
getConnection() - Method in class org.hibernate.connection.SimpleConnectionProvider
 
getConnection() - Method in class org.mule.module.db.internal.domain.xa.DataSourceWrapper
 
getConnection(String, String) - Method in class org.mule.module.db.internal.domain.xa.DataSourceWrapper
 
getConnection() - Method in class org.mule.tck.util.MuleDerbyTestDatabase
 
getConnection() - Method in class org.mule.transport.jdbc.JdbcConnector
 
getConnection() - Method in class org.mule.transport.jdbc.xa.DataSourceWrapper
 
getConnection(String, String) - Method in class org.mule.transport.jdbc.xa.DataSourceWrapper
 
getConnection() - Method in class org.mule.transport.jms.JmsConnector
 
getConnectionDescription() - Method in interface org.mule.api.transport.Connectable
Returns a string identifying the underlying resource
getConnectionDescription() - Method in class org.mule.transport.AbstractConnector
 
getConnectionDescription() - Method in class org.mule.transport.AbstractMessageReceiver
 
getConnectionDescription() - Method in class org.mule.transport.AbstractTransportMessageHandler
Returns a string identifying the underlying resource
getConnectionFactory() - Method in interface org.mule.module.db.internal.domain.database.DbConfig
 
getConnectionFactory() - Method in class org.mule.module.db.internal.domain.database.GenericDbConfig
 
getConnectionFactory() - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
getConnectionFactory() - Method in class org.mule.transport.jms.JmsConnector
 
getConnectionFactoryClass() - Method in class org.mule.transport.ftp.FtpConnector
Getter for property 'connectionFactoryClass'.
getConnectionFactoryJndiName() - Method in class org.mule.transport.jms.JmsConnector
 
getConnectionFactoryProperties() - Method in class org.mule.transport.jms.JmsConnector
 
getConnectionIdleTimeout() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getConnectionIdleTimeout() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getConnectionLock(DbConnection) - Method in class org.mule.module.db.internal.result.statement.StatementStreamingResultSetCloser
 
getConnectionProperties() - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
getConnectionResultSets(DbConnection, ResultSet) - Method in class org.mule.module.db.internal.result.statement.StatementStreamingResultSetCloser
 
getConnectionTimeout() - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
getConnectionTimeout() - Method in class org.mule.transport.tcp.AbstractTcpSocketFactory
 
getConnectionTimeout() - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
getConnectionTimeout() - Method in interface org.mule.transport.tcp.TcpClientSocketProperties
 
getConnectionTimeout() - Method in class org.mule.transport.tcp.TcpConnector
 
getConnector() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
The endpoint that will be used to send the message on.
getConnector() - Method in exception org.mule.api.transport.ConnectorException
 
getConnector() - Method in interface org.mule.api.transport.MessageDispatcher
Gets the connector for this dispatcher
getConnector() - Method in interface org.mule.api.transport.MessageRequester
Gets the connector for this dispatcher
getConnector() - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
getConnector() - Method in class org.mule.endpoint.AbstractEndpoint
 
getConnector() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getConnector() - Method in class org.mule.endpoint.AbstractMetaEndpointBuilder
 
getConnector() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getConnector() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getConnector() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getConnector() - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
getConnector() - Method in class org.mule.module.cxf.transport.MuleUniversalTransport
 
getConnector() - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
getConnector() - Method in class org.mule.security.oauth.BaseOAuth1Manager
 
getConnector() - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
Retrieves connector
getConnector() - Method in interface org.mule.security.oauth.callback.HttpCallbackAdapter
Retrieves connector
getConnector() - Method in interface org.mule.security.oauth.OAuth1Manager
 
getConnector() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getConnector() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
getConnector() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
getConnector() - Method in class org.mule.transport.DefaultReplyToHandler
 
getConnector() - Method in class org.mule.transport.jms.DefaultJmsTopicResolver
Getter for property 'connector'.
getConnector() - Method in class org.mule.transport.quartz.config.ScheduleAnnotationParser
 
getConnector() - Method in class org.mule.transport.servlet.jetty.AbstractConnectorHolder
 
getConnector() - Method in interface org.mule.transport.servlet.jetty.ConnectorHolder
 
getConnector() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
getConnector() - Method in class org.mule.transport.tcp.LocalSocketTcpMessageDispatcher
 
getConnector() - Method in class org.mule.transport.tcp.TcpSocketKey
 
getConnectorByProtocol(String) - Method in class org.mule.transport.service.TransportFactory
 
getConnectorConfig() - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
getConnectorName() - Method in interface org.mule.api.endpoint.EndpointURI
 
getConnectorName() - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
getConnectorName() - Method in class org.mule.endpoint.MuleEndpointURI
 
getConnectorName(Connector) - Method in class org.mule.util.ObjectNameHelper
 
getConnectorProtocol() - Method in class org.mule.transport.ajax.container.MuleAjaxServlet
 
getConnectors() - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
Use lookupConnector() instead
getConnectors() - Method in class org.mule.registry.MuleRegistryHelper
getConnectorServerProperties() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
getConnectorServerProperties() - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
getConnectorServerUrl() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
getConnectorServerUrl() - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
getConstraint() - Method in interface org.mule.api.transaction.TransactionConfig
 
getConstraint() - Method in class org.mule.transaction.MuleTransactionConfig
 
getConstructor() - Method in class org.mule.endpoint.URIBuilder
 
getConstructor(Class, Class[]) - Static method in class org.mule.util.ClassUtils
 
getConstructor(Class, Class[], boolean) - Static method in class org.mule.util.ClassUtils
Returns available constructor in the target class that as the parameters specified.
getConstructor() - Method in class org.mule.util.generics.MethodParameter
Return the wrapped Constructor, if any.
getConstructType() - Method in class org.mule.construct.AbstractFlowConstruct
 
getConstructType() - Method in class org.mule.construct.Bridge
 
getConstructType() - Method in class org.mule.construct.Flow
 
getConstructType() - Method in class org.mule.construct.SimpleService
 
getConstructType() - Method in class org.mule.construct.Validator
 
getConstructType() - Method in class org.mule.module.ws.construct.WSProxy
 
getConstructType() - Method in class org.mule.transport.http.construct.HttpProxy
 
getConsumer(OAuth1Adapter) - Method in class org.mule.security.oauth.BaseOAuth1Manager
 
getConsumer() - Method in interface org.mule.security.oauth.OAuth1Adapter
Returns an OAuthConsumer for this adapter
getConsumerKey() - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
getConsumerKey() - Method in interface org.mule.security.oauth.OAuth1Connector
 
getConsumerKey() - Method in interface org.mule.security.oauth.OAuth2Connector
 
getConsumerSecret() - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
getConsumerSecret() - Method in interface org.mule.security.oauth.OAuth1Connector
 
getConsumerSecret() - Method in interface org.mule.security.oauth.OAuth2Connector
 
getContent() - Method in class org.mule.module.http.internal.domain.ByteArrayHttpEntity
 
getContent() - Method in class org.mule.module.http.internal.multipart.HttpPartDataSource
 
getContentDispositionFilename() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
Get the filename from the content-disposition.
getContentHandler() - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
getContentLength() - Method in class org.mule.module.http.internal.domain.InputStreamHttpEntity
 
getContentLength() - Method in class org.mule.module.http.internal.listener.HttpResponseHeaderBuilder
 
getContentLength() - Method in class org.mule.transport.http.HttpRequest
 
getContentLength() - Method in class org.mule.transport.http.HttpResponse
 
getContentLength() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getContentLength() - Method in class org.mule.transport.http.StreamPayloadRequestEntity
 
getContents() - Method in class org.mule.module.pgp.SignedMessage
 
getContentType() - Method in class org.mule.message.ds.ByteArrayDataSource
 
getContentType() - Method in class org.mule.message.ds.InputStreamDataSource
 
getContentType() - Method in class org.mule.message.ds.StringDataSource
 
getContentType() - Method in class org.mule.module.http.internal.listener.HttpResponseHeaderBuilder
 
getContentType() - Method in class org.mule.module.http.internal.multipart.HttpPart
 
getContentType() - Method in class org.mule.module.http.internal.multipart.HttpPartDataSource
 
getContentType(Class) - Method in class org.mule.transport.email.DefaultDataContentHandlerFactory
 
getContentType() - Method in class org.mule.transport.email.SmtpConnector
 
getContentType() - Method in class org.mule.transport.email.transformers.PlainTextDataSource
 
getContentType() - Method in class org.mule.transport.http.HttpRequest
 
getContentType() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
getContentType() - Method in interface org.mule.transport.http.multipart.Part
Gets the content type of this part.
getContentType() - Method in class org.mule.transport.http.multipart.PartDataSource
 
getContentType() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getContentType() - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
getContentType() - Method in class org.mule.transport.http.StreamPayloadRequestEntity
 
getContentType(DataType<?>) - Static method in class org.mule.util.DataTypeUtils
Generates a HTTP content type for a given data type
getContentTypeParameter(String, String) - Static method in class org.mule.module.http.internal.HttpParser
Extracts a parameter value from a content type
getContentTypeSubType(String) - Static method in class org.mule.module.http.internal.HttpParser
Extracts the subtype from a content type
getContext() - Method in class org.mule.module.ws.consumer.MuleWSDLLocatorConfig
 
getContext() - Method in class org.mule.object.JndiObjectFactory
 
getContext() - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
getContext() - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver.ThreadContextLocal
 
getContextClassLoader() - Method in class org.mule.util.concurrent.NamedThreadFactory
 
getContextFactory() - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
getContextForResourceOwner(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ConfigOAuthContext
Retrieves the oauth context for a particular user.
getContextInfo(MuleEvent, MessageProcessor) - Method in interface org.mule.api.execution.ExceptionContextProvider
 
getContextInfo(MuleEvent, MessageProcessor) - Method in class org.mule.context.notification.MessageProcessingFlowTraceManager
 
getContextInfo(MuleEvent, MessageProcessor) - Method in class org.mule.exception.MessagingExceptionLocationProvider
 
getContextPath() - Method in class org.mule.module.atom.server.MuleRequestContext
 
getContextPath() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getContextProperties() - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
getContextProperties() - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
getContextProperties() - Method in class org.mule.module.xml.transformer.XQueryTransformer
Gets the parameters to be used when applying the transformation
getContextProperties() - Method in class org.mule.module.xml.transformer.XsltTransformer
Gets the parameters to be used when applying the transformation
getContextProperties() - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
getContextResolver() - Method in class org.mule.module.xml.transformer.jaxb.JAXBTransformerResolver
 
getConversationFactory() - Method in class org.mule.transport.xmpp.XmppConnector
 
getConverters() - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
getConverters() - Method in class org.mule.transformer.CompositeConverter
 
getCookieManager() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getCookiePolicy(String) - Static method in class org.mule.transport.http.CookieHelper
 
getCookies() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getCookieSpec(String) - Static method in class org.mule.transport.http.CookieHelper
 
getCookieSpec() - Method in class org.mule.transport.http.HttpConnector
 
getCookieValueFromCookies(Object, String) - Static method in class org.mule.transport.http.CookieHelper
Searches and return the cookie with the cookieName in the cookiesObject.
getCopyright() - Method in class org.mule.module.management.mbean.MuleService
 
getCopyright() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getCoreExtensions() - Method in class org.mule.test.infrastructure.deployment.AbstractFakeMuleServerTestCase
 
getCorrelationExpression() - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
getCorrelationGroup() - Method in class org.mule.module.cxf.MuleSoapHeaders
 
getCorrelationGroupSize() - Method in interface org.mule.api.MuleMessage
Determines how many messages are in the correlation group
getCorrelationGroupSize() - Method in class org.mule.DefaultMuleMessage
Determines how many messages are in the correlation group
getCorrelationGroupSize() - Method in class org.mule.el.context.MessageContext
 
getCorrelationId() - Method in interface org.mule.api.MuleMessage
Sets a correlationId for this message.
getCorrelationId(MuleMessage) - Method in interface org.mule.api.routing.MessageInfoMapping
 
getCorrelationId() - Method in class org.mule.DefaultMuleMessage
Sets a correlationId for this message.
getCorrelationId() - Method in class org.mule.el.context.MessageContext
 
getCorrelationId() - Method in class org.mule.module.cxf.MuleSoapHeaders
 
getCorrelationId(MuleMessage) - Method in class org.mule.routing.correlation.CorrelationPropertiesExpressionEvaluator
 
getCorrelationId(MuleMessage) - Method in class org.mule.routing.ExpressionMessageInfoMapping
 
getCorrelationId(MuleMessage) - Method in class org.mule.routing.MuleMessageInfoMapping
 
getCorrelationId(MuleEvent) - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
getCorrelationIdExpression() - Method in class org.mule.routing.ExpressionMessageInfoMapping
 
getCorrelationSequence() - Method in interface org.mule.api.MuleMessage
Gets the sequence or ordering number for this message in the the correlation group (as defined by the correlationId)
getCorrelationSequence() - Method in class org.mule.DefaultMuleMessage
Gets the sequence or ordering number for this message in the the correlation group (as defined by the correlationId)
getCorrelationSequence() - Method in class org.mule.el.context.MessageContext
 
getCorrelationSequence() - Method in class org.mule.module.cxf.MuleSoapHeaders
 
getCorrelatorCallback(MuleContext) - Method in class org.mule.routing.AbstractAggregator
 
getCorrelatorCallback(MuleContext) - Method in class org.mule.routing.AbstractCorrelationAggregator
 
getCorrelatorCallback(MuleContext) - Method in class org.mule.routing.MessageChunkAggregator
 
getCorrelatorCallback(MuleContext) - Method in class org.mule.routing.Resequencer
 
getCorrelatorCallback(MuleContext) - Method in class org.mule.routing.SimpleCollectionAggregator
 
getCount() - Method in class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
getCount() - Method in class org.mule.tck.functional.CountdownCallback
 
getCounter() - Method in class org.mule.util.concurrent.NamedThreadFactory
 
getCounter(String) - Static method in class org.mule.util.counters.CounterFactory
Search the defined counters for a counter of the given name.
getCounter(String) - Static method in class org.mule.util.counters.impl.CounterFactoryImpl
 
getCounters() - Static method in class org.mule.util.counters.CounterFactory
Retrieve an iterator giving the list of public defined counters.
getCounters() - Static method in class org.mule.util.counters.impl.CounterFactoryImpl
 
getCreated() - Method in class org.mule.routing.EventGroup
Return the creation timestamp of the current group in milliseconds.
getCredentialList(String) - Method in class org.mule.module.jaas.loginmodule.DefaultLoginModule
This method parses the credentials string and populates the credentials list against which the username and password submitted with the request will be checked
getCredentials() - Method in interface org.mule.api.MuleEvent
 
getCredentials() - Method in interface org.mule.api.security.Authentication
 
getCredentials(MuleEvent) - Method in interface org.mule.api.security.CredentialsAccessor
 
getCredentials() - Method in class org.mule.DefaultMuleEvent
 
getCredentials() - Method in class org.mule.module.jaas.JaasAuthentication
 
getCredentials() - Method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider
Gets the user's credentials, i.e.
getCredentials() - Method in class org.mule.module.pgp.PGPAuthentication
 
getCredentials() - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
getCredentials() - Method in class org.mule.security.DefaultMuleAuthentication
 
getCredentials(MuleEvent) - Method in class org.mule.security.MuleHeaderCredentialsAccessor
 
getCredentials() - Method in class org.mule.VoidMuleEvent
 
getCredentialsAccessor() - Method in interface org.mule.api.security.AuthenticationFilter
 
getCredentialsAccessor() - Method in class org.mule.module.pgp.KeyBasedEncryptionStrategy
 
getCredentialsAccessor() - Method in class org.mule.security.AbstractAuthenticationFilter
 
getCronExpression() - Method in class org.mule.modules.schedulers.cron.CronScheduler
 
getCurrent(MuleContext) - Static method in class org.mule.module.management.support.JmxRegistrationContext
Get current context or create one if none exist for the current startup cycle.
getCurrentMessage() - Static method in class org.mule.module.sxc.SxcFilteringOutboundRouter
 
getCurrentMuleContext() - Static method in class org.mule.config.spring.MuleArtifactContext
 
getCurrentNanoTime() - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
getCurrentPhase() - Method in interface org.mule.api.lifecycle.LifecycleManager
The current phase for the lifecycle manager.
getCurrentPhase() - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
getCurrentReadFile() - Method in class org.mule.util.queue.QueueControlDataFile
 
getCurrentTransaction() - Method in interface org.mule.api.MuleEventContext
Returns the current transaction (if any) for the session
getCurrentTransaction() - Method in class org.mule.DefaultMuleEventContext
Returns the current transaction (if any) for the session
getCurrentWriteFile() - Method in class org.mule.util.queue.QueueControlDataFile
 
getCustomEvaluator() - Method in class org.mule.expression.ExpressionConfig
 
getCustomEvaluator() - Method in class org.mule.expression.transformers.ExpressionArgument
 
getCustomEvaluator() - Method in class org.mule.routing.ExpressionSplitter
 
getCustomEvaluator() - Method in class org.mule.routing.filters.ExpressionFilter
 
getCustomEvaluator() - Method in class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
getCustomEvaluator() - Method in class org.mule.routing.outbound.ExpressionMessageSplitter
Deprecated.
 
getCustomEvaluator() - Method in class org.mule.routing.outbound.ExpressionRecipientList
 
getCustomEvaluator() - Method in class org.mule.transport.quartz.jobs.CustomJobFromMessageConfig
 
getCustomHeaders() - Method in class org.mule.transport.email.SmtpConnector
 
getCustomParameters() - Method in class org.mule.module.extension.internal.DefaultDescribingContext
getCustomParameters() - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
getCustomResponseParameters() - Method in class org.mule.module.oauth2.internal.TokenResponseProcessor
 
getCustomValidator() - Method in class org.mule.module.cxf.config.WsSecurity
 
getCxfBus() - Method in class org.mule.module.cxf.CxfConfiguration
 
getData() - Method in class org.mule.component.simple.StaticComponent
 
getData() - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
getDatabase() - Method in class org.mule.module.db.internal.config.domain.database.AbstractVendorConfigResolverFactoryBean
 
getDatabase() - Method in class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
getDatabase() - Method in class org.mule.transport.jdbc.config.DerbyDataSourceFactoryBean
 
getDatabinding() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getDatabinding() - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
getDataContentHandler(Class) - Method in class org.mule.transport.email.DefaultDataContentHandlerFactory
 
getDataFile() - Method in class org.mule.component.simple.StaticComponent
 
getDataSource() - Method in interface org.mule.module.db.internal.domain.database.DbConfig
 
getDataSource() - Method in class org.mule.module.db.internal.domain.database.GenericDbConfig
 
getDataSource() - Method in class org.mule.transport.jdbc.JdbcConnector
 
getDataType() - Method in interface org.mule.api.MuleMessage
Returns the data type (if any) associated with the message's payload.
getDataType() - Method in class org.mule.DefaultMuleMessage
 
getDataType() - Method in class org.mule.el.context.MessageContext
 
getDataType(MuleMessage, ASTNode) - Method in class org.mule.el.mvel.datatype.AbstractExpressionDataTypeResolver
 
getDataType(MuleMessage, ASTNode) - Method in class org.mule.el.mvel.datatype.AbstractVariableExpressionDataTypeResolver
 
getDataType(MuleMessage, ASTNode) - Method in class org.mule.el.mvel.datatype.PayloadExpressionDataTypeResolver
 
getDataType(MuleMessage, ASTNode) - Method in class org.mule.el.mvel.datatype.PropertyExpressionDataTypeResolver
 
getDataType() - Method in class org.mule.transformer.types.TypedValue
 
getDataTypeConverterResolver() - Method in interface org.mule.api.MuleContext
 
getDataTypeConverterResolver() - Method in class org.mule.DefaultMuleContext
 
getDataTypeMetadataModel(int) - Method in class org.mule.module.db.internal.metadata.AbstractQueryMetadataProvider
 
getDate() - Method in class org.mule.el.datetime.DateTime
 
getDate() - Method in interface org.mule.tck.testmodels.services.DateService
 
getDate() - Method in class org.mule.tck.testmodels.services.TestServiceComponent
 
getDateFromString(String, String) - Static method in class org.mule.util.DateUtils
 
getDateHeader(String) - Method in class org.mule.module.atom.server.MuleRequestContext
 
getDateHeader(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getDateTime() - Method in class org.mule.el.context.ServerContext
 
getDateValue(String, String, XmlPullParser) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method getDateValue.
getDateValue(String, String, String, XmlPullParser) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method getDateValue.
getDayOfMonth() - Method in interface org.mule.api.el.datetime.Date
 
getDayOfMonth() - Method in class org.mule.el.datetime.DateTime
 
getDayOfWeek() - Method in interface org.mule.api.el.datetime.Date
 
getDayOfWeek() - Method in class org.mule.el.datetime.DateTime
 
getDayOfYear() - Method in interface org.mule.api.el.datetime.Date
 
getDayOfYear() - Method in class org.mule.el.datetime.DateTime
 
getDbTypeManager() - Method in class org.mule.module.db.internal.domain.database.GenericDbConfig
 
getDeadLetterQueue() - Method in class org.mule.routing.UntilSuccessful
 
getDebugInfo(MuleEvent) - Method in interface org.mule.api.debug.DebugInfoProvider
Returns debug information about the fields of this object.
getDebugInfo(MuleEvent) - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
getDebugInfo(MuleEvent) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
getDeclarationDescriptor() - Method in class org.mule.module.extension.internal.DefaultDescribingContext
getDeclaringClass() - Method in class org.mule.util.generics.MethodParameter
Return the class that declares the underlying Method or Constructor.
getDecoupledEndpoint() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getDeepestOccurenceOfType(Throwable, Class<ET>) - Static method in class org.mule.util.ExceptionUtils
This method returns the throwable closest to the root cause that matches the specified class or subclass.
getDefault() - Static method in class org.mule.api.security.tls.RestrictedSSLSocketFactory
 
getDefault() - Static method in class org.mule.transport.email.ImapsSocketFactory
 
getDefault() - Static method in class org.mule.transport.email.Pop3sSocketFactory
 
getDefault() - Static method in class org.mule.transport.email.SmtpsSocketFactory
 
getDefaultAccessTokenId() - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
getDefaultAccessTokenId() - Method in interface org.mule.security.oauth.OAuth2Manager
 
getDefaultCaCerts() - Static method in class org.mule.api.security.tls.TlsConfiguration
 
getDefaultCipherSuites() - Method in class org.mule.api.security.tls.RestrictedSSLServerSocketFactory
 
getDefaultCipherSuites() - Method in class org.mule.api.security.tls.RestrictedSSLSocketFactory
 
getDefaultCipherSuites() - Method in class org.mule.api.security.tls.TlsPropertiesSocketFactory
 
getDefaultClientEndpoint(Service, Object, boolean) - Method in class org.mule.module.client.MuleClient
 
getDefaultCompressionStrategy() - Static method in class org.mule.util.compression.CompressionHelper
 
getDefaultConfigResource() - Method in class org.mule.config.builders.MuleXmlBuilderContextListener
If no config location resource is configured on the servlet context, the value returned from this method will be used to initialise the MuleManager.
getDefaultConnectionFactory() - Method in class org.mule.transport.jms.activemq.ActiveMQJmsConnector
 
getDefaultConnectionFactory() - Method in class org.mule.transport.jms.activemq.ActiveMQXAJmsConnector
 
getDefaultConnectionFactory() - Method in class org.mule.transport.jms.JmsConnector
Override this method to provide a default ConnectionFactory for a vendor-specific JMS Connector.
getDefaultConnectionFactory() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getDefaultConnector() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getDefaultConnectorByProtocol(String) - Method in class org.mule.transport.service.TransportFactory
 
getDefaultDeleteUnacceptedMessages(Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getDefaultDisableTransportTransformer() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getDefaultDomainClassLoader() - Method in interface org.mule.module.launcher.domain.DomainClassLoaderRepository
 
getDefaultDomainClassLoader() - Method in class org.mule.module.launcher.domain.MuleDomainClassLoaderRepository
 
getDefaultEncoding() - Method in interface org.mule.api.config.MuleConfiguration
 
getDefaultEncoding() - Method in class org.mule.config.DefaultMuleConfiguration
 
getDefaultEncoding(MuleContext) - Static method in class org.mule.util.SystemUtils
 
getDefaultEndpointEncoding(Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getDefaultEndpointName() - Method in class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
getDefaultExceptionStrategy() - Method in interface org.mule.api.MuleContext
 
getDefaultExceptionStrategy() - Method in class org.mule.DefaultMuleContext
 
getDefaultExceptionStrategyName() - Method in interface org.mule.api.config.MuleConfiguration
 
getDefaultExceptionStrategyName() - Method in class org.mule.config.DefaultMuleConfiguration
 
getDefaultExchangePattern() - Method in interface org.mule.api.transport.Connector
 
getDefaultExchangePattern() - Method in class org.mule.transport.AbstractConnector
 
getDefaultExchangePattern() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
getDefaultExchangePattern() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
getDefaultFile() - Method in class org.mule.transport.http.components.StaticResourceMessageProcessor
 
getDefaultInboundTransformers(TransportServiceDescriptor, ImmutableEndpoint) - Static method in class org.mule.transformer.TransformerUtils
 
getDefaultInboundTransformers(ImmutableEndpoint) - Method in class org.mule.transport.AbstractConnector
 
getDefaultInitialState(Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getDefaultMessageDispatcherThreadingProfile() - Method in interface org.mule.api.MuleContext
 
getDefaultMessageDispatcherThreadingProfile() - Method in class org.mule.DefaultMuleContext
 
getDefaultMessageProcessorsFactory() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getDefaultMessageReceiverThreadingProfile() - Method in interface org.mule.api.MuleContext
 
getDefaultMessageReceiverThreadingProfile() - Method in class org.mule.DefaultMuleContext
 
getDefaultMessageRequesterThreadingProfile() - Method in interface org.mule.api.MuleContext
 
getDefaultMessageRequesterThreadingProfile() - Method in class org.mule.DefaultMuleContext
 
getDefaultObjectSerializer() - Method in interface org.mule.api.config.MuleConfiguration
Returns the default instance of ObjectSerializer to be used.
getDefaultObjectSerializer() - Method in class org.mule.config.DefaultMuleConfiguration
Returns the default instance of ObjectSerializer to be used.
getDefaultOutboundTransformers(TransportServiceDescriptor, ImmutableEndpoint) - Static method in class org.mule.transformer.TransformerUtils
 
getDefaultOutboundTransformers(ImmutableEndpoint) - Method in class org.mule.transport.AbstractConnector
 
getDefaultPort() - Method in enum org.mule.module.http.api.HttpConstants.Protocols
 
getDefaultPort() - Method in class org.mule.transport.email.AbstractMailConnector
 
getDefaultPort() - Method in class org.mule.transport.email.SmtpConnector
 
getDefaultProcessingStrategy() - Method in interface org.mule.api.config.MuleConfiguration
The default ProcessingStrategy to be used by all Flows which doesn't specify otherwise
getDefaultProcessingStrategy() - Method in class org.mule.config.DefaultMuleConfiguration
The default ProcessingStrategy to be used by all Flows which doesn't specify otherwise
getDefaultProcessMessageAction() - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
getDefaultQueueTimeout() - Method in interface org.mule.api.config.MuleConfiguration
 
getDefaultQueueTimeout() - Method in class org.mule.config.DefaultMuleConfiguration
 
getDefaultResponseTimeout() - Method in interface org.mule.api.config.MuleConfiguration
 
getDefaultResponseTimeout() - Method in class org.mule.config.DefaultMuleConfiguration
 
getDefaultResponseTimeout(Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getDefaultResponseTransformers(TransportServiceDescriptor, ImmutableEndpoint) - Static method in class org.mule.transformer.TransformerUtils
 
getDefaultResponseTransformers(ImmutableEndpoint) - Method in class org.mule.transport.AbstractConnector
 
getDefaultRetryPolicyTemplate() - Method in class org.mule.module.db.internal.domain.database.GenericDbConfigFactory
 
getDefaultRoute() - Method in class org.mule.routing.AbstractMatchingRouter
 
getDefaultScope() - Method in class org.mule.MessagePropertiesContext
 
getDefaultSecurityFilter() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getDefaultSecurityProvider() - Static method in class org.mule.util.SecurityUtils
Returns the default security provider that should be used in scenarios where ONE provider must be explicitly given.
getDefaultService() - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
 
getDefaultServiceThreadingProfile() - Method in interface org.mule.api.MuleContext
 
getDefaultServiceThreadingProfile() - Method in class org.mule.DefaultMuleContext
 
getDefaultThreadingProfile() - Method in interface org.mule.api.MuleContext
 
getDefaultThreadingProfile() - Method in class org.mule.DefaultMuleContext
 
getDefaultTransactionConfig() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getDefaultTransactionTimeout() - Method in interface org.mule.api.config.MuleConfiguration
 
getDefaultTransactionTimeout() - Method in class org.mule.config.DefaultMuleConfiguration
 
getDefaultTransactionTimeout() - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
Gets the default transaction timeout in milliseconds.
getDefaultTransactionTimeout() - Method in class org.mule.util.xa.AbstractResourceManager
Gets the default transaction timeout in milliseconds.
getDefaultUnauthorizedConnector() - Method in class org.mule.security.oauth.BaseOAuth2Manager
Retrieves defaultUnauthorizedConnector
getDefaultUnauthorizedConnector() - Method in interface org.mule.security.oauth.OAuth2Manager
Retrieve default unauthorized connector
getDefaultValue(Optional) - Static method in class org.mule.module.extension.internal.util.MuleExtensionUtils
 
getDefinition(EndpointInfo) - Method in class org.mule.module.cxf.support.ProxyWSDLQueryHandler
 
getDefinition(EndpointInfo) - Method in class org.mule.module.cxf.support.WSDLQueryHandler
 
getDefvalue() - Method in class com.javaforge.bobber.archetype.model.Variable
Get the defvalue field.
getDelayedResult(Source) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
Get a delayed result.
getDelayedResult(MuleMessage, String, Source) - Method in class org.mule.module.xml.transformer.XsltTransformer
 
getDelayedResultCallback(DelayedResult) - Method in class org.mule.module.cxf.support.OutputPayloadInterceptor
 
getDelegate(int) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
getDelegate(Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.AbstractParallelDelegatingDefinitionParser
 
getDelegate(Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.AttributeSelectionDefinitionParser
 
getDelegate(Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.BooleanAttributeSelectionDefinitionParser
 
getDelegate(Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
getDelegate(Element, ParserContext) - Method in class org.mule.config.spring.parsers.specific.ComponentDelegatingDefinitionParser
 
getDelegate() - Method in class org.mule.module.launcher.application.ApplicationWrapper
 
getDelegate() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
getDelegate() - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
getDelegate() - Method in class org.mule.module.spring.security.SpringProviderAdapter
 
getDelegate() - Method in class org.mule.retry.async.AsynchronousRetryTemplate
 
getDelegate() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getDelegate(Element, ParserContext) - Method in class org.mule.transport.http.builder.HttpHeaderDefinitionParser
 
getDelegateReader() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getDelegateSession() - Method in class org.mule.transport.file.FileMessageDispatcher
There is no associated session for a file connector
getDelegateSession() - Method in class org.mule.transport.file.FileMessageRequester
There is no associated session for a file connector
getDeleteProperties() - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
getDeleteQuery() - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
getDeleteQueryKey() - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
getDeleteUnacceptedMessages(Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getDelimiter() - Method in class org.mule.transformer.simple.ObjectArrayToString
 
getDelimiter() - Method in class org.mule.transformer.simple.StringToObjectArray
 
getDependantMethod() - Method in class org.mule.module.launcher.coreextension.LinkedMuleCoreExtensionDependency
 
getDependencies(String) - Method in class org.mule.config.spring.SpringRegistry
 
getDependencyClass() - Method in class org.mule.module.launcher.coreextension.LinkedMuleCoreExtensionDependency
 
getDependencyComparator() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Return the dependency comparator for this BeanFactory (may be null.
getDependentAgents() - Method in class org.mule.module.management.agent.YourKitProfilerAgent
 
getDependsOnVar() - Method in class com.javaforge.bobber.archetype.model.Template
Get if the specified variable is true, the template will be processed, otherwise skipped.
getDeploymentDirectory() - Method in interface org.mule.module.launcher.ArchiveDeployer
 
getDeploymentDirectory() - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
getDeploymentDirectory() - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
getDeploymentFile(File, String, String) - Static method in class org.mule.module.launcher.artifact.ArtifactFactoryUtils
Finds the deployment file within a given artifact.
getDeploymentProperties() - Method in interface org.mule.api.MuleContext
 
getDeploymentProperties() - Method in class org.mule.DefaultMuleContext
 
getDeploymentProperties() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
getDeploymentProperties() - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
getDeploymentStates() - Method in class org.mule.module.launcher.ArtifactDeploymentStatusTracker
 
getDeprecationMessage() - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
getDeprecationMessage() - Method in class org.mule.module.xml.expression.BeanPayloadExpressionEvaluator
Deprecated.
 
getDeprecationMessage() - Method in class org.mule.module.xml.expression.XPathBranchExpressionEvaluator
Deprecated.
 
getDeprecationMessage() - Method in class org.mule.module.xml.expression.XPathExpressionEvaluator
Deprecated.
 
getDeprecationMessage() - Method in class org.mule.module.xml.expression.XPathNodeExpressionEvaluator
Deprecated.
 
getDeprecationWarning() - Static method in class org.mule.module.ognl.config.OGNLNamespaceHandler
 
getDeprecationWarning() - Method in class org.mule.transport.jdbc.config.JdbcNamespaceHandler
 
getDescribers() - Method in class org.mule.tck.junit4.ExtensionsFunctionalTestCase
Implement this method to limit the amount of extensions initialised by providing the Describers for the extensions that you actually want to use for this test.
getDescription() - Method in class com.javaforge.bobber.archetype.model.Variable
Get the description field.
getDescription() - Method in class org.mule.AbstractAgent
 
getDescription() - Method in class org.mule.agent.EndpointNotificationLoggerAgent
Should be a 1 line description of the agent
getDescription() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
Should be a 1 line description of the agent
getDescription() - Method in interface org.mule.api.agent.Agent
A description of the agent that gets displayed in the splash screen when the Mule Context starts up.
getDescription() - Method in interface org.mule.api.retry.RetryContext
 
getDescription() - Method in class org.mule.config.spring.util.CachedResource
 
getDescription() - Method in class org.mule.module.client.remoting.RemoteDispatcherAgent
Deprecated.
Should be a 1 line description of the agent
getDescription() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
getDescription() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
Should be a 1 line description of the agent
getDescription() - Method in class org.mule.module.management.agent.JdmkAgent
 
getDescription() - Method in class org.mule.module.management.agent.JmxServerNotificationAgent
 
getDescription() - Method in class org.mule.module.management.agent.Log4jAgent
Deprecated.
 
getDescription() - Method in class org.mule.module.management.agent.Mx4jAgent
 
getDescription() - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
getDescription() - Method in class org.mule.module.management.agent.WrapperManagerAgent
 
getDescription() - Method in class org.mule.module.management.agent.YourKitProfilerAgent
 
getDescription() - Method in class org.mule.retry.async.FutureRetryContext
 
getDescription() - Method in class org.mule.retry.DefaultRetryContext
 
getDescription() - Method in class org.mule.transport.servlet.jetty.JettyWebappServerAgent
 
getDescriptor() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
getDescriptor() - Method in interface org.mule.module.launcher.artifact.Artifact
 
getDescriptor() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
getDescriptor() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
getDeserializationMixins() - Method in class org.mule.module.json.transformers.JsonToObject
 
getDestination(EndpointInfo) - Method in class org.mule.module.cxf.transport.MuleUniversalTransport
 
getDestination(EndpointInfo, EndpointReferenceType) - Method in class org.mule.module.cxf.transport.MuleUniversalTransport
 
getDetail() - Method in exception org.mule.module.ws.consumer.SoapFaultException
 
getDetailedMessage() - Method in exception org.mule.api.MuleException
 
getDetailedMessage() - Method in exception org.mule.routing.CompositeRoutingException
 
getDetails() - Method in class org.mule.module.pgp.PGPAuthentication
 
getDetails() - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
getDevkitBuild() - Method in interface org.mule.api.MetadataAware
Returns the build of the DevKit used to create this module
getDevkitVersion() - Method in interface org.mule.api.MetadataAware
Returns the version of the DevKit used to create this module
getDirectory() - Method in class org.mule.transport.servlet.jetty.WebappsConfiguration
 
getDirectory() - Method in class org.mule.util.store.TextFileObjectStore
 
getDiscardedObjectPlaceholder() - Method in class org.mule.config.spring.CompositeOptionalObjectsController
 
getDiscardedObjectPlaceholder() - Method in class org.mule.config.spring.DefaultOptionalObjectsController
 
getDiscardedObjectPlaceholder() - Method in interface org.mule.config.spring.OptionalObjectsController
A placeholder for Spring to temporarily work with.
getDispatcherFactory() - Method in interface org.mule.api.transport.Connector
The dispatcher factory is used to create a message dispatcher of the current request
getDispatcherFactory() - Method in class org.mule.transport.AbstractConnector
 
getDispatcherName() - Method in class org.mule.transport.AbstractMessageDispatcher
 
getDispatcherPoolFactory() - Method in class org.mule.transport.AbstractConnector
 
getDispatchers() - Method in class org.mule.transport.tcp.TcpConnector
 
getDispatcherThreadingProfile() - Method in class org.mule.transport.AbstractConnector
Getter for property 'dispatcherThreadingProfile'.
getDispatcherType() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getDispatcherWorkManager() - Method in class org.mule.transport.AbstractConnector
Returns a work manager for message dispatchers.
getDlqMP() - Method in class org.mule.routing.UntilSuccessful
 
getDlqMP() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
getDocName(Object) - Static method in class org.mule.api.execution.LocationExecutionContextProvider
 
getDocumentBuilderFactory() - Method in class org.mule.module.xml.filters.AbstractJaxpFilter
The document builder factory to use in case XML needs to be parsed.
getDocumentBuilderFactory() - Method in class org.mule.util.xmlsecurity.XMLSecureFactories
 
getDocumentBuilderFactory(DefaultXMLSecureFactories) - Method in class org.mule.util.xmlsecurity.XMLSecureFactoriesCache
 
getDocUrl(Class<?>) - Static method in class org.mule.config.ExceptionHelper
Deprecated.
since 3.8.0
getDom4jXPath() - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
getDomain() - Method in class org.mule.context.notification.MuleContextNotification
 
getDomain() - Method in class org.mule.module.http.internal.domain.request.HttpRequestAuthentication
 
getDomain() - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
getDomain() - Method in interface org.mule.module.launcher.application.Application
 
getDomain() - Method in class org.mule.module.launcher.application.ApplicationWrapper
 
getDomain() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
getDomain() - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
getDomain() - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
Retrieves domain
getDomain() - Method in interface org.mule.security.oauth.callback.HttpCallbackAdapter
Retrieves domain
getDomainBuilder(String) - Method in class org.mule.tck.junit4.DomainContextBuilder
 
getDomainClassLoader(DomainDescriptor) - Method in interface org.mule.module.launcher.domain.DomainClassLoaderRepository
 
getDomainClassLoader(String) - Method in interface org.mule.module.launcher.domain.DomainClassLoaderRepository
 
getDomainClassLoader(DomainDescriptor) - Method in class org.mule.module.launcher.domain.MuleDomainClassLoaderRepository
 
getDomainClassLoader(String) - Method in class org.mule.module.launcher.domain.MuleDomainClassLoaderRepository
 
getDomainConfig() - Method in class org.mule.tck.junit4.DomainFunctionalTestCase
 
getDomainDeploymentStatusTracker() - Method in class org.mule.module.launcher.DeploymentStatusTracker
 
getDomainFolder(String) - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getDomainId() - Method in interface org.mule.api.config.MuleConfiguration
 
getDomainId() - Method in class org.mule.config.DefaultMuleConfiguration
 
getDomainLibFolder(String) - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getDomainName(MuleContext) - Method in class org.mule.module.management.support.AbstractJmxSupport
Calculates the domain name for the current Mule instance.
getDomainName(MuleContext, boolean) - Method in class org.mule.module.management.support.AbstractJmxSupport
 
getDomainName(MuleContext) - Method in interface org.mule.module.management.support.JmxSupport
Calculates the domain name for the current Mule instance.
getDomainName(MuleContext, boolean) - Method in interface org.mule.module.management.support.JmxSupport
 
getDomains() - Method in interface org.mule.module.launcher.DeploymentService
 
getDomains() - Method in class org.mule.module.launcher.MuleDeploymentService
 
getDomains(MBeanServer) - Method in class org.mule.module.management.support.AbstractJmxSupport
List all domains of this MBean server.
getDomains(MBeanServer) - Method in class org.mule.module.management.support.JmxLegacySupport
List all domains of this MBean server.
getDomains(MBeanServer) - Method in class org.mule.module.management.support.JmxModernSupport
List all domains of this MBean server.
getDomainsFolder() - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getDOMXPath() - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
getDouble(Object, Double) - Static method in class org.mule.util.ObjectUtils
Gets a double from a value in a null-safe manner.
getDoubleProperty(String, double) - Method in interface org.mule.api.MuleMessage
getDoubleProperty(String, double) - Method in class org.mule.DefaultMuleMessage
Deprecated.
getDoubleProperty(String, double) - Method in class org.mule.MessagePropertiesContext
 
getDoubleValue(String, String, XmlPullParser, boolean) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method getDoubleValue.
getDriverClass() - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
getDriverClassName() - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
getDTDHandler() - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
getDuplicateHandling() - Method in class org.mule.transport.sftp.SftpConnector
 
getDuplicateHandling() - Method in class org.mule.transport.sftp.SftpUtil
 
getDynamicInputMetadata(PreparedStatement, Query) - Method in class org.mule.module.db.internal.metadata.AbstractQueryMetadataProvider
Calculates the input metadata for a statement
getDynamicInputMetadata(PreparedStatement, Query) - Method in class org.mule.module.db.internal.metadata.PreparedBulkUpdateMetadataProvider
 
getDynamicOutputMetadata(PreparedStatement) - Method in class org.mule.module.db.internal.metadata.AbstractQueryMetadataProvider
Calculates the dynamic output metadata from a statement
getDynamicOutputMetadata(PreparedStatement) - Method in class org.mule.module.db.internal.metadata.PreparedBulkUpdateMetadataProvider
 
getDynamicOutputMetadata(PreparedStatement) - Method in class org.mule.module.db.internal.metadata.SelectMetadataProvider
 
getDynamicOutputMetadata(PreparedStatement) - Method in class org.mule.module.db.internal.metadata.UpdateMetadataProvider
 
getEffectiveTime(long) - Static method in class org.mule.management.stats.ProcessingTime
Convert processing time to effective processing time.
getEffectiveUrl() - Method in class org.mule.module.db.internal.config.domain.database.AbstractVendorConfigResolverFactoryBean
 
getEffectiveUrl() - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
getElementName() - Method in class org.mule.util.annotation.AnnotationMetaData
 
getElements() - Method in interface org.mule.api.context.notification.FlowCallStack
 
getElements() - Method in class org.mule.context.notification.DefaultFlowCallStack
 
getElementString() - Method in class org.mule.config.spring.parsers.DefaultXmlMetadataAnnotations
 
getElementString() - Method in interface org.mule.config.spring.parsers.XmlMetadataAnnotations
 
getElementText() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getElementText() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getEnableCorrelation() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
getEnabledCipherSuites() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getEnabledCipherSuites() - Method in class org.mule.api.security.tls.TlsProperties
 
getEnabledProtocols() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getEnabledProtocols() - Method in class org.mule.api.security.tls.TlsProperties
 
getEncodedConstructor() - Method in class org.mule.endpoint.URIBuilder
 
getEncodedState() - Method in class org.mule.module.oauth2.internal.StateEncoder
 
getEncoding() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
Decides the encoding to be used for events received by this endpoint
getEncoding() - Method in interface org.mule.api.MuleEvent
Gets the encoding for this message.
getEncoding() - Method in interface org.mule.api.MuleEventContext
Gets the encoding for the current message.
getEncoding() - Method in interface org.mule.api.MuleMessage
Gets the encoding for the current message.
getEncoding() - Method in interface org.mule.api.transformer.DataType
The encoding for the object to transform
getEncoding() - Method in interface org.mule.api.transformer.Transformer
Return the encoding returned by the transformer (if any).
getEncoding() - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
getEncoding() - Method in class org.mule.DefaultMuleEvent
Gets the encoding for this message.
getEncoding() - Method in class org.mule.DefaultMuleEventContext
Gets the encoding for the current message.
getEncoding() - Method in class org.mule.DefaultMuleMessage
Gets the encoding for the current message.
getEncoding() - Method in class org.mule.el.context.AppContext
 
getEncoding() - Method in class org.mule.endpoint.AbstractEndpoint
 
getEncoding() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getEncoding() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getEncoding() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getEncoding() - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
getEncoding() - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
getEncoding() - Method in class org.mule.module.management.mbean.MuleConfigurationService
 
getEncoding() - Method in interface org.mule.module.management.mbean.MuleConfigurationServiceMBean
 
getEncoding() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getEncoding() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
getEncoding() - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
getEncoding() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getEncoding() - Method in class org.mule.transformer.AbstractTransformer
 
getEncoding(Object) - Method in class org.mule.transformer.AbstractTransformer
 
getEncoding() - Method in class org.mule.transformer.CompositeConverter
 
getEncoding() - Method in class org.mule.transformer.types.SimpleDataType
 
getEncoding() - Method in class org.mule.transport.http.ResponseWriter
 
getEncoding() - Method in class org.mule.util.store.TextFileObjectStore
 
getEncoding() - Method in class org.mule.VoidMuleEvent
 
getEncryptionStrategies() - Method in interface org.mule.api.security.SecurityManager
 
getEncryptionStrategies() - Method in class org.mule.security.MuleSecurityManager
 
getEncryptionStrategy() - Method in exception org.mule.api.security.CryptoFailureException
 
getEncryptionStrategy(String) - Method in interface org.mule.api.security.SecurityManager
 
getEncryptionStrategy(String) - Method in class org.mule.security.MuleSecurityManager
 
getEndpoint() - Method in class org.mule.agent.EndpointNotificationLoggerAgent
 
getEndpoint() - Method in interface org.mule.api.component.InterfaceBinding
 
getEndpoint() - Method in exception org.mule.api.exception.MessageRedeliveredException
 
getEndpoint() - Method in interface org.mule.api.security.EndpointSecurityFilter
Deprecated.
 
getEndpoint() - Method in interface org.mule.api.transformer.Transformer
Deprecated. 
getEndpoint() - Method in interface org.mule.api.transport.MessageDispatcher
 
getEndpoint() - Method in interface org.mule.api.transport.MessageReceiver
 
getEndpoint() - Method in interface org.mule.api.transport.MessageRequester
 
getEndpoint() - Method in class org.mule.component.DefaultInterfaceBinding
 
getEndpoint() - Method in class org.mule.context.notification.BaseConnectorMessageNotification
 
getEndpoint(EndpointURI, DefaultEndpointFactory.EndpointSource) - Method in class org.mule.endpoint.DefaultEndpointFactory
 
getEndpoint() - Method in class org.mule.endpoint.URIBuilder
 
getEndpoint() - Method in class org.mule.message.ExceptionMessage
 
getEndpoint() - Method in class org.mule.module.client.remoting.RemoteDispatcherAgent
Deprecated.
 
getEndpoint(DestinationFactory, String) - Static method in class org.mule.module.cxf.support.CxfUtils
 
getEndpoint(MuleContext, String) - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
getEndpoint() - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
getEndpoint() - Method in class org.mule.module.jbpm.MuleReceiveActivity
 
getEndpoint() - Method in class org.mule.module.spring.events.MuleApplicationEvent
Deprecated.
 
getEndpoint() - Method in class org.mule.routing.ForwardingCatchAllStrategy
Deprecated.
 
getEndpoint() - Method in class org.mule.routing.outbound.SplitMessage.MessagePart
 
getEndpoint() - Method in class org.mule.security.AbstractEndpointSecurityFilter
Deprecated.
 
getEndpoint(String) - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
getEndpoint() - Method in class org.mule.transformer.AbstractTransformer
 
getEndpoint() - Method in class org.mule.transformer.CompositeConverter
 
getEndpoint() - Method in class org.mule.transport.AbstractMessageDispatcher
 
getEndpoint() - Method in class org.mule.transport.AbstractMessageReceiver
 
getEndpoint() - Method in class org.mule.transport.AbstractMessageRequester
 
getEndpoint() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
getEndpoint(MuleEvent, String) - Method in class org.mule.transport.DefaultReplyToHandler
 
getEndpoint() - Method in class org.mule.transport.sftp.notification.SftpTransportNotification
 
getEndpoint() - Method in class org.mule.transport.tcp.TcpSocketKey
 
getEndpointAddressWithoutMetaScheme(String) - Static method in class org.mule.endpoint.AbstractMetaEndpointBuilder
 
getEndpointBuilder(String) - Method in interface org.mule.api.endpoint.EndpointFactory
Used to retrieve the an EndpointBuilder equal to the one would be used to create an endpoint.

This is useful if you need to customize a builder before creation of an endpoint as you can use this method to obtain the endpoint builder, custommize it and then call the factory methods that take a EndpointBuilder rather than a String.
getEndpointBuilder(AnnotatedEndpointData) - Method in class org.mule.config.endpoint.AnnotatedEndpointHelper
 
getEndpointBuilder() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getEndpointBuilder(String) - Method in class org.mule.endpoint.DefaultEndpointFactory
 
getEndpointBuilderName() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
The name of the endpoint builder used to create this endpoint.
getEndpointBuilderName() - Method in class org.mule.endpoint.AbstractEndpoint
 
getEndpointBuilderName() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getEndpointBuilderName() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getEndpointBuilderName() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getEndpointBuilderName() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getEndpointEncoding(Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getEndpointFactory() - Method in interface org.mule.api.MuleContext
Returns the EndpointFactory configured for this instance of Mule
getEndpointFactory() - Method in class org.mule.DefaultMuleContext
 
getEndpointForURI(HttpServletRequest) - Method in class org.mule.transport.servlet.MuleRESTReceiverServlet
 
getEndpointHelper() - Method in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
getEndpointName() - Method in interface org.mule.api.endpoint.EndpointURI
Deprecated.
This property is used by endpoint-identifiers, global-endpoints use ImmutableEndpoint.getName()
getEndpointName() - Method in class org.mule.endpoint.MuleEndpointURI
 
getEndpointName() - Method in class org.mule.module.cxf.support.MuleServiceConfiguration
 
getEndpointName() - Method in class org.mule.module.cxf.support.ProxyServiceConfiguration
Override to use port name from service definition in WSDL when we are doing WSDL-first.
getEndpointName(EndpointURI) - Method in class org.mule.util.ObjectNameHelper
 
getEndpointNameFor(EndpointURI) - Static method in class org.mule.util.ObjectNameHelper
 
getEndpointParser(Annotation, Class<?>, Member) - Method in interface org.mule.config.AnnotationsParserFactory
Retrieves a parser for the given annotation, the parameters passed in can be used to validate the use of the annotation, i.e.
getEndpointParser(Annotation, Class, Member) - Method in class org.mule.config.endpoint.RegistryBackedAnnotationsParserFactory
 
getEndpointRef() - Method in class org.mule.transport.quartz.jobs.EndpointPollingJobConfig
 
getEndpointRef() - Method in class org.mule.transport.quartz.jobs.ScheduledDispatchJobConfig
 
getEndpoints() - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
Use EndpointFactory for creation/lookup of individual endpoints instead
getEndpoints() - Method in class org.mule.registry.MuleRegistryHelper
getEndpoints() - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
getEndpointURI() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
This specifess the communication endpointUri.
getEndpointURI() - Method in interface org.mule.api.MuleEventContext
Returns a reference to the Endpoint Uri for this context This is the endpoint on which the event was received
getEndpointURI() - Method in interface org.mule.api.transport.MessageReceiver
The endpointUri that this receiver listens on
getEndpointURI() - Method in class org.mule.DefaultMuleEventContext
 
getEndpointURI() - Method in class org.mule.endpoint.AbstractEndpoint
 
getEndpointURI() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getEndpointURI() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getEndpointURI() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getEndpointURI() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getEndpointURI() - Method in class org.mule.transport.AbstractMessageReceiver
 
getEntity() - Method in interface org.mule.module.http.internal.domain.HttpMessage
 
getEntity() - Method in class org.mule.module.http.internal.domain.request.DefaultHttpRequest
 
getEntity() - Method in class org.mule.module.http.internal.domain.response.DefaultHttpResponse
 
getEntity() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyHttpRequestAdapter
 
getEntityResolver() - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
getEntries() - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
getEntryFilter() - Method in class org.mule.module.atom.routing.FeedSplitter
 
getEntryFilter() - Method in class org.mule.module.rss.routing.FeedSplitter
 
getEntryPoint() - Method in class org.mule.module.bpm.RulesComponent
 
getEntryPointLabel() - Method in class org.mule.module.bpm.Rules
 
getEntryPointResolvers() - Method in class org.mule.model.resolvers.DefaultEntryPointResolverSet
 
getEntryPointResolverSet() - Method in interface org.mule.api.component.JavaComponent
A JavaComponent can have a custom entry-point resolver for its own object.
getEntryPointResolverSet() - Method in interface org.mule.api.model.Model
Deprecated.
The entry point resolver is used to determine the method to be called on a service when an event is received for it.
getEntryPointResolverSet() - Method in class org.mule.component.AbstractJavaComponent
 
getEntryPointResolverSet() - Method in class org.mule.model.AbstractModel
Deprecated.
 
getEntryTTL() - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
getEntryTTL() - Method in class org.mule.util.store.ManagedObjectStore
 
getEnv() - Method in class org.mule.el.context.ServerContext
 
getenv() - Static method in class org.mule.util.SystemUtils
Get the operating system environment variables.
getenv(String) - Static method in class org.mule.util.SystemUtils
 
getEnvironment() - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
getEnvironment() - Method in class org.mule.jndi.SimpleContext
 
getEnvironment() - Method in class org.mule.tck.jndi.InMemoryContext
 
getEnvironment() - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
getErrorClass(int) - Static method in class org.mule.config.ExceptionHelper
 
getErrorCode(Class) - Static method in class org.mule.config.ExceptionHelper
 
getErrorCodePropertyName(String, MuleContext) - Static method in class org.mule.config.ExceptionHelper
 
getErrorHandler() - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
getErrorHandler() - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
getErrorHandler() - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
getErrorHandler() - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
getErrorHandler() - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
getErrorMapping(String, Class, MuleContext) - Static method in class org.mule.config.ExceptionHelper
Maps an exception thrown for a certain protocol to an error.
getErrorMessage() - Method in class org.mule.api.model.InvocationResult
Returns the error message set on this result or null if none has been set
getEvaluator() - Method in class org.mule.expression.ExpressionConfig
 
getEvaluator() - Method in class org.mule.expression.transformers.ExpressionArgument
 
getEvaluator() - Method in class org.mule.routing.ExpressionSplitter
 
getEvaluator() - Method in class org.mule.routing.filters.ExpressionFilter
 
getEvaluator() - Method in class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
getEvaluator() - Method in class org.mule.routing.outbound.ExpressionMessageSplitter
Deprecated.
 
getEvaluator() - Method in class org.mule.routing.outbound.ExpressionRecipientList
 
getEvaluator() - Method in class org.mule.transport.quartz.jobs.CustomJobFromMessageConfig
 
getEvent() - Method in exception org.mule.api.MessagingException
 
getEvent() - Method in interface org.mule.api.security.Authentication
 
getEvent(MuleMessage, MessageExchangePattern) - Method in class org.mule.module.client.MuleClient
 
getEvent() - Method in class org.mule.module.extension.internal.runtime.DefaultOperationContext
 
getEvent() - Method in interface org.mule.module.extension.internal.runtime.OperationContextAdapter
Returns the MuleEvent on which an operation is to be executed
getEvent() - Method in class org.mule.module.jaas.JaasAuthentication
 
getEvent() - Method in class org.mule.module.pgp.PGPAuthentication
 
getEvent() - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
getEvent() - Static method in class org.mule.RequestContext
Deprecated.
 
getEvent() - Method in class org.mule.routing.requestreply.MultipleRequestReplierEvent
 
getEvent() - Method in class org.mule.security.DefaultMuleAuthentication
 
getEvent() - Method in class org.mule.work.AbstractMuleEventWork
 
getEventCallback() - Method in class org.mule.tck.functional.FunctionalTestComponent
An event callback is called when a message is received by the service.
getEventComparator() - Method in class org.mule.routing.Resequencer
 
getEventContext() - Method in class org.mule.expression.MuleContextExpressionEvaluator
 
getEventContext() - Static method in class org.mule.RequestContext
Deprecated.
 
getEventContext() - Method in class org.mule.tck.functional.FunctionalTestNotification
 
getEventGroup() - Method in exception org.mule.routing.AggregationException
 
getEventGroup(Serializable) - Method in class org.mule.routing.correlation.EventCorrelator
 
getEventGroupsPartitionKey() - Method in class org.mule.routing.correlation.EventCorrelator
 
getEventKeyPrefix() - Method in class org.mule.routing.UntilSuccessful
 
getEventQueue() - Method in class org.mule.context.notification.ServerNotificationManager
Deprecated.
getEvents() - Method in class org.mule.api.routing.AggregationContext
 
getEventType() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getEventType() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getEvictionCheckIntervalMillis() - Method in class org.mule.config.PoolingProfile
 
getException() - Method in interface org.mule.api.ExceptionPayload
 
getException() - Method in class org.mule.context.notification.AsyncMessageNotification
 
getException() - Method in class org.mule.context.notification.ExceptionNotification
 
getException() - Method in class org.mule.context.notification.PipelineMessageNotification
 
getException() - Method in class org.mule.message.DefaultExceptionPayload
 
getException() - Method in class org.mule.message.ExceptionMessage
 
getException() - Method in class org.mule.module.xml.transformer.XsltTransformer.DefaultErrorListener
 
getException() - Method in class org.mule.retry.async.RetryWorker
 
getException() - Method in class org.mule.tck.concurrency.TestingThread
 
getExceptionCode() - Method in exception org.mule.api.MuleException
 
getExceptionContextProviders() - Method in interface org.mule.api.MuleContext
 
getExceptionContextProviders() - Method in class org.mule.DefaultMuleContext
 
getExceptionForRouteIndex(Integer) - Method in exception org.mule.routing.CompositeRoutingException
Returns the Exception for the given route index
getExceptionInfo(Throwable) - Static method in class org.mule.config.ExceptionHelper
 
getExceptionListener() - Method in interface org.mule.api.construct.FlowConstruct
 
getExceptionListener() - Method in interface org.mule.api.model.Model
Deprecated.
The exception strategy to use by components managed by the model.
getExceptionListener() - Method in interface org.mule.api.MuleContext
 
getExceptionListener() - Method in interface org.mule.api.service.Service
Deprecated.
 
getExceptionListener() - Method in class org.mule.client.DefaultLocalMuleClient.MuleClientFlowConstruct
 
getExceptionListener() - Method in class org.mule.construct.AbstractFlowConstruct
 
getExceptionListener() - Method in class org.mule.DefaultMuleContext
 
getExceptionListener() - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
getExceptionListener() - Method in class org.mule.exception.MessagingExceptionStrategyAcceptorDelegate
 
getExceptionListener() - Method in class org.mule.model.AbstractModel
Deprecated.
 
getExceptionListener() - Method in class org.mule.service.AbstractService
Deprecated.
 
getExceptionListeners() - Method in class org.mule.exception.ChoiceMessagingExceptionStrategy
 
getExceptionMappings() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
getExceptionMappings() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
getExceptionPayload() - Method in interface org.mule.api.MuleMessage
If an error occurred during the processing of this message this will return a ErrorPayload that contains the root exception and Mule error code, plus any other releated info
getExceptionPayload() - Method in class org.mule.DefaultMuleMessage
If an error occurred during the processing of this message this will return a ErrorPayload that contains the root exception and Mule error code, plus any other releated info
getExceptionPayload() - Static method in class org.mule.RequestContext
Deprecated.
 
getExceptionReader(Throwable) - Static method in class org.mule.config.ExceptionHelper
Gets an exception reader for the exception
getExceptions() - Method in exception org.mule.routing.CompositeRoutingException
 
getExceptions() - Method in class org.mule.util.ExceptionHolder
 
getExceptionsAsList(Throwable) - Static method in class org.mule.config.ExceptionHelper
 
getExceptionStack(Throwable) - Static method in class org.mule.config.ExceptionHelper
 
getExceptionText() - Method in class org.mule.tck.functional.FunctionalTestComponent
 
getExceptionThrown() - Method in class org.mule.context.notification.MessageProcessorNotification
 
getExceptionToThrow() - Method in class org.mule.tck.functional.FunctionalTestComponent
 
getExceptionType() - Method in interface org.mule.api.config.ExceptionReader
 
getExceptionType() - Method in class org.mule.config.DefaultExceptionReader
 
getExceptionType() - Method in class org.mule.config.MuleExceptionReader
 
getExceptionType() - Method in class org.mule.config.NamingExceptionReader
 
getExceptionType(Throwable, Class<? extends Throwable>) - Method in class org.mule.exception.AbstractExceptionListener
 
getExceptionType() - Method in class org.mule.transport.jdbc.SQLExceptionReader
 
getExceptionType() - Method in class org.mule.transport.jms.JmsExceptionReader
 
getExceptionType() - Method in class org.mule.transport.soap.axis.AxisFaultExceptionReader
 
getExchangePattern() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
 
getExchangePattern() - Method in interface org.mule.api.MuleEvent
Returns the message exchange pattern for this event
getExchangePattern() - Method in interface org.mule.api.MuleEventContext
 
getExchangePattern() - Method in class org.mule.DefaultMuleEvent
 
getExchangePattern() - Method in class org.mule.DefaultMuleEventContext
 
getExchangePattern() - Method in class org.mule.endpoint.AbstractEndpoint
 
getExchangePattern() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getExchangePattern() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getExchangePattern() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getExchangePattern() - Method in class org.mule.module.http.internal.request.client.HttpRequestCacheKey
 
getExchangePattern() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getExchangePattern() - Method in class org.mule.VoidMuleEvent
 
getExecutedEvents() - Method in class org.mule.management.stats.ComponentStatistics
Then number of events executed since last cleared.
getExecutedEvents() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
getExecutedEvents() - Method in class org.mule.module.management.mbean.ServiceService
 
getExecutedEvents() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getExecutedEvents() - Method in interface org.mule.module.management.mbean.ServiceStatsMBean
Deprecated.
 
getExecutedProcessors() - Method in interface org.mule.api.context.notification.ProcessorsTrace
 
getExecutedProcessors() - Method in class org.mule.context.notification.DefaultProcessorsTrace
 
getExecutingPhase() - Method in interface org.mule.api.lifecycle.LifecycleManager
Returns the lifecycle phase being executed.
getExecutingPhase() - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
getExecution(String) - Method in class org.mule.module.jbpm.EndedProcess
 
getExecutionClassLoader() - Method in interface org.mule.api.MuleContext
 
getExecutionClassLoader() - Method in class org.mule.DefaultMuleContext
 
getExecutionClassLoader() - Method in interface org.mule.execution.MessageProcessContext
 
getExecutionClassLoader() - Method in class org.mule.module.http.internal.listener.HttpMessageProcessContext
 
getExecutionClassLoader() - Method in class org.mule.module.management.agent.ClassloaderSwitchingMBeanWrapper
 
getExecutionClassLoader() - Method in class org.mule.transport.TransportMessageProcessContext
 
getExecutionErrors() - Method in class org.mule.management.stats.ApplicationStatistics
 
getExecutionErrors() - Method in class org.mule.management.stats.FlowConstructStatistics
 
getExecutionErrors() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getExecutionErrors() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
getExecutionErrors() - Method in interface org.mule.module.management.mbean.FlowConstructStatsMBean
 
getExecutionFolder() - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getExecutionManager() - Method in interface org.mule.api.debug.DebuggingSession
Returns the execution handler
getExecutions() - Method in class org.mule.module.jbpm.EndedProcess
 
getExecutionsMap() - Method in class org.mule.module.jbpm.EndedProcess
 
getExecutor(ServerAddress) - Method in interface org.mule.module.http.internal.listener.grizzly.ExecutorProvider
Provides an Executor for a ServerAddress
getExecutor(ServerAddress) - Method in class org.mule.module.http.internal.listener.grizzly.WorkManagerSourceExecutorProvider
 
getExhaustedAction() - Method in class org.mule.config.PoolingProfile
 
getExpandEntities() - Method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
getExpectedType() - Method in class org.mule.routing.filters.PayloadTypeFilter
 
getExpectedType() - Method in class org.mule.transport.xmpp.filters.XmppPacketTypeFilter
 
getExpectedValue() - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
getExpectedValue() - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
getExpectedValue() - Method in class org.mule.module.xml.filters.XPathFilter
 
getExpirationInterval() - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
getExpirationInterval() - Method in class org.mule.util.store.ManagedObjectStore
 
getExpirationRegex() - Method in interface org.mule.security.oauth.OAuth2Connector
 
getExpirationTimePattern() - Method in interface org.mule.security.oauth.OAuth2Adapter
Returns a compiled Pattern which can be used to extract the expiration time from a String
getExpiredAndDispatchedPartitionKey() - Method in class org.mule.routing.correlation.EventCorrelator
 
getExpires() - Method in class org.mule.module.ws.security.WssTimestampSecurityStrategy
 
getExpiresIn() - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
getExpiresIn() - Method in class org.mule.module.oauth2.internal.authorizationcode.TokenResponseConfiguration
 
getExpiresIn() - Method in class org.mule.module.oauth2.internal.TokenResponseProcessor
 
getExpression() - Method in exception org.mule.api.expression.InvalidExpressionException
 
getExpression() - Method in class org.mule.expression.ExpressionConfig
 
getExpression() - Method in class org.mule.expression.transformers.ExpressionArgument
 
getExpression() - Method in class org.mule.keygenerator.ExpressionMuleEventKeyGenerator
 
getExpression() - Method in class org.mule.module.http.internal.HttpMapParam
 
getExpression() - Method in class org.mule.module.ognl.filters.OGNLFilter
 
getExpression() - Method in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
 
getExpression() - Method in class org.mule.module.xml.transformer.XPathExtractor
 
getExpression() - Method in class org.mule.routing.ExpressionSplitter
 
getExpression() - Method in class org.mule.routing.filters.ExpressionFilter
 
getExpression() - Method in class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
getExpression() - Method in class org.mule.routing.outbound.ExpressionMessageSplitter
Deprecated.
 
getExpression() - Method in class org.mule.routing.outbound.ExpressionRecipientList
 
getExpression() - Method in class org.mule.transport.email.filters.MailSubjectRegExFilter
 
getExpression() - Method in class org.mule.transport.jms.filters.JmsPropertyFilter
Returns the match expression
getExpression() - Method in class org.mule.transport.jms.filters.JmsSelectorFilter
 
getExpression() - Method in class org.mule.transport.quartz.jobs.CustomJobFromMessageConfig
 
getExpressionConfig(String, String) - Method in class org.mule.expression.MuleExpressionEvaluator
Deprecated.
 
getExpressionConfig() - Method in class org.mule.expression.transformers.ExpressionArgument
 
getExpressionLanguage() - Method in interface org.mule.api.MuleContext
Expression Language for evaluating expressions using Mule as the context
getExpressionLanguage() - Method in class org.mule.DefaultMuleContext
 
getExpressionLanguage() - Method in class org.mule.expression.DefaultExpressionManager
 
getExpressionManager() - Method in interface org.mule.api.MuleContext
Returns the Expression Manager configured for this instance of Mule
getExpressionManager() - Method in class org.mule.DefaultMuleContext
Returns the Expression Manager configured for this instance of Mule
getExpressionParser(Annotation) - Method in interface org.mule.config.AnnotationsParserFactory
Retrieves a parser for the given annotation, where the annotation is an Expression annotation; one annotated with the Evaluator annotation.
getExpressionParser(Annotation) - Method in class org.mule.config.endpoint.RegistryBackedAnnotationsParserFactory
 
getExtendedProperties() - Method in class org.mule.config.DefaultMuleConfiguration
 
getExtendedProperties() - Method in class org.mule.session.DefaultMuleSession
 
getExtendedProperty(String) - Method in class org.mule.config.DefaultMuleConfiguration
 
getExtension(Class<T>) - Method in interface org.mule.api.config.MuleConfiguration
 
getExtension(Class<T>) - Method in class org.mule.config.DefaultMuleConfiguration
 
getExtensionManager() - Method in interface org.mule.api.MuleContext
 
getExtensionManager() - Method in class org.mule.DefaultMuleContext
 
getExtensions() - Method in class org.mule.config.DefaultMuleConfiguration
 
getExtensions() - Method in class org.mule.module.extension.internal.manager.DefaultExtensionManager
getExtensionsCapableOf(Class<C>) - Method in class org.mule.module.extension.internal.manager.DefaultExtensionManager
getExternalEntities() - Method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
getExternalRedirectionUrl() - Method in interface org.mule.module.oauth2.internal.authorizationcode.AuthorizationCodeGrantType
 
getExternalRedirectionUrl() - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
getFactories() - Method in class org.mule.config.spring.processors.PropertyPlaceholderProcessor
 
getFactory() - Method in interface org.mule.api.transaction.TransactionConfig
 
getFactory() - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
getFactory() - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
getFactory() - Method in class org.mule.transaction.MuleTransactionConfig
 
getFactoryProperties() - Method in class org.mule.transport.quartz.QuartzConnector
 
getFailed() - Method in exception org.mule.transport.ConnectException
 
getFailingMessageProcessor() - Method in exception org.mule.api.MessagingException
 
getFailureExpression() - Method in class org.mule.routing.UntilSuccessful
 
getFailureExpressionFilter() - Method in class org.mule.routing.UntilSuccessful
 
getFailureExpressionFilter() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
getFallbackCharset() - Method in class org.mule.transport.http.HttpResponse
 
getFatalErrors() - Method in class org.mule.management.stats.ApplicationStatistics
 
getFatalErrors() - Method in class org.mule.management.stats.FlowConstructStatistics
 
getFatalErrors() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getFatalErrors() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
getFatalErrors() - Method in interface org.mule.module.management.mbean.FlowConstructStatsMBean
 
getFaultCode() - Method in exception org.mule.module.ws.consumer.SoapFaultException
 
getFaultForClass(BindingOperationInfo, Class) - Method in class org.mule.module.cxf.support.ProxyFaultOutInterceptor
 
getFeature(String) - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
getFeatures() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getFeatures() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getFetchSize() - Method in class org.mule.streaming.PagingConfiguration
 
getField() - Method in class org.mule.module.extension.internal.introspection.ParameterGroup
 
getField(Class<?>, Parameter) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
getField(Class<?>, ParameterDeclaration) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
getField(Class<?>, String, Class<?>) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
getFieldAnnotations(Class<?>, Class<? extends Annotation>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
getFieldAnnotations() - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
getFieldAnnotationsForHeirarchy(Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
use getFieldAnnotationsForHierarchy(Class)
getFieldAnnotationsForHeirarchy(Class<?>, Class<? extends Annotation>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
use getFieldAnnotationsForHierarchy(Class, Class)
getFieldAnnotationsForHierarchy(Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
getFieldAnnotationsForHierarchy(Class<?>, Class<? extends Annotation>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
getFieldAnnotationsForInterfaces(Class<?>, Set<AnnotationMetaData>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
getFieldAnnotationsForInterfaces(Class<?>, Set<AnnotationMetaData>, Class<? extends Annotation>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
getFieldAnnotationsForSuperClasses(Class<?>, Set<AnnotationMetaData>) - Static method in class org.mule.util.annotation.AnnotationUtils
 
getFieldAnnotationsForSuperClasses(Class<?>, Set<AnnotationMetaData>, Class<? extends Annotation>) - Static method in class org.mule.util.annotation.AnnotationUtils
 
getFieldDataType(Field) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
Returns a DataType describing the given Field's type
getFieldValue(Object, String, boolean) - Static method in class org.mule.util.ClassUtils
 
getFile() - Method in class com.javaforge.bobber.archetype.model.Template
Get the file field.
getFile() - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
getFile() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
Get the file, if any, the data has been written to.
getFile(HttpServletRequest) - Method in class org.mule.transport.servlet.JarResourceServlet
 
getFile() - Method in class org.mule.util.queue.QueueFileProvider
 
getFileAge() - Method in class org.mule.transport.file.FileConnector
 
getFileAge() - Method in class org.mule.transport.sftp.SftpConnector
Returns the file age.
getFileList(String) - Method in class org.mule.tck.util.ftp.FtpClient
Get a list of file names in a given directory for admin
getFileName() - Method in class org.mule.module.http.internal.multipart.HttpPart
 
getFilename(MuleMessage, String) - Method in class org.mule.transport.file.ExpressionFilenameParser
 
getFilename(MuleMessage, String, TemplateParser) - Method in class org.mule.transport.file.ExpressionFilenameParser
 
getFilename(MuleMessage, String) - Method in interface org.mule.transport.file.FilenameParser
 
getFileName() - Method in class org.mule.transport.sftp.SftpInputStream
 
getFilenameFilter() - Method in class org.mule.transport.ftp.FtpMessageRequester
 
getFilenameParser() - Method in class org.mule.transport.file.FileConnector
 
getFilenameParser() - Method in class org.mule.transport.ftp.FtpConnector
 
getFilenameParser() - Method in class org.mule.transport.sftp.SftpConnector
 
getFileSeparator() - Method in class org.mule.el.context.ServerContext
 
getFileSizeThreshold() - Method in class org.mule.transport.http.multipart.MultipartConfiguration
Gets the size threshold after which files will be written to disk.
getFileTimeStamp(URL) - Static method in class org.mule.util.FileUtils
Returns a file timestamp.
getFilter() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
The filter to apply to incoming messages.
getFilter() - Method in exception org.mule.api.routing.filter.FilterUnacceptedException
 
getFilter() - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
getFilter() - Method in class org.mule.endpoint.AbstractEndpoint
 
getFilter() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getFilter() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getFilter() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getFilter() - Method in class org.mule.processor.SecurityFilterMessageProcessor
 
getFilter() - Method in class org.mule.routing.filters.logic.NotFilter
 
getFilter() - Method in class org.mule.routing.MessageFilter
 
getFilter() - Method in class org.mule.routing.MessageProcessorFilterPair
 
getFilter() - Method in class org.mule.routing.outbound.FilteringOutboundRouter
 
getFilter() - Method in class org.mule.routing.WireTap
 
getFilter() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getFilter() - Method in class org.mule.transport.http.components.RestServiceWrapper
 
getFilter() - Method in class org.mule.transport.xmpp.filters.XmppNotFilter
 
getFilterAddress() - Method in interface org.mule.api.endpoint.EndpointURI
 
getFilterAddress() - Method in class org.mule.endpoint.MuleEndpointURI
 
getFilters() - Method in class org.mule.routing.filters.logic.AbstractFilterCollection
 
getFilters() - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
getFilters() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
getFirst() - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
reads the first element in the queue
getFirst() - Method in class org.mule.util.queue.DefaultQueueStoreDelegate
 
getFirst() - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
getFirstHeader(String) - Method in class org.mule.module.http.internal.domain.response.HttpResponseBuilder
 
getFirstHeader(String) - Method in class org.mule.transport.http.HttpRequest
 
getFirstHeader(String) - Method in class org.mule.transport.http.HttpResponse
 
getFirstMessage() - Method in class org.mule.transport.vm.VMMessageReceiver
 
getFirstMessages() - Method in class org.mule.transport.vm.VMMessageReceiver
 
getFirstName() - Method in class org.mule.tck.testmodels.services.Person
 
getFirstQueueFileForTesting(String, String) - Static method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
getFirstReturnMessage() - Method in interface org.mule.api.retry.RetryContext
 
getFirstReturnMessage() - Method in class org.mule.retry.async.FutureRetryContext
 
getFirstReturnMessage() - Method in class org.mule.retry.DefaultRetryContext
 
getFlags() - Method in class org.mule.routing.filters.RegExFilter
 
getFloat(Object, Float) - Static method in class org.mule.util.ObjectUtils
Gets a float from a value in a null-safe manner.
getFloatProperty(String, float) - Method in class org.mule.MessagePropertiesContext
 
getFloatValue(String, String, XmlPullParser, boolean) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method getFloatValue.
getFlow() - Method in class org.mule.security.oauth.DefaultHttpCallback
 
getFlowCallStack() - Method in interface org.mule.api.MuleEvent
Events have a stack of executed flows (same as a call stack), so that at any given instant an application developer can determine where this event came from.
getFlowCallStack() - Method in class org.mule.DefaultMuleEvent
 
getFlowCallStack() - Method in class org.mule.VoidMuleEvent
 
getFlowConstruct() - Method in interface org.mule.api.MuleEvent
Retrieves the service for the current event
getFlowConstruct() - Method in interface org.mule.api.MuleEventContext
 
getFlowConstruct() - Method in interface org.mule.api.MuleSession
Deprecated.
getFlowConstruct() - Method in interface org.mule.api.transport.MessageReceiver
 
getFlowConstruct() - Method in class org.mule.component.AbstractComponent
 
getFlowConstruct() - Method in class org.mule.context.notification.BaseConnectorMessageNotification
 
getFlowConstruct() - Method in class org.mule.context.notification.ComponentMessageNotification
 
getFlowConstruct() - Method in class org.mule.DefaultMuleEvent
Gets the recipient service of this event
getFlowConstruct() - Method in class org.mule.DefaultMuleEventContext
 
getFlowConstruct() - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
Retrieves flowConstruct
getFlowConstruct() - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
getFlowConstruct() - Method in interface org.mule.execution.MessageProcessContext
 
getFlowConstruct() - Method in class org.mule.module.http.internal.listener.HttpMessageProcessContext
 
getFlowConstruct() - Method in class org.mule.processor.AbstractMuleObjectOwner
 
getFlowConstruct() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
getFlowConstruct() - Method in class org.mule.security.oauth.BaseOAuth2Manager
Retrieves flowConstruct
getFlowConstruct() - Method in class org.mule.session.DefaultMuleSession
 
getFlowConstruct(String) - Method in class org.mule.tck.FunctionalTestCase
Deprecated.
 
getFlowConstruct(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
 
getFlowConstruct() - Method in class org.mule.transport.AbstractMessageReceiver
 
getFlowConstruct() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
getFlowConstruct() - Method in class org.mule.transport.TransportMessageProcessContext
 
getFlowConstruct() - Method in class org.mule.VoidMuleEvent
 
getFlowConstructBuilder() - Method in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
getFlowConstructBuilder() - Method in class org.mule.config.spring.factories.BridgeFactoryBean
 
getFlowConstructBuilder() - Method in class org.mule.config.spring.factories.SimpleServiceFactoryBean
 
getFlowConstructBuilder() - Method in class org.mule.config.spring.factories.ValidatorFactoryBean
 
getFlowConstructBuilder() - Method in class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
getFlowConstructBuilder() - Method in class org.mule.transport.http.config.spring.factories.HttpProxyFactoryBean
 
getFlowConstructStatistics(FlowConstruct) - Method in class org.mule.exception.DefaultServiceExceptionStrategy
Deprecated.
 
getFlowConstructType() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
 
getFlowExecutionWorkManager() - Method in interface org.mule.execution.MessageProcessContext
 
getFlowExecutionWorkManager() - Method in class org.mule.module.http.internal.listener.HttpMessageProcessContext
 
getFlowExecutionWorkManager() - Method in class org.mule.transport.TransportMessageProcessContext
 
getFlowMap() - Method in class org.mule.util.NotificationUtils.FlowMap
 
getFlowName() - Method in class org.mule.api.context.notification.FlowStackElement
 
getFlowTraceManager() - Method in interface org.mule.api.MuleContext
 
getFlowTraceManager() - Method in class org.mule.DefaultMuleContext
 
getFlowVariable(String) - Method in interface org.mule.api.MuleEvent
 
getFlowVariable(String) - Method in class org.mule.DefaultMuleEvent
 
getFlowVariable(String) - Method in class org.mule.VoidMuleEvent
 
getFlowVariableDataType(String) - Method in interface org.mule.api.MuleEvent
Gets the data type for a given flow variable
getFlowVariableDataType(String) - Method in class org.mule.DefaultMuleEvent
 
getFlowVariableDataType(String) - Method in class org.mule.VoidMuleEvent
 
getFlowVariableNames() - Method in interface org.mule.api.MuleEvent
 
getFlowVariableNames() - Method in class org.mule.DefaultMuleEvent
 
getFlowVariableNames() - Method in class org.mule.VoidMuleEvent
 
getFolder() - Method in class org.mule.transport.email.RetrieveMessageReceiver
 
getFollowRedirects() - Method in interface org.mule.module.http.api.requester.HttpRequesterConfig
 
getFollowRedirects() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getFormatId() - Method in class org.mule.util.xa.MuleXid
 
getFormattedDuration(long) - Static method in class org.mule.util.DateUtils
 
getFormattedMessage(String, Object[]) - Static method in class org.mule.util.StringMessageUtils
 
getFragment() - Method in class org.mule.endpoint.MuleEndpointURI
 
getFreeMemory() - Method in class org.mule.module.management.mbean.MuleService
 
getFreeMemory() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getFrequency() - Method in class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
getFrequency() - Method in class org.mule.transport.AbstractPollingMessageReceiver
 
getFrequency() - Method in class org.mule.transport.polling.schedule.FixedFrequencyScheduler
 
getFromAddress() - Method in class org.mule.transport.email.SmtpConnector
 
getFrontend() - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
getFtp(ImmutableEndpoint) - Method in class org.mule.transport.ftp.FtpConnector
 
getFtpClient() - Method in class org.mule.tck.util.ftp.FtpServer
 
getFtpPool(ImmutableEndpoint) - Method in class org.mule.transport.ftp.FtpConnector
 
getFullExpression(ExpressionManager) - Method in class org.mule.expression.ExpressionConfig
 
getFullExpression() - Method in class org.mule.expression.transformers.ExpressionArgument
 
getFullExpression() - Method in class org.mule.routing.filters.ExpressionFilter
 
getFullExpression() - Method in class org.mule.routing.outbound.ExpressionRecipientList
 
getFullListenerPath(String) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
getFullName(String, String) - Static method in class org.mule.transport.quartz.QuartzConnector
Obtains a full unique name for each Quartz configuration
getFullScheme() - Method in interface org.mule.api.endpoint.EndpointURI
 
getFullScheme() - Method in class org.mule.endpoint.MuleEndpointURI
 
getFullStackTraceWithoutMessages(Throwable) - Static method in class org.mule.util.ExceptionUtils
Similar to #getFullStackTrace(Throwable) but removing the exception and causes messages.
getFullUri() - Method in class org.mule.transport.http.HttpServerConnection
 
getFunctionalTestComponent(String) - Method in class org.mule.tck.FunctionalTestCase
Deprecated.
A convenience method to get a type-safe reference to the FunctionTestComponent
getFunctionalTestComponent(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
A convenience method to get a type-safe reference to the FunctionTestComponent
getFunctionName() - Method in class org.mule.module.db.internal.el.AbstractDbFunction
 
getFunctionName() - Method in class org.mule.module.db.internal.el.DbCreateArrayFunction
 
getFunctionName() - Method in class org.mule.module.db.internal.el.DbCreateStructFunction
 
getGenericParameterType() - Method in class org.mule.util.generics.MethodParameter
Return the generic type of the method/constructor parameter.
getGetProperty() - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
getGlobalEndpointBuilderBeanClass() - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
getGlobalFunctions() - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
getGlobalName() - Method in interface org.mule.api.GlobalNameableObject
 
getGlobalName() - Method in class org.mule.exception.AbstractExceptionListener
 
getGlobalName() - Method in class org.mule.exception.ChoiceMessagingExceptionStrategy
 
getGlobalStoreCapacity() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getGlobalTransactionId() - Method in class org.mule.util.xa.MuleXid
 
getGrandparentBeanName(Element) - Method in class org.mule.config.spring.parsers.generic.GrandchildDefinitionParser
 
getGroupId() - Method in class org.mule.routing.EventGroup
Returns an identifier for this EventGroup.
getGroupName() - Method in class org.mule.transport.quartz.config.AbstractJobConfig
 
getGroupName() - Method in interface org.mule.transport.quartz.config.JobConfig
 
getGroups() - Method in class org.mule.module.extension.internal.capability.metadata.ParameterGroupCapability
 
getHandler() - Method in class org.mule.DefaultMuleMessage.SerializedDataHandler
 
getHeader(String) - Method in class org.mule.module.atom.server.MuleRequestContext
 
getHeader(String) - Method in class org.mule.module.http.internal.domain.response.HttpResponseBuilder
 
getHeader(String) - Method in class org.mule.module.http.internal.listener.HttpResponseHeaderBuilder
 
getHeader(String) - Method in class org.mule.module.http.internal.multipart.HttpPart
 
getHeader(String) - Method in class org.mule.module.http.internal.multipart.HttpPartDataSource
 
getHeader(String) - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
getHeader(String) - Method in interface org.mule.transport.http.multipart.Part
Returns the value of the specified mime header as a String.
getHeader(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getHeader(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
getHeaderIterator() - Method in class org.mule.transport.http.HttpRequest
 
getHeaderIterator() - Method in class org.mule.transport.http.HttpResponse
 
getHeaderNames() - Method in class org.mule.module.atom.server.MuleRequestContext
 
getHeaderNames() - Method in interface org.mule.module.http.internal.domain.HttpMessage
 
getHeaderNames() - Method in class org.mule.module.http.internal.domain.request.DefaultHttpRequest
 
getHeaderNames() - Method in class org.mule.module.http.internal.domain.response.DefaultHttpResponse
 
getHeaderNames() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyHttpRequestAdapter
 
getHeaderNames() - Method in class org.mule.module.http.internal.listener.HttpResponseHeaderBuilder
 
getHeaderNames() - Method in class org.mule.module.http.internal.multipart.HttpPart
 
getHeaderNames() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
getHeaderNames() - Method in interface org.mule.transport.http.multipart.Part
Gets the header names of this Part.
getHeaderNames() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getHeaderNames() - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
getHeaders() - Method in class org.mule.management.stats.printers.AbstractTablePrinter
 
getHeaders() - Method in class org.mule.management.stats.printers.XMLPrinter
 
getHeaders(String) - Method in class org.mule.module.atom.server.MuleRequestContext
 
getHeaders() - Method in class org.mule.module.http.internal.domain.request.HttpRequestBuilder
 
getHeaders(String) - Method in class org.mule.module.http.internal.multipart.HttpPart
 
getHeaders(MuleEvent) - Method in class org.mule.module.http.internal.request.HttpRequesterRequestBuilder
 
getHeaders() - Method in class org.mule.transport.http.HttpRequest
 
getHeaders() - Method in class org.mule.transport.http.HttpResponse
 
getHeaders(String) - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
getHeaders(String) - Method in interface org.mule.transport.http.multipart.Part
Gets the values of the Part header with the given name.
getHeaders(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getHeaders(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
getHeaderValue(String) - Method in interface org.mule.module.http.internal.domain.HttpMessage
 
getHeaderValue(String) - Method in class org.mule.module.http.internal.domain.request.DefaultHttpRequest
 
getHeaderValue(String) - Method in class org.mule.module.http.internal.domain.response.DefaultHttpResponse
 
getHeaderValue(String) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyHttpRequestAdapter
 
getHeaderValueIgnoreCase(String) - Method in class org.mule.module.http.internal.domain.BaseHttpMessage
 
getHeaderValueIgnoreCase(String) - Method in interface org.mule.module.http.internal.domain.HttpMessage
 
getHeaderValues(String) - Method in interface org.mule.module.http.internal.domain.HttpMessage
 
getHeaderValues(String) - Method in class org.mule.module.http.internal.domain.request.DefaultHttpRequest
 
getHeaderValues(String) - Method in class org.mule.module.http.internal.domain.response.DefaultHttpResponse
 
getHeaderValues(String) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyHttpRequestAdapter
 
getHeaderValuesIgnoreCase(String) - Method in class org.mule.module.http.internal.domain.BaseHttpMessage
 
getHeaderValuesIgnoreCase(String) - Method in interface org.mule.module.http.internal.domain.HttpMessage
 
getHoldability() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
getHoldability() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getHoldability() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getHolderKey(ImmutableEndpoint) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
getHoldObject() - Method in class org.mule.module.db.internal.domain.xa.DataSourceWrapper
 
getHoldObject() - Method in class org.mule.transport.jdbc.xa.DataSourceWrapper
 
getHoldObject() - Method in interface org.mule.util.xa.XaResourceFactoryHolder
 
getHome() - Method in class org.mule.el.context.MuleInstanceContext
 
getHomeDir() - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
getHost() - Method in class org.apache.commons.httpclient.HttpConnection
Returns the host.
getHost() - Method in interface org.mule.api.endpoint.EndpointURI
 
getHost() - Method in class org.mule.el.context.ServerContext
 
getHost() - Method in class org.mule.endpoint.MuleEndpointURI
 
getHost() - Method in class org.mule.endpoint.URIBuilder
 
getHost() - Method in class org.mule.module.db.internal.config.domain.database.AbstractVendorConfigResolverFactoryBean
 
getHost() - Method in interface org.mule.module.http.api.listener.HttpListenerConfig
 
getHost() - Method in interface org.mule.module.http.api.requester.HttpRequesterConfig
 
getHost() - Method in interface org.mule.module.http.api.requester.proxy.ProxyConfig
 
getHost() - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
getHost() - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
getHost() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getHost() - Method in class org.mule.module.http.internal.request.DefaultProxyConfig
 
getHost() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
Deprecated.
getHost() - Method in class org.mule.module.management.agent.JdmkAgent
 
getHost() - Method in class org.mule.module.management.agent.Mx4jAgent
 
getHost() - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
getHost() - Method in class org.mule.module.management.mbean.YourKitProfilerService
getHost() - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
getHost() - Method in class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
getHost() - Method in class org.mule.transport.jdbc.config.OracleDataSourceFactoryBean
 
getHost() - Method in class org.mule.transport.servlet.jetty.WebappsConfiguration
 
getHost() - Method in class org.mule.transport.sftp.config.SftpProxyConfig
 
getHost() - Method in class org.mule.transport.sftp.SftpClient
 
getHost() - Method in class org.mule.transport.xmpp.XmppConnector
 
getHostConfig(URI) - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
getHostConfig(URI) - Method in class org.mule.transport.http.HttpsClientMessageDispatcher
 
getHostIp() - Method in class org.mule.module.management.mbean.MuleService
 
getHostIp() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getHostname() - Method in class org.mule.module.management.mbean.MuleService
 
getHostname() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getHours() - Method in interface org.mule.api.el.datetime.Time
 
getHours() - Method in class org.mule.el.datetime.DateTime
 
getHttpClient() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getHttpConnectionManager() - Method in class org.apache.commons.httpclient.HttpConnection
Returns the httpConnectionManager.
getHttpMethod() - Method in class org.mule.transport.http.components.RestServiceWrapper
 
getHttpResponseStatus(AxisFault) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
getHttpServer() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
getHttpServerConnection() - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
getHttpVersion() - Method in class org.mule.transport.http.HttpResponse
 
getHttpVersion() - Method in class org.mule.transport.http.RequestLine
 
getI18nMessage() - Method in exception org.mule.api.MuleException
 
getId() - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Get the id field.
getId() - Method in interface org.mule.api.config.MuleConfiguration
 
getId() - Method in interface org.mule.api.MuleEvent
Every event in the system is assigned a universally unique id (UUID).
getId() - Method in interface org.mule.api.MuleSession
Returns the unique id for this session
getId() - Method in interface org.mule.api.transaction.Transaction
 
getId() - Method in class org.mule.config.DefaultMuleConfiguration
 
getId() - Method in class org.mule.DefaultMuleEvent
 
getId() - Method in class org.mule.el.context.MessageContext
 
getId(Object) - Method in interface org.mule.module.bpm.BPMS
 
getId() - Method in class org.mule.module.db.internal.domain.type.AbstractDbType
 
getId() - Method in interface org.mule.module.db.internal.domain.type.DbType
 
getId() - Method in class org.mule.module.db.internal.domain.type.DynamicDbType
 
getId() - Method in class org.mule.module.jbpm.EndedProcess
 
getId(Object) - Method in class org.mule.module.jbpm.Jbpm
 
getId() - Method in class org.mule.processor.DelegateTransaction
 
getId() - Method in class org.mule.session.DefaultMuleSession
 
getId() - Method in class org.mule.transaction.AbstractTransaction
 
getID() - Method in class org.mule.transport.http.ntlm.NTLMScheme
 
getId() - Method in class org.mule.util.store.InMemoryObjectStore.StoredObject
 
getId() - Method in class org.mule.VoidMuleEvent
 
getIdentifier() - Method in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
getIdentifier() - Method in class org.mule.transport.quartz.config.ScheduleAnnotationParser
 
getIdentityFile() - Method in class org.mule.transport.sftp.SftpConnector
 
getIdentityFile() - Method in class org.mule.transport.sftp.SftpUtil
 
getIdExpression() - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
getIdExpression() - Method in class org.mule.routing.IdempotentMessageFilter
 
getIdForEvent(MuleEvent) - Method in class org.mule.routing.IdempotentMessageFilter
 
getIdForEvent(MuleEvent) - Method in class org.mule.routing.IdempotentSecureHashMessageFilter
 
getIgnoredAttributes() - Method in class org.mule.config.spring.parsers.specific.TransactionDefinitionParser
 
getIgnoredAttributes() - Method in class org.mule.config.spring.parsers.specific.XaTransactionDefinitionParser
 
getIgnoredMethods() - Method in class org.mule.model.resolvers.ReflectionEntryPointResolver
Returns an unmodifiable Set of ignoredMethods on this resolver To add method to the resolver use ReflectionEntryPointResolver.addIgnoredMethod(String)
getIgnoredObjectTypes() - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
getIgnoredObjectTypes() - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
getImmutableEndpoint() - Method in class org.mule.context.notification.EndpointMessageNotification
 
getImportInputSource(String, String) - Method in class org.mule.module.ws.consumer.MuleWSDLLocator
 
getInboundAttachment(String) - Method in interface org.mule.api.MuleMessage
Retrieve an attachment with the given name.
getInboundAttachment(String) - Method in class org.mule.DefaultMuleMessage
 
getInboundAttachmentNames() - Method in interface org.mule.api.MuleMessage
 
getInboundAttachmentNames() - Method in class org.mule.DefaultMuleMessage
 
getInboundAttachments() - Method in class org.mule.el.context.MessageContext
 
getInboundEndpoint(String, MessageExchangePattern) - Method in interface org.mule.api.endpoint.EndpointCache
 
getInboundEndpoint(String) - Method in interface org.mule.api.endpoint.EndpointFactory
Creates an endpoint with the "INBOUND" role.
getInboundEndpoint(EndpointBuilder) - Method in interface org.mule.api.endpoint.EndpointFactory
Creates an endpoint with the "INBOUND" role using the builder provided.
getInboundEndpoint(EndpointURI) - Method in interface org.mule.api.endpoint.EndpointFactory
Deprecated. 
getInboundEndpoint(String) - Method in class org.mule.endpoint.DefaultEndpointFactory
 
getInboundEndpoint(EndpointBuilder) - Method in class org.mule.endpoint.DefaultEndpointFactory
 
getInboundEndpoint(EndpointURI) - Method in class org.mule.endpoint.DefaultEndpointFactory
 
getInboundEndpoint() - Method in class org.mule.endpoint.inbound.InboundNotificationMessageProcessor
 
getInboundEndpoint(String, MessageExchangePattern) - Method in class org.mule.endpoint.SimpleEndpointCache
 
getInboundEndpoint(String) - Method in class org.mule.module.client.MuleClient
 
getInboundEndpoint() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
getInboundEndpointFactoryBeanClass() - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
getInboundExchangePatterns() - Method in interface org.mule.api.transport.Connector
 
getInboundExchangePatterns() - Method in class org.mule.transport.AbstractConnector
 
getInboundExchangePatterns() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
getInboundExchangePatterns() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
getInboundMessageExchangePattern() - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundEndpointBuilder
 
getInboundMessageExchangePattern() - Method in class org.mule.construct.builder.BridgeBuilder
 
getInboundMessageExchangePattern() - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
getInboundMessageExchangePattern() - Method in class org.mule.construct.builder.ValidatorBuilder
 
getInboundMessageExchangePattern() - Method in class org.mule.module.ws.construct.builder.WSProxyBuilder
 
getInboundMessageExchangePattern() - Method in class org.mule.transport.http.construct.builder.HttpProxyBuilder
 
getInboundProperties() - Method in class org.mule.el.context.MessageContext
 
getInboundProperty(String, T) - Method in interface org.mule.api.MuleMessage
 
getInboundProperty(String) - Method in interface org.mule.api.MuleMessage
 
getInboundProperty(String, T) - Method in class org.mule.DefaultMuleMessage
 
getInboundProperty(String) - Method in class org.mule.DefaultMuleMessage
 
getInboundPropertyNames() - Method in interface org.mule.api.MuleMessage
 
getInboundPropertyNames() - Method in class org.mule.DefaultMuleMessage
 
getInboundRouterStat() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
getInboundTransformer() - Method in class org.mule.transformer.wire.TransformerPairWireFormat
 
getInbuiltBackChannel(Message) - Method in class org.mule.module.cxf.transport.MuleUniversalDestination
 
getIndentEnabled() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
getIndentSize() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
getIndentString() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
getIndex() - Method in class org.mule.module.db.internal.domain.param.AbstractQueryParam
 
getIndex() - Method in interface org.mule.module.db.internal.domain.param.QueryParam
Returns the parameter's index in the containing SQL query.
getIndex() - Method in class org.mule.module.launcher.util.ElementEvent
 
getIndexedVariableResolver(int) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
getInetAddress() - Method in class org.mule.transport.tcp.TcpSocketKey
 
getInFaultInterceptors() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getInFaultInterceptors() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getInfo(Throwable) - Method in interface org.mule.api.config.ExceptionReader
Returns a map of the non-standard information stored on the exception
getInfo() - Method in interface org.mule.api.ExceptionPayload
 
getInfo() - Method in exception org.mule.api.MuleException
 
getInfo(Throwable) - Method in class org.mule.config.DefaultExceptionReader
Returns a map of the non-stanard information stored on the exception
getInfo(Throwable) - Method in class org.mule.config.MuleExceptionReader
Returns a map of the non-stanard information stored on the exception
getInfo(Throwable) - Method in class org.mule.config.NamingExceptionReader
Returns a map of the non-stanard information stored on the exception
getInfo() - Method in class org.mule.message.DefaultExceptionPayload
 
getInfo(Throwable) - Method in class org.mule.transport.jdbc.SQLExceptionReader
Returns a map of the non-stanard information stored on the exception
getInfo(Throwable) - Method in class org.mule.transport.jms.JmsExceptionReader
Returns a map of the non-stanard information stored on the exception
getInfo() - Method in class org.mule.transport.sftp.notification.SftpTransportNotification
 
getInfo(Throwable) - Method in class org.mule.transport.soap.axis.AxisFaultExceptionReader
Returns a map of the non-stanard information stored on the exception
getInInterceptors() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getInInterceptors() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getInitialContext(Hashtable) - Method in class org.mule.config.spring.jndi.SpringInitialContextFactory
 
getInitialContext(Hashtable) - Method in class org.mule.jndi.MuleInitialContextFactory
 
getInitialContext() - Method in class org.mule.tck.jndi.InMemoryContextFactory
 
getInitialContext(Hashtable) - Method in class org.mule.tck.jndi.InMemoryContextFactory
 
getInitialContext() - Method in class org.mule.tck.jndi.TestContextFactory
 
getInitialContext(Hashtable) - Method in class org.mule.tck.jndi.TestContextFactory
 
getInitialFactory() - Method in class org.mule.object.JndiObjectFactory
 
getInitialFacts() - Method in class org.mule.module.bpm.RulesComponent
 
getInitialisationPolicy() - Method in class org.mule.config.PoolingProfile
 
getInitialiserEvent(MuleContext) - Static method in class org.mule.module.extension.internal.util.MuleExtensionUtils
 
getInitialMethod(MuleEvent) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
getInitialRetryCount() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getInitialState() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
Sets the state the endpoint will be loaded in.
getInitialState() - Method in interface org.mule.api.service.Service
Deprecated.
Returns the initial state of this service
getInitialState() - Method in class org.mule.construct.AbstractFlowConstruct
 
getInitialState() - Method in class org.mule.endpoint.AbstractEndpoint
Sets the state the endpoint will be loaded in.
getInitialState(Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getInitialState() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getInitialState() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getInitialState() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getInitialState() - Method in class org.mule.service.AbstractService
Deprecated.
 
getInitialState() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getInitialVariables() - Method in class org.mule.module.bpm.Rules
 
getInjector() - Method in interface org.mule.api.MuleContext
Returns a Injector capable of injecting dependencies into objects
getInjector() - Method in class org.mule.DefaultMuleContext
Returns a Injector capable of injecting dependencies into objects
getInputClass() - Method in class org.mule.transformer.TransformerWeighting
 
getInputMetaData() - Method in class org.mule.module.db.internal.metadata.AbstractQueryMetadataProvider
 
getInputMetaData() - Method in class org.mule.module.db.internal.metadata.BulkExecuteMetadataProvider
 
getInputMetaData() - Method in class org.mule.module.db.internal.metadata.DdlMetadataProvider
 
getInputMetaData() - Method in class org.mule.module.db.internal.metadata.NullMetadataProvider
 
getInputMetaData() - Method in interface org.mule.module.db.internal.metadata.QueryMetadataProvider
Provides input metadata
getInputMetaData() - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
getInputParams() - Method in class org.mule.module.db.internal.domain.query.QueryTemplate
Returns the input parameter definitions.
getInputStream() - Method in class org.mule.config.ConfigResource
 
getInputStream() - Method in class org.mule.config.spring.util.CachedResource
 
getInputStream() - Method in class org.mule.message.ds.ByteArrayDataSource
 
getInputStream() - Method in class org.mule.message.ds.InputStreamDataSource
 
getInputStream() - Method in class org.mule.message.ds.StringDataSource
 
getInputStream() - Method in class org.mule.module.atom.server.MuleRequestContext
 
getInputStream() - Method in class org.mule.module.http.internal.domain.InputStreamHttpEntity
 
getInputStream() - Method in class org.mule.module.http.internal.multipart.HttpPart
 
getInputStream() - Method in class org.mule.module.http.internal.multipart.HttpPartDataSource
 
getInputStream() - Method in class org.mule.module.json.transformers.TransformerInputs
 
getInputStream() - Method in class org.mule.transport.email.transformers.PlainTextDataSource
 
getInputStream() - Method in class org.mule.transport.http.HttpServerConnection
 
getInputStream() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
getInputStream() - Method in interface org.mule.transport.http.multipart.Part
Gets the content of this part as an InputStream
getInputStream() - Method in class org.mule.transport.http.multipart.PartDataSource
 
getInputStream() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getInputStream() - Method in class org.mule.transport.servlet.CachedHttpServletRequest
 
getInputStream() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
getInputStream() - Method in class org.mule.transport.stdio.StdioConnector
 
getInputStream() - Method in class org.mule.transport.stdio.StdioMessageReceiver
 
getInputStreamEntity() - Method in class org.mule.module.http.internal.domain.request.DefaultHttpRequest
 
getInputStreamEntity() - Method in interface org.mule.module.http.internal.domain.request.HttpRequest
 
getInputStreamEntity() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyHttpRequestAdapter
 
getInputWeighting() - Method in class org.mule.transformer.TransformerWeighting
 
getInsertQuery() - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
getInsertQueryKey() - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
getInstance(MuleContext) - Method in interface org.mule.api.object.ObjectFactory
Retrieve an instance of the object.
getInstance(MuleContext) - Method in class org.mule.component.PooledJavaComponent.LifeCycleAdapterFactory
 
getInstance(MuleContext) - Method in class org.mule.config.spring.util.SpringBeanLookup
 
getInstance() - Static method in class org.mule.module.db.internal.domain.type.UnknownDbType
 
getInstance() - Static method in class org.mule.module.extension.internal.runtime.resolver.ConfigurationInstanceArgumentResolver
 
getInstance() - Static method in class org.mule.module.extension.internal.runtime.resolver.EventArgumentResolver
 
getInstance() - Static method in class org.mule.module.extension.internal.runtime.resolver.MessageArgumentResolver
 
getInstance() - Static method in class org.mule.module.http.internal.listener.NoListenerRequestHandler
 
getInstance() - Static method in class org.mule.module.http.internal.listener.NoMethodRequestHandler
 
getInstance() - Static method in class org.mule.module.http.internal.listener.ServiceTemporarilyUnavailableListenerRequestHandler
 
getInstance() - Static method in class org.mule.module.management.support.AutoDiscoveryJmxSupportFactory
Obtain an instance of the factory class.
getInstance() - Method in class org.mule.module.xml.transformer.XStreamFactory
 
getInstance() - Static method in class org.mule.NonBlockingVoidMuleEvent
 
getInstance(MuleContext) - Method in class org.mule.object.AbstractObjectFactory
Creates an initialized object instance based on the class and sets any properties.
getInstance(MuleContext) - Method in class org.mule.object.JndiObjectFactory
 
getInstance(MuleContext) - Method in class org.mule.object.SingletonObjectFactory
Always returns the same instance of the object.
getInstance() - Static method in class org.mule.transaction.TransactionCoordination
 
getInstance() - Static method in class org.mule.transport.email.DefaultDataContentHandlerFactory
 
getInstance() - Method in class org.mule.transport.jdbc.config.OracleDataSourceFactoryBean
 
getInstance() - Static method in class org.mule.transport.NullPayload
 
getInstance() - Static method in class org.mule.util.xmlsecurity.XMLSecureFactoriesCache
 
getInstance() - Static method in class org.mule.VoidMuleEvent
 
getInstance() - Static method in class org.mule.VoidResult
 
getInstanceId() - Method in class org.mule.module.management.mbean.MuleService
 
getInstanceId() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getInt(String, Map, int) - Static method in class org.hibernate.connection.SimpleConnectionProvider
Get the config value as an int
getInt(Object, Integer) - Static method in class org.mule.util.ObjectUtils
Gets a int from a value in a null-safe manner.
getInteger(String, Map) - Static method in class org.hibernate.connection.SimpleConnectionProvider
Get the config value as an Integer
getIntegerValue(String, String, XmlPullParser, boolean) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method getIntegerValue.
getInterceptors() - Method in class org.mule.component.AbstractComponent
 
getInterceptors() - Method in class org.mule.interceptor.InterceptorStack
 
getInterface() - Method in interface org.mule.api.component.InterfaceBinding
 
getInterface() - Method in class org.mule.component.DefaultInterfaceBinding
 
getInterfaceBindings() - Method in interface org.mule.api.component.JavaComponent
 
getInterfaceBindings() - Method in class org.mule.component.AbstractJavaComponent
 
getInterfaceBindings() - Method in class org.mule.module.scripting.component.ScriptComponent
 
getInterfaceClass() - Method in class org.mule.component.DefaultInterfaceBinding
 
getInterfacesForComponent(Service) - Static method in class org.mule.transport.soap.axis.AxisServiceProxy
 
getInterfaceToTypes() - Method in class org.mule.context.notification.ServerNotificationManager
 
getInterval() - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
getInterval() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
getIntHeader(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getIntProperty(String, int) - Method in interface org.mule.api.MuleMessage
getIntProperty(String, int) - Method in class org.mule.DefaultMuleMessage
Deprecated.
getIntProperty(String, int) - Method in class org.mule.MessagePropertiesContext
 
getInvalidJson() - Method in exception org.mule.module.json.validation.JsonSchemaValidationException
Returns a String representation of the failing json
getInvocationProperty(String, T) - Method in interface org.mule.api.MuleMessage
 
getInvocationProperty(String) - Method in interface org.mule.api.MuleMessage
 
getInvocationProperty(String, T) - Method in class org.mule.DefaultMuleMessage
 
getInvocationProperty(String) - Method in class org.mule.DefaultMuleMessage
 
getInvocationPropertyNames() - Method in interface org.mule.api.MuleMessage
 
getInvocationPropertyNames() - Method in class org.mule.DefaultMuleMessage
 
getIp() - Method in class org.mule.el.context.ServerContext
 
getIp() - Method in class org.mule.module.http.internal.listener.ServerAddress
 
getIsProcessInstance() - Method in class org.mule.module.jbpm.EndedProcess
 
getItem() - Method in class org.mule.util.store.InMemoryObjectStore.StoredObject
 
getItem() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper.StoredObject
 
getItemType() - Method in class org.mule.transformer.types.CollectionDataType
 
getIterationCount() - Method in class org.mule.security.PasswordBasedEncryptionStrategy
 
getIterator(MuleEvent) - Method in class org.mule.module.db.internal.processor.AbstractBulkUpdateMessageProcessor
 
getJaasConfig() - Static method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider.JaasConfig
Returns the Jas Configuration
getJavaBeanXPath() - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
getJavaDocUrl(Class<?>) - Static method in class org.mule.config.ExceptionHelper
Deprecated.
since 3.8.0
getJavaPID() - Static method in class org.mule.module.management.agent.WrapperManagerAgent
This method is a copy of the implementation of WrapperManagerMBean.getJavaPID() and it is here because that method is not present in the WrapperManagerMBean until version 3.2.3.
getJavaVendor() - Method in class org.mule.el.context.ServerContext
 
getJavaVersion() - Method in class org.mule.el.context.ServerContext
 
getJaxbContext() - Method in class org.mule.module.xml.transformer.jaxb.JAXBMarshallerTransformer
 
getJaxbContext() - Method in class org.mule.module.xml.transformer.jaxb.JAXBUnmarshallerTransformer
 
getJdbcConnector() - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
getJdbcUrlPrefix() - Method in class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
getJdbcUrlPrefix() - Method in class org.mule.transport.jdbc.config.Db2DatasourceFactoryBean
 
getJdbcUrlPrefix() - Method in class org.mule.transport.jdbc.config.MssqlDatasourceFactoryBean
 
getJdbcUrlPrefix() - Method in class org.mule.transport.jdbc.config.MysqlDataSourceFactoryBean
 
getJdbcUrlPrefix() - Method in class org.mule.transport.jdbc.config.PostgresqlDataSourceFactoryBean
 
getJdkVersion() - Method in class org.mule.module.management.mbean.MuleService
 
getJdkVersion() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getJdkVersion() - Static method in class org.mule.util.JdkVersionUtils
 
getJmsSupport() - Method in class org.mule.transport.jms.JmsConnector
 
getJmxAdaptorUrl() - Method in class org.mule.module.management.agent.JdmkAgent
 
getJmxAdaptorUrl() - Method in class org.mule.module.management.agent.Mx4jAgent
 
getJmxAuthenticator() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
getJmxAuthenticator() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
getJmxSupport() - Method in class org.mule.module.management.support.AutoDiscoveryJmxSupportFactory
Will try to detect if JMX 1.2 or later is available, otherwise will fallback to the JMX 1.1 version of the support class.
getJmxSupport() - Method in interface org.mule.module.management.support.JmxSupportFactory
Create an instance of a JMX support class.
getJmxSupportFactory() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
getJmxSupportFactory() - Method in class org.mule.module.management.agent.JmxServerNotificationAgent
 
getJndiContext(String) - Method in class org.mule.transport.AbstractJndiConnector
 
getJndiContext() - Method in class org.mule.transport.AbstractJndiConnector
 
getJndiDestination(String) - Method in class org.mule.transport.jms.Jms11Support
 
getJndiInitialFactory() - Method in class org.mule.transport.AbstractJndiConnector
 
getJndiInitialFactory() - Method in class org.mule.transport.jms.JmsConnector
Deprecated.
use a JndiNameResolver instead of access this property
getJndiInitialFactory() - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
getJndiName() - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
getJndiNameResolver() - Method in class org.mule.transport.jms.JmsConnector
 
getJndiProviderProperties() - Method in class org.mule.transport.AbstractJndiConnector
 
getJndiProviderProperties() - Method in class org.mule.transport.jms.JmsConnector
Deprecated.
use a JndiNameResolver instead of access this property
getJndiProviderProperties() - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
getJndiProviderUrl() - Method in class org.mule.transport.AbstractJndiConnector
 
getJndiProviderUrl() - Method in class org.mule.transport.jms.JmsConnector
Deprecated.
use a JndiNameResolver instead of access this property
getJndiProviderUrl() - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
getJndiUrlPkgPrefixes() - Method in class org.mule.transport.AbstractJndiConnector
 
getJob() - Method in class org.mule.transport.polling.schedule.PollScheduler
 
getJob() - Method in class org.mule.transport.quartz.jobs.CustomJobConfig
 
getJob(MuleMessage) - Method in class org.mule.transport.quartz.jobs.CustomJobFromMessageConfig
 
getJobClass() - Method in class org.mule.transport.quartz.config.AbstractJobConfig
 
getJobClass() - Method in interface org.mule.transport.quartz.config.JobConfig
 
getJobConfig(MuleMessage) - Method in class org.mule.transport.quartz.jobs.CustomJobFromMessageConfig
 
getJobGroupName() - Method in class org.mule.transport.quartz.config.AbstractJobConfig
 
getJobGroupName() - Method in interface org.mule.transport.quartz.config.JobConfig
 
getJournal() - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
 
getJSON() - Method in class org.mule.transport.ajax.container.MuleAjaxServlet.MuleMessageImpl
 
getKeepAlive() - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
getKeepAlive() - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
getKeepAlive() - Method in interface org.mule.transport.tcp.TcpClientSocketProperties
 
getKeepAlive() - Method in interface org.mule.transport.tcp.TcpServerSocketProperties
 
getKeepAliveMonitor() - Method in class org.mule.transport.tcp.TcpConnector
 
getKeepAliveTimeout() - Method in class org.mule.transport.tcp.TcpConnector
 
getKernelCoreSize() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getKey() - Method in class org.mule.api.registry.AbstractServiceDescriptor.Key
 
getKey() - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
getKey() - Method in class org.mule.config.spring.parsers.collection.ChildMapEntryDefinitionParser.KeyValuePair
 
getKey() - Method in class org.mule.module.jbpm.EndedProcess
 
getKey() - Method in interface org.mule.security.SecretKeyFactory
 
getKey() - Method in class org.mule.tck.security.MockKeyFactory
 
getKey() - Method in class org.mule.transformer.simple.MapLookup
 
getKey() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper.StoredObject
 
getKey() - Method in class org.mule.util.store.PersistentObjectStorePartition.StoreValue
 
getKeyAlias() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getKeyAlias() - Method in interface org.mule.api.security.TlsDirectKeyStore
 
getKeyAlias() - Method in class org.mule.transport.http.HttpsConnector
 
getKeyAlias() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getKeyFactory() - Method in class org.mule.security.SecretKeyEncryptionStrategy
Deprecated.
 
getKeyManager() - Method in class org.mule.module.pgp.filters.PGPSecurityFilter
 
getKeyManager() - Method in class org.mule.module.pgp.KeyBasedEncryptionStrategy
 
getKeyManager() - Method in class org.mule.module.pgp.PGPSecurityProvider
 
getKeyManagerAlgorithm() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getKeyManagerAlgorithm() - Method in interface org.mule.api.security.TlsDirectKeyStore
 
getKeyManagerAlgorithm() - Method in class org.mule.transport.http.HttpsConnector
 
getKeyManagerAlgorithm() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getKeyManagerFactory() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getKeyManagerFactory() - Method in interface org.mule.api.security.TlsDirectKeyStore
 
getKeyManagerFactory() - Method in class org.mule.transport.http.HttpsConnector
 
getKeyManagerFactory() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getKeyPassword() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getKeyPassword() - Method in interface org.mule.api.security.TlsDirectKeyStore
 
getKeyPassword() - Method in class org.mule.transport.http.HttpsConnector
 
getKeyPassword() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getKeys() - Method in class org.mule.transport.soap.axis.extensions.AxisMuleSession
 
getKeyStore() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getKeyStore() - Method in interface org.mule.api.security.TlsDirectKeyStore
 
getKeyStore() - Method in class org.mule.transport.http.HttpsConnector
 
getKeyStore() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getKeyStorePassword() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getKeyStorePassword() - Method in interface org.mule.api.security.TlsDirectKeyStore
 
getKeyStorePassword() - Method in class org.mule.transport.http.HttpsConnector
 
getKeyStorePassword() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getKeyStoreType() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getKeyStoreType() - Method in interface org.mule.api.security.TlsDirectKeyStore
 
getKeyStoreType() - Method in class org.mule.transport.http.HttpsConnector
 
getKeyStoreType() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getKeyType() - Method in class org.mule.module.db.internal.domain.transaction.DbTransaction
 
getKeyType() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
getKeyType() - Method in class org.mule.transport.jdbc.JdbcTransaction
 
getKeyType() - Method in class org.mule.transport.jms.JmsTransaction
 
getKeyType() - Method in class org.mule.transport.vm.VMTransaction
 
getKnownHostsFile() - Method in class org.mule.transport.sftp.SftpClient
 
getKnownHostsFile() - Method in class org.mule.transport.sftp.SftpConnector
 
getKnownHostsFile() - Method in class org.mule.transport.sftp.SftpUtil
 
getKnownVariables() - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
getLastChildPathMap(String) - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.PathMap
 
getLastFailure() - Method in interface org.mule.api.retry.RetryContext
The most recent failure which prevented the context from validating the connection.
getLastFailure() - Method in class org.mule.retry.async.FutureRetryContext
 
getLastFailure() - Method in class org.mule.retry.DefaultRetryContext
 
getLastModifiedTime(String) - Method in class org.mule.transport.sftp.SftpClient
 
getLastName() - Method in class org.mule.tck.testmodels.services.Person
 
getLastPhaseExecuted() - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
getLastReceivedMessage() - Method in class org.mule.tck.functional.FunctionalTestComponent
If enableMessageHistory = true, returns the last message received by the service in chronological order.
getLastResponseInputStream() - Method in class org.apache.commons.httpclient.HttpConnection
Returns the stream used to read the last response's body.
getLastUpdate() - Method in class org.mule.module.atom.routing.EntryLastUpdatedFilter
 
getLastUpdate() - Method in class org.mule.module.atom.routing.FeedLastUpdatedFilter
 
getLastUpdate() - Method in class org.mule.module.rss.routing.EntryLastUpdatedFilter
 
getLastUpdate() - Method in class org.mule.module.rss.routing.FeedLastUpdatedFilter
 
getLatestImportURI() - Method in class org.mule.module.ws.consumer.MuleWSDLLocator
 
getLeftFilter() - Method in class org.mule.transport.xmpp.filters.XmppAndFilter
 
getLength(Object) - Static method in class org.mule.util.ArrayUtils
 
getLevelMappings() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
getLibraries(File) - Method in class org.mule.module.launcher.artifact.ArtifactStartedSplashScreen
 
getLicense() - Method in class org.mule.module.management.mbean.MuleService
 
getLicense() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getLifecycleAdapterFactory() - Method in interface org.mule.api.component.JavaComponent
Returns the factory used create life-cycle adaptors that are used to wrap component instance.
getLifecycleAdapterFactory() - Method in interface org.mule.api.model.Model
Deprecated.
The lifecycle adapter is used by the model to translate Mule lifecycle event to events that components registered with the model understand.
getLifecycleAdapterFactory() - Method in class org.mule.component.AbstractJavaComponent
 
getLifecycleAdapterFactory() - Method in class org.mule.model.AbstractModel
Deprecated.
 
getLifecycleClass() - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
getLifecycleClass() - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
getLifecycleManager() - Method in interface org.mule.api.MuleContext
 
getLifecycleManager() - Method in interface org.mule.api.service.Service
Deprecated.
 
getLifecycleManager() - Method in class org.mule.context.DefaultMuleContextBuilder
 
getLifecycleManager() - Method in class org.mule.DefaultMuleContext
 
getLifecycleManager() - Method in class org.mule.registry.AbstractRegistry
 
getLifecycleManager() - Method in class org.mule.service.AbstractService
Deprecated.
 
getLifecycleObject() - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
getLifecycleRegistry() - Method in class org.mule.registry.DefaultRegistryBroker
Deprecated.
 
getLifecycleState() - Method in interface org.mule.api.lifecycle.LifecycleStateEnabled
 
getLifecycleState() - Method in class org.mule.client.DefaultLocalMuleClient.MuleClientFlowConstruct
 
getLifecycleState() - Method in class org.mule.construct.AbstractFlowConstruct
 
getLifecycleState() - Method in class org.mule.model.AbstractModel
Deprecated.
 
getLifecycleState() - Method in class org.mule.service.AbstractService
Deprecated.
 
getLifecycleState() - Method in class org.mule.transport.AbstractConnector
 
getLifecycleState() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
getLimit() - Method in class org.mule.transport.tcp.protocols.StreamingProtocol
 
getLineNumber() - Method in class org.mule.config.spring.parsers.DefaultXmlMetadataAnnotations
 
getLineNumber() - Method in interface org.mule.config.spring.parsers.XmlMetadataAnnotations
 
getLineSeparator() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
getLinger() - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
getLinger() - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
getLinger() - Method in interface org.mule.transport.tcp.TcpClientSocketProperties
 
getLinger() - Method in interface org.mule.transport.tcp.TcpServerSocketProperties
 
getList() - Method in class org.mule.module.management.agent.JmxServerNotificationAgent.NotificationListener
 
getList(Object) - Static method in class org.mule.transport.http.multipart.LazyList
Get the real List from a LazyList.
getList(Object, boolean) - Static method in class org.mule.transport.http.multipart.LazyList
Get the real List from a LazyList.
getList() - Method in class org.mule.util.MapCombiner
 
getListDelimiter() - Method in class org.mule.routing.outbound.StaticRecipientList
Deprecated.
Overloading classes can change the delimiter used to separate entries in the recipient list.
getListElementIndex(Element) - Method in class org.mule.module.db.internal.config.domain.param.AbstractParamDefinitionDefinitionParser
 
getListener() - Method in class org.mule.context.notification.ListenerSubscriptionPair
 
getListener() - Method in class org.mule.module.spring.events.AsynchronousEventListener
Deprecated.
 
getListener() - Method in class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
getListener() - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
getListeners() - Method in class org.mule.context.notification.ServerNotificationManager
 
getListIterator() - Method in class org.mule.module.launcher.util.ObservableList.ObservableListIterator
 
getListOfValues(String) - Method in class com.javaforge.bobber.plugin.archetype.BobberArchetype
 
getListSize() - Method in class org.mule.module.management.agent.JmxServerNotificationAgent.NotificationListener
 
getListSize() - Method in interface org.mule.module.management.agent.JmxServerNotificationAgent.NotificationListenerMBean
 
getLoaderOverride() - Method in class org.mule.module.launcher.descriptor.ArtifactDescriptor
 
getLoaderOverride() - Method in class org.mule.module.launcher.plugin.PluginDescriptor
 
getLocalAddr() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getLocalAddress() - Method in class org.apache.commons.httpclient.HttpConnection
Return the local address used when creating the connection.
getLocalAuthorizationUrlResourceOwnerIdEvaluator() - Method in interface org.mule.module.oauth2.internal.authorizationcode.AuthorizationCodeGrantType
 
getLocalAuthorizationUrlResourceOwnerIdEvaluator() - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
getLocalCertificateChain() - Method in class org.mule.transport.http.HttpServerConnection
 
getLocale() - Method in class org.mule.el.context.ServerContext
 
getLocale() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getLocale() - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
getLocales() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getLocalHost() - Static method in class org.mule.util.NetworkUtils
 
getLocalHostIp(String) - Static method in class org.mule.util.NetworkUtils
Resolves a local IP for a host name.
getLocalName() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getLocalName() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getLocalName() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getLocalObjectStoreManager() - Method in class org.mule.DefaultMuleContext
When running in clustered mode, it returns a ObjectStoreManager that creates ObjectStore instances which are only local to the current node.
getLocalPort() - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
Retrieves localPort
getLocalPort() - Method in interface org.mule.security.oauth.callback.HttpCallbackAdapter
Retrieves localPort
getLocalPort() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getLocalQueueManager() - Method in class org.mule.DefaultMuleContext
When running in clustered mode, it returns a QueueManager that creates Queue instances which are only local to the current node.
getLocalResourceLocations() - Method in class org.mule.module.launcher.artifact.AbstractArtifactClassLoader
 
getLocalResourceLocations() - Method in class org.mule.module.launcher.MuleApplicationClassLoader
 
getLocalResourceLocations() - Method in class org.mule.module.launcher.MuleSharedDomainClassLoader
 
getLocation() - Method in class org.mule.api.debug.Breakpoint
Returns the location of this breakpoint
getLocation() - Method in class org.mule.module.http.internal.request.RamlApiConfiguration
 
getLocation() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getLocation() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getLocation() - Method in class org.mule.transport.http.multipart.MultipartConfiguration
Gets the directory location where files will be stored.
getLock() - Method in interface org.mule.module.launcher.DeploymentService
Obtains the object used to synchronize the service.
getLock() - Method in class org.mule.module.launcher.MuleDeploymentService
 
getLock() - Method in class org.mule.util.concurrent.AbstractSynchronizedVariable
 
getLock() - Method in class org.mule.util.lock.InstanceLockGroup.LockEntry
 
getLockFactory() - Method in interface org.mule.api.MuleContext
Factory for creating locks for synchronizing mule components.
getLockFactory() - Method in class org.mule.DefaultMuleContext
 
getLockObject() - Method in class org.mule.transport.soap.axis.extensions.AxisMuleSession
 
getLocksCount() - Method in class org.mule.module.db.internal.result.statement.StatementStreamingResultSetCloser
 
getLog() - Method in class org.mule.test.infrastructure.process.Controller
 
getLog(String) - Method in class org.mule.test.infrastructure.process.Controller
 
getLog() - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
getLog(String) - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
getLogConfigFile() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
getLogConfigFile() - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
getLogEntriesForTx(T) - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
 
getLogEntriesForTx(Xid) - Method in class org.mule.util.journal.queue.XaTxQueueTransactionJournal
 
getLogEntriesForTx(T) - Method in class org.mule.util.journal.TransactionJournal
 
getLogFile() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
getLogger() - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
getLogger() - Method in class org.mule.module.cxf.transport.MuleUniversalDestination
 
getLogger() - Method in class org.mule.module.cxf.transport.MuleUniversalDestination.ResponseConduit
 
getLogger() - Method in class org.mule.module.drools.DroolsSessionData
 
getLogger() - Method in class org.mule.module.launcher.MuleContainer
 
getLogger() - Method in class org.mule.MuleServer
 
getLogger() - Method in class org.mule.security.oauth.BaseOAuth1Manager
 
getLogger() - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
getLogger(String) - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
getLogin() - Method in class org.mule.module.management.agent.Mx4jAgent
 
getLoginConfig() - Method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider
Gets the Login Configuration
getLoginContextName() - Method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider
Gets the Login Context Name
getLoginModule() - Method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider
Gets the login module name
getLoginTimeout() - Method in class org.mule.module.db.internal.domain.xa.DataSourceWrapper
 
getLoginTimeout() - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
getLoginTimeout() - Method in class org.mule.transport.jdbc.xa.DataSourceWrapper
 
getLogLevel() - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
getLogLevel() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
getLogName() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
getLogsDir() - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
getLogWriter() - Method in class org.mule.module.db.internal.domain.xa.DataSourceWrapper
 
getLogWriter() - Method in class org.mule.transport.jdbc.xa.DataSourceWrapper
 
getLong(Object, Long) - Static method in class org.mule.util.ObjectUtils
Gets a long from a value in a null-safe manner.
getLongProperty(String, long) - Method in interface org.mule.api.MuleMessage
getLongProperty(String, long) - Method in class org.mule.DefaultMuleMessage
Deprecated.
getLongProperty(String, long) - Method in class org.mule.MessagePropertiesContext
 
getLongValue(String, String, XmlPullParser, boolean) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method getLongValue.
getLostObjects() - Method in class org.mule.registry.TransientRegistry.RegistryMap
Deprecated.
 
getLowerVersion() - Method in class org.mule.util.VersionRange
 
getMailboxFolder() - Method in class org.mule.transport.email.AbstractMailConnector
 
getMajor() - Method in class org.mule.util.JdkVersionUtils.JdkVersion
 
getManagedExceptions() - Method in class org.mule.security.oauth.callback.ProcessCallback
 
getManager() - Method in class org.mule.module.spring.transaction.SpringTransactionFactory
 
getManifest() - Static method in class org.mule.config.MuleManifest
 
getManifestProperty(String) - Static method in class org.mule.config.MuleManifest
 
getMap() - Method in class org.mule.transport.http.multipart.MultiPartInputStream
 
getMapKeyFieldType(Field) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic key type of the given Map field.
getMapKeyFieldType(Field, int) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic key type of the given Map field.
getMapKeyParameterType(MethodParameter) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic key type of the given Map parameter.
getMapKeyReturnType(Method) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic key type of the given Map return type.
getMapKeyReturnType(Method, int) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic key type of the given Map return type.
getMapKeyType(Class<? extends Map<?, ?>>) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic key type of the given Map class (if it declares one through a generic superclass or generic interface).
getMappedClass() - Method in class org.mule.module.db.internal.domain.type.MappedStructResolvedDbType
 
getMapper() - Method in class org.mule.module.json.transformers.AbstractJsonTransformer
 
getMapperResolver() - Method in class org.mule.module.json.transformers.JsonTransformerResolver
 
getMapValueFieldType(Field) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic value type of the given Map field.
getMapValueFieldType(Field, int) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic value type of the given Map field.
getMapValueParameterType(MethodParameter) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic value type of the given Map parameter.
getMapValueReturnType(Method) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic value type of the given Map return type.
getMapValueReturnType(Method, int) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic value type of the given Map return type.
getMapValueType(Class<? extends Map<?, ?>>) - Static method in class org.mule.util.generics.GenericsUtils
Determine the generic value type of the given Map class (if it declares one through a generic superclass or generic interface).
getMatches(String, String, int, ExpressionLanguageContext) - Method in class org.mule.el.function.RegexExpressionLanguageFuntion
 
getMatchingClasses() - Method in class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
 
getMaxActive() - Method in class org.mule.config.PoolingProfile
 
getMaxActive() - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
Returns the cap on the number of active instances per key.
getMaxActive() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
getMaxActive() - Method in class org.mule.util.pool.CommonsPoolObjectPool
 
getMaxActive() - Method in interface org.mule.util.pool.ObjectPool
 
getMaxActiveTransformers() - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
getMaxActiveTransformers() - Method in class org.mule.module.xml.transformer.XsltTransformer
 
getMaxBufferSize() - Method in interface org.mule.api.config.ThreadingProfile
 
getMaxBufferSize() - Method in class org.mule.config.ChainedThreadingProfile
 
getMaxBufferSize() - Method in class org.mule.config.ImmutableThreadingProfile
 
getMaxBufferSize() - Method in class org.mule.config.MutableThreadingProfile
 
getMaxBufferSize() - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
getMaxConnectionPoolSize() - Method in class org.mule.transport.sftp.SftpConnector
 
getMaxConnections() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getMaxConnections() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getMaxDispatchersActive() - Method in class org.mule.transport.AbstractConnector
Returns the maximum number of dispatchers that can be concurrently active per endpoint.
getMaxEntries() - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
getMaxEntries() - Method in class org.mule.util.store.ManagedObjectStore
 
getMaxExecutionTime() - Method in class org.mule.management.stats.ComponentStatistics
The maximum total event execution time seen since last cleared.
getMaxExecutionTime() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated. 
getMaxExecutionTime() - Method in class org.mule.module.management.mbean.ServiceService
 
getMaxExecutionTime() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getMaxExecutionTime() - Method in interface org.mule.module.management.mbean.ServiceStatsMBean
Deprecated.
 
getMaxFileSize() - Method in class org.mule.transport.http.multipart.MultipartConfiguration
Gets the maximum size allowed for uploaded files.
getMaxIdle() - Method in class org.mule.config.PoolingProfile
 
getMaxIdle() - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
Returns the cap on the number of "idle" instances per key.
getMaxIdle() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
getMaxIdleTransformers() - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
getMaxIdleTransformers() - Method in class org.mule.module.xml.transformer.XsltTransformer
 
getMaxInterval() - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
getMaxInterval() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
getMaxKernelPoolSize() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getMaxMemory() - Method in class org.mule.module.management.mbean.MuleService
 
getMaxMemory() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getMaxMessageLength() - Method in class org.mule.transport.tcp.protocols.LengthProtocol
 
getMaxOutstandingMessages() - Method in class org.mule.config.QueueProfile
This specifies the number of messages that can be queued before it starts blocking.
getMaxOutstandingMessages() - Method in class org.mule.config.spring.factories.QueueProfileFactoryBean
 
getMaxPoolSize() - Method in class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
getMaxProcessingTime() - Method in class org.mule.management.stats.ApplicationStatistics
 
getMaxProcessingTime() - Method in class org.mule.management.stats.FlowConstructStatistics
 
getMaxProcessingTime() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getMaxProcessingTime() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
getMaxProcessingTime() - Method in interface org.mule.module.management.mbean.FlowConstructStatsMBean
 
getMaxQueuePrefetch() - Method in class org.mule.transport.jms.JmsConnector
 
getMaxQueueSize() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
getMaxQueueSize() - Method in class org.mule.module.management.mbean.ServiceService
 
getMaxQueueSize() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getMaxQueueSize() - Method in interface org.mule.module.management.mbean.ServiceStatsMBean
Deprecated.
 
getMaxQueueSize() - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
getMaxQueueTransactionFilesSizeInMegabytes() - Method in interface org.mule.api.config.MuleConfiguration
The approximated maximum space in megabytes used by the transaction log files for transactional persistent queues.
getMaxQueueTransactionFilesSizeInMegabytes() - Method in class org.mule.config.DefaultMuleConfiguration
 
getMaxRedelivery() - Method in exception org.mule.api.exception.MessageRedeliveredException
 
getMaxRedelivery() - Method in class org.mule.transport.jms.JmsConnector
 
getMaxRedeliveryAttempts() - Method in class org.mule.exception.RollbackMessagingExceptionStrategy
 
getMaxRedeliveryCount() - Method in class org.mule.processor.AbstractRedeliveryPolicy
 
getMaxRequestersActive() - Method in class org.mule.transport.AbstractConnector
Returns the maximum number of requesters that can be concurrently active per endpoint.
getMaxRequestSize() - Method in class org.mule.transport.http.multipart.MultipartConfiguration
Gets the maximum size allowed for multipart/form-data requests.
getMaxRetries() - Method in class org.mule.routing.UntilSuccessful
 
getMaxRetries() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
getMaxThreads() - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
getMaxThreadsActive() - Method in interface org.mule.api.config.ThreadingProfile
 
getMaxThreadsActive() - Method in class org.mule.config.ChainedThreadingProfile
 
getMaxThreadsActive() - Method in class org.mule.config.ImmutableThreadingProfile
 
getMaxThreadsActive() - Method in class org.mule.config.MutableThreadingProfile
 
getMaxThreadsIdle() - Method in interface org.mule.api.config.ThreadingProfile
 
getMaxThreadsIdle() - Method in class org.mule.config.ChainedThreadingProfile
 
getMaxThreadsIdle() - Method in class org.mule.config.ImmutableThreadingProfile
 
getMaxThreadsIdle() - Method in class org.mule.config.MutableThreadingProfile
 
getMaxTotal() - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
Returns the overall maximum number of objects (across pools) that can exist at one time.
getMaxTotal() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
getMaxTotalDispatchers() - Method in class org.mule.transport.AbstractConnector
Returns the maximum number of dispatchers that can be concurrently active for all endpoints.
getMaxUnackedSize() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getMaxWait() - Method in class org.mule.config.PoolingProfile
 
getMaxWait() - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
Returns the maximum amount of time (in milliseconds) the KeyedObjectPool.borrowObject(K) method should block before throwing an exception when the pool is exhausted and the "when exhausted" action is ConfigurableKeyedObjectPool.WHEN_EXHAUSTED_BLOCK.
getMaxWait() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
getMaxWaitMillis() - Method in class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
getMaxWorkerPoolSize() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getMBeanServer() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
getMBeanServer() - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
getMember() - Method in class org.mule.util.annotation.AnnotationMetaData
 
getMemberName(Capable, String) - Static method in class org.mule.module.extension.internal.introspection.MuleExtensionAnnotationParser
 
getMep() - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
getMergedListeners(ServerNotificationManager) - Method in class org.mule.config.spring.ServerNotificationManagerConfigurator
 
getMergedSession(MuleEvent[]) - Method in class org.mule.routing.correlation.CollectionCorrelatorCallback
 
getMergedSession() - Method in class org.mule.routing.EventGroup
 
getMessage(Throwable) - Method in interface org.mule.api.config.ExceptionReader
 
getMessage() - Method in interface org.mule.api.context.notification.MuleMessageAware
 
getMessage() - Method in interface org.mule.api.ExceptionPayload
 
getMessage() - Method in exception org.mule.api.expression.InvalidExpressionException
 
getMessage() - Method in class org.mule.api.FutureMessageResult
 
getMessage(long) - Method in class org.mule.api.FutureMessageResult
 
getMessage() - Method in interface org.mule.api.MuleEvent
Returns the message payload for this event
getMessage() - Method in interface org.mule.api.MuleEventContext
Returns the message payload for this event
getMessage() - Method in exception org.mule.api.MuleException
 
getMessage(int) - Method in interface org.mule.api.MuleMessageCollection
 
getMessage(Throwable) - Method in class org.mule.config.DefaultExceptionReader
 
getMessage() - Method in class org.mule.config.i18n.Message
 
getMessage(Throwable) - Method in class org.mule.config.MuleExceptionReader
 
getMessage(Throwable) - Method in class org.mule.config.NamingExceptionReader
 
getMessage(int) - Method in class org.mule.DefaultMessageCollection
 
getMessage() - Method in class org.mule.DefaultMuleEvent
 
getMessage() - Method in class org.mule.DefaultMuleEventContext
Returns the message payload for this event
getMessage() - Method in class org.mule.message.DefaultExceptionPayload
 
getMessage() - Method in class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
Deprecated.
 
getMessage(byte[]) - Static method in class org.mule.module.pgp.MessageFactory
 
getMessage() - Method in class org.mule.transformer.simple.StringAppendTransformer
 
getMessage(Throwable) - Method in class org.mule.transport.jdbc.SQLExceptionReader
 
getMessage(Throwable) - Method in class org.mule.transport.jms.JmsExceptionReader
 
getMessage() - Method in class org.mule.transport.jms.JmsMessageDispatcher.LatchReplyToListener
 
getMessage(Throwable) - Method in class org.mule.transport.soap.axis.AxisFaultExceptionReader
 
getMessage() - Method in class org.mule.VoidMuleEvent
 
getMessageAsBytes() - Method in interface org.mule.api.MuleEvent
Returns the contents of the message as a byte array.
getMessageAsBytes() - Method in interface org.mule.api.MuleEventContext
Deprecated.
Use getMessage().getPayload(DataType.BYTE_ARRAY_DATA_TYPE)
getMessageAsBytes() - Method in class org.mule.DefaultMuleEvent
 
getMessageAsBytes() - Method in class org.mule.DefaultMuleEventContext
Reterns the conents of the message as a byte array.
getMessageAsBytes() - Method in class org.mule.VoidMuleEvent
 
getMessageAsString() - Method in interface org.mule.api.MuleEvent
Returns the message contents as a string If necessary this will use the encoding set on the event
getMessageAsString(String) - Method in interface org.mule.api.MuleEvent
Returns the message contents as a string
getMessageAsString() - Method in interface org.mule.api.MuleEventContext
Returns the message contents as a string This method will use the encoding set on the event
getMessageAsString(String) - Method in interface org.mule.api.MuleEventContext
Returns the message contents as a string
getMessageAsString() - Method in class org.mule.DefaultMuleEvent
 
getMessageAsString(String) - Method in class org.mule.DefaultMuleEvent
Returns the message contents for logging
getMessageAsString(String) - Method in class org.mule.DefaultMuleEventContext
Returns the message contents as a string
getMessageAsString() - Method in class org.mule.DefaultMuleEventContext
Returns the message contents as a string This method will use the default encoding on the event
getMessageAsString() - Method in class org.mule.VoidMuleEvent
 
getMessageAsString(String) - Method in class org.mule.VoidMuleEvent
 
getMessageCode() - Method in exception org.mule.api.MuleException
 
getMessageCollectionEvent() - Method in class org.mule.routing.EventGroup
 
getMessageCount() - Method in class org.mule.transport.email.RetrieveMessageRequester
 
getMessageDelayTime() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
getMessageDigestAlgorithm() - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
getMessageDigestAlgorithm() - Method in class org.mule.routing.IdempotentSecureHashMessageFilter
 
getMessageExchangePattern() - Method in class org.mule.module.management.mbean.EndpointService
 
getMessageExchangePattern() - Method in interface org.mule.module.management.mbean.EndpointServiceMBean
 
getMessageId() - Method in exception org.mule.api.exception.MessageRedeliveredException
 
getMessageId(MuleMessage) - Method in interface org.mule.api.routing.MessageInfoMapping
 
getMessageId(MuleMessage) - Method in class org.mule.routing.correlation.CorrelationPropertiesExpressionEvaluator
 
getMessageId(MuleMessage) - Method in class org.mule.routing.ExpressionMessageInfoMapping
 
getMessageId(MuleMessage) - Method in class org.mule.routing.MuleMessageInfoMapping
 
getMessageIdExpression() - Method in class org.mule.routing.ExpressionMessageInfoMapping
 
getMessageInfoMapping() - Method in interface org.mule.api.construct.FlowConstruct
 
getMessageInfoMapping() - Method in class org.mule.client.DefaultLocalMuleClient.MuleClientFlowConstruct
 
getMessageInfoMapping() - Method in class org.mule.construct.AbstractFlowConstruct
 
getMessageInfoMapping() - Method in class org.mule.service.AbstractService
Deprecated.
 
getMessageList() - Method in class org.mule.DefaultMessageCollection
 
getMessageListener() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
getMessageListener() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
getMessageListener() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
getMessageParts(MuleMessage, List<MessageProcessor>) - Method in class org.mule.routing.outbound.AbstractMessageSplitter
Implementing classes should create a SplitMessage instance and for each part can associate an endpoint.
getMessageParts(MuleMessage, List<MessageProcessor>) - Method in class org.mule.routing.outbound.AbstractRoundRobinMessageSplitter
Retrieves a specific message part for the given endpoint.
getMessageProcessor(String, OperationOptions, MessageExchangePattern) - Method in interface org.mule.api.connector.ConnectorOperationProvider
A MessageProcessor that contains the behaviour for the URL
getMessageProcessor() - Method in class org.mule.api.processor.DefaultMessageProcessorPathElement
 
getMessageProcessor() - Method in interface org.mule.api.processor.MessageProcessorPathElement
 
getMessageProcessor() - Method in class org.mule.context.notification.AsyncMessageNotification
 
getMessageProcessor(String, OperationOptions, MessageExchangePattern) - Method in class org.mule.module.http.internal.request.client.HttpConnectorMessageProcessorProvider
 
getMessageProcessor() - Method in class org.mule.routing.MessageProcessorFilterPair
 
getMessageProcessor() - Method in class org.mule.security.oauth.callback.DefaultRestoreAccessTokenCallback
Retrieves messageProcessor
getMessageProcessor() - Method in class org.mule.security.oauth.callback.DefaultSaveAccessTokenCallback
Retrieves messageProcessor
getMessageProcessor() - Method in class org.mule.security.oauth.processor.AbstractListeningMessageProcessor
Retrieves messageProcessor
getMessageProcessorBuilder() - Method in class org.mule.module.cxf.config.FlowConfiguringMessageProcessor
 
getMessageProcessorChain() - Method in class org.mule.client.DefaultLocalMuleClient.MuleClientFlowConstruct
 
getMessageProcessorChain(FlowConstruct) - Method in class org.mule.endpoint.AbstractEndpoint
 
getMessageProcessorChain() - Method in class org.mule.service.AbstractService
Deprecated.
 
getMessageProcessorDebugInfo(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
getMessageProcessorDebugInfo(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.processor.AbstractSingleQueryDbMessageProcessor
 
getMessageProcessorDebugInfo(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.processor.BulkExecuteMessageProcessor
 
getMessageProcessorDebugInfo(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.processor.DynamicBulkUpdateMessageProcessor
 
getMessageProcessorDebugInfo(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.processor.PreparedBulkUpdateMessageProcessor
 
getMessageProcessors() - Method in interface org.mule.api.construct.Pipeline
 
getMessageProcessors() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
 
getMessageProcessors() - Method in interface org.mule.api.processor.MessageProcessorChain
 
getMessageProcessors() - Method in class org.mule.construct.AbstractPipeline
 
getMessageProcessors() - Method in class org.mule.endpoint.AbstractEndpoint
 
getMessageProcessors() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getMessageProcessors() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getMessageProcessors() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getMessageProcessors() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getMessageProcessors() - Method in class org.mule.exception.AbstractExceptionListener
 
getMessageProcessors() - Method in class org.mule.exception.RedeliveryExceeded
 
getMessageProcessors() - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
getMessageProcessors() - Method in class org.mule.processor.chain.InterceptingChainLifecycleWrapper
 
getMessageProcessors() - Method in class org.mule.processor.NullMessageProcessor
 
getMessageProcessors() - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
getMessageProcessors() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getMessageProcessorsFactory() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
 
getMessageProcessorsFactory() - Method in class org.mule.endpoint.AbstractEndpoint
 
getMessageProcessorsFactory() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getMessageProcessorsFactory() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getMessageProcessorsFactory() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getMessageProcessorsFactory() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getMessageProcessorsFactory() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getMessageReceiver() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
getMessageReceiver() - Method in class org.mule.transport.TransportMessageProcessContext
 
getMessageRootId() - Method in interface org.mule.api.MuleMessage
gets an identifier that is the same among parent and child messages
getMessageRootId() - Method in class org.mule.DefaultMuleMessage
 
getMessages() - Method in class org.mule.transport.jdbc.JdbcMessageReceiver
 
getMessages() - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
getMessages() - Method in class org.mule.transport.TransactedPollingMessageReceiver
 
getMessages() - Method in class org.mule.transport.vm.VMMessageReceiver
It's impossible to process all messages in the receive transaction
getMessagesAsArray() - Method in interface org.mule.api.MuleMessageCollection
 
getMessagesAsArray() - Method in class org.mule.DefaultMessageCollection
 
getMessageSigner() - Method in interface org.mule.security.oauth.OAuth1Connector
 
getMessageSize() - Method in class org.mule.routing.MessageChunkSplitter
 
getMessageSize() - Method in class org.mule.routing.outbound.MessageChunkingRouter
Deprecated.
 
getMessageSource() - Method in interface org.mule.api.construct.Pipeline
 
getMessageSource() - Method in interface org.mule.api.service.Service
Deprecated.
 
getMessageSource() - Method in class org.mule.construct.AbstractPipeline
 
getMessageSource() - Method in interface org.mule.execution.MessageProcessContext
 
getMessageSource() - Method in class org.mule.module.http.internal.listener.HttpMessageProcessContext
 
getMessageSource() - Method in class org.mule.service.AbstractService
Deprecated.
 
getMessageSource() - Method in class org.mule.transport.TransportMessageProcessContext
 
getMessageSourceName() - Method in interface org.mule.api.MuleEvent
Returns the message source name if it has one, otherwise returns toString() of the URI returned be getMessageSourceURI()
getMessageSourceName() - Method in class org.mule.DefaultMuleEvent
 
getMessageSourceName() - Method in class org.mule.VoidMuleEvent
 
getMessageSourceURI() - Method in interface org.mule.api.MuleEvent
Returns the URI of the MessageSource that recieved or generated the message being processed.
getMessageSourceURI() - Method in class org.mule.DefaultMuleEvent
 
getMessageSourceURI() - Method in class org.mule.VoidMuleEvent
 
getMessageStream(MuleEvent) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
Gets the stream representation of the current message.
getMessageThreadPoolSize() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getMessagingExceptionHandler() - Method in class org.mule.processor.AbstractMuleObjectOwner
 
getMeta() - Method in class org.mule.endpoint.URIBuilder
 
getMetaData() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
getMetaData(MetaDataKey) - Method in class org.mule.module.db.internal.domain.database.GenericDbConfig
 
getMetaData() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getMetaData(MetaDataKey) - Method in class org.mule.module.db.internal.resolver.database.AbstractDbConfigResolver
 
getMetaData(MetaDataKey) - Method in class org.mule.module.db.internal.resolver.database.DynamicDbConfigResolver
 
getMetaData() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getMetaDataKeys() - Method in class org.mule.module.db.internal.domain.database.GenericDbConfig
 
getMetaDataKeys() - Method in class org.mule.module.db.internal.resolver.database.AbstractDbConfigResolver
 
getMetaDataKeys() - Method in class org.mule.module.db.internal.resolver.database.DynamicDbConfigResolver
 
getMetadataProvider() - Method in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
getMetadataProvider() - Method in class org.mule.module.db.internal.config.processor.BulkExecuteProcessorBeanDefinitionParser
 
getMetadataProvider() - Method in class org.mule.module.db.internal.config.processor.ExecuteDdlProcessorBeanDefinitionParser
 
getMetadataProvider() - Method in class org.mule.module.db.internal.config.processor.PreparedBulkUpdateProcessorBeanDefinitionParser
 
getMetadataProvider() - Method in class org.mule.module.db.internal.config.processor.SelectProcessorDefinitionParser
 
getMetadataProvider() - Method in class org.mule.module.db.internal.config.processor.SingleUpdateProcessorDefinitionParser
 
getMetadataProvider() - Method in class org.mule.module.db.internal.config.processor.StoredProcedureProcessorBeanDefinitionParser
 
getMetaInfo() - Method in interface org.mule.api.retry.RetryContext
 
getMetaInfo() - Method in interface org.mule.api.retry.RetryPolicyTemplate
 
getMetaInfo() - Method in class org.mule.retry.async.AsynchronousRetryTemplate
 
getMetaInfo() - Method in class org.mule.retry.async.FutureRetryContext
 
getMetaInfo() - Method in class org.mule.retry.DefaultRetryContext
 
getMetaInfo() - Method in class org.mule.retry.policies.AbstractPolicyTemplate
 
getMethod() - Method in interface org.mule.api.component.InterfaceBinding
 
getMethod() - Method in class org.mule.component.DefaultInterfaceBinding
 
getMethod(MuleEvent) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
getMethod() - Method in interface org.mule.module.http.api.client.HttpRequestOptions
 
getMethod() - Method in class org.mule.module.http.internal.domain.request.DefaultHttpRequest
 
getMethod() - Method in interface org.mule.module.http.internal.domain.request.HttpRequest
 
getMethod() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyHttpRequestAdapter
 
getMethod() - Method in class org.mule.module.http.internal.request.client.DefaultHttpRequestOptions
 
getMethod() - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
getMethod(MuleEvent) - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
getMethod() - Method in class org.mule.transport.http.RequestLine
 
getMethod() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getMethod(Class<?>, String, Class<?>[]) - Static method in class org.mule.util.ClassUtils
Returns a matching method for the given name and parameters on the given class If the parameterTypes arguments is null it will return the first matching method on the class.
getMethod(Class, String, Class[], boolean) - Static method in class org.mule.util.ClassUtils
 
getMethod() - Method in class org.mule.util.generics.MethodParameter
Return the wrapped Method, if any.
getMethodAnnotation(Class<T>) - Method in class org.mule.util.generics.MethodParameter
Return the method/constructor annotation of the given type, if available.
getMethodAnnotations(Class<?>, Class<? extends Annotation>) - Static method in class org.mule.util.annotation.AnnotationUtils
 
getMethodAnnotations() - Method in class org.mule.util.generics.MethodParameter
Return the annotations associated with the target method/constructor itself.
getMethodAnnotations() - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
getMethodArguments() - Method in class org.mule.transport.rmi.RmiMessageReceiver
Returns the method arguments to use when invoking the method on the Remote object.
getMethodArgumentTypes(Object[]) - Method in class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
 
getMethodArgumentTypes(Object[]) - Method in class org.mule.model.resolvers.ArrayEntryPointResolver
 
getMethodArgumentTypes(Object[]) - Method in class org.mule.model.resolvers.NoArgumentsEntryPointResolver
 
getMethodArgumentTypes(Method) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
Returns an array of DataType representing each of the given Method's argument types.
getMethodByArguments(Object, Object[]) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
getMethodByName(Object, String, MuleEventContext) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
getMethodCache(Object) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
getMethodCalled() - Method in class org.mule.api.model.InvocationResult
Returns the name of the method invoked, this property is only set if the state of the invocation is InvocationResult.State.SUCCESSFUL
getMethodMetaAnnotations(Class<?>, Class<? extends Annotation>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
getMethodName() - Method in class org.mule.module.scripting.component.GroovyRefreshableBeanBuilder
 
getMethodNames(Class<?>[]) - Static method in class org.mule.transport.soap.axis.AxisServiceProxy
 
getMethodObject(Remote, MuleEvent, OutboundEndpoint) - Method in class org.mule.transport.rmi.RmiConnector
Helper method for Dispatchers and Receives to extract the correct method from a Remote object
getMethodOrOperationName(MuleEvent) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
getMethodProperty() - Method in class org.mule.model.resolvers.MethodHeaderPropertyEntryPointResolver
 
getMethodRequestMatcher() - Method in class org.mule.module.http.internal.listener.matcher.ListenerRequestMatcher
 
getMethodReturnType(Method) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
Returns a DataType representing the given Method's return type
getMethods() - Method in class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
 
getMethods(Class<?>[]) - Static method in class org.mule.transport.soap.axis.AxisServiceProxy
 
getMethodsList() - Method in class org.mule.module.http.internal.listener.matcher.MethodRequestMatcher
 
getMicro() - Method in class org.mule.util.JdkVersionUtils.JdkVersion
 
getMilestone() - Method in class org.mule.util.JdkVersionUtils.JdkVersion
 
getMillisBetweenRetries() - Method in class org.mule.routing.UntilSuccessful
 
getMillisBetweenRetries() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
getMilliSeconds() - Method in interface org.mule.api.el.datetime.Time
 
getMilliSeconds() - Method in class org.mule.el.datetime.DateTime
 
getMimeType() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
Return the mime type defined for the endpoint, if any
getMimeType() - Method in interface org.mule.api.transformer.DataType
The mime type of the the source object to transform.
getMimeType() - Method in interface org.mule.api.transformer.Transformer
Return the mime type returned by the transformer (if any).
getMimeType() - Method in class org.mule.endpoint.AbstractEndpoint
 
getMimeType() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getMimeType() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getMimeType() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getMimeType() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getMimeType() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getMimeType() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getMimeType() - Method in class org.mule.module.cxf.builder.ProxyClientMessageProcessorBuilder
 
getMimeType() - Method in class org.mule.module.cxf.builder.ProxyServiceMessageProcessorBuilder
 
getMimeType() - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
getMimeType() - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
getMimeType() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getMimeType() - Method in class org.mule.transformer.AbstractTransformer
 
getMimeType() - Method in class org.mule.transformer.CompositeConverter
 
getMimeType() - Method in class org.mule.transformer.types.SimpleDataType
 
getMimeType(Object) - Method in class org.mule.transport.AbstractMuleMessageFactory
 
getMimeType(Object) - Method in class org.mule.transport.file.FileMuleMessageFactory
 
getMimeType(Object) - Method in class org.mule.transport.ftp.FtpMuleMessageFactory
 
getMinEvictionMillis() - Method in class org.mule.config.PoolingProfile
 
getMinExecutionTime() - Method in class org.mule.management.stats.ComponentStatistics
The minimum total event execution time seen since last cleared.
getMinExecutionTime() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated. 
getMinExecutionTime() - Method in class org.mule.module.management.mbean.ServiceService
 
getMinExecutionTime() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getMinExecutionTime() - Method in interface org.mule.module.management.mbean.ServiceStatsMBean
Deprecated.
 
getMinMuleVersion() - Method in interface org.mule.api.MetadataAware
Returns the minimun compatible runtime version
getMinor() - Method in class org.mule.util.JdkVersionUtils.JdkVersion
 
getMinPoolSize() - Method in class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
getMinProcessingTime() - Method in class org.mule.management.stats.ApplicationStatistics
 
getMinProcessingTime() - Method in class org.mule.management.stats.FlowConstructStatistics
 
getMinProcessingTime() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getMinProcessingTime() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
getMinProcessingTime() - Method in interface org.mule.module.management.mbean.FlowConstructStatsMBean
 
getMinThreads() - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
getMinutes() - Method in interface org.mule.api.el.datetime.Time
 
getMinutes() - Method in class org.mule.el.datetime.DateTime
 
getMixins() - Method in class org.mule.module.json.config.MapperFactoryBean
 
getMixins() - Method in class org.mule.module.json.transformers.AbstractJsonTransformer
 
getMode() - Method in class org.mule.transport.soap.axis.NamedParameter
 
getModel() - Method in interface org.mule.api.service.Service
Deprecated.
Returns the name of the model that this descriptor is registered with.
getModel() - Method in class org.mule.service.AbstractService
Deprecated.
 
getModelClass() - Method in interface org.mule.api.model.ModelServiceDescriptor
Deprecated.
 
getModelClass() - Method in class org.mule.model.DefaultModelServiceDescriptor
Deprecated.
getModelEncoding() - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
 
getModelEncoding() - Method in class com.javaforge.bobber.archetype.model.Template
 
getModelEncoding() - Method in class com.javaforge.bobber.archetype.model.Variable
 
getModels() - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
Use lookupModel() instead
getModels() - Method in class org.mule.registry.MuleRegistryHelper
Deprecated.
getModuleName() - Method in interface org.mule.api.MetadataAware
Returns the user-friendly name of this module
getModuleVersion() - Method in interface org.mule.api.MetadataAware
Returns the version of this module
getMonth() - Method in interface org.mule.api.el.datetime.Date
 
getMonth() - Method in class org.mule.el.datetime.DateTime
 
getMostSpecificMethod(Method, Class<?>) - Static method in class org.mule.module.cxf.MuleInvoker
Given a method, which may come from an interface, and a targetClass used in the current AOP invocation, find the most specific method if there is one.
getMoveDirectory() - Method in class org.mule.transport.file.FileMessageRequester
 
getMoveToDirectory() - Method in class org.mule.transport.file.FileConnector
 
getMoveToFolder() - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
getMoveToPattern() - Method in class org.mule.transport.file.FileConnector
 
getMoveToPattern() - Method in class org.mule.transport.file.FileMessageRequester
 
getMtomEnabled() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getMule() - Method in class org.mule.test.infrastructure.process.rules.MuleStandalone
 
getMuleAppConfiguration(String) - Static method in class org.mule.config.PropertiesMuleConfigurationFactory
 
getMuleAppDefaultConfigFile(String) - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
getMuleAppDir(String) - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
getMuleAppsDir() - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
getMuleBin() - Method in class org.mule.test.infrastructure.process.Controller
 
getMuleBin() - Method in class org.mule.test.infrastructure.process.UnixController
 
getMuleBin() - Method in class org.mule.test.infrastructure.process.WindowsController
 
getMuleConfDir() - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
getMuleConfiguration() - Method in class org.mule.context.DefaultMuleContextBuilder
 
getMuleConfiguration() - Method in class org.mule.module.launcher.domain.DomainMuleContextBuilder
 
getMuleContext() - Method in interface org.mule.api.config.ThreadingProfile
 
getMuleContext() - Method in interface org.mule.api.construct.FlowConstruct
 
getMuleContext() - Method in interface org.mule.api.endpoint.EndpointURI
 
getMuleContext() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
 
getMuleContext() - Method in interface org.mule.api.MuleEvent
Returns the muleContext for the Mule node that this event was received in
getMuleContext() - Method in interface org.mule.api.MuleEventContext
 
getMuleContext() - Method in interface org.mule.api.MuleMessage
Deprecated.
Avoid getting access to the MuleContext through the message. You can get access to the MuleContext by making your class implement MuleContextAware
getMuleContext() - Method in interface org.mule.api.retry.RetryContext
 
getMuleContext() - Method in interface org.mule.api.service.Service
Deprecated.
 
getMuleContext() - Method in interface org.mule.api.transport.Connector
Only use this method to use the Connector's MuleContext.
getMuleContext() - Method in class org.mule.client.DefaultLocalMuleClient.MuleClientFlowConstruct
 
getMuleContext() - Method in class org.mule.config.ChainedThreadingProfile
 
getMuleContext() - Method in class org.mule.config.ImmutableThreadingProfile
 
getMuleContext() - Method in class org.mule.config.MutableThreadingProfile
 
getMuleContext() - Method in class org.mule.config.spring.MuleArtifactContext
 
getMuleContext() - Method in class org.mule.construct.AbstractFlowConstruct
 
getMuleContext() - Method in class org.mule.context.notification.MuleContextNotification
 
getMuleContext() - Method in class org.mule.DefaultMuleEvent
 
getMuleContext() - Method in class org.mule.DefaultMuleEventContext
 
getMuleContext() - Method in class org.mule.DefaultMuleMessage
getMuleContext() - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
Retrieves muleContext
getMuleContext() - Method in class org.mule.endpoint.AbstractEndpoint
 
getMuleContext() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getMuleContext() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getMuleContext() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getMuleContext() - Method in class org.mule.endpoint.MuleEndpointURI
 
getMuleContext() - Method in class org.mule.endpoint.URIBuilder
 
getMuleContext() - Method in class org.mule.expression.MuleContextExpressionEvaluator
 
getMuleContext() - Method in class org.mule.model.AbstractModel
Deprecated.
 
getMuleContext() - Method in class org.mule.module.client.MuleClient
The overriding method may want to return a custom MuleContext here
getMuleContext() - Method in class org.mule.module.cxf.CxfConfiguration
 
getMuleContext() - Method in class org.mule.module.db.internal.domain.database.DataSourceFactory
 
getMuleContext() - Method in interface org.mule.module.launcher.application.Application
 
getMuleContext() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
getMuleContext() - Method in interface org.mule.module.launcher.artifact.Artifact
 
getMuleContext() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
getMuleContext() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
getMuleContext() - Method in interface org.mule.module.launcher.domain.Domain
 
getMuleContext() - Method in class org.mule.module.launcher.domain.DomainWrapper
 
getMuleContext() - Method in class org.mule.module.oauth2.internal.AbstractTokenRequestHandler
 
getMuleContext() - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
getMuleContext() - Method in class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
 
getMuleContext() - Method in class org.mule.MuleServer
 
getMuleContext() - Method in class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
getMuleContext() - Method in class org.mule.processor.AbstractMuleObjectOwner
 
getMuleContext() - Method in class org.mule.retry.async.FutureRetryContext
 
getMuleContext() - Method in class org.mule.retry.DefaultRetryContext
 
getMuleContext() - Method in class org.mule.routing.AbstractRoutingStrategy
 
getMuleContext() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
getMuleContext() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
getMuleContext() - Method in class org.mule.security.oauth.BaseOAuth2Manager
Returns the mule context
getMuleContext() - Method in interface org.mule.security.oauth.OAuth2Manager
Returns the mule context
getMuleContext() - Method in class org.mule.security.oauth.process.RetryProcessInterceptor
Retrieves muleContext
getMuleContext() - Method in class org.mule.service.AbstractService
Deprecated.
 
getMuleContext() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getMuleContext() - Method in class org.mule.transport.AbstractConnector
Only use this method to use the Connector's MuleContext.
getMuleContext() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
getMuleContext() - Method in class org.mule.transport.quartz.config.AbstractJobConfig
 
getMuleContext(JobExecutionContext) - Method in class org.mule.transport.quartz.jobs.AbstractJob
 
getMuleContext(JobExecutionContext) - Method in class org.mule.transport.quartz.jobs.PollEndpointJob
 
getMuleContext() - Method in class org.mule.util.queue.AbstractQueueManager
 
getMuleContext() - Method in class org.mule.util.queue.AbstractQueueSession
 
getMuleContext() - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
getMuleContext() - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
getMuleContext() - Method in class org.mule.VoidMuleEvent
 
getMuleContext() - Method in class org.mule.work.MuleWorkManager
 
getMuleContextConfigurationId() - Method in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
getMuleContextForApp(String) - Method in class org.mule.tck.junit4.DomainFunctionalTestCase
 
getMuleContextForDomain() - Method in class org.mule.tck.junit4.DomainFunctionalTestCase
 
getMuleDomainsDir() - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
getMuleEvent() - Method in interface org.mule.execution.AsyncResponseFlowProcessingPhaseTemplate
 
getMuleEvent() - Method in interface org.mule.execution.FlowProcessingPhaseTemplate
 
getMuleEvent() - Method in interface org.mule.execution.ThrottlingPhaseTemplate
 
getMuleEvent() - Method in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
getMuleEvent() - Method in class org.mule.security.oauth.notification.OAuthAuthorizeNotification
 
getMuleEvent() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
getMuleEventContext() - Method in class org.mule.module.spring.events.MuleApplicationEvent
Deprecated.
 
getMuleHome() - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
getMuleHome() - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
getMuleHome() - Method in class org.mule.test.infrastructure.process.rules.MuleInstallation
 
getMuleHome() - Method in class org.mule.tools.anttasks.MuleDeploy
 
getMuleHomeDirectory() - Method in interface org.mule.api.config.MuleConfiguration
 
getMuleHomeDirectory() - Method in class org.mule.config.DefaultMuleConfiguration
 
getMuleHomeDirectoryFor(int) - Method in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
getMuleHomeFile() - Static method in class org.mule.module.boot.MuleBootstrapUtils
 
getMuleHomeFile() - Static method in class org.mule.util.JarUtils
 
getMuleHomeFolder() - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getMuleLibDir() - Static method in class org.mule.module.boot.MuleBootstrapUtils
 
getMuleLibDir() - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
getMuleLibDir() - Static method in class org.mule.util.JarUtils
 
getMuleLibFolder() - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getMuleLocalJarFile() - Static method in class org.mule.module.boot.MuleBootstrapUtils
 
getMuleLocalJarFile() - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
getMuleLocalJarFile() - Static method in class org.mule.util.JarUtils
 
getMuleMessage() - Method in exception org.mule.api.MessagingException
Deprecated.
use #getEvent().getMessage() instead
getMuleMessageFactory() - Method in class org.mule.transport.AbstractConnector
The connector creates a MuleMessageFactory lazily and holds a reference to it for others to use.
getMuleModuleDir() - Static method in class org.mule.util.JarUtils
 
getMuleMQFactoryClass() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getMuleMQFactoryClass() - Method in class org.mule.transport.jms.mulemq.MuleMQXAJmsConnector
 
getMuleMqMaxRedelivery() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getMultiFrameInterval() - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
getMultiFrameInterval() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
getName() - Method in class com.javaforge.bobber.archetype.model.Variable
Get the name field.
getName() - Method in class org.mule.AbstractAgent
 
getName() - Method in class org.mule.api.debug.DebuggerFrame
The name of the frame
getName() - Method in class org.mule.api.debug.FieldDebugInfo
 
getName() - Method in interface org.mule.api.NamedObject
Gets the name of the object
getName() - Method in class org.mule.api.processor.DefaultMessageProcessorPathElement
 
getName() - Method in interface org.mule.api.processor.MessageProcessorPathElement
 
getName() - Method in class org.mule.api.processor.NamedStageNameSource
 
getName() - Method in class org.mule.api.processor.SequentialStageNameSource
 
getName() - Method in interface org.mule.api.processor.StageNameSource
Generates the name for a staged queue.
getName() - Method in enum org.mule.api.registry.ServiceType
 
getName() - Method in class org.mule.client.DefaultLocalMuleClient.MuleClientFlowConstruct
 
getName() - Method in class org.mule.component.AbstractComponent
 
getName() - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
getName() - Method in class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
getName() - Method in class org.mule.config.spring.parsers.generic.NamedDefinitionParser
 
getName() - Method in class org.mule.config.support.InheritedModel
Deprecated.
 
getName() - Method in class org.mule.construct.AbstractFlowConstruct
 
getName() - Method in class org.mule.el.context.AppContext
 
getName() - Method in class org.mule.el.mvel.EventVariableResolverFactory.FlowContext
 
getName() - Method in class org.mule.endpoint.AbstractEndpoint
 
getName(EndpointURI) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getName() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getName() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getName() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getName() - Method in class org.mule.expression.AttachmentExpressionEnricher
 
getName() - Method in class org.mule.expression.EndpointInfoExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.ExceptionTypeExpressionEvaluator
 
getName() - Method in class org.mule.expression.FunctionExpressionEvaluator
Gts the name of the object
getName() - Method in class org.mule.expression.MapPayloadExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.MessageAttachmentExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.MessageAttachmentsExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.MessageAttachmentsListExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.MessageExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.MessageHeaderExpressionEnricher
 
getName() - Method in class org.mule.expression.MessageHeaderExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.MessageHeadersExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.MessageHeadersListExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.MessagePayloadExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.MessageProcessorExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.MuleContextExpressionEvaluator
Gts the name of the object
getName() - Method in class org.mule.expression.MuleExpressionEvaluator
Deprecated.
 
getName() - Method in class org.mule.expression.OutboundAttachmentsExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.PayloadTypeExpressionEvaluator
 
getName() - Method in class org.mule.expression.RegexExpressionEvaluator
 
getName() - Method in class org.mule.expression.RegistryExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.StringExpressionEvaluator
Gts the name of the object
getName() - Method in class org.mule.expression.transformers.ExpressionArgument
 
getName() - Method in class org.mule.expression.VariableExpressionEnricher
 
getName() - Method in class org.mule.expression.VariableExpressionEvaluator
Gets the name of the object
getName() - Method in class org.mule.expression.WilcardExpressionEvaluator
 
getName() - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
getName() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
 
getName() - Method in class org.mule.message.ds.ByteArrayDataSource
 
getName() - Method in class org.mule.message.ds.InputStreamDataSource
 
getName() - Method in class org.mule.message.ds.StringDataSource
 
getName() - Method in class org.mule.model.AbstractModel
Deprecated.
 
getName() - Method in class org.mule.module.bpm.Process
 
getName() - Method in class org.mule.module.bpm.ProcessComponent
 
getName() - Method in class org.mule.module.cxf.config.WsSecurity
 
getName() - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
getName(Element) - Method in class org.mule.module.db.internal.config.domain.param.AbstractParamDefinitionDefinitionParser
 
getName() - Method in class org.mule.module.db.internal.domain.database.GenericDbConfig
 
getName() - Method in class org.mule.module.db.internal.domain.param.AbstractQueryParam
 
getName() - Method in interface org.mule.module.db.internal.domain.param.QueryParam
Returns the name parameter name.
getName() - Method in class org.mule.module.db.internal.domain.query.QueryParamValue
 
getName() - Method in class org.mule.module.db.internal.domain.type.AbstractDbType
 
getName() - Method in interface org.mule.module.db.internal.domain.type.DbType
 
getName() - Method in class org.mule.module.db.internal.domain.type.DynamicDbType
 
getName() - Method in class org.mule.module.db.internal.result.statement.OutputParamResult
 
getName() - Method in class org.mule.module.db.internal.result.statement.ResultSetResult
 
getName() - Method in interface org.mule.module.db.internal.result.statement.StatementResult
 
getName() - Method in class org.mule.module.db.internal.result.statement.UpdateCountResult
 
getName() - Method in class org.mule.module.drools.Drools
 
getName() - Method in class org.mule.module.extension.internal.capability.metadata.MemberNameCapability
The name of the member in which an aliased object is defined
getName() - Method in interface org.mule.module.http.api.requester.proxy.ProxyConfig
 
getName() - Method in class org.mule.module.http.internal.HttpMessageBuilder
 
getName() - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
getName() - Method in class org.mule.module.http.internal.multipart.HttpPart
 
getName() - Method in class org.mule.module.http.internal.multipart.HttpPartDataSource
 
getName() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getName() - Method in class org.mule.module.http.internal.request.DefaultProxyConfig
 
getName() - Method in class org.mule.module.jaas.MuleJaasPrincipal
 
getName() - Method in class org.mule.module.jbpm.EndedProcess
 
getName() - Method in class org.mule.module.jbpm.Jbpm
 
getName() - Method in class org.mule.module.json.config.MapperFactoryBean
 
getName() - Method in class org.mule.module.json.JsonExpressionEvaluator
 
getName() - Method in class org.mule.module.json.JsonNodeExpressionEvaluator
 
getName() - Method in class org.mule.module.launcher.descriptor.ArtifactDescriptor
 
getName() - Method in class org.mule.module.launcher.descriptor.EmptyApplicationDescriptor
 
getName() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
getName() - Method in class org.mule.module.launcher.plugin.PluginDescriptor
 
getName() - Method in class org.mule.module.management.agent.YourKitProfilerAgent
 
getName() - Method in class org.mule.module.management.mbean.ConnectorService
 
getName() - Method in interface org.mule.module.management.mbean.ConnectorServiceMBean
 
getName() - Method in class org.mule.module.management.mbean.EndpointService
 
getName() - Method in interface org.mule.module.management.mbean.EndpointServiceMBean
 
getName() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getName() - Method in interface org.mule.module.management.mbean.FlowConstructServiceMBean
The name of this service
getName() - Method in class org.mule.module.management.mbean.ModelService
Deprecated.
 
getName() - Method in interface org.mule.module.management.mbean.ModelServiceMBean
 
getName() - Method in interface org.mule.module.management.mbean.RegistryServiceMBean
 
getName() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getName() - Method in class org.mule.module.ognl.expression.OgnlExpressionEvaluator
 
getName() - Method in class org.mule.module.scripting.expression.GroovyExpressionEvaluator
 
getName() - Method in class org.mule.module.scripting.filter.ScriptFilter
 
getName() - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
getName() - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
getName() - Method in class org.mule.module.xml.config.JaxbContextFactoryBean
 
getName() - Method in class org.mule.module.xml.expression.BeanPayloadExpressionEvaluator
Deprecated.
Gets the name of the object
getName() - Method in class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
 
getName() - Method in class org.mule.module.xml.expression.JXPathExpressionEvaluator
Deprecated.
Gets the name of the object
getName() - Method in class org.mule.module.xml.expression.XPathBranchExpressionEvaluator
Deprecated.
Gets the name of the object
getName() - Method in class org.mule.module.xml.expression.XPathExpressionEvaluator
Deprecated.
Gets the name of the object
getName() - Method in class org.mule.module.xml.expression.XPathNodeExpressionEvaluator
Deprecated.
Gets the name of the object
getName() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getName() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getName() - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
getName() - Method in class org.mule.processor.chain.InterceptingChainLifecycleWrapper
 
getName() - Method in class org.mule.processor.InvokerMessageProcessor
 
getName() - Method in class org.mule.processor.NullMessageProcessor
 
getName(Object) - Method in class org.mule.registry.MuleRegistryHelper
Returns the name for the object passed in.
getName() - Method in class org.mule.security.AbstractNamedEncryptionStrategy
 
getName() - Method in class org.mule.security.AbstractSecurityProvider
 
getName() - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
getName() - Method in class org.mule.service.AbstractService
Deprecated.
 
getName() - Method in class org.mule.tck.security.Named
 
getName() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getName() - Method in class org.mule.transformer.AbstractTransformer
 
getName() - Method in class org.mule.transformer.CompositeConverter
 
getName() - Method in class org.mule.transport.AbstractConnector
 
getName() - Method in class org.mule.transport.email.transformers.PlainTextDataSource
 
getName() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
getName() - Method in interface org.mule.transport.http.multipart.Part
Gets the name of this part
getName() - Method in class org.mule.transport.http.multipart.PartDataSource
 
getName() - Method in class org.mule.transport.http.PatchMethod
 
getName() - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
getName() - Method in class org.mule.transport.jms.JmsTransactionFactory
 
getName() - Method in class org.mule.transport.polling.schedule.PollScheduler
 
getName() - Method in class org.mule.transport.quartz.config.ScheduleConfigBuilder
 
getName() - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
getName() - Method in class org.mule.transport.soap.axis.extensions.WSDDJavaMuleProvider
 
getName() - Method in class org.mule.transport.soap.axis.NamedParameter
 
getName() - Method in class org.mule.transport.soap.axis.SoapMethod
 
getName() - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
getName() - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
getName() - Method in class org.mule.util.concurrent.NamedThreadFactory
 
getName() - Method in class org.mule.util.counters.CounterFactory.Type
 
getName() - Method in class org.mule.util.counters.impl.AbstractCounter
 
getName() - Method in class org.mule.util.queue.DefaultQueueStore
 
getName() - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
getName() - Method in interface org.mule.util.queue.QueueStore
 
getName() - Method in class org.mule.util.queue.TransactionAwareQueueStore
 
getName() - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
getName() - Method in class org.mule.util.TemplateParser.PatternInfo
 
getName() - Method in class org.mule.util.timer.EventTimerTask
Gets the task name (this is also the timer thread name)
getName() - Method in class org.mule.util.timer.TimeEvent
 
getNamedParameters() - Method in class org.mule.transport.soap.axis.SoapMethod
 
getNameForDestination(Destination) - Static method in class org.mule.transport.jms.JmsMessageUtils
 
getNameFromParam(String) - Method in class org.mule.transport.jdbc.JdbcConnector
 
getNameInNamespace() - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
getNameInNamespace() - Method in class org.mule.jndi.SimpleContext
 
getNameInNamespace() - Method in class org.mule.tck.jndi.InMemoryContext
 
getNameOrId(Element) - Static method in class org.mule.config.spring.util.SpringXMLUtils
 
getNameParser(Name) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
getNameParser(String) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
getNameParser(Name) - Method in class org.mule.jndi.SimpleContext
 
getNameParser(Attributes.Name) - Method in class org.mule.jndi.SimpleContext
 
getNameParser(String) - Method in class org.mule.jndi.SimpleContext
 
getNameParser(Name) - Method in class org.mule.tck.jndi.InMemoryContext
 
getNameParser(String) - Method in class org.mule.tck.jndi.InMemoryContext
 
getNamespace() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getNamespaceContext() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getNamespaceContext() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getNamespaceCount() - Method in class org.mule.module.ws.consumer.NamespaceRestorerXMLStreamReader
 
getNamespaceCount() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getNamespaceCount() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getNamespaceList() - Method in class org.mule.module.xml.stax.EndElementEventX
 
getNamespaceList() - Method in class org.mule.module.xml.stax.StartElementEventX
 
getNamespaceManager() - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
getNamespaceManager() - Method in class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
 
getNamespaceManager() - Method in class org.mule.module.xml.expression.JXPathExpressionEvaluator
Deprecated.
 
getNamespacePrefix(int) - Method in class org.mule.module.ws.consumer.NamespaceRestorerXMLStreamReader
 
getNamespacePrefix(int) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getNamespacePrefix(int) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getNamespaces() - Method in class org.mule.module.sxc.SxcFilteringOutboundRouter
 
getNamespaces() - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
getNamespaces() - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
getNamespaces() - Method in class org.mule.module.xml.filters.XPathFilter
The prefix-to-namespace map for the namespace context to be applied to the XPath evaluation.
getNamespaces() - Method in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
 
getNamespaces() - Method in class org.mule.module.xml.transformer.XPathExtractor
The prefix-to-namespace map.
getNamespaces() - Method in class org.mule.module.xml.util.NamespaceManager
 
getNamespaceURI(String) - Method in class org.mule.module.ws.consumer.NamespaceRestorerXMLStreamReader
 
getNamespaceURI(int) - Method in class org.mule.module.ws.consumer.NamespaceRestorerXMLStreamReader
 
getNamespaceURI() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getNamespaceURI(int) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getNamespaceURI(String) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getNamespaceURI(String) - Method in class org.mule.module.xml.stax.MapNamespaceContext
 
getNamespaceURI() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getNamespaceURI(int) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getNamespaceURI(String) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getNearestTransformerMatch(List<Transformer>, Class, Class) - Method in class org.mule.registry.TypeBasedTransformerResolver
 
getNestingLevel() - Method in class org.mule.util.generics.MethodParameter
Return the nesting level of the target type (typically 1; e.g.
getNetworkTimeout() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
getNetworkTimeout() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getNetworkTimeout() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getNewLineAfterNTags() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
getNextFactory() - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
getNextFactoryVariableResolver(String) - Method in class org.mule.el.mvel.MuleBaseVariableResolverFactory
 
getNextFile(String, Object) - Static method in class org.mule.transport.file.FileMessageDispatcher
 
getNextMessage() - Method in class org.mule.config.i18n.Message
 
getNextMessage(Object) - Method in class org.mule.transport.AbstractReceiverResourceWorker
The method used to read the next message from the underlying transport.
getNextMessage() - Method in class org.mule.transport.email.RetrieveMessageRequester
 
getNextMessage(Object) - Method in class org.mule.transport.tcp.ExceptionReturnTcpMessageReceiver.TcpWorker
 
getNextMessage(Object) - Method in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
getNodeId() - Method in class org.mule.el.context.MuleInstanceContext
 
getNonMatchingClasses() - Method in class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
 
getNonMuleException(Throwable) - Static method in class org.mule.config.ExceptionHelper
 
getNonProxyHosts() - Method in interface org.mule.module.http.api.requester.proxy.ProxyConfig
 
getNonProxyHosts() - Method in class org.mule.module.http.internal.request.DefaultProxyConfig
 
getNotificationHelper(ServerNotificationManager) - Method in class org.mule.execution.NotificationFiringProcessingPhase
 
getNotificationManager() - Method in interface org.mule.api.MuleContext
 
getNotificationManager() - Method in class org.mule.context.DefaultMuleContextBuilder
 
getNotificationManager() - Method in class org.mule.DefaultMuleContext
 
getNotificationsList() - Method in class org.mule.module.management.agent.JmxServerNotificationAgent.NotificationListener
 
getNotificationsList() - Method in interface org.mule.module.management.agent.JmxServerNotificationAgent.NotificationListenerMBean
 
getNotifier() - Method in interface org.mule.api.retry.RetryPolicyTemplate
 
getNotifier() - Method in class org.mule.retry.async.AsynchronousRetryTemplate
 
getNotifier() - Method in class org.mule.retry.policies.AbstractPolicyTemplate
 
getNotRouted() - Method in class org.mule.management.stats.RouterStatistics
 
getNotRouted() - Method in class org.mule.module.management.mbean.RouterStats
 
getNotRouted() - Method in interface org.mule.module.management.mbean.RouterStatsMBean
 
getNtlmDomain() - Method in class org.mule.module.http.internal.request.NtlmProxyConfig
 
getNumActive(Object) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
getNumActive() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
getNumActive() - Method in class org.mule.util.pool.CommonsPoolObjectPool
 
getNumActive() - Method in interface org.mule.util.pool.ObjectPool
 
getNumber() - Method in class org.mule.tck.functional.FunctionalStreamingTestComponent
 
getNumberOfConcurrentTransactedReceivers() - Method in class org.mule.transport.AbstractConnector
Returns the number of concurrent receivers that will be launched when AbstractConnector.isCreateMultipleTransactedReceivers() returns true.
getNumberOfConsumers() - Method in class org.mule.transport.jms.JmsConnector
getNumberOfInvocationsFor(String) - Static method in class org.mule.tck.functional.InvocationCountMessageProcessor
 
getNumberOfMessages() - Method in class org.mule.routing.outbound.MessageChunkingRouter
Deprecated.
 
getNumericId() - Method in enum org.mule.module.pgp.EncryptionAlgorithm
 
getNumIdle(Object) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
getNumIdle() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
getNumPortsToFind() - Method in class org.mule.tck.DynamicPortTestCase
Deprecated.
 
getOauth1Manager() - Method in interface org.mule.security.oauth.OAuth1Adapter
Gets an instance of OAuth1Manager serving this adapter
getOauthCallback() - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
getOauthConfig() - Method in class org.mule.module.oauth2.internal.authorizationcode.AbstractAuthorizationCodeTokenRequestHandler
 
getOauthConfig() - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
getOAuthManager() - Method in class org.mule.security.oauth.processor.BaseOAuth2AuthorizeMessageProcessor
 
getOAuthManager() - Method in class org.mule.security.oauth.processor.BaseOAuth2UnauthorizeMessageProcessor
 
getOAuthManagerClass() - Method in class org.mule.security.oauth.processor.BaseOAuth2AuthorizeMessageProcessor
 
getOAuthManagerClass() - Method in class org.mule.security.oauth.processor.BaseOAuth2UnauthorizeMessageProcessor
 
getOauthRestoreAccessToken() - Method in interface org.mule.security.oauth.OAuth1Adapter
Get the callback to be called when the access token and secret need to be restored
getOauthSaveAccessToken() - Method in interface org.mule.security.oauth.OAuth1Adapter
Get the callback to be called when the access token and secret need to be saved for later restoration
getOauthVerifier() - Method in interface org.mule.security.oauth.OAuthAdapter
Retrieve OAuth verifier
getObject() - Method in class org.mule.config.spring.DefaultObjectSerializerFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.AbstractEndpointFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.AbstractSelectiveRouterFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.BootstrapObjectFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.CompositeMessageSourceFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.ConstantFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.ExtensionManagerFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.FlowRefFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.MessageProcessorChainFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.MessageProcessorFilterPairFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.ResponseMessageProcessorsFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.ScatterGatherRouterFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.TransactionalMessageProcessorsFactoryBean
 
getObject() - Method in class org.mule.config.spring.factories.TransactionManagerFactoryBean
 
getObject() - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
getObject() - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
getObject() - Method in class org.mule.config.spring.ServerNotificationManagerConfigurator
 
getObject() - Method in class org.mule.module.cxf.config.JaxWsClientFactoryBean
 
getObject() - Method in class org.mule.module.cxf.config.ProxyClientFactoryBean
 
getObject() - Method in class org.mule.module.cxf.config.ProxyServiceFactoryBean
 
getObject() - Method in class org.mule.module.cxf.config.SimpleClientFactoryBean
 
getObject() - Method in class org.mule.module.cxf.config.WebServiceFactoryBean
 
getObject() - Method in class org.mule.module.db.internal.config.domain.param.DefaultSqlParamResolverFactoryBean
 
getObject() - Method in class org.mule.module.db.internal.config.domain.param.StaticQueryParamResolverFactoryBean
 
getObject() - Method in class org.mule.module.db.internal.config.domain.query.BulkQueryResolverFactoryBean
 
getObject() - Method in class org.mule.module.db.internal.config.domain.query.DynamicQueryTemplateFactoryBean
 
getObject() - Method in class org.mule.module.db.internal.config.domain.query.ParameterizedQueryTemplateFactoryBean
 
getObject() - Method in class org.mule.module.db.internal.config.domain.query.QueryFileFactoryBean
 
getObject() - Method in class org.mule.module.db.internal.config.processor.BulkUpdateMessageProcessorFactoryBean
 
getObject() - Method in class org.mule.module.db.internal.config.resolver.database.DefaultDbConfigResolverFactoryBean
 
getObject() - Method in class org.mule.module.db.internal.config.resolver.query.QueryResolverFactoryBean
 
getObject() - Method in class org.mule.tck.testmodels.fruit.FloridaSunnyOrangeFactoryBean
 
getObjectClass() - Method in interface org.mule.api.object.ObjectFactory
Returns the class of the object to be instantiated without actually creating an instance.
getObjectClass() - Method in class org.mule.component.PooledJavaComponent.LifeCycleAdapterFactory
 
getObjectClass() - Method in class org.mule.object.AbstractObjectFactory
 
getObjectClass() - Method in class org.mule.object.JndiObjectFactory
Returns the class of the object to be instantiated without actually creating an instance.
getObjectClass() - Method in class org.mule.object.SingletonObjectFactory
 
getObjectClassName() - Method in class org.mule.object.AbstractObjectFactory
 
getObjectFactory() - Method in interface org.mule.api.component.JavaComponent
 
getObjectFactory() - Method in class org.mule.component.AbstractJavaComponent
 
getObjectFactory() - Method in class org.mule.util.pool.CommonsPoolObjectPool
 
getObjectFactory() - Method in interface org.mule.util.pool.ObjectPool
 
getObjectFactoryDefinition(Element) - Method in class org.mule.config.spring.parsers.specific.SimpleComponentDefinitionParser
 
getObjectFactoryDefinition(Element) - Method in class org.mule.config.spring.parsers.specific.StaticComponentDefinitionParser
 
getObjectName() - Method in exception org.mule.module.management.agent.JmxManagementException
 
getObjectName(String) - Method in class org.mule.module.management.support.JmxLegacySupport
For modern JMX implementation just delegate to a standard factory method.
getObjectName(String) - Method in class org.mule.module.management.support.JmxModernSupport
For modern JMX implementation just delegate to a standard factory method.
getObjectName(String) - Method in interface org.mule.module.management.support.JmxSupport
Create an object name.
getObjectName() - Method in class org.mule.object.JndiObjectFactory
 
getObjectSerializer() - Method in interface org.mule.api.MuleContext
The instance of ObjectSerializer to be used to serialize/deserealize objects
getObjectSerializer() - Method in class org.mule.DefaultMuleContext
The instance of ObjectSerializer to be used to serialize/deserealize objects
getObjectStore(String) - Method in interface org.mule.api.store.ObjectStoreManager
Return the partition of the default in-memory store with the given name, creating it if necessary.
getObjectStore(String, boolean) - Method in interface org.mule.api.store.ObjectStoreManager
Return the partition of the default in-memory or persistent store with the given name, creating it if necessary.
getObjectStore(String, boolean, int, int, int) - Method in interface org.mule.api.store.ObjectStoreManager
Return the monitored partition of the default in-memory or persistent store with the given name, creating it if necessary.
getObjectStore() - Method in class org.mule.config.QueueProfile
 
getObjectStore() - Method in class org.mule.routing.UntilSuccessful
 
getObjectStore() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
getObjectStore(String) - Method in class org.mule.util.store.MuleObjectStoreManager
 
getObjectStore(String, boolean) - Method in class org.mule.util.store.MuleObjectStoreManager
 
getObjectStore(String, boolean, int, int, int) - Method in class org.mule.util.store.MuleObjectStoreManager
 
getObjectStoreManager() - Method in interface org.mule.api.MuleContext
 
getObjectStoreManager() - Method in class org.mule.DefaultMuleContext
 
getObjectType() - Method in interface org.mule.api.component.JavaComponent
 
getObjectType() - Method in class org.mule.component.AbstractJavaComponent
 
getObjectType() - Method in class org.mule.component.SimpleCallableJavaComponent
 
getObjectType() - Method in class org.mule.config.spring.DefaultObjectSerializerFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.BootstrapObjectFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.BridgeFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.ChoiceRouterFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.CompositeMessageSourceFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.ConstantFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.ExtensionManagerFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.FlowRefFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.InboundEndpointFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.MessageProcessorChainFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.MessageProcessorFilterPairFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.ObjectStoreFromRegistryFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.OutboundEndpointFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.PollInboundEndpointFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.QueueProfileFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.ResponseMessageProcessorsFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.ScatterGatherRouterFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.SimpleServiceFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.TransactionalMessageProcessorsFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.TransactionManagerFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.ValidatorFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.factories.WatermarkFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
getObjectType() - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
getObjectType() - Method in class org.mule.config.spring.ServerNotificationManagerConfigurator
 
getObjectType() - Method in class org.mule.module.cxf.config.JaxWsClientFactoryBean
 
getObjectType() - Method in class org.mule.module.cxf.config.ProxyClientFactoryBean
 
getObjectType() - Method in class org.mule.module.cxf.config.ProxyServiceFactoryBean
 
getObjectType() - Method in class org.mule.module.cxf.config.SimpleClientFactoryBean
 
getObjectType() - Method in class org.mule.module.cxf.config.WebServiceFactoryBean
 
getObjectType() - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
getObjectType() - Method in class org.mule.module.db.internal.config.domain.param.DefaultSqlParamResolverFactoryBean
 
getObjectType() - Method in class org.mule.module.db.internal.config.domain.param.StaticQueryParamResolverFactoryBean
 
getObjectType() - Method in class org.mule.module.db.internal.config.domain.query.BulkQueryResolverFactoryBean
 
getObjectType() - Method in class org.mule.module.db.internal.config.domain.query.DynamicQueryTemplateFactoryBean
 
getObjectType() - Method in class org.mule.module.db.internal.config.domain.query.ParameterizedQueryTemplateFactoryBean
 
getObjectType() - Method in class org.mule.module.db.internal.config.domain.query.QueryFileFactoryBean
 
getObjectType() - Method in class org.mule.module.db.internal.config.domain.query.QueryTemplateFactoryBean
 
getObjectType() - Method in class org.mule.module.db.internal.config.processor.BulkUpdateMessageProcessorFactoryBean
 
getObjectType() - Method in class org.mule.module.db.internal.config.resolver.database.DefaultDbConfigResolverFactoryBean
 
getObjectType() - Method in class org.mule.module.db.internal.config.resolver.query.QueryResolverFactoryBean
 
getObjectType() - Method in class org.mule.module.json.config.MapperFactoryBean
 
getObjectType() - Method in class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
getObjectType() - Method in class org.mule.module.xml.config.JaxbContextFactoryBean
 
getObjectType() - Method in class org.mule.tck.testmodels.fruit.FloridaSunnyOrangeFactoryBean
 
getObjectType() - Method in class org.mule.transport.http.config.spring.factories.HttpProxyFactoryBean
 
getObjectType() - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
getObjectType() - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
getOnNoTokenPolicy() - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
getOnNoTokenPolicy() - Method in interface org.mule.security.oauth.OnNoTokenPolicyAware
 
getOperation() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getOperation() - Method in class org.mule.module.cxf.component.WebServiceWrapperComponent
Deprecated.
 
getOperation(String) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
getOperation(MuleEvent) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
getOperation() - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
getOperation() - Method in class org.mule.module.extension.internal.runtime.DefaultOperationContext
 
getOperation() - Method in class org.mule.module.ws.consumer.WSConsumer
 
getOperation() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
getOperationMethod(Class<?>, Operation) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
getOperationMethods(Class<?>) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
getOperationOptions() - Method in class org.mule.module.http.internal.request.client.HttpRequestCacheKey
 
getOperationResourceFactory() - Method in class org.mule.transport.AbstractConnector
 
getOperationResourceFactory() - Method in class org.mule.transport.jdbc.JdbcConnector
 
getOperationResourceFactory() - Method in class org.mule.transport.jms.JmsConnector
 
getOperationResourceFactory() - Method in class org.mule.transport.vm.VMConnector
 
getOppositeLifecyclePhase() - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
getOppositeLifecyclePhase() - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
getOptionalObjectsController() - Method in class org.mule.config.spring.MuleArtifactContext
 
getOptionalObjectsController() - Method in class org.mule.config.spring.SpringRegistryBootstrap
 
getOptionalParams() - Method in class org.mule.transport.http.components.RestServiceWrapper
Optional params that are pulled from the message.
getOrBuildInboundEndpoint(MuleContext) - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundEndpointBuilder
 
getOrBuildOutboundEndpoint(MuleContext) - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundAndOutboundEndpointBuilder
 
getOrCreateAxisComponent() - Method in class org.mule.transport.soap.axis.AxisConnector
 
getOrCreateConnectorByProtocol(ImmutableEndpoint) - Method in class org.mule.transport.service.TransportFactory
 
getOrCreateConnectorByProtocol(EndpointURI) - Method in class org.mule.transport.service.TransportFactory
Returns an initialized connector.
getOrCreateMBeanServer() - Static method in class org.mule.module.management.mbean.MBeanServerFactory
 
getOrCreateServletConnector(String) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
getOrder() - Method in class org.mule.api.transport.PropertyScope
 
getOrderedLifecycleObjects() - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
getOrderedLifecycleObjects() - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
getOriginalEvent() - Method in class org.mule.api.routing.AggregationContext
 
getOriginalMessage() - Method in interface org.mule.execution.FlowProcessingPhaseTemplate
 
getOriginalMessage() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
getOriginalPayload() - Method in interface org.mule.api.MuleMessage
Returns the original payload used to create this message.
getOriginalPayload() - Method in class org.mule.DefaultMuleMessage
Returns the original payload used to create this message.
getOrphanBeanAssembler(Element, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.AbstractHierarchicalDefinitionParser
Deprecated. 
getOrphanFlowVariables() - Method in class org.mule.DefaultMuleMessage
 
getOrphanFlowVariables() - Method in class org.mule.MessagePropertiesContext
 
getOsArch() - Method in class org.mule.el.context.ServerContext
 
getOsName() - Method in class org.mule.el.context.ServerContext
 
getOsVersion() - Method in class org.mule.el.context.ServerContext
 
getOsVersion() - Method in class org.mule.module.management.mbean.MuleService
 
getOsVersion() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getOtherwise() - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
getOut() - Method in class org.mule.transport.http.multipart.MultiPartOutputStream
 
getOutboundAttachment(String) - Method in interface org.mule.api.MuleMessage
Retrieve an attachment with the given name.
getOutboundAttachment(String) - Method in class org.mule.DefaultMuleMessage
 
getOutboundAttachmentNames() - Method in interface org.mule.api.MuleMessage
 
getOutboundAttachmentNames() - Method in class org.mule.DefaultMuleMessage
 
getOutboundAttachments() - Method in class org.mule.el.context.MessageContext
 
getOutboundEndpoint(String, MessageExchangePattern, Long) - Method in interface org.mule.api.endpoint.EndpointCache
 
getOutboundEndpoint(String) - Method in interface org.mule.api.endpoint.EndpointFactory
Creates an endpoint with the "OUTBOUND" role.
getOutboundEndpoint(EndpointBuilder) - Method in interface org.mule.api.endpoint.EndpointFactory
Creates an endpoint with the "OUTBOUND" role using the builder provided.
getOutboundEndpoint(EndpointURI) - Method in interface org.mule.api.endpoint.EndpointFactory
Deprecated. 
getOutboundEndpoint(String) - Method in class org.mule.endpoint.DefaultEndpointFactory
 
getOutboundEndpoint(EndpointBuilder) - Method in class org.mule.endpoint.DefaultEndpointFactory
 
getOutboundEndpoint(EndpointURI) - Method in class org.mule.endpoint.DefaultEndpointFactory
 
getOutboundEndpoint(String, MessageExchangePattern, Long) - Method in class org.mule.endpoint.SimpleEndpointCache
 
getOutboundEndpoint(String, MessageExchangePattern, Integer) - Method in class org.mule.module.client.MuleClient
 
getOutboundEndpoint(String) - Method in class org.mule.transport.quartz.jobs.ScheduledDispatchJob
 
getOutboundEndpointFactoryBeanClass() - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
getOutboundExchangePatterns() - Method in interface org.mule.api.transport.Connector
 
getOutboundExchangePatterns() - Method in class org.mule.transport.AbstractConnector
 
getOutboundExchangePatterns() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
getOutboundExchangePatterns() - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
getOutboundMessageExchangePattern() - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundAndOutboundEndpointBuilder
 
getOutboundMessageExchangePattern() - Method in class org.mule.construct.builder.BridgeBuilder
 
getOutboundMessageExchangePattern() - Method in class org.mule.construct.builder.ValidatorBuilder
 
getOutboundMessageExchangePattern() - Method in class org.mule.module.ws.construct.builder.WSProxyBuilder
 
getOutboundMessageExchangePattern() - Method in class org.mule.transport.http.construct.builder.HttpProxyBuilder
 
getOutboundMessageProcessor() - Method in interface org.mule.api.service.Service
Deprecated.
Outbound Routers control how events are published by a service once.
getOutboundMessageProcessor() - Method in class org.mule.service.AbstractService
Deprecated.
 
getOutboundProperties() - Method in class org.mule.el.context.MessageContext
 
getOutboundProperty(String, T) - Method in interface org.mule.api.MuleMessage
 
getOutboundProperty(String) - Method in interface org.mule.api.MuleMessage
 
getOutboundProperty(String, T) - Method in class org.mule.DefaultMuleMessage
 
getOutboundProperty(String) - Method in class org.mule.DefaultMuleMessage
 
getOutboundPropertyNames() - Method in interface org.mule.api.MuleMessage
 
getOutboundPropertyNames() - Method in class org.mule.DefaultMuleMessage
 
getOutboundRouterStat() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
getOutboundTransformer() - Method in class org.mule.transformer.wire.TransformerPairWireFormat
 
getOutFaultInterceptors() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getOutFaultInterceptors() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getOutInterceptors() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getOutInterceptors() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getOutput() - Method in class com.javaforge.bobber.archetype.model.Template
Get the output field.
getOutputClass() - Method in class org.mule.transformer.TransformerWeighting
 
getOutputEncoding() - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
getOutputFormat() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
getOutputMessage() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
getOutputMessageCode() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
getOutputMetaData(MetaData) - Method in class org.mule.module.db.internal.metadata.AbstractQueryMetadataProvider
 
getOutputMetaData(MetaData) - Method in class org.mule.module.db.internal.metadata.BulkExecuteMetadataProvider
 
getOutputMetaData(MetaData) - Method in class org.mule.module.db.internal.metadata.NullMetadataProvider
 
getOutputMetaData(MetaData) - Method in interface org.mule.module.db.internal.metadata.QueryMetadataProvider
Provides output metadata
getOutputMetaData(MetaData) - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
getOutputParams() - Method in class org.mule.module.db.internal.domain.query.QueryTemplate
Returns the output parameter definitions.
getOutputPattern() - Method in class org.mule.transport.file.FileConnector
 
getOutputPattern() - Method in class org.mule.transport.ftp.FtpConnector
 
getOutputPattern() - Method in class org.mule.transport.sftp.SftpConnector
 
getOutputStream() - Method in interface org.mule.api.MuleEvent
An outputstream the can optionally be used write response data to an incoming message.
getOutputStream() - Method in interface org.mule.api.MuleEventContext
An outputstream the can optionally be used write response data to an incoming message.
getOutputStream(OutboundEndpoint, MuleEvent) - Method in interface org.mule.api.transport.Connector
Will get the output stream for this type of transport.
getOutputStream() - Method in class org.mule.DefaultMuleEvent
An output stream can optionally be used to write response data to an incoming message.
getOutputStream() - Method in class org.mule.DefaultMuleEventContext
An outputstream the can optionally be used write response data to an incoming message.
getOutputStream() - Method in class org.mule.message.ds.ByteArrayDataSource
 
getOutputStream() - Method in class org.mule.message.ds.InputStreamDataSource
 
getOutputStream() - Method in class org.mule.message.ds.StringDataSource
 
getOutputStream() - Method in class org.mule.module.cxf.support.DelegatingOutputStream
 
getOutputStream() - Method in class org.mule.module.http.internal.multipart.HttpPartDataSource
 
getOutputStream(OutboundEndpoint, MuleEvent) - Method in class org.mule.transport.AbstractConnector
Will get the output stream for this type of transport.
getOutputStream() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
getOutputStream() - Method in class org.mule.transport.email.transformers.PlainTextDataSource
 
getOutputStream() - Method in class org.mule.transport.file.FileConnector
 
getOutputStream(OutboundEndpoint, MuleEvent) - Method in class org.mule.transport.file.FileConnector
Well get the output stream (if any) for this type of transport.
getOutputStream(OutboundEndpoint, MuleEvent) - Method in class org.mule.transport.ftp.FtpConnector
Well get the output stream (if any) for this type of transport.
getOutputStream() - Method in class org.mule.transport.http.HttpServerConnection
 
getOutputStream() - Method in class org.mule.transport.http.multipart.PartDataSource
 
getOutputStream() - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
getOutputStream() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
getOutputStream(ImmutableEndpoint, MuleMessage) - Method in class org.mule.transport.stdio.PromptStdioConnector
 
getOutputStream() - Method in class org.mule.transport.stdio.StdioConnector
 
getOutputStream(ImmutableEndpoint, MuleMessage) - Method in class org.mule.transport.tcp.TcpConnector
 
getOutputStream() - Method in class org.mule.VoidMuleEvent
 
getOutputType() - Method in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
 
getOutputWeighting() - Method in class org.mule.transformer.TransformerWeighting
 
getOverrideHost() - Method in class org.mule.module.management.agent.FixedHostRmiClientSocketFactory
Deprecated.
Getter for property 'overrideHost'.
getOwnedMessageProcessors() - Method in class org.mule.enricher.MessageEnricher
 
getOwnedMessageProcessors() - Method in class org.mule.exception.AbstractExceptionListener
 
getOwnedMessageProcessors() - Method in class org.mule.exception.RollbackMessagingExceptionStrategy
 
getOwnedMessageProcessors() - Method in class org.mule.processor.AbstractMessageProcessorOwner
 
getOwnedMessageProcessors() - Method in class org.mule.processor.AsyncDelegateMessageProcessor
 
getOwnedMessageProcessors() - Method in class org.mule.routing.Foreach
 
getOwnedMessageProcessors() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
getOwnedMessageProcessors() - Method in class org.mule.routing.ScatterGatherRouter
 
getOwnedMessageProcessors() - Method in class org.mule.routing.WireTap
 
getOwnedMessageProcessors() - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
getOwnedObjects() - Method in class org.mule.exception.ChoiceMessagingExceptionStrategy
 
getOwnedObjects() - Method in class org.mule.exception.MessagingExceptionStrategyAcceptorDelegate
 
getOwnedObjects() - Method in class org.mule.processor.AbstractMessageProcessorOwner
 
getOwnedObjects() - Method in class org.mule.processor.AbstractMuleObjectOwner
 
getOwner() - Method in class org.mule.module.launcher.util.DebuggableReentrantLock
 
getOwnerName() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getPackageNames() - Method in class org.mule.module.xml.config.JaxbContextFactoryBean
 
getPackagesToScan() - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
getPage() - Method in class org.mule.streaming.PagingDelegate
Returns the next page of items.
getPage() - Method in class org.mule.streaming.PagingDelegateWrapper
Returns the next page of items.
getPage() - Method in class org.mule.streaming.processor.ManagedPagingDelegateAdapter
Returns the next page of items.
getPage(P) - Method in class org.mule.streaming.ProviderAwarePagingDelegate
Returns the next page of items.
getPagingDelegate(MuleEvent, PagingConfiguration) - Method in class org.mule.streaming.processor.AbstractDevkitBasedPageableMessageProcessor
Implement this method to return the PagingDelegate to be used when paging.
getParamAnnotations(Method) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
getParamAnnotations() - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
getParamAnnotationsWithMeta(Method, Class<? extends Annotation>) - Static method in class org.mule.util.annotation.AnnotationUtils
 
getParameter(String) - Method in class org.mule.module.atom.server.MuleRequestContext
 
getParameter(String) - Method in class org.mule.transport.http.ntlm.NTLMScheme
Returns the authentication parameter with the given name, if available.
getParameter(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getParameterAnnotation(Class<T>) - Method in class org.mule.util.generics.MethodParameter
Return the parameter annotation of the given type, if available.
getParameterAnnotations() - Method in class org.mule.util.generics.MethodParameter
Return the annotations associated with the specific method/constructor parameter.
getParameterExtractors() - Method in class org.mule.module.oauth2.internal.authorizationcode.TokenResponseConfiguration
 
getParameterFields(Class<?>) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
getParameterGroupFields(Class<?>) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
getParameterIndex() - Method in class org.mule.util.generics.MethodParameter
Return the index of the method/constructor parameter.
getParameterMap() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getParameterName() - Method in class org.mule.util.generics.MethodParameter
Return the name of the method/constructor parameter.
getParameterNames() - Method in class org.mule.module.atom.server.MuleRequestContext
 
getParameterNames() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getParameterNames(Method) - Method in interface org.mule.util.generics.ParameterNameDiscoverer
Return parameter names for this method, or null if they cannot be determined.
getParameterNames(Constructor) - Method in interface org.mule.util.generics.ParameterNameDiscoverer
Return parameter names for this constructor, or null if they cannot be determined.
getParameterNames(Constructor) - Method in class org.mule.util.ParamReader
return the names of the declared parameters for the given constructor.
getParameterNames(Method) - Method in class org.mule.util.ParamReader
return the names of the declared parameters for the given method.
getParameterNames(Member, Class[]) - Method in class org.mule.util.ParamReader
 
getParameterNamesFromDebugInfo(Method) - Static method in class org.mule.util.ParamReader
Retrieve a list of function parameter names from a method Returns null if unable to read parameter names (i.e.
getParameters(String) - Method in class org.mule.module.atom.server.MuleRequestContext
 
getParameters() - Method in class org.mule.module.extension.internal.introspection.ParameterGroup
 
getParameterType() - Method in class org.mule.util.generics.MethodParameter
Return the type of the method/constructor parameter.
getParameterTypes(DbConnection, QueryTemplate) - Method in class org.mule.module.db.internal.resolver.param.DefaultParamTypeResolver
 
getParameterTypes(DbConnection, QueryTemplate) - Method in interface org.mule.module.db.internal.resolver.param.ParamTypeResolver
Resolves actual parameter types
getParameterTypes(DbConnection, QueryTemplate) - Method in class org.mule.module.db.internal.resolver.param.QueryParamTypeResolver
 
getParameterTypes(DbConnection, QueryTemplate) - Method in class org.mule.module.db.internal.resolver.param.StoredProcedureParamTypeResolver
 
getParameterTypes(Object, String) - Static method in class org.mule.util.ClassUtils
 
getParameterValue(CallableStatement, int) - Method in class org.mule.module.db.internal.domain.type.ArrayResolvedDbType
 
getParameterValue(CallableStatement, int) - Method in interface org.mule.module.db.internal.domain.type.DbType
Gets the value of an output parameter
getParameterValue(CallableStatement, int) - Method in class org.mule.module.db.internal.domain.type.DynamicDbType
 
getParameterValue(CallableStatement, int) - Method in class org.mule.module.db.internal.domain.type.MappedStructResolvedDbType
 
getParameterValue(CallableStatement, int) - Method in class org.mule.module.db.internal.domain.type.oracle.OracleXmlType
 
getParameterValue(CallableStatement, int) - Method in class org.mule.module.db.internal.domain.type.ResolvedDbType
 
getParameterValue(CallableStatement, int) - Method in class org.mule.module.db.internal.domain.type.UnknownDbType
 
getParameterValue(String) - Method in class org.mule.module.extension.internal.runtime.DefaultOperationContext
 
getParameterValues(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getParamName() - Method in class org.mule.module.oauth2.internal.ParameterExtractor
 
getParamNames(Method) - Static method in class org.mule.module.extension.internal.introspection.MuleExtensionAnnotationParser
 
getParamResolverBeanDefinition() - Method in class org.mule.module.db.internal.config.processor.AbstractSingleQueryProcessorDefinitionParser
 
getParamResolverBeanDefinition() - Method in class org.mule.module.db.internal.config.processor.PreparedBulkUpdateProcessorBeanDefinitionParser
 
getParams() - Method in class org.apache.commons.httpclient.HttpConnection
Returns HTTP protocol parameters associated with this method.
getParams() - Method in interface org.mule.api.endpoint.EndpointURI
 
getParams() - Method in class org.mule.endpoint.MuleEndpointURI
 
getParams() - Method in class org.mule.module.db.internal.domain.query.QueryTemplate
 
getParams(ImmutableEndpoint, List, MuleMessage, String) - Method in class org.mule.transport.jdbc.JdbcConnector
 
getParams() - Method in class org.mule.util.scan.annotations.AnnotationInfo
Deprecated.
 
getParamsAsMap() - Method in class org.mule.util.scan.annotations.AnnotationInfo
Deprecated.
 
getParamTypes(QueryTemplate) - Method in class org.mule.module.db.internal.domain.connection.AbstractDbConnection
 
getParamTypes(QueryTemplate) - Method in interface org.mule.module.db.internal.domain.connection.DbConnection
Determines actual parameter types for the parameters defined in a query template.
getParamTypesUsingMetadata(DbConnection, QueryTemplate) - Method in class org.mule.module.db.internal.resolver.param.DefaultParamTypeResolver
 
getParamValue(ImmutableEndpoint, MuleMessage, String) - Method in class org.mule.transport.jdbc.JdbcConnector
 
getParamValues() - Method in class org.mule.module.db.internal.domain.query.Query
 
getParent() - Method in class org.mule.api.processor.DefaultMessageProcessorPathElement
 
getParent() - Method in interface org.mule.api.processor.MessageProcessorPathElement
 
getParent() - Method in class org.mule.module.jbpm.EndedProcess
 
getParentBeanDefinition(Element) - Method in class org.mule.config.spring.parsers.AbstractHierarchicalDefinitionParser
 
getParentBeanDefinition(Element) - Method in class org.mule.config.spring.parsers.generic.OptionalChildDefinitionParser
 
getParentBeanName(Element) - Method in class org.mule.config.spring.parsers.AbstractHierarchicalDefinitionParser
 
getParentBeanName(Element) - Method in class org.mule.config.spring.parsers.generic.DescendentDefinitionParser
 
getParentBeanName(Element) - Method in class org.mule.config.spring.parsers.generic.GrandchildDefinitionParser
 
getParentBeanName(Element) - Method in class org.mule.config.spring.parsers.generic.NamedDefinitionParser
 
getParentBeanName(Element) - Method in class org.mule.config.spring.parsers.specific.ConfigurationChildDefinitionParser
 
getParentContext() - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
getParentLogger() - Method in class org.mule.module.db.internal.domain.xa.DataSourceWrapper
 
getParentLogger() - Method in class org.mule.transport.jdbc.xa.DataSourceWrapper
 
getParentName() - Method in class org.mule.config.support.InheritedModel
Deprecated.
 
getParserConfiguration() - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
getParserContext() - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
getParseResponse() - Method in interface org.mule.module.http.api.requester.HttpRequesterConfig
 
getParseResponse() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getPart() - Method in class org.mule.module.http.internal.multipart.HttpPartDataSource
 
getPart(int) - Method in class org.mule.routing.outbound.SplitMessage
 
getPart() - Method in class org.mule.routing.outbound.SplitMessage.MessagePart
 
getPart(String) - Method in class org.mule.transport.http.multipart.MultiPartInputStream
 
getPart() - Method in class org.mule.transport.http.multipart.PartDataSource
 
getPart(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getPartitionName() - Method in class org.mule.util.store.ObjectStorePartition
 
getPartitionName() - Method in class org.mule.util.store.PersistentObjectStorePartition
 
getParts() - Method in class org.mule.module.http.internal.domain.MultipartHttpEntity
 
getParts() - Method in class org.mule.transport.http.multipart.MultiPartInputStream
 
getParts() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getPassphrase() - Method in class org.mule.transport.sftp.SftpConnector
 
getPassphrase() - Method in class org.mule.transport.sftp.SftpUtil
 
getPassword() - Method in interface org.mule.api.endpoint.EndpointURI
Returns the decoded password component of this EndpointURI.
getPassword() - Method in interface org.mule.api.security.Credentials
 
getPassword() - Method in class org.mule.endpoint.MuleEndpointURI
 
getPassword() - Method in class org.mule.endpoint.URIBuilder
 
getPassword() - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
getPassword() - Method in interface org.mule.module.http.api.requester.proxy.ProxyConfig
 
getPassword() - Method in class org.mule.module.http.internal.domain.request.HttpRequestAuthentication
 
getPassword() - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
getPassword() - Method in class org.mule.module.http.internal.request.DefaultProxyConfig
 
getPassword() - Method in class org.mule.module.management.agent.Mx4jAgent
 
getPassword() - Method in class org.mule.module.ws.security.WssUsernameTokenSecurityStrategy
 
getPassword() - Method in class org.mule.security.MuleCredentials
 
getPassword() - Method in class org.mule.security.UsernamePasswordAuthenticationFilter
 
getPassword() - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
getPassword() - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
getPassword() - Method in class org.mule.transport.jms.CustomCachingConnectionFactory
 
getPassword() - Method in class org.mule.transport.jms.JmsConnector
 
getPassword() - Method in class org.mule.transport.sftp.config.SftpProxyConfig
 
getPassword() - Method in class org.mule.transport.xmpp.XmppConnector
 
getPasswordType() - Method in class org.mule.module.ws.security.WssUsernameTokenSecurityStrategy
 
getPath() - Method in interface org.mule.api.endpoint.EndpointURI
 
getPath() - Method in class org.mule.api.processor.DefaultMessageProcessorPathElement
 
getPath() - Method in interface org.mule.api.processor.MessageProcessorPathElement
 
getPath() - Method in enum org.mule.api.registry.ServiceType
 
getPath() - Method in class org.mule.endpoint.MuleEndpointURI
 
getPath() - Method in class org.mule.endpoint.URIBuilder
 
getPath() - Method in interface org.mule.module.http.api.listener.HttpListener
 
getPath() - Method in class org.mule.module.http.internal.domain.request.DefaultHttpRequest
 
getPath() - Method in interface org.mule.module.http.internal.domain.request.HttpRequest
 
getPath() - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
getPath() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyHttpRequestAdapter
 
getPath() - Method in class org.mule.module.http.internal.listener.matcher.ListenerRequestMatcher
 
getPath() - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
getPath() - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
Retrieves path
getPath() - Method in interface org.mule.security.oauth.callback.HttpCallbackAdapter
Retrieves path
getPathInfo() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getPathInJar() - Method in class org.mule.module.management.agent.Mx4jAgent
 
getPathTranslated() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getPattern() - Method in class org.mule.module.sxc.SxcFilter
 
getPattern() - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
getPattern() - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
getPattern() - Method in class org.mule.module.xml.filters.XPathFilter
 
getPattern() - Method in class org.mule.routing.filters.EqualsFilter
 
getPattern() - Method in class org.mule.routing.filters.MessagePropertyFilter
 
getPattern() - Method in class org.mule.routing.filters.RegExFilter
 
getPattern() - Method in class org.mule.routing.filters.WildcardFilter
 
getPattern() - Method in exception org.mule.security.oauth.exception.AuthorizationCodeNotFoundException
 
getPattern() - Method in class org.mule.transport.jms.filters.JmsPropertyFilter
Sets the regex pattern to match on
getPattern() - Method in class org.mule.transport.xmpp.filters.XmppFromContainsFilter
 
getPattern() - Method in class org.mule.util.TemplateParser.PatternInfo
 
getPayload() - Method in interface org.mule.api.MuleMessage
 
getPayload(Class<T>) - Method in interface org.mule.api.MuleMessage
Will attempt to obtain the payload of this message with the desired Class type.
getPayload(DataType<T>) - Method in interface org.mule.api.MuleMessage
Will attempt to obtain the payload of this message with the desired Class type.
getPayload(Class) - Method in class org.mule.DefaultMessageCollection
Applies the MuleMessage.getPayload(Class) call to every message in the collection and returns a List of results.
getPayload(Class<T>) - Method in class org.mule.DefaultMuleMessage
Will attempt to obtain the payload of this message with the desired Class type.
getPayload(DataType<T>) - Method in class org.mule.DefaultMuleMessage
Will attempt to obtain the payload of this message with the desired Class type.
getPayload(DataType<T>, String) - Method in class org.mule.DefaultMuleMessage
Will attempt to obtain the payload of this message with the desired Class type.
getPayload() - Method in class org.mule.DefaultMuleMessage
getPayload() - Method in class org.mule.el.context.MessageContext
 
getPayload() - Method in class org.mule.message.ExceptionMessage
 
getPayload() - Method in class org.mule.module.cxf.builder.ProxyClientMessageProcessorBuilder
 
getPayload() - Method in class org.mule.module.cxf.builder.ProxyServiceMessageProcessorBuilder
 
getPayload() - Method in class org.mule.transport.quartz.jobs.EventGeneratorJobConfig
 
getPayloadAsBytes() - Method in interface org.mule.api.MuleMessage
Converts the message implementation into a byte array representation
getPayloadAsBytes() - Method in class org.mule.DefaultMessageCollection
Converts the message implementation into a byte array representation
getPayloadAsBytes() - Method in class org.mule.DefaultMuleMessage
Converts the message implementation into a byte array representation
getPayloadAsString(String) - Method in interface org.mule.api.MuleMessage
Converts the message implementation into a String representation
getPayloadAsString() - Method in interface org.mule.api.MuleMessage
Converts the message implementation into a String representation.
getPayloadAsString(String) - Method in class org.mule.DefaultMessageCollection
Converts the message implementation into a String representation
getPayloadAsString() - Method in class org.mule.DefaultMuleMessage
Converts the message implementation into a String representation.
getPayloadAsString(String) - Method in class org.mule.DefaultMuleMessage
Converts the message implementation into a String representation
getPayloadBodyPart(Object, String) - Method in class org.mule.transport.email.transformers.ObjectToMimeMessage
 
getPayloadClass() - Method in class org.mule.module.jbpm.MuleReceiveActivity
 
getPayloadExpression() - Method in class org.mule.module.jbpm.MuleSendActivity
 
getPayloadForLogging() - Method in interface org.mule.api.MuleMessage
Get the message payload for logging without throwing exception Converts the message implementation into a String representation.
getPayloadForLogging(String) - Method in interface org.mule.api.MuleMessage
Get the message payload for logging without throwing exception Converts the message implementation into a String representation.
getPayloadForLogging(String) - Method in class org.mule.DefaultMessageCollection
Get the message payload for logging without throwing exception Converts the message implementation into a String representation.
getPayloadForLogging() - Method in class org.mule.DefaultMessageCollection
Get the message payload for logging without throwing exception Converts the message implementation into a String representation.
getPayloadForLogging(String) - Method in class org.mule.DefaultMuleMessage
Get the message payload for logging without throwing exception Converts the message implementation into a String representation.
getPayloadForLogging() - Method in class org.mule.DefaultMuleMessage
Get the message payload for logging without throwing exception Converts the message implementation into a String representation.
getPayloadForMethod(Method, Object, MuleEventContext) - Method in class org.mule.impl.model.resolvers.AnnotatedEntryPointResolver
 
getPayloadForXPath(MuleMessage) - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
getPayloadForXPath(MuleMessage) - Method in class org.mule.module.xml.expression.BeanPayloadExpressionEvaluator
Deprecated.
 
getPayloadFromMessage(MuleEventContext) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
getPayloadFromMessage(MuleEventContext) - Method in class org.mule.model.resolvers.ArrayEntryPointResolver
 
getPayloadFromMessage(MuleEventContext) - Method in class org.mule.model.resolvers.NoArgumentsEntryPointResolver
 
getPayloadFromMessageWithAnnotations(Method, MuleEventContext) - Method in class org.mule.impl.model.resolvers.AnnotatedEntryPointResolver
 
getPayloadList() - Method in class org.mule.DefaultMessageCollection
 
getPayloadParameterNames() - Method in class org.mule.transport.http.components.RestServiceWrapper
 
getPayloadsAsArray() - Method in interface org.mule.api.MuleMessageCollection
 
getPayloadsAsArray() - Method in class org.mule.DefaultMessageCollection
 
getPayloadToArguments() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getPayloadToArguments() - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
getPayloadToArgumentsParameterValue() - Method in enum org.mule.module.cxf.CxfPayloadToArguments
 
getPayloadToString() - Method in class org.mule.api.context.notification.ServerNotification
 
getPayloadToString() - Method in class org.mule.context.notification.BaseConnectorMessageNotification
 
getPayloadToString() - Method in class org.mule.context.notification.ComponentMessageNotification
 
getPayloadToString() - Method in class org.mule.context.notification.ConnectionNotification
 
getPayloadToString() - Method in class org.mule.context.notification.MuleContextNotification
 
getPayloadToString() - Method in class org.mule.context.notification.RoutingNotification
 
getPayloadToString() - Method in class org.mule.transport.sftp.notification.SftpTransportNotification
 
getPeerCertificateChain() - Method in class org.mule.transport.http.HttpServerConnection
 
getPeople() - Method in interface org.mule.tck.testmodels.services.PeopleService
 
getPeople() - Method in class org.mule.tck.testmodels.services.TestServiceComponent
 
getPersistentDelivery(MuleMessage) - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
getPerson(String) - Method in interface org.mule.tck.testmodels.services.PeopleService
 
getPerson() - Method in class org.mule.tck.testmodels.services.PersonResponse
 
getPerson(String) - Method in class org.mule.tck.testmodels.services.TestServiceComponent
 
getPhrase() - Method in class org.mule.transport.http.HttpResponse
 
getPIData() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getPIData() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getPITarget() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getPITarget() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getPluginClassLoaders() - Method in class org.mule.module.launcher.MulePluginClassLoaderManager
 
getPluginClassLoaders() - Method in interface org.mule.module.launcher.PluginClassLoaderManager
Immutable list of current plugin classloaders
getPlugins() - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
getPluginsDir() - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
getPolledMessageProcessor() - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
getPollingFrequency() - Method in class org.mule.transport.file.FileConnector
 
getPollingFrequency() - Method in class org.mule.transport.ftp.FtpConnector
 
getPollingFrequency() - Method in class org.mule.transport.http.HttpPollingConnector
 
getPollingFrequency() - Method in class org.mule.transport.http.HttpsPollingConnector
 
getPollingFrequency() - Method in class org.mule.transport.jdbc.JdbcConnector
 
getPollingFrequency() - Method in class org.mule.transport.rmi.RmiConnector
 
getPollingFrequency() - Method in class org.mule.transport.sftp.SftpConnector
 
getPollingFrequency() - Method in class org.mule.transport.tcp.PollingTcpConnector
 
getPooledObjectFactory() - Method in class org.mule.util.pool.CommonsPoolObjectPool
Template method to be overridden by implementations that do more than just invoke objectFactory
getPooledObjectFactory() - Method in class org.mule.util.pool.DefaultLifecycleEnabledObjectPool
 
getPoolExhaustedAction() - Method in interface org.mule.api.config.ThreadingProfile
 
getPoolExhaustedAction() - Method in class org.mule.config.ChainedThreadingProfile
 
getPoolExhaustedAction() - Method in class org.mule.config.ImmutableThreadingProfile
 
getPoolExhaustedAction() - Method in class org.mule.config.MutableThreadingProfile
 
getPoolExhaustedAction() - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
getPoolFactory() - Method in interface org.mule.api.config.ThreadingProfile
 
getPoolFactory() - Method in class org.mule.config.ChainedThreadingProfile
 
getPoolFactory() - Method in class org.mule.config.ImmutableThreadingProfile
 
getPoolFactory() - Method in class org.mule.config.MutableThreadingProfile
 
getPoolingProfile() - Method in class org.mule.component.PooledJavaComponent
 
getPoolingProfile() - Method in class org.mule.model.seda.SedaModel
Deprecated.
 
getPoolingProfile() - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
getPort() - Method in class org.apache.commons.httpclient.HttpConnection
Returns the port of the host.
getPort() - Method in interface org.mule.api.endpoint.EndpointURI
 
getPort() - Method in class org.mule.endpoint.MuleEndpointURI
 
getPort() - Method in class org.mule.endpoint.URIBuilder
 
getPort() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getPort() - Method in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
getPort() - Method in class org.mule.module.cxf.builder.WsdlClientMessageProcessorBuilder
 
getPort() - Method in class org.mule.module.db.internal.config.domain.database.AbstractVendorConfigResolverFactoryBean
 
getPort() - Method in interface org.mule.module.http.api.listener.HttpListenerConfig
 
getPort() - Method in interface org.mule.module.http.api.requester.HttpRequesterConfig
 
getPort() - Method in interface org.mule.module.http.api.requester.proxy.ProxyConfig
 
getPort() - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
getPort() - Method in class org.mule.module.http.internal.listener.ServerAddress
 
getPort() - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
getPort() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getPort() - Method in class org.mule.module.http.internal.request.DefaultProxyConfig
 
getPort() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
getPort() - Method in class org.mule.module.management.agent.JdmkAgent
 
getPort() - Method in class org.mule.module.management.agent.Mx4jAgent
 
getPort() - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
getPort() - Method in class org.mule.module.management.mbean.YourKitProfilerService
getPort() - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
getPort() - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
getPort() - Method in class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
getPort() - Method in class org.mule.transport.jdbc.config.OracleDataSourceFactoryBean
 
getPort() - Method in class org.mule.transport.servlet.jetty.WebappsConfiguration
 
getPort() - Method in class org.mule.transport.sftp.config.SftpProxyConfig
 
getPort() - Method in class org.mule.transport.tcp.TcpSocketKey
 
getPort() - Method in class org.mule.transport.xmpp.XmppConnector
 
getPostcode() - Method in class org.mule.tck.testmodels.services.Address
 
getPostfix() - Method in class org.mule.component.simple.StaticComponent
 
getPostNotification() - Method in class org.mule.lifecycle.LifecycleObject
 
getPostNotificationName() - Method in class org.mule.lifecycle.NotificationLifecycleObject
 
getPreemptive() - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
getPreferredAuthenticationMethods() - Method in class org.mule.transport.sftp.SftpConnector
 
getPreferredLocale() - Method in class org.mule.module.atom.server.MuleRequestContext
 
getPreferredLocales() - Method in class org.mule.module.atom.server.MuleRequestContext
 
getPrefix() - Method in class org.mule.component.simple.StaticComponent
 
getPrefix() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getPrefix(String) - Method in class org.mule.module.xml.stax.MapNamespaceContext
 
getPrefix() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getPrefix(MuleContext) - Static method in class org.mule.util.concurrent.ThreadNameHelper
Generate a generic thread name prefix for this context.
getPrefix() - Method in class org.mule.util.TemplateParser.PatternInfo
 
getPrefixes(String) - Method in class org.mule.module.xml.stax.MapNamespaceContext
 
getPreNotification() - Method in class org.mule.lifecycle.LifecycleObject
 
getPreNotificationName() - Method in class org.mule.lifecycle.NotificationLifecycleObject
 
getPreparedStatementCacheSize() - Method in class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
getPrincipal() - Method in interface org.mule.api.security.Authentication
 
getPrincipal() - Method in class org.mule.module.jaas.JaasAuthentication
 
getPrincipal() - Method in class org.mule.module.pgp.PGPAuthentication
 
getPrincipal() - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
getPrincipal() - Method in class org.mule.security.DefaultMuleAuthentication
 
getPriority() - Method in class org.mule.module.jbpm.EndedProcess
 
getPriority(MuleMessage) - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
getPriority(Object) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Return the priority assigned for the given bean instance by the javax.annotation.Priority annotation.
getPriorityWeighting() - Method in interface org.mule.api.transformer.Converter
If two or more discoverable transformers are equal, this value can be used to select the correct one
getPriorityWeighting() - Method in class org.mule.config.transformer.AnnotatedTransformerProxy
 
getPriorityWeighting() - Method in class org.mule.module.json.transformers.AbstractJsonTransformer
 
getPriorityWeighting() - Method in class org.mule.module.xml.transformer.DomDocumentToXml
 
getPriorityWeighting() - Method in class org.mule.module.xml.transformer.XmlToDomDocument
 
getPriorityWeighting() - Method in class org.mule.module.xml.transformer.XmlToOutputHandler
 
getPriorityWeighting() - Method in class org.mule.module.xml.transformer.XmlToXMLStreamReader
 
getPriorityWeighting() - Method in class org.mule.transformer.AbstractDiscoverableTransformer
 
getPriorityWeighting() - Method in class org.mule.transformer.CompositeConverter
 
getPriorityWeighting() - Method in class org.mule.transformer.simple.BeanToMap
 
getPriorityWeighting() - Method in class org.mule.transformer.simple.ByteArrayToSerializable
 
getPriorityWeighting() - Method in class org.mule.transformer.simple.MapToBean
 
getPriorityWeighting() - Method in class org.mule.transformer.simple.NumberToString
 
getPriorityWeighting() - Method in class org.mule.transformer.simple.ObjectArrayToString
 
getPriorityWeighting() - Method in class org.mule.transformer.simple.ObjectToOutputHandler
 
getPriorityWeighting() - Method in class org.mule.transformer.simple.ObjectToString
 
getPriorityWeighting() - Method in class org.mule.transformer.simple.PropertyEditorTextToValueTransformer
 
getPriorityWeighting() - Method in class org.mule.transformer.simple.PropertyEditorValueToTextTransformer
 
getPriorityWeighting() - Method in class org.mule.transformer.simple.SerializableToByteArray
 
getPriorityWeighting() - Method in class org.mule.transformer.simple.StringToBoolean
 
getPriorityWeighting() - Method in class org.mule.transformer.simple.StringToNumber
 
getPriorityWeighting() - Method in class org.mule.transport.file.transformers.FileToByteArray
 
getPriorityWeighting() - Method in class org.mule.transport.http.transformers.ServletRequestToOutputHandler
If 2 or more discoverable transformers are equal, this value can be used to select the correct one
getPriorityWeighting() - Method in class org.mule.transport.jms.transformers.AbstractJmsTransformer
 
getProbableServices(Definition) - Method in class org.mule.module.cxf.support.ProxyServiceConfiguration
This method returns the list of services that matches with the local part of the service QName.
getProcess() - Method in class org.mule.module.bpm.ProcessComponent
 
getProcessDefinitionId() - Method in class org.mule.module.jbpm.EndedProcess
 
getProcessDefinitions() - Method in class org.mule.module.jbpm.Jbpm
 
getProcessedEvents() - Method in class org.mule.management.stats.ApplicationStatistics
 
getProcessedEvents() - Method in class org.mule.management.stats.FlowConstructStatistics
 
getProcessedEvents() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getProcessedEvents() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
getProcessedEvents() - Method in interface org.mule.module.management.mbean.FlowConstructStatsMBean
 
getProcessEngine() - Method in class org.mule.module.jbpm.Jbpm
 
getProcessId() - Method in class org.mule.test.infrastructure.process.Controller
 
getProcessId() - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
getProcessId() - Method in class org.mule.test.infrastructure.process.UnixController
 
getProcessId() - Method in class org.mule.test.infrastructure.process.WindowsController
 
getProcessIdField() - Method in class org.mule.module.bpm.Process
 
getProcessIdField() - Method in class org.mule.module.bpm.ProcessComponent
 
getProcessingStrategy() - Method in interface org.mule.api.construct.Pipeline
 
getProcessingStrategy() - Method in class org.mule.construct.AbstractPipeline
 
getProcessingStrategy() - Method in class org.mule.processor.AsyncDelegateMessageProcessor
 
getProcessingTime() - Method in interface org.mule.api.MuleEvent
Returns the times spent processing this event (so far)
getProcessingTime() - Method in class org.mule.DefaultMuleEvent
 
getProcessingTime() - Method in class org.mule.VoidMuleEvent
 
getProcessInstance() - Method in class org.mule.module.jbpm.EndedProcess
 
getProcessor() - Method in class org.mule.context.notification.MessageProcessorNotification
 
getProcessorPath(MessageProcessor) - Method in interface org.mule.api.construct.MessageProcessorPathResolver
 
getProcessorPath() - Method in class org.mule.api.context.notification.FlowStackElement
 
getProcessorPath(MessageProcessor) - Method in class org.mule.construct.AbstractPipeline
 
getProcessorPath() - Method in class org.mule.context.notification.MessageProcessorNotification
 
getProcessorPath(MuleEvent, MessageProcessor) - Method in class org.mule.exception.MessagingExceptionLocationProvider
 
getProcessorsTrace() - Method in interface org.mule.api.MuleEvent
Events have a list of message processor paths it went trough so that the execution path of an event can be reconstructed after it has executed.
getProcessorsTrace() - Method in class org.mule.DefaultMuleEvent
 
getProcessorsTrace() - Method in class org.mule.VoidMuleEvent
 
getProcessorTimeWatcher() - Method in interface org.mule.api.MuleContext
 
getProcessorTimeWatcher() - Method in class org.mule.DefaultMuleContext
 
getProcessTemplate() - Method in interface org.mule.api.devkit.ProcessAdapter
 
getProcessTemplate() - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
getProcessTemplate() - Method in interface org.mule.security.oauth.OAuth2Manager
 
getProductDescription() - Static method in class org.mule.config.MuleManifest
 
getProductLicenseInfo() - Static method in class org.mule.config.MuleManifest
 
getProductMoreInfo() - Static method in class org.mule.config.MuleManifest
 
getProductName() - Static method in class org.mule.config.MuleManifest
 
getProductSupport() - Static method in class org.mule.config.MuleManifest
 
getProductUrl() - Static method in class org.mule.config.MuleManifest
 
getProductVersion() - Static method in class org.mule.config.MuleManifest
 
getPromptMessage() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
getPromptMessageCode() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
getProperties() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
Returns any properties set on this endpoint
getProperties() - Method in interface org.mule.api.security.Authentication
 
getProperties() - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
getProperties() - Method in class org.mule.endpoint.AbstractEndpoint
 
getProperties() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getProperties() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getProperties() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getProperties() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getProperties() - Method in class org.mule.message.ExceptionMessage
Returns a map of all properties on this message
getProperties() - Method in class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
Deprecated.
 
getProperties() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getProperties() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getProperties() - Method in class org.mule.module.jaas.JaasAuthentication
 
getProperties() - Method in class org.mule.module.jboss.transaction.JBossArjunaTransactionManagerFactory
 
getProperties() - Method in class org.mule.module.pgp.PGPAuthentication
 
getProperties() - Method in class org.mule.module.scripting.component.Scriptable
 
getProperties() - Method in class org.mule.module.spring.events.MuleApplicationEvent
Deprecated.
 
getProperties() - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
getProperties() - Method in class org.mule.object.AbstractObjectFactory
 
getProperties() - Method in class org.mule.object.JndiObjectFactory
 
getProperties() - Method in class org.mule.security.DefaultMuleAuthentication
 
getProperties() - Method in class org.mule.session.DefaultMuleSession
 
getProperties() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getProperties(Schedule) - Method in class org.mule.transport.quartz.config.ScheduleAnnotationParser
 
getProperties() - Method in class org.mule.transport.soap.axis.AxisStringWriter
 
getProperties() - Method in class org.mule.transport.soap.axis.component.WebServiceWrapperComponent
 
getPropertiesForURI(URI, MuleContext) - Method in class org.mule.endpoint.AbstractEndpointURIBuilder
 
getPropertiesFromQueryString(String) - Static method in class org.mule.util.PropertiesUtils
 
getPropertiesFromString(String, char) - Static method in class org.mule.util.PropertiesUtils
 
getPropertiesWithoutPrefix(Map, String) - Static method in class org.mule.util.PropertiesUtils
 
getPropertiesWithPrefix(Map, String, Map) - Static method in class org.mule.util.PropertiesUtils
Will create a map of properties where the names have a prefix Allows the callee to supply the target map so a comparator can be set
getProperty(Object) - Method in interface org.mule.api.endpoint.ImmutableEndpoint
Retrieves a property set on the endpoint
getProperty(String) - Method in interface org.mule.api.MuleEvent
Deprecated. 
getProperty(String, Object) - Method in interface org.mule.api.MuleEvent
Deprecated. 
getProperty(String) - Method in interface org.mule.api.MuleMessage
Deprecated.
use the overloaded version with an explicit lookup scope. This method will now use only the outbound scope.
getProperty(String, Object) - Method in interface org.mule.api.MuleMessage
Deprecated.
use scope-aware methods instead
getProperty(String, PropertyScope) - Method in interface org.mule.api.MuleMessage
Gets a property from the message with a given scope.
getProperty(String, PropertyScope, T) - Method in interface org.mule.api.MuleMessage
Gets a property from the message with a given scope and provides a default value if the property is not present on the message in the scope specified.
getProperty(String) - Method in interface org.mule.api.MuleSession
Will retrieve a session scope property.
getProperty(Object) - Method in interface org.mule.api.MuleSession
Deprecated.
getProperty(String) - Method in class org.mule.DefaultMuleEvent
Deprecated.
use appropriate scope-aware calls on the MuleMessage (via event.getMessage())
getProperty(String, Object) - Method in class org.mule.DefaultMuleEvent
Deprecated.
use appropriate scope-aware calls on the MuleMessage (via event.getMessage())
getProperty(String) - Method in class org.mule.DefaultMuleMessage
Deprecated.
getProperty(String, Object) - Method in class org.mule.DefaultMuleMessage
Gets a property from the message
getProperty(String, PropertyScope) - Method in class org.mule.DefaultMuleMessage
Gets a property from the message with a given scope.
getProperty(String, PropertyScope, T) - Method in class org.mule.DefaultMuleMessage
Gets a property from the message with a given scope and provides a default value if the property is not present on the message in the scope specified.
getProperty(Object) - Method in class org.mule.endpoint.AbstractEndpoint
 
getProperty(Object) - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getProperty(Object) - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getProperty(Object) - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getProperty(String, PropertyScope, MuleMessage) - Static method in class org.mule.expression.ExpressionUtils
Gets a property or map/list of properties specified by an expression supporting multiple return types as well as all and optional modifiers.
getProperty(String, PropertyScope, MuleMessage, Class<T>) - Static method in class org.mule.expression.ExpressionUtils
Gets a property or map/list of properties specific by an expression supporting multiple return types as well as all and optional modifiers
getProperty(String) - Method in class org.mule.message.ExceptionMessage
 
getProperty(String) - Method in class org.mule.MessagePropertiesContext
Deprecated.
use the overloaded version with an explicit lookup scope. This method will now use only the outbound scope.
getProperty(String, PropertyScope) - Method in class org.mule.MessagePropertiesContext
 
getProperty(String, Object) - Method in class org.mule.MessagePropertiesContext
 
getProperty(RequestContext.Property) - Method in class org.mule.module.atom.server.MuleRequestContext
 
getProperty(String) - Method in class org.mule.module.client.MuleClient
 
getProperty(Object) - Method in class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
Deprecated.
 
getProperty(Object) - Method in class org.mule.module.spring.events.MuleApplicationEvent
Deprecated.
 
getProperty(String) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getProperty(String) - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
getProperty(Object) - Method in class org.mule.session.DefaultMuleSession
Will retrieve a session level property.
getProperty(String) - Method in class org.mule.session.DefaultMuleSession
 
getProperty(Object) - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getProperty(String) - Method in class org.mule.VoidMuleEvent
 
getProperty(String, Object) - Method in class org.mule.VoidMuleEvent
 
getPropertyChangeListeners() - Method in class org.mule.module.launcher.util.ObservableList
 
getPropertyChangeListeners(String) - Method in class org.mule.module.launcher.util.ObservableList
 
getPropertyClass() - Method in class org.mule.transport.jms.filters.JmsPropertyFilter
Returns the class type of the property
getPropertyDataType(String, PropertyScope) - Method in interface org.mule.api.MuleMessage
Gets a property data type from the message with a given scope.
getPropertyDataType(String) - Method in interface org.mule.api.MuleSession
Retrieves a session scope property data type
getPropertyDataType(String, PropertyScope) - Method in class org.mule.DefaultMuleMessage
 
getPropertyDataType(String, PropertyScope) - Method in class org.mule.MessagePropertiesContext
 
getPropertyDataType(String) - Method in class org.mule.session.DefaultMuleSession
 
getPropertyDescriptors() - Method in class org.mule.endpoint.URIBuilderBeanInfo
 
getPropertyInternal(String, PropertyScope, boolean, MuleMessage, Class<T>) - Static method in class org.mule.expression.ExpressionUtils
Obtains a property or map/list of properties from a message using an expression that specifies which property or properties to evaluate.
getPropertyName(Element) - Method in class org.mule.config.spring.parsers.AbstractChildDefinitionParser
 
getPropertyName() - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration.NamedValueMap
 
getPropertyName(Element) - Method in class org.mule.config.spring.parsers.collection.AttributeListEntryDefinitionParser
 
getPropertyName(Element) - Method in class org.mule.config.spring.parsers.generic.ChildDefinitionParser
 
getPropertyName(Element) - Method in class org.mule.config.spring.parsers.generic.WrappingChildDefinitionParser
 
getPropertyName(Element) - Method in class org.mule.config.spring.parsers.specific.ComponentDefinitionParser
 
getPropertyName(Element) - Method in class org.mule.config.spring.parsers.specific.endpoint.support.ChildEndpointDefinitionParser
 
getPropertyName(Element) - Method in class org.mule.config.spring.parsers.specific.InterceptorDefinitionParser
 
getPropertyName(Element) - Method in class org.mule.config.spring.parsers.specific.ObjectFactoryDefinitionParser
 
getPropertyName(Element) - Method in class org.mule.module.xml.config.XsltTextDefinitionParser
 
getPropertyName() - Method in class org.mule.transformer.simple.GetBeanProperty
 
getPropertyName() - Method in class org.mule.transport.jms.filters.JmsPropertyFilter
Returns the name of the property
getPropertyName() - Method in class org.mule.util.PropertyChecker
 
getPropertyNames() - Method in interface org.mule.api.MuleMessage
getPropertyNames(PropertyScope) - Method in interface org.mule.api.MuleMessage
Gets all property names in a given scope.
getPropertyNames() - Method in interface org.mule.api.MuleSession
Deprecated.
Use getPropertyNamesAsSet() instead (Will be removed in 4.0)
getPropertyNames() - Method in class org.mule.DefaultMuleMessage
getPropertyNames(PropertyScope) - Method in class org.mule.DefaultMuleMessage
Gets all property names in a given scope.
getPropertyNames(PropertyScope) - Method in class org.mule.MessagePropertiesContext
 
getPropertyNames() - Method in class org.mule.session.DefaultMuleSession
Deprecated.
Use getPropertyNamesAsSet() instead
getPropertyNamesAsSet() - Method in interface org.mule.api.MuleSession
 
getPropertyNamesAsSet() - Method in class org.mule.session.DefaultMuleSession
 
getPropertyWithScope(String, MuleMessage) - Static method in class org.mule.expression.ExpressionUtils
Gets a property or map/list of properties specific by an expression supporting multiple return types as well as all and optional modifiers Handles scope-aware expressions like "#[header:INBOUND:foo]
getPropertyWithScope(String, MuleMessage, Class<T>) - Static method in class org.mule.expression.ExpressionUtils
Gets a property or map/list of properties specific by an expression supporting multiple return types as well as all and optional modifiers Handles scope-aware expressions like "#[header:INBOUND:foo]
getProtocol() - Method in class org.apache.commons.httpclient.HttpConnection
Returns the protocol used to establish the connection.
getProtocol() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
The transport protocol name that the message endpoint communicates over.
getProtocol() - Method in interface org.mule.api.transport.Connector
 
getProtocol() - Method in class org.mule.endpoint.AbstractEndpoint
 
getProtocol() - Method in class org.mule.endpoint.dynamic.NullConnector
 
getProtocol() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getProtocol() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getProtocol() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getProtocol() - Method in class org.mule.endpoint.URIBuilder
 
getProtocol() - Method in class org.mule.module.http.internal.domain.request.DefaultHttpRequest
 
getProtocol() - Method in interface org.mule.module.http.internal.domain.request.HttpRequest
 
getProtocol() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyHttpRequestAdapter
 
getProtocol() - Method in class org.mule.module.http.internal.listener.properties.SSLSessionProperties
 
getProtocol() - Method in class org.mule.module.management.mbean.ConnectorService
 
getProtocol() - Method in interface org.mule.module.management.mbean.ConnectorServiceMBean
 
getProtocol() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getProtocol() - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
getProtocol() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
getProtocol() - Method in class org.mule.transport.ejb.EjbConnector
 
getProtocol() - Method in class org.mule.transport.email.ImapConnector
 
getProtocol() - Method in class org.mule.transport.email.ImapsConnector
 
getProtocol() - Method in class org.mule.transport.email.Pop3Connector
 
getProtocol() - Method in class org.mule.transport.email.Pop3sConnector
 
getProtocol() - Method in class org.mule.transport.email.SmtpConnector
 
getProtocol() - Method in class org.mule.transport.email.SmtpsConnector
 
getProtocol() - Method in class org.mule.transport.file.FileConnector
 
getProtocol() - Method in class org.mule.transport.ftp.FtpConnector
 
getProtocol() - Method in class org.mule.transport.http.HttpConnector
 
getProtocol() - Method in class org.mule.transport.http.HttpsConnector
 
getProtocol() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getProtocol() - Method in class org.mule.transport.jdbc.JdbcConnector
 
getProtocol() - Method in class org.mule.transport.jms.JmsConnector
 
getProtocol() - Method in class org.mule.transport.jnp.JnpConnector
 
getProtocol() - Method in class org.mule.transport.multicast.MulticastConnector
 
getProtocol() - Method in class org.mule.transport.polling.MessageProcessorPollingConnector
 
getProtocol() - Method in class org.mule.transport.quartz.QuartzConnector
 
getProtocol() - Method in class org.mule.transport.rmi.RmiConnector
 
getProtocol() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
getProtocol() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getProtocol() - Method in class org.mule.transport.servlet.ServletConnector
 
getProtocol() - Method in class org.mule.transport.sftp.config.SftpProxyConfig
 
getProtocol() - Method in class org.mule.transport.sftp.SftpConnector
 
getProtocol() - Method in class org.mule.transport.soap.axis.AxisConnector
 
getProtocol() - Method in class org.mule.transport.soap.axis.wsdl.AxisWsdlConnector
 
getProtocol() - Method in class org.mule.transport.stdio.StdioConnector
 
getProtocol() - Method in class org.mule.transport.tcp.TcpConnector
 
getProtocol() - Method in class org.mule.transport.udp.UdpConnector
 
getProtocol() - Method in class org.mule.transport.vm.VMConnector
 
getProtocol() - Method in class org.mule.transport.xmpp.XmppConnector
 
getProtocolFromKey(String) - Method in class org.mule.transport.soap.axis.SoapServiceFinder
 
getProtocolFromKey(String) - Method in class org.mule.transport.soap.axis.WsdlServiceFinder
 
getProvider(String) - Method in interface org.mule.api.security.SecurityManager
 
getProvider() - Method in class org.mule.module.atom.AbderaServiceComponent
 
getProvider(String) - Method in class org.mule.security.MuleSecurityManager
 
getProviders() - Method in interface org.mule.api.security.SecurityManager
 
getProviders() - Method in class org.mule.security.MuleSecurityManager
 
getProviderStatsHtml(String) - Method in class org.mule.management.stats.printers.HtmlTablePrinter
 
getProxy() - Static method in class org.mule.module.management.util.ManagementUtils
 
getProxyConfig() - Method in interface org.mule.module.http.api.requester.HttpRequesterConfig
 
getProxyConfig() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getProxyConfig() - Method in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
getProxyConfig() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getProxyConfig() - Method in class org.mule.module.ws.consumer.MuleWSDLLocatorConfig
 
getProxyConfig() - Method in class org.mule.transport.sftp.SftpConnector
 
getProxyHost() - Method in class org.apache.commons.httpclient.HttpConnection
Returns the proxy host.
getProxyHostname() - Method in class org.mule.transport.http.HttpConnector
 
getProxyPassword() - Method in class org.mule.transport.http.HttpConnector
 
getProxyPort() - Method in class org.apache.commons.httpclient.HttpConnection
Returns the port of the proxy host.
getProxyPort() - Method in class org.mule.transport.http.HttpConnector
 
getProxyUsername() - Method in class org.mule.transport.http.HttpConnector
 
getPublicId() - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
getPublicKey() - Method in class org.mule.module.pgp.PGPCryptInfo
 
getPublicKey(String) - Method in interface org.mule.module.pgp.PGPKeyRing
 
getPublicKey(String) - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
getPublicKeyRingFileName() - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
getPublicKeys() - Method in interface org.mule.module.pgp.PGPKeyRing
 
getPublicKeys() - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
getQuartzScheduler() - Method in class org.mule.transport.quartz.QuartzConnector
 
getQueries() - Method in class org.mule.transport.jdbc.JdbcConnector
 
getQuery() - Method in interface org.mule.api.endpoint.EndpointURI
 
getQuery() - Method in class org.mule.endpoint.MuleEndpointURI
 
getQuery(ImmutableEndpoint, String) - Method in class org.mule.transport.jdbc.JdbcConnector
 
getQueryMap() - Method in class org.mule.endpoint.URIBuilder
 
getQueryMetadataProvider() - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
getQueryParams() - Method in class org.mule.module.http.internal.domain.request.DefaultHttpRequest
 
getQueryParams(MuleEvent) - Method in class org.mule.module.http.internal.request.HttpRequesterRequestBuilder
 
getQueryRunner() - Method in class org.mule.transport.jdbc.JdbcConnector
 
getQueryRunnerFor(ImmutableEndpoint) - Method in class org.mule.transport.jdbc.JdbcConnector
 
getQueryString() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getQueryTemplate() - Method in class org.mule.module.db.internal.domain.query.Query
 
getQueryTemplates() - Method in class org.mule.module.db.internal.domain.query.BulkQuery
 
getQueryTimeout() - Method in class org.mule.transport.jdbc.ExtendedQueryRunner
 
getQueryTimeout() - Method in class org.mule.transport.jdbc.JdbcConnector
 
getQueryType() - Method in class org.mule.module.db.internal.config.processor.AbstractUpdateProcessorBeanDefinitionParser
 
getQueryType() - Method in class org.mule.module.db.internal.config.processor.DeleteProcessorBeanDefinitionParser
 
getQueryType() - Method in class org.mule.module.db.internal.config.processor.InsertProcessorBeanDefinitionParser
 
getQueryType() - Method in class org.mule.module.db.internal.config.processor.UpdateProcessorBeanDefinitionParser
 
getQueue(String) - Method in class org.mule.util.queue.AbstractQueueManager
 
getQueue(String) - Method in class org.mule.util.queue.AbstractQueueSession
 
getQueue(String) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
getQueue(String, QueueConfiguration) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
getQueue(String) - Method in interface org.mule.util.queue.QueueProvider
 
getQueue(String) - Method in interface org.mule.util.queue.QueueSession
Retrieves a queue.
getQueuedEvents() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
getQueuedEvents() - Method in class org.mule.module.management.mbean.ServiceService
 
getQueuedEvents() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getQueuedEvents() - Method in interface org.mule.module.management.mbean.ServiceStatsMBean
Deprecated.
 
getQueueInfo(String) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
getQueueManager() - Method in interface org.mule.api.MuleContext
Gets the queue manager used by mule for queuing events.
getQueueManager() - Method in class org.mule.DefaultMuleContext
 
getQueueManager() - Method in class org.mule.transport.vm.VMConnector
 
getQueueName() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
getQueueName() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
getQueueProfile() - Method in class org.mule.model.seda.SedaModel
Deprecated.
 
getQueueProfile() - Method in class org.mule.model.seda.SedaService
Deprecated.
 
getQueueProfile() - Method in class org.mule.transport.vm.VMConnector
 
getQueueProvider() - Method in class org.mule.util.queue.AbstractQueueSession
 
getQueueSession() - Method in class org.mule.util.queue.DelegateQueueManager
 
getQueueSession() - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
Returns a new instance of QueueSession bounded to this QueueManager
getQueueSession() - Method in interface org.mule.util.queue.QueueManager
Returns a new instance of QueueSession bounded to this QueueManager
getQueueSession() - Method in class org.mule.util.queue.TransactionalQueueManager
Returns a new instance of QueueSession bounded to this QueueManager
getQueueSize() - Method in class org.mule.module.management.mbean.ServiceService
 
getQueueSize() - Method in interface org.mule.module.management.mbean.ServiceServiceMBean
Deprecated.
The number of queued events for this service
getQueueSize() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
getQueueStatistics() - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
getQueueStore() - Method in class org.mule.config.spring.factories.QueueProfileFactoryBean
 
getQueueStore() - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
getQueueTimeout() - Method in class org.mule.model.seda.SedaModel
Deprecated.
 
getQueueTimeout() - Method in class org.mule.model.seda.SedaService
Deprecated.
 
getQueueTimeout() - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
getQueueTimeout() - Method in class org.mule.transport.vm.VMConnector
 
getQueueWindowSize() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getRadius() - Method in class org.mule.tck.testmodels.fruit.FloridaSunnyOrangeFactoryBean
 
getRandomAccessFile() - Method in class org.mule.util.queue.QueueFileProvider
 
getRawAuthority() - Method in class org.mule.endpoint.MuleEndpointURI
 
getRawFragment() - Method in class org.mule.endpoint.MuleEndpointURI
 
getRawPath() - Method in class org.mule.endpoint.MuleEndpointURI
 
getRawQuery() - Method in class org.mule.endpoint.MuleEndpointURI
 
getRawSchemeSpecificPart() - Method in class org.mule.endpoint.MuleEndpointURI
 
getRawUserInfo() - Method in class org.mule.endpoint.MuleEndpointURI
 
getRawValue() - Method in class org.mule.util.AttributeEvaluator
 
getReadAndAckStatements(ImmutableEndpoint) - Method in class org.mule.transport.jdbc.JdbcConnector
 
getReader() - Method in class org.mule.module.atom.server.MuleRequestContext
 
getReader() - Method in class org.mule.module.json.transformers.TransformerInputs
 
getReader() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getReadFromDirectory() - Method in class org.mule.transport.file.FileConnector
 
getRealm() - Method in class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
 
getRealm() - Method in class org.mule.transport.http.ntlm.NTLMScheme
The concept of an authentication realm is not supported by the NTLM authentication scheme.
getRealmURL() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getRealPath(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getReasonPhrase() - Method in enum org.mule.module.http.api.HttpConstants.HttpStatus
 
getReasonPhrase() - Method in class org.mule.module.http.internal.domain.response.DefaultHttpResponse
 
getReasonPhrase() - Method in interface org.mule.module.http.internal.domain.response.HttpResponse
 
getReasonPhrase() - Method in class org.mule.module.http.internal.domain.response.ResponseStatus
 
getReasonPhraseForStatusCode(int) - Static method in enum org.mule.module.http.api.HttpConstants.HttpStatus
 
getReceiveBacklog() - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
getReceiveBacklog() - Method in class org.mule.transport.tcp.TcpConnector
 
getReceiveBacklog() - Method in interface org.mule.transport.tcp.TcpServerSocketProperties
 
getReceiveBufferSize() - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
getReceiveBufferSize() - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
getReceiveBufferSize() - Method in interface org.mule.transport.tcp.TcpClientSocketProperties
 
getReceiveBufferSize() - Method in class org.mule.transport.tcp.TcpConnector
 
getReceiveBufferSize() - Method in interface org.mule.transport.tcp.TcpServerSocketProperties
 
getReceiveBufferSize() - Method in class org.mule.transport.udp.UdpConnector
 
getReceivedMessage(int) - Method in class org.mule.tck.functional.FunctionalTestComponent
If enableMessageHistory = true, returns a message received by the service in chronological order.
getReceivedMessagesCount() - Method in class org.mule.tck.functional.FunctionalTestComponent
If enableMessageHistory = true, returns the number of messages received by this service.
getReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.AbstractConnector
 
getReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.http.HttpConnector
 
getReceiver() - Method in class org.mule.transport.PollingReceiverWorker
 
getReceiverArguments(Map) - Method in class org.mule.transport.ftp.FtpConnector
 
getReceiverByEndpoint(EndpointURI) - Method in class org.mule.transport.vm.VMConnector
 
getReceiverForURI(HttpServletRequest) - Method in class org.mule.transport.servlet.jetty.JettyReceiverServlet
 
getReceiverForURI(HttpServletRequest) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
getReceiverKey() - Method in interface org.mule.api.transport.MessageReceiver
 
getReceiverKey(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.AbstractConnector
The method determines the key used to store the receiver against.
getReceiverKey() - Method in class org.mule.transport.AbstractMessageReceiver
 
getReceiverKey(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.file.FileConnector
 
getReceiverKey(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.http.HttpConnector
The method determines the key used to store the receiver against.
getReceiverKey(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.jms.JmsConnector
 
getReceiverKey(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.multicast.MulticastConnector
 
getReceiverKey(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.nameable.AbstractInboundEndpointNameableConnector
 
getReceiverKey(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.polling.MessageProcessorPollingConnector
 
getReceiverKey(MessageReceiver) - Method in class org.mule.transport.servlet.jetty.JettyReceiverServlet
 
getReceiverKey(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.servlet.ServletConnector
 
getReceiverKey(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.soap.axis.AxisConnector
The method determines the key used to store the receiver against.
getReceiverKey(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.udp.UdpConnector
 
getReceiverName(HttpServletRequest) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
getReceivers() - Method in class org.mule.transport.AbstractConnector
Getter for property 'receivers'.
getReceivers(String) - Method in class org.mule.transport.AbstractConnector
 
getReceivers() - Method in class org.mule.transport.http.HttpConnector
 
getReceivers() - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
getReceivers() - Method in class org.mule.transport.servlet.ServletConnector
 
getReceiverServlet() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
getReceiverThreadingProfile() - Method in class org.mule.transport.AbstractConnector
Getter for property 'receiverThreadingProfile'.
getReceiverWorkManager() - Method in class org.mule.transport.AbstractConnector
Returns a work manager for message receivers.
getRecipient(ImmutableEndpoint) - Static method in class org.mule.transport.xmpp.XmppConnector
 
getRecipientEndpoint(MuleMessage, Object) - Method in class org.mule.routing.outbound.AbstractRecipientList
 
getRecipientEndpointFromString(MuleMessage, String) - Method in class org.mule.routing.outbound.AbstractRecipientList
 
getRecipientEndpointFromUri(EndpointURI) - Method in class org.mule.routing.outbound.AbstractRecipientList
 
getRecipients(MuleEvent) - Method in class org.mule.routing.outbound.AbstractRecipientList
 
getRecipients(MuleEvent) - Method in class org.mule.routing.outbound.ExpressionRecipientList
 
getRecipients(MuleEvent) - Method in class org.mule.routing.outbound.StaticRecipientList
Deprecated.
 
getRecipients() - Method in class org.mule.routing.outbound.StaticRecipientList
Deprecated.
 
getRecommendedJdks() - Static method in class org.mule.util.JdkVersionUtils
 
getRecommndedJdks() - Static method in class org.mule.config.MuleManifest
 
getRecoveryQueue(String) - Method in interface org.mule.util.queue.QueueProvider
 
getRecoveryQueue(String) - Method in class org.mule.util.queue.TransactionalQueueManager
 
getRedeliveryCount() - Method in exception org.mule.api.exception.MessageRedeliveredException
 
getRedeliveryHandlerFactory() - Method in class org.mule.transport.jms.JmsConnector
 
getRedeliveryPolicy() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
Return the endpoint's redelivery policy, if any
getRedeliveryPolicy() - Method in class org.mule.endpoint.AbstractEndpoint
 
getRedeliveryPolicy() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getRedeliveryPolicy() - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
getRedeliveryPolicy() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getRedeliveryPolicy() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getRedeliveryPolicy() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getRedeliveryPolicy() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getRedirectionUrl() - Method in interface org.mule.module.oauth2.internal.authorizationcode.AuthorizationCodeGrantType
 
getRedirectionUrl() - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
getRedirectUri() - Method in class org.mule.security.oauth.processor.FetchAccessTokenMessageProcessor
 
getRef() - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
getRef() - Method in class org.mule.module.cxf.config.WsSecurity
 
getRef() - Method in class org.mule.module.http.internal.HttpMessageBuilderRef
 
getReferencedFlow(String, FlowConstruct) - Method in class org.mule.config.spring.factories.FlowRefFactoryBean
 
getRefreshableBean() - Method in class org.mule.module.scripting.component.GroovyRefreshableBeanBuilder
 
getRefreshToken() - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
getRefreshToken() - Method in class org.mule.module.oauth2.internal.authorizationcode.TokenResponseConfiguration
 
getRefreshToken() - Method in class org.mule.module.oauth2.internal.TokenResponseProcessor
 
getRefreshToken() - Method in interface org.mule.security.oauth.OAuth2Adapter
Retrieve refresh token
getRefreshTokenPattern() - Method in interface org.mule.security.oauth.OAuth2Adapter
Returns a compiled Pattern which can be used to extract the refresh token from a String
getRefreshTokenRegex() - Method in interface org.mule.security.oauth.OAuth2Connector
 
getRefreshTokenWhen() - Method in class org.mule.module.oauth2.internal.AbstractTokenRequestHandler
 
getRefreshTokenWhen() - Method in interface org.mule.module.oauth2.internal.authorizationcode.AuthorizationCodeGrantType
 
getRefreshTokenWhen() - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
getRefreshTokenWhen() - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
getRefreshUserOAuthContextLock() - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
getRefsThreshold() - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
getRefsThreshold() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
getRegEx() - Method in class org.mule.util.TemplateParser.PatternInfo
 
getRegisteredNamespaces() - Method in class org.mule.module.xml.xpath.JaxpXPathEvaluator
Returns a Map with the registered namespaces.
getRegisteredNamespaces() - Method in interface org.mule.module.xml.xpath.XPathEvaluator
Returns a Map with the registered namespaces.
getRegistries() - Method in interface org.mule.api.registry.RegistryProvider
Returns an immutable view of all active Registry instances for the current MuleContext.
getRegistries() - Method in class org.mule.registry.DefaultRegistryBroker
Deprecated.
Returns an immutable view of all active Registry instances for the current MuleContext.
getRegistries() - Method in class org.mule.registry.MuleRegistryHelper
 
getRegistry() - Method in interface org.mule.api.MuleContext
 
getRegistry() - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
getRegistry() - Method in class org.mule.DefaultMuleContext
getRegistry() - Method in class org.mule.el.context.AppContext
 
getRegistryId() - Method in interface org.mule.api.registry.Registry
 
getRegistryId() - Method in class org.mule.registry.AbstractRegistry
 
getRegistryId() - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
getRegistryId() - Method in class org.mule.registry.MuleRegistryHelper
getRejectedExecutionHandler() - Method in interface org.mule.api.config.ThreadingProfile
 
getRejectedExecutionHandler() - Method in class org.mule.config.ChainedThreadingProfile
 
getRejectedExecutionHandler() - Method in class org.mule.config.ImmutableThreadingProfile
 
getRejectedExecutionHandler() - Method in class org.mule.config.MutableThreadingProfile
 
getRelativePath(String) - Method in class org.mule.module.http.internal.listener.ListenerPath
 
getReloadControl() - Method in class org.mule.config.i18n.MessageFactory
Subclasses should override to customize the bundle reload control.
getRemoteAddr() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getRemoteClientAddress() - Method in class org.mule.transport.http.HttpServerConnection
 
getRemoteDispatcher(String) - Method in class org.mule.module.client.MuleClient
Deprecated.
getRemoteDispatcher(String, String, String) - Method in class org.mule.module.client.MuleClient
Deprecated.
getRemoteHost() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getRemoteHostAddress() - Method in class org.mule.module.http.internal.domain.request.ClientConnection
 
getRemoteInvocationExecutor() - Method in class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
getRemoteObject(ImmutableEndpoint) - Method in class org.mule.transport.ejb.EjbConnector
 
getRemoteObject(ImmutableEndpoint) - Method in class org.mule.transport.rmi.RmiConnector
 
getRemotePort() - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
Retrieves remotePort
getRemotePort() - Method in interface org.mule.security.oauth.callback.HttpCallbackAdapter
Retrieves remotePort
getRemotePort() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getRemoteRef(ImmutableEndpoint) - Method in class org.mule.transport.rmi.RmiConnector
 
getRemoteUser() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getRenameProperties() - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
getReplyMessage() - Method in class org.mule.tck.functional.FunctionalTestNotification
 
getReplyTo() - Method in interface org.mule.api.MuleMessage
Returns a replyTo address for this message.
getReplyTo() - Method in class org.mule.DefaultMuleMessage
Returns a replyTo address for this message.
getReplyTo() - Method in class org.mule.el.context.MessageContext
 
getReplyTo() - Method in class org.mule.module.cxf.MuleSoapHeaders
 
getReplyTo() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
getReplyToAddresses() - Method in class org.mule.transport.email.SmtpConnector
 
getReplyToDestination() - Method in interface org.mule.api.MuleEvent
Return the destination (if any) that will be passed to the reply-to handler.
getReplyToDestination() - Method in class org.mule.DefaultMuleEvent
 
getReplyToDestination(Message, Session, MuleEvent, boolean, boolean) - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
getReplyToDestination() - Method in class org.mule.VoidMuleEvent
 
getReplyToEventsSent() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
getReplyToEventsSent() - Method in class org.mule.module.management.mbean.ServiceService
 
getReplyToEventsSent() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getReplyToEventsSent() - Method in interface org.mule.module.management.mbean.ServiceStatsMBean
Deprecated.
 
getReplyToHandler() - Method in interface org.mule.api.MuleEvent
Return the replyToHandler (if any) that will be used to perform async reply
getReplyToHandler() - Method in class org.mule.DefaultMuleEvent
 
getReplyToHandler(ImmutableEndpoint) - Method in class org.mule.transport.AbstractConnector
Getter for property 'replyToHandler'.
getReplyToHandler() - Method in class org.mule.transport.AbstractMessageReceiver
 
getReplyToHandler(ImmutableEndpoint) - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
getReplyToHandler(ImmutableEndpoint) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
getReplyToHandler(ImmutableEndpoint) - Method in class org.mule.transport.jms.JmsConnector
 
getReplyToHandler() - Method in class org.mule.VoidMuleEvent
 
getRequest() - Method in class org.mule.module.http.internal.domain.request.HttpRequestContext
 
getRequestBuilder() - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
getRequestDispatcher(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getRequestedSessionId() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getRequesterConfig() - Method in interface org.mule.module.http.api.client.HttpRequestOptions
 
getRequesterConfig() - Method in class org.mule.module.http.internal.request.client.DefaultHttpRequestOptions
 
getRequesterFactory() - Method in interface org.mule.api.transport.Connector
The requester factory is used to create a message requester of the current request
getRequesterFactory() - Method in class org.mule.transport.AbstractConnector
 
getRequesterName() - Method in class org.mule.transport.AbstractMessageRequester
 
getRequesterThreadingProfile() - Method in class org.mule.transport.AbstractConnector
Getter for property 'requesterThreadingProfile'.
getRequesterWorkManager() - Method in class org.mule.transport.AbstractConnector
Returns a work manager for message requesters.
getRequestHandler(String, int, HttpRequest) - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry
 
getRequestHandler() - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.RequestHandlerMatcherPair
 
getRequestHandler(String, int, HttpRequest) - Method in interface org.mule.module.http.internal.listener.RequestHandlerProvider
Retrieves a RequestHandler to handle the http request
getRequestHandlerMatcherPairs() - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.PathMap
 
getRequestLine() - Method in class org.mule.transport.http.HttpRequest
 
getRequestLine() - Method in class org.mule.transport.http.HttpServerConnection
 
getRequestMatcher() - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.RequestHandlerMatcherPair
 
getRequestOutputStream() - Method in class org.apache.commons.httpclient.HttpConnection
Returns an OutputStream suitable for writing the request.
getRequestPath(MuleMessage) - Static method in class org.mule.module.cxf.HttpRequestPropertyManager
 
getRequestStreamingMode() - Method in interface org.mule.module.http.api.client.HttpRequestOptions
 
getRequestStreamingMode() - Method in interface org.mule.module.http.api.requester.HttpRequesterConfig
 
getRequestStreamingMode() - Method in class org.mule.module.http.internal.request.client.DefaultHttpRequestOptions
 
getRequestStreamingMode() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getRequestToken() - Method in interface org.mule.security.oauth.OAuth1Adapter
Returns the request token
getRequestTokenSecret() - Method in interface org.mule.security.oauth.OAuth1Adapter
Gets the request token secret
getRequestTokenUrl() - Method in interface org.mule.security.oauth.OAuth1Adapter
Retrieves requestTokenUrl
getRequestTokenUrl() - Method in class org.mule.security.oauth.processor.BaseOAuth1AuthorizeMessageProcessor
Retrieves requestTokenUrl
getRequestTokenUrl() - Method in class org.mule.security.oauth.processor.OAuth1FetchAccessTokenMessageProcessor
Retrieves requestTokenUrl
getRequestURI() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getRequestURL() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getRequestUrl(HttpServletRequest) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
getRequiredAttributeValue(String, String, XmlPullParser, boolean) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method getRequiredAttributeValue.
getRequiredAuthorities() - Method in class org.mule.module.spring.security.AuthorizationFilter
 
getRequiredParams() - Method in class org.mule.transport.http.components.RestServiceWrapper
 
getResolvedDomain() - Method in class org.mule.module.management.support.JmxRegistrationContext
Getter for property 'resolvedDomain'.
getResolvedEntity(String) - Method in class org.mule.module.http.internal.listener.ErrorRequestHandler
 
getResolvedEntity(String) - Method in class org.mule.module.http.internal.listener.NoListenerRequestHandler
 
getResolvedPath() - Method in class org.mule.module.http.internal.listener.ListenerPath
 
getResolvers() - Method in class org.mule.module.extension.internal.runtime.resolver.ResolverSet
 
getResource(Object) - Method in interface org.mule.api.transaction.Transaction
 
getResource(String) - Method in class org.mule.config.spring.MuleResourceLoader
 
getResource(String, Class) - Static method in class org.mule.module.boot.MuleBootstrapUtils
 
getResource() - Method in class org.mule.module.bpm.Process
 
getResource() - Method in class org.mule.module.bpm.ProcessComponent
 
getResource() - Method in class org.mule.module.bpm.Rules
 
getResource() - Method in class org.mule.module.bpm.RulesComponent
 
getResource(String) - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
getResource(String) - Method in class org.mule.module.launcher.MuleApplicationClassLoader
 
getResource(String, Class<?>) - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
getResource(Object) - Method in class org.mule.module.spring.transaction.SpringTransactionFactory.SpringTransaction
 
getResource(Object) - Method in class org.mule.processor.DelegateTransaction
 
getResource(Object) - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
getResource(Object) - Method in class org.mule.transaction.XaTransaction
 
getResource() - Method in class org.mule.transport.xmpp.XmppConnector
 
getResource(String, Class<?>) - Static method in class org.mule.util.ClassUtils
Load a given resource.
getResourceAsStream(String) - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
getResourceAsStream(String, Class) - Static method in class org.mule.util.IOUtils
Attempts to load a resource from the file system, from a URL, or from the classpath, in that order.
getResourceAsStream(String, Class, boolean, boolean) - Static method in class org.mule.util.IOUtils
Attempts to load a resource from the file system, from a URL, or from the classpath, in that order.
getResourceAsString(String) - Method in class org.mule.module.db.internal.util.DefaultFileReader
 
getResourceAsString(String) - Method in interface org.mule.module.db.internal.util.FileReader
Attempts to load a resource from the file system, from a URL, or from the classpath, in that order.
getResourceAsString(String, Class) - Static method in class org.mule.util.IOUtils
Attempts to load a resource from the file system, from a URL, or from the classpath, in that order.
getResourceAsUrl(String, Class) - Static method in class org.mule.util.IOUtils
Attempts to load a resource from the file system or from the classpath, in that order.
getResourceAsUrl(String, Class, boolean, boolean) - Static method in class org.mule.util.IOUtils
Attempts to load a resource from the file system or from the classpath, in that order.
getResourceBase() - Method in class org.mule.transport.http.components.StaticResourceMessageProcessor
 
getResourceBase() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
getResourceBundle() - Method in class org.mule.transport.stdio.PromptStdioConnector
 
getResourceByPath(String) - Method in class org.mule.config.spring.MuleResourceLoader
 
getResourceConfig() - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
getResourceFiles() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
getResourceFiles() - Method in interface org.mule.module.launcher.artifact.Artifact
 
getResourceFiles() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
getResourceFiles() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
getResourceIdentifier() - Method in class org.mule.api.context.notification.ServerNotification
 
getResourceInfo() - Method in interface org.mule.api.endpoint.EndpointURI
 
getResourceInfo() - Method in class org.mule.endpoint.MuleEndpointURI
 
getResourceManager() - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
getResourceManager() - Method in class org.mule.util.xa.DefaultXASession
 
getResourceName() - Method in class org.mule.config.ConfigResource
 
getResourceOwnerId() - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
getResourceOwnerIdEvaluator() - Method in interface org.mule.module.oauth2.internal.authorizationcode.AuthorizationCodeGrantType
 
getResourceOwnerIdEvaluator() - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
getResourcePath(String, Class) - Static method in class org.mule.util.FileUtils
 
getResourcePath(String, Class, String) - Static method in class org.mule.util.FileUtils
 
getResourceResolver() - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
getResourceResolver() - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
getResourceResolver() - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
getResourceResolver() - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
getResources(String) - Method in class org.mule.config.spring.MuleResourceLoader
 
getResources(String) - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
getResources(String) - Method in class org.mule.module.launcher.MuleApplicationClassLoader
 
getResources(String, Class<?>) - Static method in class org.mule.util.ClassUtils
 
getResourceType() - Method in class org.mule.module.db.internal.domain.transaction.DbTransaction
 
getResourceType() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
getResourceType() - Method in class org.mule.transport.jdbc.JdbcTransaction
 
getResourceType() - Method in class org.mule.transport.jms.JmsTransaction
 
getResourceType() - Method in class org.mule.transport.vm.VMTransaction
 
getResponseBody(Message, MuleMessage) - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
getResponseBufferSize() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getResponseBufferSize() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getResponseCode() - Method in exception org.mule.transport.http.HttpResponseException
 
getResponseContentType(String, String) - Method in class org.mule.module.cxf.support.WSDLQueryHandler
 
getResponseFromMethod(HttpMethod, ExceptionPayload) - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
getResponseInputStream() - Method in class org.apache.commons.httpclient.HttpConnection
Return a InputStream suitable for reading the response.
getResponseMessageProcessors() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
 
getResponseMessageProcessors() - Method in class org.mule.endpoint.AbstractEndpoint
 
getResponseMessageProcessors() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getResponseMessageProcessors() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getResponseMessageProcessors() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getResponseMessageProcessors() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getResponseMessageProcessors() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getResponseOutputHandler(MessageImpl) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
getResponseOutputHandler(Exchange) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
getResponsePayloadClass() - Method in class org.mule.module.jbpm.MuleSendActivity
 
getResponseProperties() - Method in interface org.mule.api.endpoint.OutboundEndpoint
 
getResponseProperties() - Method in class org.mule.endpoint.DefaultOutboundEndpoint
 
getResponseProperties() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getResponseProperties() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getResponseStreaming() - Method in class org.mule.module.http.internal.listener.HttpResponseBuilder
 
getResponseText() - Method in exception org.mule.transport.http.HttpResponseException
 
getResponseTimeout() - Method in class org.mule.api.client.AbstractBaseOptionsBuilder
 
getResponseTimeout() - Method in interface org.mule.api.client.OperationOptions
 
getResponseTimeout() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
The timeout value for waiting for a response from a remote invocation or back channel.
getResponseTimeout() - Method in class org.mule.client.SimpleOptions
 
getResponseTimeout() - Method in class org.mule.endpoint.AbstractEndpoint
The timeout value for remoteSync invocations
getResponseTimeout(Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getResponseTimeout() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getResponseTimeout() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getResponseTimeout() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getResponseTimeout() - Method in interface org.mule.module.http.api.client.HttpRequestOptions
 
getResponseTimeout() - Method in interface org.mule.module.http.api.requester.HttpRequesterConfig
 
getResponseTimeout() - Method in class org.mule.module.http.internal.request.client.DefaultHttpRequestOptions
 
getResponseTimeout() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getResponseTimeout() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getResponseTransformers() - Method in interface org.mule.api.endpoint.EndpointURI
 
getResponseTransformers() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
Deprecated.
use getResponseMessageProcessors() instead
getResponseTransformers() - Method in class org.mule.endpoint.AbstractEndpoint
Deprecated.
use getResponseMessageProcessors()
getResponseTransformers() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getResponseTransformers() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getResponseTransformers() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getResponseTransformers() - Method in class org.mule.endpoint.MuleEndpointURI
 
getResponseTransformers() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getResponseTransformersFromUri(EndpointURI) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getResponseTransportTransformers() - Method in class org.mule.transport.http.HttpMessageReceiver
 
getResponseValidator() - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
getResponseVariableName() - Method in class org.mule.module.jbpm.MuleSendActivity
 
getRessponseOutputHandler(MessageImpl) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
Deprecated.
getResult() - Method in class org.mule.api.model.InvocationResult
The result of this invocation
getResult() - Method in class org.mule.module.db.internal.result.statement.OutputParamResult
 
getResult() - Method in class org.mule.module.db.internal.result.statement.ResultSetResult
 
getResult() - Method in interface org.mule.module.db.internal.result.statement.StatementResult
 
getResult() - Method in class org.mule.module.db.internal.result.statement.UpdateCountResult
 
getResult() - Method in interface org.mule.module.xml.transformer.AbstractXmlTransformer.ResultHolder
 
getResult(long, TimeUnit) - Method in class org.mule.work.ProcessingMuleEventWork
This method is useful for having a thread other than the one executing this work waiting for the result being available.
getResultHolder(Class<?>) - Static method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
getResultObject() - Method in interface org.mule.module.xml.transformer.AbstractXmlTransformer.ResultHolder
 
getResultSetHandler() - Method in class org.mule.transport.jdbc.JdbcConnector
 
getResultsHandler() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
getResultType() - Method in class org.mule.module.xml.transformer.XPathExtractor
Result type from this transformer.
getRetryContext() - Method in class org.mule.retry.async.RetryWorker
 
getRetryPolicyTemplate() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
The retry policy on the endpoint configures how retries are handled.
getRetryPolicyTemplate() - Method in interface org.mule.api.transport.Connector
 
getRetryPolicyTemplate() - Method in class org.mule.endpoint.AbstractEndpoint
 
getRetryPolicyTemplate(Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getRetryPolicyTemplate() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getRetryPolicyTemplate() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getRetryPolicyTemplate() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getRetryPolicyTemplate() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getRetryPolicyTemplate() - Method in class org.mule.transport.AbstractConnector
 
getReturnClass() - Method in interface org.mule.api.transformer.Transformer
Deprecated.
getReturnClass() - Method in class org.mule.expression.transformers.ExpressionArgument
 
getReturnClass() - Method in class org.mule.transformer.AbstractTransformer
Deprecated.
getReturnClass() - Method in class org.mule.transformer.CompositeConverter
 
getReturnClass() - Method in class org.mule.transformer.simple.StringToNumber
 
getReturnClass() - Method in class org.mule.transport.soap.axis.SoapMethod
 
getReturnData() - Method in class org.mule.tck.functional.FunctionalTestComponent
Often you will may want to return a fixed message payload to simulate and external system call.
getReturnDataType() - Method in interface org.mule.api.transformer.Transformer
Specifies the return type of the result after this transformer has been executed.
getReturnDataType() - Method in class org.mule.transformer.AbstractTransformer
 
getReturnDataType() - Method in class org.mule.transformer.CompositeConverter
 
getReturnMessages() - Method in interface org.mule.api.retry.RetryContext
 
getReturnMessages() - Method in class org.mule.retry.async.FutureRetryContext
 
getReturnMessages() - Method in class org.mule.retry.DefaultRetryContext
 
getReturnType() - Method in class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
 
getReturnType() - Method in class org.mule.transport.soap.axis.SoapMethod
 
getReuseAddress() - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
getReuseAddress() - Method in interface org.mule.transport.tcp.TcpServerSocketProperties
 
getRightFilter() - Method in class org.mule.transport.xmpp.filters.XmppAndFilter
 
getRmiRegistry() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
getRmiRegistry() - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
getRoles() - Method in interface org.mule.api.security.Credentials
 
getRoles() - Method in class org.mule.security.MuleCredentials
 
getRollbackTxFilter() - Method in class org.mule.exception.AbstractExceptionListener
 
getRootException() - Method in interface org.mule.api.ExceptionPayload
 
getRootException(Throwable) - Static method in class org.mule.config.ExceptionHelper
 
getRootException() - Method in class org.mule.message.DefaultExceptionPayload
 
getRootId() - Method in class org.mule.el.context.MessageContext
 
getRootMuleException(Throwable) - Static method in class org.mule.config.ExceptionHelper
 
getRootParentException(Throwable) - Static method in class org.mule.config.ExceptionHelper
 
getRoute() - Method in exception org.mule.api.routing.RoutingException
 
getRoute(String) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
getRoute(int, MuleEvent) - Method in class org.mule.routing.outbound.FilteringOutboundRouter
Will Return the target at the given index and will resolve any template tags on the Endpoint URI if necessary
getRoute() - Method in class org.mule.routing.UntilSuccessful
 
getRoute() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
getRouted(String) - Method in class org.mule.management.stats.RouterStatistics
 
getRouted() - Method in class org.mule.management.stats.RouterStatistics
 
getRouted() - Method in class org.mule.module.management.mbean.RouterStats
 
getRouted() - Method in interface org.mule.module.management.mbean.RouterStatsMBean
 
getRouteIdentifier(MuleEvent) - Method in class org.mule.routing.DynamicRouteResolverAdapter
 
getRouteIdentifier(MuleEvent) - Method in interface org.mule.routing.IdentifiableDynamicRouteResolver
Returns an identifier of the DynamicRouteResolver.
getRouter() - Method in class org.mule.routing.UntilSuccessful
 
getRouter() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
getRouterInbound() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getRouterInfo(RouterStatistics, String[], int) - Method in class org.mule.management.stats.printers.AbstractTablePrinter
 
getRouterInfo(RouterStatistics, String[], int) - Method in class org.mule.management.stats.printers.XMLPrinter
 
getRouterOutbound() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getRouterParser(Annotation, Class<?>, Member) - Method in interface org.mule.config.AnnotationsParserFactory
Retrieves a parser for the given annotation, where the annotation is a Router annotation; one annotated with the Router annotation.
getRouterParser(Annotation, Class, Member) - Method in class org.mule.config.endpoint.RegistryBackedAnnotationsParserFactory
 
getRouterStatistics() - Method in interface org.mule.api.routing.OutboundRouterCollection
Deprecated.
 
getRouterStatistics() - Method in class org.mule.routing.AbstractCatchAllStrategy
Deprecated.
 
getRouterStatistics() - Method in class org.mule.routing.AbstractSelectiveRouter
 
getRouterStatistics() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
getRouterStatistics() - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
getRouterStatistics() - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
getRoutes() - Method in interface org.mule.api.routing.OutboundRouter
Gets a list of MessageProcessor instances associated with this router
getRoutes() - Method in interface org.mule.api.routing.OutboundRouterCollection
Deprecated.
 
getRoutes() - Method in class org.mule.routing.AbstractMatchingRouter
 
getRoutes() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
getRoutes() - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
getRSSNamespace() - Method in class org.mule.module.rss.transformers.RssParser
 
getRuntimeClassesDir() - Method in class org.mule.module.launcher.plugin.PluginClasspath
 
getRuntimeLibs() - Method in class org.mule.module.launcher.plugin.PluginClasspath
 
getSalt() - Method in class org.mule.security.PasswordBasedEncryptionStrategy
 
getSameRMOverrideValue() - Method in class org.mule.transport.jms.JmsConnector
 
getSamplePeriod() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
 
getSatisfiableMethods(Class<?>, Class<?>[], boolean, boolean, Set<String>) - Static method in class org.mule.util.ClassUtils
A helper method that will find all matching methods on a class with the given parameter type
getSatisfiableMethods(Class<?>, Class<?>[], boolean, boolean, Collection<String>, WildcardFilter) - Static method in class org.mule.util.ClassUtils
A helper method that will find all matching methods on a class with the given parameter type
getSatisfiableMethodsWithReturnType(Class, Class, boolean, Set<String>) - Static method in class org.mule.util.ClassUtils
Match all method son a class with a defined return type
getSAXParserFactory() - Method in class org.mule.util.xmlsecurity.XMLSecureFactories
 
getSAXParserFactory(DefaultXMLSecureFactories) - Method in class org.mule.util.xmlsecurity.XMLSecureFactoriesCache
 
getScanner(Class<?>) - Method in class org.mule.util.scan.ClasspathScanner
Deprecated.
Works out the correct scanner based on the class passed in

Note that these could be better architected by breaking out filters into strategy objects, but for now this suits my needs

getScheduler() - Method in class org.mule.transport.AbstractConnector
Returns a Scheduler service for periodic tasks, currently limited to internal use.
getScheduler() - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
getSchema() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
getSchema() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getSchema() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getSchemaFactory(String) - Method in class org.mule.util.xmlsecurity.XMLSecureFactories
 
getSchemaFactory(DefaultXMLSecureFactories, String) - Method in class org.mule.util.xmlsecurity.XMLSecureFactoriesCache
 
getSchemaLanguage() - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
getSchemaLanguage() - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
getSchemaLanguage() - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
getSchemaLanguage() - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
getSchemaLocations() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getSchemaLocations() - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
getSchemaLocations() - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
getSchemaLocations() - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
getSchemaLocations() - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
getSchemaObject() - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
getSchemaObject() - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
getSchemaObject() - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
getSchemaObject() - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
getSchemas(Definition) - Static method in class org.mule.module.ws.consumer.WSDLUtils
Returns all the XML schemas from a WSDL definition.
getScheme() - Method in interface org.mule.api.endpoint.EndpointURI
 
getScheme() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getScheme() - Method in class org.mule.endpoint.AbstractMetaEndpointBuilder
 
getScheme() - Method in class org.mule.endpoint.MuleEndpointURI
 
getScheme(MuleEvent) - Static method in class org.mule.module.cxf.HttpRequestPropertyManager
 
getScheme() - Method in enum org.mule.module.http.api.HttpConstants.Protocols
 
getScheme() - Method in class org.mule.module.http.internal.domain.request.HttpRequestContext
 
getScheme() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getScheme() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getSchemeMetaInfo() - Method in interface org.mule.api.endpoint.EndpointURI
 
getSchemeMetaInfo() - Method in class org.mule.endpoint.MuleEndpointURI
 
getSchemeName() - Method in class org.mule.transport.http.ntlm.NTLMScheme
Returns textual designation of the NTLM authentication scheme.
getSchemeSpecificPart() - Method in class org.mule.endpoint.MuleEndpointURI
 
getScope(String) - Static method in class org.mule.expression.ExpressionUtils
 
getScope() - Method in class org.mule.routing.filters.MessagePropertyFilter
 
getScope() - Method in class org.mule.security.oauth.BaseOAuth2Manager
Retrieves scope
getScope() - Method in interface org.mule.security.oauth.OAuth1Connector
 
getScope() - Method in interface org.mule.security.oauth.OAuth2Connector
 
getScope() - Method in class org.mule.transformer.simple.AbstractAddVariablePropertyTransformer
 
getScope() - Method in class org.mule.transformer.simple.AbstractRemoveVariablePropertyTransformer
 
getScope() - Method in class org.mule.transformer.simple.AddFlowVariableTransformer
 
getScope() - Method in class org.mule.transformer.simple.AddPropertyTransformer
 
getScope() - Method in class org.mule.transformer.simple.AddSessionVariableTransformer
 
getScope() - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
getScope() - Method in class org.mule.transformer.simple.RemoveFlowVariableTransformer
 
getScope() - Method in class org.mule.transformer.simple.RemovePropertyTransformer
 
getScope() - Method in class org.mule.transformer.simple.RemoveSessionVariableTransformer
 
getScopedProperties(PropertyScope) - Method in class org.mule.MessagePropertiesContext
 
getScopeName() - Method in class org.mule.api.transport.PropertyScope
 
getScopeName() - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
For XML-based config
getScript() - Method in class org.mule.module.scripting.component.ScriptComponent
 
getScript(String) - Method in class org.mule.module.scripting.expression.AbstractScriptExpressionEvaluator
 
getScript() - Method in class org.mule.module.scripting.filter.ScriptFilter
 
getScript() - Method in class org.mule.module.scripting.transformer.ScriptTransformer
 
getScriptEngine() - Method in class org.mule.module.scripting.component.Scriptable
 
getScriptEngineName() - Method in class org.mule.module.scripting.component.Scriptable
 
getScriptFile() - Method in class org.mule.module.scripting.component.Scriptable
 
getScriptText() - Method in class org.mule.module.scripting.component.Scriptable
 
getSeconds() - Method in interface org.mule.api.el.datetime.Time
 
getSeconds() - Method in class org.mule.el.datetime.DateTime
 
getSecretAliasId() - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
getSecretKey() - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
getSecretKey() - Method in class org.mule.security.PasswordBasedEncryptionStrategy
 
getSecretKey() - Method in class org.mule.security.SecretKeyEncryptionStrategy
Deprecated.
 
getSecretKeyRingFileName() - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
getSecretKeys() - Method in interface org.mule.module.pgp.PGPKeyRing
 
getSecretKeys() - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
getSecretPassphrase() - Method in interface org.mule.module.pgp.PGPKeyRing
 
getSecretPassphrase() - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
getSecurity() - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
getSecurityContext() - Method in interface org.mule.api.MuleSession
The security context for this session.
getSecurityContext() - Method in class org.mule.session.DefaultMuleSession
The security context for this session.
getSecurityContextFactory() - Method in class org.mule.security.AbstractSecurityProvider
 
getSecurityFilter() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
Deprecated.
getSecurityFilter() - Method in class org.mule.endpoint.AbstractEndpoint
Returns an EndpointSecurityFilter for this endpoint.
getSecurityFilter() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getSecurityFilter() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getSecurityFilter() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getSecurityFilter() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getSecurityFilter() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getSecurityManager() - Method in interface org.mule.api.MuleContext
Gets the security manager used by this Mule instance to authenticate and authorise incoming and outgoing event traffic and service invocations
getSecurityManager() - Method in interface org.mule.api.security.SecurityFilter
 
getSecurityManager() - Method in class org.mule.DefaultMuleContext
Gets the security manager used by this Mule instance to authenticate and authorise incoming and outgoing event traffic and service invocations
getSecurityManager() - Method in class org.mule.module.cxf.config.WsSecurity
 
getSecurityManager() - Method in class org.mule.security.AbstractSecurityFilter
 
getSecurityManager() - Method in class org.mule.transport.rmi.RmiConnector
 
getSecurityModel() - Static method in class org.mule.util.SecurityUtils
 
getSecurityPolicy() - Method in class org.mule.transport.rmi.RmiConnector
 
getSecurityProperties() - Method in class org.mule.module.spring.security.SpringProviderAdapter
 
getSecurityProviders() - Method in interface org.mule.api.security.SecurityFilter
 
getSecurityProviders() - Method in class org.mule.security.AbstractSecurityFilter
 
getSegments() - Method in class org.mule.tck.testmodels.fruit.FloridaSunnyOrangeFactoryBean
 
getSelectedValue() - Method in class org.mule.transport.polling.watermark.selector.WatermarkSelector
Returns the selected value.
getSelectedValue() - Method in class org.mule.transport.polling.watermark.selector.WatermarkSelectorWrapper
 
getSelector(ImmutableEndpoint) - Method in class org.mule.transport.jms.JmsConnector
 
getSelectorRunnersCount() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getSelectors() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
Get the number of "selector" threads Jetty should use.
getSelectQuery() - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
getSelectQueryKey() - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
getSendBodyMode() - Method in interface org.mule.module.http.api.requester.HttpRequesterConfig
 
getSendBodyMode() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getSendBufferSize() - Method in class org.apache.commons.httpclient.HttpConnection
Gets the socket's sendBufferSize.
getSendBufferSize() - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
getSendBufferSize() - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
getSendBufferSize() - Method in interface org.mule.transport.tcp.TcpClientSocketProperties
 
getSendBufferSize() - Method in class org.mule.transport.tcp.TcpConnector
 
getSendBufferSize() - Method in interface org.mule.transport.tcp.TcpServerSocketProperties
 
getSendBufferSize() - Method in class org.mule.transport.udp.UdpConnector
 
getSendTcpNoDelay() - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
getSendTcpNoDelay() - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
getSendTcpNoDelay() - Method in interface org.mule.transport.tcp.TcpClientSocketProperties
 
getSendTcpNoDelay() - Method in interface org.mule.transport.tcp.TcpServerSocketProperties
 
getSerializationId() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Return an id for serialization purposes, if specified, allowing this BeanFactory to be deserialized from this id back into the BeanFactory object, if needed.
getSerializationMixins() - Method in class org.mule.module.json.transformers.ObjectToJson
 
getSerivce(InboundEndpoint, WireFormat, String, int, MuleContext) - Static method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
getServer() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getServer() - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
getServerAddress() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyServer
 
getServerAddress() - Method in interface org.mule.module.http.internal.listener.Server
 
getServerClasses() - Method in class org.mule.transport.servlet.jetty.WebappsConfiguration
 
getServerClassName() - Method in class org.mule.transport.rmi.RmiConnector
 
getServerCodebase() - Method in class org.mule.transport.rmi.RmiConnector
 
getServerConfig() - Method in class org.mule.transport.soap.axis.AxisConnector
 
getServerId() - Method in class org.mule.api.context.notification.ServerNotification
 
getServerId() - Method in class org.mule.module.management.mbean.MuleService
 
getServerId() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getServerName() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getServerPort() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getServerProvider() - Method in class org.mule.transport.soap.axis.AxisConnector
 
getServerSocket(URI) - Method in class org.mule.transport.http.HttpConnector
 
getServerSocket(URI) - Method in class org.mule.transport.http.HttpsConnector
 
getServerSocket(URI) - Method in class org.mule.transport.tcp.TcpConnector
 
getServerSocket() - Method in class org.mule.transport.tcp.TcpMessageReceiver
Obtain the serverSocket
getServerSocketFactory() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getServerSocketFactory() - Method in class org.mule.transport.tcp.TcpConnector
 
getServerSoTimeout() - Method in class org.mule.transport.tcp.TcpConnector
 
getServerTimeout() - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
getServerTimeout() - Method in interface org.mule.transport.tcp.TcpServerSocketProperties
 
getServerUri() - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
getServerUrl() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
getService() - Method in class org.mule.api.registry.AbstractServiceDescriptor
 
getService() - Method in interface org.mule.api.registry.ServiceDescriptor
 
getService() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getService() - Method in class org.mule.module.cxf.builder.WsdlClientMessageProcessorBuilder
 
getService() - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
getService(QName) - Method in class org.mule.transport.soap.axis.extensions.WSDDFileProvider
retrieve an instance of the named service
getServiceAddress() - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
getServiceBean() - Method in class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
getServiceClass() - Method in class org.mule.module.cxf.builder.AbstractClientMessageProcessorBuilder
 
getServiceClass() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getServiceClass() - Method in class org.mule.module.cxf.builder.ProxyServiceMessageProcessorBuilder
 
getServiceClass() - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
getServiceClass() - Method in class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
getServiceClass(String, SOAPService, MessageContext) - Method in class org.mule.transport.soap.axis.extensions.MuleMsgProvider
 
getServiceClass(String, SOAPService, MessageContext) - Method in class org.mule.transport.soap.axis.extensions.MuleRPCProvider
 
getServiceDescriptor() - Method in class org.mule.transport.AbstractConnector
Get the TransportServiceDescriptor for this connector.
getServiceFromDefinition(Definition) - Method in class org.mule.module.cxf.support.ProxyServiceConfiguration
 
getServiceInterface() - Method in class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
getServiceName() - Method in class org.mule.context.notification.ComponentMessageNotification
 
getServiceName() - Method in class org.mule.module.cxf.support.MuleServiceConfiguration
 
getServiceName(MuleEventContext, EndpointURI) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
getServiceName() - Method in class org.mule.transport.xmpp.XmppConnector
 
getServiceNamespace() - Method in class org.mule.module.cxf.support.MuleServiceConfiguration
 
getServiceOverrides() - Method in class org.mule.transport.AbstractConnector
A map of fully qualified class names that should override those in the connectors' service descriptor This map will be null if there are no overrides
getServiceStartedAssertingMessageProcessor() - Method in class org.mule.model.seda.SedaService
Deprecated.
 
getServiceStartedAssertingMessageProcessor() - Method in class org.mule.service.AbstractService
Deprecated.
 
getServiceStatistics(FlowConstruct) - Method in class org.mule.exception.DefaultServiceExceptionStrategy
Deprecated.
 
getServiceStatistics() - Method in class org.mule.management.stats.AllStatistics
 
getServiceStatistics() - Method in class org.mule.module.management.mbean.StatisticsService
 
getServiceUrl() - Method in class org.mule.transport.http.components.RestServiceWrapper
 
getServlet() - Method in class org.mule.transport.servlet.jetty.AbstractConnectorHolder
 
getServlet() - Method in interface org.mule.transport.servlet.jetty.ConnectorHolder
 
getServletContext() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getServletPath() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getServletResponse() - Method in class org.mule.transport.servlet.jetty.JettyMessageProcessTemplate
 
getServletResponseWriter() - Method in class org.mule.transport.servlet.jetty.JettyMessageProcessTemplate
 
getServletUrl() - Method in class org.mule.transport.servlet.ServletConnector
 
getSession() - Method in interface org.mule.api.MuleEvent
Retrieves the service session for the current event
getSession() - Method in interface org.mule.api.MuleEventContext
 
getSession() - Method in class org.mule.DefaultMuleEvent
 
getSession() - Method in class org.mule.DefaultMuleEventContext
 
getSession() - Method in class org.mule.module.drools.DroolsSessionData
 
getSession() - Method in class org.mule.transport.email.SessionDetails
 
getSession() - Method in class org.mule.transport.email.transformers.Rfc822ByteArraytoMimeMessage
 
getSession(boolean) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getSession() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getSession(ImmutableEndpoint) - Method in class org.mule.transport.jms.JmsConnector
 
getSession(boolean, boolean) - Method in class org.mule.transport.jms.JmsConnector
 
getSession() - Method in class org.mule.transport.jms.transformers.AbstractJmsTransformer
 
getSession() - Method in class org.mule.VoidMuleEvent
 
getSessionCacheSize() - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
getSessionData() - Method in class org.mule.module.bpm.Rules
 
getSessionDetails(ImmutableEndpoint) - Method in class org.mule.transport.email.AbstractMailConnector
 
getSessionFromTransaction() - Method in class org.mule.transport.jms.JmsConnector
 
getSessionHandler() - Method in interface org.mule.api.transport.Connector
 
getSessionHandler() - Method in class org.mule.transport.AbstractConnector
Getter for property 'sessionHandler'.
getSessionIDKey() - Method in interface org.mule.api.transport.SessionHandler
Deprecated.
This method is no longer needed and will be removed in the next major release
getSessionIDKey() - Method in class org.mule.session.LegacySessionHandler
Deprecated.
This method is no longer needed and will be removed in the next major release
getSessionIDKey() - Method in class org.mule.session.NullSessionHandler
The property name of the session id to use when creating the Mule session.
getSessionIDKey() - Method in class org.mule.session.SerializeOnlySessionHandler
Deprecated.
This method is no longer needed and will be removed in the next major release
getSessionIDKey() - Method in class org.mule.session.SimpleSessionHandler
Deprecated.
This method is no longer needed and will be removed in the next major release
getSessionProperty(String, T) - Method in interface org.mule.api.MuleMessage
getSessionProperty(String) - Method in interface org.mule.api.MuleMessage
getSessionProperty(String, T) - Method in class org.mule.DefaultMuleMessage
 
getSessionProperty(String) - Method in class org.mule.DefaultMuleMessage
 
getSessionPropertyNames() - Method in interface org.mule.api.MuleMessage
Deprecated.
getSessionPropertyNames() - Method in class org.mule.DefaultMuleMessage
 
getSessionVariable(String) - Method in interface org.mule.api.MuleEvent
Deprecated.
use getSession() to manipulate session state
getSessionVariable(String) - Method in class org.mule.DefaultMuleEvent
 
getSessionVariable(String) - Method in class org.mule.VoidMuleEvent
 
getSessionVariableDataType(String) - Method in interface org.mule.api.MuleEvent
Deprecated.
use getSession() to manipulate session state
getSessionVariableDataType(String) - Method in class org.mule.DefaultMuleEvent
 
getSessionVariableDataType(String) - Method in class org.mule.VoidMuleEvent
 
getSessionVariableNames() - Method in interface org.mule.api.MuleEvent
Deprecated.
use getSession() to manipulate session state
getSessionVariableNames() - Method in class org.mule.DefaultMuleEvent
 
getSessionVariableNames() - Method in class org.mule.VoidMuleEvent
 
getSharedPluginLibs() - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
getShort(Object, Short) - Static method in class org.mule.util.ObjectUtils
Gets a short from a value in a null-safe manner.
getShortProperty(String, short) - Method in class org.mule.MessagePropertiesContext
 
getShortValue(String, String, XmlPullParser, boolean) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method getShortValue.
getShutdownScreen() - Method in class org.mule.context.DefaultMuleContextBuilder
 
getShutdownTimeout() - Method in interface org.mule.api.config.MuleConfiguration
 
getShutdownTimeout() - Method in class org.mule.config.DefaultMuleConfiguration
 
getShutdownTimeout() - Method in class org.mule.module.management.mbean.MuleConfigurationService
 
getShutdownTimeout() - Method in interface org.mule.module.management.mbean.MuleConfigurationServiceMBean
 
getSignature(Member, Class[]) - Static method in class org.mule.util.ClassReader
 
getSigningStrategy() - Method in interface org.mule.security.oauth.OAuth1Connector
 
getSimpleName(Class) - Static method in class org.mule.util.ClassUtils
Provide a simple-to-understand class name (with access to only Java 1.4 API).
getSingleCapability(Capable, Class<T>) - Static method in class org.mule.module.extension.internal.util.CapabilityUtils
Expects capable to have at most one capability of type capabilityType and returns such capability.
getSingleCapability(Set<?>, Class<T>) - Static method in class org.mule.module.extension.internal.util.CapabilityUtils
Expects the capabilities Set to have at most one capability of type capabilityType and returns such capability.
getSingleProperty(String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
getSingleProperty(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
getSingleProperty(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
getSingleProperty(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
getSize() - Method in class org.mule.module.http.internal.multipart.HttpPart
 
getSize() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
getSize() - Method in interface org.mule.transport.http.multipart.Part
Returns the size of this file.
getSize() - Method in class org.mule.transport.sftp.notification.SftpTransportNotification
 
getSize(String) - Method in class org.mule.transport.sftp.SftpClient
 
getSize() - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
 
getSize() - Method in class org.mule.util.queue.DefaultQueueStore
 
getSize() - Method in class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
Deprecated.
 
getSize() - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
getSize() - Method in interface org.mule.util.queue.objectstore.QueueInfoDelegate
Deprecated.
Return the size of the queue
getSize() - Method in interface org.mule.util.queue.QueueStore
 
getSize() - Method in interface org.mule.util.queue.QueueStoreDelegate
Return the size of the queue
getSizeCheckWaitTime() - Method in class org.mule.transport.sftp.SftpConnector
 
getSizeCheckWaitTime() - Method in class org.mule.transport.sftp.SftpUtil
 
getSoapAction(MuleMessage) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
getSoapBodyParts(BindingOperation) - Static method in class org.mule.module.ws.consumer.WSDLUtils
Retrieves the list of SOAP body parts of a binding operation, or null if there is no SOAP body defined.
getSoapService() - Method in class org.mule.transport.soap.axis.AxisMessageReceiver
 
getSoapVersion() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getSoapVersion() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getSoapVersion(Binding) - Static method in class org.mule.module.ws.consumer.WSDLUtils
Retrieves the SOAP version of a WSDL binding, or null if it is not a SOAP binding.
getSocket() - Method in class org.apache.commons.httpclient.HttpConnection
Returns the connection socket.
getSocket() - Method in class org.mule.ResponseOutputStream
 
getSocket(SocketHolder, MessageContext, String, String, int, int, StringBuffer, BooleanHolder) - Method in class org.mule.transport.soap.axis.extensions.MuleHttpSender
Deprecated.
Creates a socket connection to the SOAP server
getSocket(ImmutableEndpoint) - Method in class org.mule.transport.tcp.TcpConnector
Lookup a socket in the list of dispatcher sockets but don't create a new socket
getSocket() - Method in class org.mule.transport.udp.UdpMessageReceiver
Obtain the serverSocket
getSocketFactory() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getSocketFactory() - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
getSocketFactory() - Method in class org.mule.transport.email.SmtpsConnector
 
getSocketFactory() - Method in class org.mule.transport.tcp.TcpConnector
 
getSocketFactoryFallback() - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
getSocketFactoryFallback() - Method in class org.mule.transport.email.SmtpsConnector
 
getSocketFactoryProperties() - Method in class org.mule.module.management.agent.Mx4jAgent
 
getSocketMaxWait() - Method in class org.mule.transport.tcp.TcpConnector
 
getSocketReceiveBufferSize() - Method in class org.mule.transport.http.HttpServerConnection
Gets the value of the SO_RCVBUF for the underlying socket.
getSocketSoLinger() - Method in class org.mule.transport.tcp.TcpConnector
 
getSocketsPoolMaxActive() - Method in class org.mule.transport.tcp.TcpConnector
 
getSocketsPoolMaxIdle() - Method in class org.mule.transport.tcp.TcpConnector
 
getSocketsPoolMaxWait() - Method in class org.mule.transport.tcp.TcpConnector
 
getSocketsPoolNumActive() - Method in class org.mule.transport.tcp.TcpConnector
 
getSocketTimeout() - Method in class org.mule.transport.http.HttpServerConnection
Returns the value of the SO_TIMEOUT for the underlying socket.
getSoTimeout() - Method in class org.apache.commons.httpclient.HttpConnection
getSource() - Method in class org.mule.context.notification.BaseConnectorMessageNotification
 
getSource() - Method in class org.mule.context.notification.ComponentMessageNotification
 
getSource() - Method in class org.mule.context.notification.MessageProcessorNotification
 
getSource() - Method in class org.mule.enricher.MessageEnricher.EnrichExpressionPair
 
getSource() - Method in class org.mule.module.db.internal.processor.AbstractBulkUpdateMessageProcessor
 
getSource() - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
getSource() - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
getSourceClass() - Method in class org.mule.module.json.transformers.ObjectToJson
 
getSourceClass() - Method in class org.mule.module.xml.transformer.jaxb.JAXBMarshallerTransformer
 
getSourceDataTypes() - Method in interface org.mule.api.transformer.Transformer
Returns an unmodifiable list of Source types registered on this transformer
getSourceDataTypes() - Method in class org.mule.transformer.AbstractTransformer
 
getSourceDataTypes() - Method in class org.mule.transformer.CompositeConverter
 
getSourceFile(AnnotatedObject) - Static method in class org.mule.api.execution.LocationExecutionContextProvider
 
getSourceFileLine(AnnotatedObject) - Static method in class org.mule.api.execution.LocationExecutionContextProvider
 
getSources() - Method in interface org.mule.api.source.CompositeMessageSource
 
getSources() - Method in class org.mule.source.StartableCompositeMessageSource
 
getSourceTypes() - Method in interface org.mule.api.transformer.Transformer
Deprecated.
getSourceTypes() - Method in class org.mule.transformer.AbstractTransformer
Deprecated.
getSourceTypes() - Method in class org.mule.transformer.CompositeConverter
 
getSourceXML(AnnotatedObject) - Static method in class org.mule.api.execution.LocationExecutionContextProvider
 
getSpecification() - Method in class org.mule.transport.jms.JmsConnector
 
getSqlStatementStrategyFactory() - Method in class org.mule.transport.jdbc.JdbcConnector
 
getSqlText() - Method in class org.mule.module.db.internal.domain.query.QueryTemplate
Returns the SQL sentence for this query.
getSslContext() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getSslContext(TrustManager[]) - Method in class org.mule.api.security.tls.TlsConfiguration
 
getSslHandshakeTimeout() - Method in class org.mule.transport.http.HttpsConnector
 
getSslSession() - Method in class org.mule.module.http.internal.domain.request.ClientConnection
 
getSslSocketFactory() - Method in class org.mule.transport.http.HttpsConnector
 
getSslSocketHandshakeCompleteLatch() - Method in class org.mule.transport.http.HttpServerConnection
 
getSslType() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getSslType() - Method in class org.mule.transport.http.HttpsConnector
 
getSslType() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getStackTraceFilter() - Method in class org.mule.module.management.mbean.MuleConfigurationService
 
getStackTraceFilter() - Method in interface org.mule.module.management.mbean.MuleConfigurationServiceMBean
 
getStageDescription() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
getStageName() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
getStartableName(Startable) - Method in class org.mule.lifecycle.processor.ProcessIfStartedMessageProcessor
 
getStartDate() - Method in interface org.mule.api.MuleContext
Returns the date when the server was started.
getStartDate() - Method in class org.mule.DefaultMuleContext
Returns the long date when the server was started
getStartDelay() - Method in class org.mule.transport.polling.schedule.FixedFrequencyScheduler
 
getStartTime() - Method in class org.mule.management.stats.AllStatistics
 
getStartTime() - Method in class org.mule.module.management.mbean.MuleService
 
getStartTime() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getStartTimeout() - Method in class org.mule.work.WorkerContext
Gets the time duration (in milliseconds) within which the execution of the Work instance must start.
getStartupOptions() - Method in class org.mule.config.StartupContext
 
getStartupPropertiesFile() - Static method in class org.mule.module.launcher.MuleContainer
 
getStartupPropertiesFile() - Static method in class org.mule.MuleServer
 
getStartupScreen() - Method in class org.mule.context.DefaultMuleContextBuilder
 
getState() - Method in interface org.mule.api.lifecycle.LifecycleManager
Provides access to a state machine for this lifecycle manager.
getState() - Method in class org.mule.api.model.InvocationResult
 
getState() - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
getState(Object) - Method in interface org.mule.module.bpm.BPMS
 
getState() - Method in class org.mule.module.jbpm.EndedProcess
 
getState(Object) - Method in class org.mule.module.jbpm.Jbpm
 
getState(ProcessInstance) - Static method in class org.mule.module.jbpm.Jbpm
 
getState() - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
getState() - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
getStatefulJobClass() - Method in class org.mule.transport.quartz.config.AbstractJobConfig
 
getStatefulJobClass() - Method in class org.mule.transport.quartz.jobs.CustomJobConfig
 
getStatefulJobClass() - Method in class org.mule.transport.quartz.jobs.CustomJobFromMessageConfig
 
getStatefulJobClass() - Method in class org.mule.transport.quartz.jobs.EndpointPollingJobConfig
 
getStatefulJobClass() - Method in class org.mule.transport.quartz.jobs.EventGeneratorJobConfig
 
getStatefulJobClass() - Method in class org.mule.transport.quartz.jobs.ScheduledDispatchJobConfig
 
getStatelessJobClass() - Method in class org.mule.transport.quartz.config.AbstractJobConfig
 
getStatelessJobClass() - Method in class org.mule.transport.quartz.jobs.CustomJobConfig
 
getStatelessJobClass() - Method in class org.mule.transport.quartz.jobs.CustomJobFromMessageConfig
 
getStatelessJobClass() - Method in class org.mule.transport.quartz.jobs.EndpointPollingJobConfig
 
getStatelessJobClass() - Method in class org.mule.transport.quartz.jobs.EventGeneratorJobConfig
 
getStatelessJobClass() - Method in class org.mule.transport.quartz.jobs.ScheduledDispatchJobConfig
 
getStatement(ResultSet) - Method in class org.mule.module.db.internal.result.resultset.SingleResultResultSetCloser
 
getStatement(ImmutableEndpoint) - Method in class org.mule.transport.jdbc.JdbcConnector
 
getStatementResultIteratorFactory(ResultSetHandler) - Method in class org.mule.module.db.internal.domain.connection.AbstractDbConnection
 
getStatementResultIteratorFactory(ResultSetHandler) - Method in interface org.mule.module.db.internal.domain.connection.DbConnection
Returns the StatementResultIteratorFactory used to create the StatementResultIterator for this connection.
getStaticEndpoint(MuleEvent) - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getStaticOutputMetadata() - Method in class org.mule.module.db.internal.metadata.AbstractQueryMetadataProvider
 
getStaticOutputMetadata() - Method in class org.mule.module.db.internal.metadata.PreparedBulkUpdateMetadataProvider
 
getStaticOutputMetadata() - Method in class org.mule.module.db.internal.metadata.SelectMetadataProvider
 
getStaticOutputMetadata() - Method in class org.mule.module.db.internal.metadata.UpdateMetadataProvider
 
getStatistics() - Method in interface org.mule.api.component.Component
Component statistics are used to gather component statistics such as sync/async invocation counts and total and average execution time.
getStatistics() - Method in interface org.mule.api.construct.FlowConstruct
 
getStatistics() - Method in interface org.mule.api.MuleContext
 
getStatistics() - Method in interface org.mule.api.service.Service
Deprecated.
Returns the Service statistics.
getStatistics() - Method in class org.mule.client.DefaultLocalMuleClient.MuleClientFlowConstruct
 
getStatistics() - Method in class org.mule.component.AbstractComponent
 
getStatistics() - Method in class org.mule.construct.AbstractFlowConstruct
 
getStatistics() - Method in class org.mule.DefaultMuleContext
Gets all statistics for this instance
getStatistics() - Method in class org.mule.management.stats.ProcessingTime
 
getStatistics() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getStatistics() - Method in interface org.mule.module.management.mbean.FlowConstructServiceMBean
The statistics for this flow construct
getStatistics() - Method in class org.mule.module.management.mbean.ServiceService
 
getStatistics() - Method in class org.mule.service.AbstractService
Deprecated.
 
getStatus() - Method in interface org.mule.api.transaction.Transaction
 
getStatus() - Method in interface org.mule.module.launcher.application.Application
 
getStatus() - Method in class org.mule.module.launcher.application.ApplicationWrapper
 
getStatus() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
getStatus() - Method in class org.mule.module.management.mbean.YourKitProfilerService
Get current profiling status.
getStatus() - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
Get current profiling status.
getStatus() - Method in class org.mule.processor.DelegateTransaction
 
getStatus() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
getStatus() - Method in class org.mule.transaction.XaTransaction
 
getStatus() - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
getStatusCode() - Method in enum org.mule.module.http.api.HttpConstants.HttpStatus
 
getStatusCode() - Method in class org.mule.module.http.internal.domain.response.DefaultHttpResponse
 
getStatusCode() - Method in interface org.mule.module.http.internal.domain.response.HttpResponse
 
getStatusCode() - Method in class org.mule.module.http.internal.domain.response.ResponseStatus
 
getStatuscode() - Method in class org.mule.transport.http.HttpResponse
Deprecated.
getStatusCode() - Method in class org.mule.transport.http.HttpResponse
 
getStatusLine() - Method in class org.mule.transport.http.HttpResponse
 
getStore() - Method in class org.mule.routing.IdempotentMessageFilter
 
getStore() - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
getStoreName() - Method in class org.mule.util.store.ManagedObjectStore
 
getStorePrefix() - Method in class org.mule.routing.AbstractAggregator
 
getStrategies() - Method in class org.mule.module.ws.security.WSSecurity
 
getStrategy() - Method in class org.mule.module.pgp.filters.PGPSecurityFilter
 
getStrategy() - Method in class org.mule.security.filters.MuleEncryptionEndpointSecurityFilter
 
getStrategy() - Method in class org.mule.transformer.compression.AbstractCompressionTransformer
 
getStrategy() - Method in class org.mule.transformer.encryption.AbstractEncryptionTransformer
 
getStrategyName() - Method in class org.mule.transformer.encryption.AbstractEncryptionTransformer
 
getStreamCloserService() - Method in interface org.mule.api.MuleContext
Returns the configured StreamCloserService
getStreamCloserService() - Method in class org.mule.DefaultMuleContext
Returns the configured StreamCloserService
getStreamFrom(String) - Method in class org.mule.module.ws.consumer.MuleWSDLLocator
 
getStreamSource() - Method in class org.mule.module.xml.transformer.XsltTransformer
Returns the StreamSource corresponding to xslt (which should have been loaded in AbstractXmlTransformer.initialise()).
getString(String, String) - Static method in class org.mule.config.i18n.LocaleMessageHandler
Get the resource string for the given bundle name and resource code
getString(String, String, Object) - Static method in class org.mule.config.i18n.LocaleMessageHandler
Get the resource string for the given bundle name, resource code and one argument
getString(String, String, Object, Object) - Static method in class org.mule.config.i18n.LocaleMessageHandler
Get the resource string for the given bundle name, resource code and two arguments
getString(String, String, Object[]) - Static method in class org.mule.config.i18n.LocaleMessageHandler
Get the resource string for the given bundle name, resource code and array of arguments.
getString(String, Locale, String, Object[]) - Static method in class org.mule.config.i18n.LocaleMessageHandler
Get the resource string for the given bundle name, locale, resource code and array of arguments.
getString(String, int) - Method in class org.mule.config.i18n.MessageFactory
Factory method to read the message with code code from the resource bundle.
getString(String, int, Object) - Method in class org.mule.config.i18n.MessageFactory
Factory method to read the message with code code from the resource bundle.
getString(String, int, Object, Object) - Method in class org.mule.config.i18n.MessageFactory
Factory method to read the message with code code from the resource bundle.
getString(String, int, Object[]) - Method in class org.mule.config.i18n.MessageFactory
 
getString(Object) - Method in class org.mule.transport.http.multipart.MultiMap
Get value as String.
getString(Object, String) - Static method in class org.mule.util.ObjectUtils
Gets a String from a value in a null-safe manner.
getString(byte[], String) - Static method in class org.mule.util.StringMessageUtils
 
getStringData() - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
getStringFromDate(Date, String) - Static method in class org.mule.util.DateUtils
 
getStringProperty(String, String) - Method in interface org.mule.api.MuleMessage
getStringProperty(String, String) - Method in class org.mule.DefaultMuleMessage
Deprecated.
getStringProperty(String, String) - Method in class org.mule.MessagePropertiesContext
Deprecated.
getStringProperty(String, PropertyScope, String) - Method in class org.mule.MessagePropertiesContext
 
getStyle() - Method in class org.mule.transport.soap.axis.component.WebServiceWrapperComponent
 
getStyle() - Method in class org.mule.util.TemplateParser
 
getSubCode() - Method in exception org.mule.module.ws.consumer.SoapFaultException
 
getSubFlow(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
 
getSubFlowName() - Method in class org.mule.processor.chain.SubflowInterceptingChainLifecycleWrapper
 
getSubFlowName() - Method in interface org.mule.processor.chain.SubFlowMessageProcessor
 
getSubject() - Method in class org.mule.module.jaas.JaasAuthentication
 
getSubject() - Method in class org.mule.transport.email.SmtpConnector
 
getSubPaths() - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.PathMap
 
getSubProcessInstance() - Method in class org.mule.module.jbpm.EndedProcess
 
getSubscription() - Method in class org.mule.context.notification.ListenerSubscriptionPair
 
getSubscriptionFilter() - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
the type of filter used to filter subscriptions
getSubscriptions() - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
A list of endpoints the eventMulticaster will receive events on Note that if this eventMulticaster has a Mule Descriptor associated with it, these endpoints are ignored and the ones on the Mule Descriptor are used.
getSubscriptions() - Method in interface org.mule.module.spring.events.MuleSubscriptionEventListener
Deprecated.
 
getSuffix() - Method in class org.mule.util.TemplateParser.PatternInfo
 
getSummary() - Method in class org.mule.tck.functional.FunctionalStreamingTestComponent
 
getSummaryMessage() - Method in exception org.mule.api.MuleException
 
getSupportedCipherSuites() - Method in class org.mule.api.security.tls.RestrictedSSLServerSocketFactory
 
getSupportedCipherSuites() - Method in class org.mule.api.security.tls.RestrictedSSLSocketFactory
 
getSupportedCipherSuites() - Method in class org.mule.api.security.tls.TlsPropertiesSocketFactory
 
getSupportedFormat() - Method in interface org.mule.module.launcher.descriptor.DescriptorParser
 
getSupportedFormat() - Method in class org.mule.module.launcher.descriptor.PropertiesDescriptorParser
 
getSupportedJdks() - Static method in class org.mule.config.MuleManifest
 
getSupportedJdks() - Static method in class org.mule.util.JdkVersionUtils
 
getSupportedPhases() - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
getSupportedPhases() - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
getSupportedProtocols() - Method in class org.mule.transport.AbstractConnector
Returns an unmodifiable list of the protocols supported by this connector
getSupportedSchemes() - Method in class org.mule.transport.soap.axis.AxisConnector
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.AbstractMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.ajax.AjaxMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.DefaultMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.email.MailMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.file.FileContentsMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.file.FileMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.ftp.FtpMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.rmi.RmiMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.soap.axis.AxisMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.udp.UdpMuleMessageFactory
 
getSupportedTransportMessageTypes() - Method in class org.mule.transport.xmpp.XmppMuleMessageFactory
 
getSyncBatchSize() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getSyncEventsReceived() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
 
getSyncEventsReceived() - Method in class org.mule.management.stats.ApplicationStatistics
 
getSyncEventsReceived() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getSyncEventsReceived() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
getSyncEventsReceived() - Method in interface org.mule.module.management.mbean.FlowConstructStatsMBean
 
getSyncEventsReceived() - Method in class org.mule.module.management.mbean.ServiceService
 
getSyncEventsSent() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
getSyncEventsSent() - Method in class org.mule.module.management.mbean.ServiceService
 
getSyncEventsSent() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getSyncEventsSent() - Method in interface org.mule.module.management.mbean.ServiceStatsMBean
Deprecated.
 
getSynchronous() - Method in class org.mule.routing.outbound.AbstractRecipientList
 
getSynchronousEventTimeout() - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
getSynchronousEventTimeout() - Method in class org.mule.module.management.mbean.MuleConfigurationService
 
getSynchronousEventTimeout() - Method in interface org.mule.module.management.mbean.MuleConfigurationServiceMBean
 
getSyncTime() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
getSystemClasses() - Method in class org.mule.transport.servlet.jetty.WebappsConfiguration
 
getSystemId() - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
getSystemModelType() - Method in interface org.mule.api.config.MuleConfiguration
 
getSystemModelType() - Method in class org.mule.config.DefaultMuleConfiguration
 
getSystemModules(MuleContext) - Method in class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
getSystemName() - Method in interface org.mule.api.config.MuleConfiguration
 
getSystemName() - Method in class org.mule.config.DefaultMuleConfiguration
 
getSystemProperties() - Method in class org.mule.el.context.ServerContext
 
getTable(Collection) - Method in class org.mule.management.stats.printers.AbstractTablePrinter
 
getTap() - Method in class org.mule.routing.WireTap
 
getTarget() - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
 
getTarget() - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
getTarget() - Method in class org.mule.enricher.MessageEnricher.EnrichExpressionPair
 
getTarget() - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
getTarget() - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
getTargetBasePath() - Method in class org.mule.module.atom.server.MuleRequestContext
 
getTargetBuilder(RequestContext) - Method in class org.mule.module.atom.MuleProvider
 
getTargetClass(Service) - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
Try to determine the target class from the Service.
getTargetConfig() - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
getTargetObject() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getTargetObject() - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
Get XAConnection or XASession from wrapper / proxy
getTargetObject() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getTargetObject() - Method in class org.mule.transport.jms.xa.ConnectionInvocationHandler
 
getTargetObject() - Method in class org.mule.transport.jms.xa.SessionInvocationHandler
 
getTargetObject() - Method in interface org.mule.util.proxy.TargetInvocationHandler
 
getTargetOrEndpoint() - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
getTargetPropertyConfiguration() - Method in class org.mule.config.spring.parsers.AbstractHierarchicalDefinitionParser
 
getTargetPropertyConfiguration() - Method in class org.mule.config.spring.parsers.delegate.AbstractSingleParentFamilyChildDefinitionParser
 
getTargetPropertyConfiguration() - Method in class org.mule.config.spring.parsers.delegate.MapDefinitionParserMutator
 
getTargetPropertyConfiguration() - Method in interface org.mule.config.spring.parsers.MuleChildDefinitionParser
 
getTargetReceiver(MuleMessage, ImmutableEndpoint) - Method in class org.mule.transport.http.OldHttpMessageReceiver
 
getTargetReference(EndpointInfo, EndpointReferenceType) - Static method in class org.mule.module.cxf.transport.MuleUniversalConduit
Get the target endpoint reference.
getTargetResolver(RequestContext) - Method in class org.mule.module.atom.MuleProvider
 
getTargetType(MethodParameter) - Static method in class org.mule.util.generics.GenericTypeResolver
Determine the target type for the given parameter specification.
getTcpProtocol() - Method in class org.mule.transport.tcp.TcpConnector
 
getTempDirInbound() - Method in class org.mule.transport.sftp.SftpConnector
 
getTempDirInbound() - Method in class org.mule.transport.sftp.SftpUtil
 
getTempDirOutbound() - Method in class org.mule.transport.sftp.SftpConnector
 
getTempDirOutbound() - Method in class org.mule.transport.sftp.SftpUtil
 
getTemplates() - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Method getTemplates.
getTestHeader() - Method in class org.mule.tck.AbstractServiceAndFlowTestCase
Deprecated.
 
getTestTimeoutSecs() - Method in class org.mule.test.infrastructure.process.AbstractMultipleProcessTestCase
 
getText() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getText() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getTextCharacters() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getTextCharacters(int, char[], int, int) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getTextCharacters() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getTextCharacters(int, char[], int, int) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getTextChild(Element) - Static method in class org.mule.util.XMLUtils
 
getTextData() - Method in class org.mule.module.pgp.LiteralMessage
 
getTextLength() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getTextLength() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getTextStart() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getTextStart() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
getTheFailedMessageProcessor() - Method in class org.mule.processor.AbstractRedeliveryPolicy
 
getThirdPartyCode() - Method in exception org.mule.api.ConnectionException
Get a code for what went wrong as provided by the third party API
getThreadFactory() - Method in interface org.mule.api.config.ThreadingProfile
 
getThreadFactory() - Method in class org.mule.config.ChainedThreadingProfile
 
getThreadFactory() - Method in class org.mule.config.ImmutableThreadingProfile
 
getThreadFactory() - Method in class org.mule.config.MutableThreadingProfile
 
getThreadingProfile() - Method in class org.mule.config.spring.factories.ScatterGatherRouterFactoryBean
 
getThreadingProfile() - Method in class org.mule.model.seda.SedaService
Deprecated.
 
getThreadingProfile() - Method in class org.mule.routing.UntilSuccessful
 
getThreadingProfile() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
getThreadingProfile() - Method in class org.mule.work.MuleWorkManager
 
getThreadNamePrefix() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getThreadPoolFor(Connection, IOEvent) - Method in class org.mule.module.http.internal.listener.grizzly.ExecutorPerServerAddressIOStrategy
 
getThreadPoolName(String, MuleContext) - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
getThreadPoolSize() - Method in class org.mule.management.stats.FlowConstructStatistics
 
getThreadPriority() - Method in class org.mule.work.WorkerContext
Gets the priority level of the thread, which will be dispatched to process this work.
getThreadTTL() - Method in interface org.mule.api.config.ThreadingProfile
 
getThreadTTL() - Method in class org.mule.config.ChainedThreadingProfile
 
getThreadTTL() - Method in class org.mule.config.ImmutableThreadingProfile
 
getThreadTTL() - Method in class org.mule.config.MutableThreadingProfile
 
getThreadTTL() - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
getThreadWaitTimeout() - Method in interface org.mule.api.config.ThreadingProfile
 
getThreadWaitTimeout() - Method in class org.mule.config.ChainedThreadingProfile
 
getThreadWaitTimeout() - Method in class org.mule.config.ImmutableThreadingProfile
 
getThreadWaitTimeout() - Method in class org.mule.config.MutableThreadingProfile
 
getThreadWaitTimeout() - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
getThrowable() - Method in class org.mule.retry.PolicyStatus
 
getTime() - Method in class org.mule.el.datetime.DateTime
 
getTime() - Method in class org.mule.tck.testmodels.services.PersonResponse
 
getTime() - Method in class org.mule.util.counters.impl.RatePerUnit
 
getTimeExpired() - Method in class org.mule.util.timer.TimeEvent
 
getTimeout() - Method in interface org.mule.api.MuleEvent
The number of milliseconds to wait for a return event when running synchronously.
getTimeout() - Method in interface org.mule.api.MuleEventContext
Get the timeout value associated with the event
getTimeout() - Method in interface org.mule.api.transaction.Transaction
 
getTimeout() - Method in interface org.mule.api.transaction.TransactionConfig
 
getTimeout() - Method in class org.mule.DefaultMuleEvent
 
getTimeout() - Method in class org.mule.DefaultMuleEventContext
Get the timeout value associated with the event
getTimeout() - Method in class org.mule.processor.DelegateTransaction
 
getTimeout() - Method in class org.mule.routing.AbstractAggregator
 
getTimeout() - Method in class org.mule.routing.correlation.EventCorrelator
 
getTimeout() - Method in class org.mule.service.ServiceAsyncReplyCompositeMessageSource
Deprecated.
 
getTimeout(int) - Static method in class org.mule.test.infrastructure.process.TestUtils
 
getTimeout() - Method in class org.mule.transaction.AbstractTransaction
 
getTimeout() - Method in class org.mule.transaction.MuleTransactionConfig
 
getTimeout() - Method in class org.mule.transaction.XaTransactionFactory
 
getTimeout() - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
getTimeout() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
getTimeout() - Method in class org.mule.transport.quartz.jobs.EndpointPollingJobConfig
 
getTimeout() - Method in class org.mule.transport.soap.axis.extensions.AxisMuleSession
 
getTimeout() - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
getTimeout() - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
getTimeout() - Method in interface org.mule.transport.tcp.TcpClientSocketProperties
 
getTimeout() - Method in interface org.mule.transport.tcp.TcpServerSocketProperties
 
getTimeout() - Method in class org.mule.transport.udp.UdpConnector
 
getTimeout() - Method in class org.mule.VoidMuleEvent
 
getTimestamp() - Method in class org.mule.api.context.notification.ServerNotification
 
getTimeStamp() - Method in class org.mule.message.ExceptionMessage
 
getTimeStamp(String) - Static method in class org.mule.util.DateUtils
 
getTimestamp() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper.StoredObject
 
getTimeToLive(MuleMessage) - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
getTimeToLive() - Method in class org.mule.transport.multicast.MulticastConnector
 
getTimeUnit() - Method in class org.mule.transport.AbstractPollingMessageReceiver
 
getTimeUnit() - Method in class org.mule.transport.polling.schedule.FixedFrequencyScheduler
 
getTimeZone() - Method in interface org.mule.api.el.datetime.Instant
 
getTimeZone() - Method in class org.mule.el.context.ServerContext
 
getTimeZone() - Method in class org.mule.el.datetime.AbstractInstant
 
getTimeZone() - Method in class org.mule.modules.schedulers.cron.CronScheduler
 
getTlsContext() - Method in interface org.mule.module.http.api.listener.HttpListenerConfig
 
getTlsContext() - Method in interface org.mule.module.http.api.requester.HttpRequesterConfig
 
getTlsContext() - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
getTlsContext() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
getTlsContext() - Method in interface org.mule.module.oauth2.internal.authorizationcode.AuthorizationCodeGrantType
 
getTlsContext() - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
getTlsContext() - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
getTlsContext() - Method in class org.mule.module.ws.security.WssDecryptSecurityStrategy
 
getTlsContext() - Method in class org.mule.module.ws.security.WssEncryptSecurityStrategy
 
getTlsContext() - Method in class org.mule.module.ws.security.WssSignSecurityStrategy
 
getTlsContext() - Method in class org.mule.module.ws.security.WssVerifySignatureSecurityStrategy
 
getTlsContextFactory() - Method in interface org.mule.module.http.api.client.HttpRequestOptions
 
getTlsContextFactory() - Method in class org.mule.module.http.internal.request.client.DefaultHttpRequestOptions
 
getTlsContextFactory() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getTlsContextFactory() - Method in class org.mule.module.ws.consumer.MuleWSDLLocatorConfig
 
getTmpDir() - Method in class org.mule.el.context.ServerContext
 
getToken() - Method in class org.mule.security.MuleCredentials
 
getTokenResponseParameters() - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
getTokenResponseProcessor() - Method in exception org.mule.module.oauth2.internal.TokenNotFoundException
 
getTokenUrl() - Method in class org.mule.module.oauth2.internal.AbstractTokenRequestHandler
 
getTokenUrlResponse() - Method in exception org.mule.module.oauth2.internal.AbstractTokenRequestHandler.TokenUrlResponseException
 
getTokenUrlResponse() - Method in exception org.mule.module.oauth2.internal.TokenNotFoundException
 
getTopicResolver() - Method in class org.mule.transport.jms.JmsConnector
Getter for property 'topicResolver'.
getTopLevelTypeName(DataType) - Static method in class org.mule.module.extension.internal.util.NameUtils
Returns the name of the give top level type.
getTotalEventsReceived() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
 
getTotalEventsReceived() - Method in class org.mule.management.stats.ApplicationStatistics
 
getTotalEventsReceived() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getTotalEventsReceived() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
getTotalEventsReceived() - Method in interface org.mule.module.management.mbean.FlowConstructStatsMBean
 
getTotalEventsReceived() - Method in class org.mule.module.management.mbean.ServiceService
 
getTotalEventsSent() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
getTotalEventsSent() - Method in class org.mule.module.management.mbean.ServiceService
 
getTotalEventsSent() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getTotalEventsSent() - Method in interface org.mule.module.management.mbean.ServiceStatsMBean
Deprecated.
 
getTotalExecutionTime() - Method in class org.mule.management.stats.ComponentStatistics
The total cumulative execution time since statistics were last cleared.
getTotalExecutionTime() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated. 
getTotalExecutionTime() - Method in class org.mule.module.management.mbean.ServiceService
 
getTotalExecutionTime() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
getTotalExecutionTime() - Method in interface org.mule.module.management.mbean.ServiceStatsMBean
Deprecated.
 
getTotalMemory() - Method in class org.mule.module.management.mbean.MuleService
 
getTotalMemory() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getTotalProcessingTime() - Method in class org.mule.management.stats.ApplicationStatistics
 
getTotalProcessingTime() - Method in class org.mule.management.stats.FlowConstructStatistics
 
getTotalProcessingTime() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getTotalProcessingTime() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
getTotalProcessingTime() - Method in interface org.mule.module.management.mbean.FlowConstructStatsMBean
 
getTotalReceived() - Method in class org.mule.management.stats.RouterStatistics
 
getTotalReceived() - Method in class org.mule.module.management.mbean.RouterStats
 
getTotalReceived() - Method in interface org.mule.module.management.mbean.RouterStatsMBean
 
getTotalResults() - Method in class org.mule.streaming.PagingDelegate
returns the total amount of items in the unpaged resultset.
getTotalResults() - Method in class org.mule.streaming.PagingDelegateWrapper
returns the total amount of items in the unpaged resultset.
getTotalResults() - Method in class org.mule.streaming.processor.ManagedPagingDelegateAdapter
 
getTotalResults(P) - Method in class org.mule.streaming.ProviderAwarePagingDelegate
returns the total amount of items in the non-paged result set.
getTotalRouted() - Method in class org.mule.management.stats.RouterStatistics
 
getTotalRouted() - Method in class org.mule.module.management.mbean.RouterStats
 
getTotalRouted() - Method in interface org.mule.module.management.mbean.RouterStatsMBean
 
getTrackedConnectionLock(DbConnection) - Method in class org.mule.module.db.internal.result.statement.StatementStreamingResultSetCloser
 
getTransacted() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
getTransacted() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
getTransacted() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
getTransaction() - Method in interface org.mule.api.MuleEventContext
Returns the transaction for the current event or null if there is no transaction in progresss
getTransaction() - Method in class org.mule.DefaultMuleEventContext
Returns the transaction for the current event or null if there is no transaction in progresss
getTransaction() - Method in interface org.mule.module.db.internal.domain.transaction.DbTransactionManager
 
getTransaction() - Method in class org.mule.module.db.internal.domain.transaction.TransactionCoordinationDbTransactionManager
 
getTransaction() - Method in class org.mule.transaction.TransactionCoordination
 
getTransaction() - Method in class org.mule.transaction.XaTransaction
 
getTransactionalAction() - Method in class org.mule.module.db.internal.domain.connection.AbstractDbConnection
 
getTransactionalAction() - Method in interface org.mule.module.db.internal.domain.connection.DbConnection
Indicates which TransactionalAction used to create this connection
getTransactionalContext() - Method in class org.mule.util.queue.AbstractQueueSession
 
getTransactionalContext() - Method in class org.mule.util.queue.TransactionalQueueSession
 
getTransactionalContext() - Method in interface org.mule.util.queue.TransactionContextProvider
 
getTransactionalResource(ImmutableEndpoint) - Method in class org.mule.transport.AbstractConnector
Returns transactional resource to use based on endpoint configuration and transactional context.
getTransactionalResource(Xid) - Method in class org.mule.util.queue.objectstore.xa.AbstractXAResourceManager
Deprecated.
 
getTransactionalResource(Xid) - Method in class org.mule.util.xa.AbstractXAResourceManager
 
getTransactionConfig() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
Returns the transaction configuration for this endpoint
getTransactionConfig() - Method in class org.mule.endpoint.AbstractEndpoint
 
getTransactionConfig() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getTransactionConfig() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getTransactionConfig() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getTransactionConfig() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getTransactionConfig() - Method in interface org.mule.execution.MessageProcessContext
 
getTransactionConfig() - Method in class org.mule.module.http.internal.listener.HttpMessageProcessContext
 
getTransactionConfig() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
getTransactionConfig() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getTransactionConfig() - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
getTransactionConfig() - Method in class org.mule.transport.TransportMessageProcessContext
 
getTransactionContext() - Method in class org.mule.util.queue.QueueTypeTransactionContextAdapter
 
getTransactionContext() - Method in class org.mule.util.xa.DefaultXASession
 
getTransactionFactory() - Method in class org.mule.config.spring.factories.TransactionalMessageProcessorsFactoryBean
 
getTransactionFactoryFor(Class) - Method in class org.mule.api.SingleResourceTransactionFactoryManager
 
getTransactionFactoryManager() - Method in interface org.mule.api.MuleContext
 
getTransactionFactoryManager() - Method in class org.mule.DefaultMuleContext
 
getTransactionIsolation() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
getTransactionIsolation() - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
getTransactionIsolation() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getTransactionIsolation() - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
getTransactionIsolation() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getTransactionManager() - Method in interface org.mule.api.MuleContext
Returns the Jta transaction manager used by this Mule server instance.
getTransactionManager() - Method in class org.mule.DefaultMuleContext
Returns the Jta transaction manager used by this Mule server instance.
getTransactionStringId() - Method in class org.mule.context.notification.TransactionNotification
 
getTransactionTimeout() - Method in class org.mule.module.management.mbean.MuleConfigurationService
 
getTransactionTimeout() - Method in interface org.mule.module.management.mbean.MuleConfigurationServiceMBean
 
getTransactionTimeout() - Method in class org.mule.transport.jms.xa.XAResourceWrapper
 
getTransactionTimeout() - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
getTransactionTimeout() - Method in class org.mule.util.queue.TransactionalQueueSession
 
getTransactionTimeout() - Method in class org.mule.util.xa.DefaultXASession
 
getTransferEncoding() - Method in class org.mule.module.http.internal.listener.HttpResponseHeaderBuilder
 
getTransformedConstructor(Transformer, Transformer) - Method in class org.mule.endpoint.URIBuilder
 
getTransformer() - Method in exception org.mule.api.transformer.TransformerException
 
getTransformer() - Method in exception org.mule.api.transformer.TransformerMessagingException
 
getTransformer() - Static method in class org.mule.module.xml.util.XMLUtils
 
getTransformer() - Method in class org.mule.routing.outbound.TransformerRouter
Deprecated.
 
getTransformer() - Method in class org.mule.transformer.TransformerWeighting
 
getTransformerFactory() - Method in class org.mule.module.json.transformers.JsonXsltTransformer
 
getTransformerFactory() - Method in class org.mule.module.xml.transformer.XsltTransformer
 
getTransformerFactory() - Method in class org.mule.util.xmlsecurity.XMLSecureFactories
 
getTransformerFactory(DefaultXMLSecureFactories) - Method in class org.mule.util.xmlsecurity.XMLSecureFactoriesCache
 
getTransformerForMethodWithAnnotations(Method, MuleContext) - Static method in class org.mule.config.expression.ExpressionAnnotationsHelper
 
getTransformers() - Method in interface org.mule.api.endpoint.EndpointURI
 
getTransformers() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
Deprecated.
use getMessageProcessors() instead
getTransformers() - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
Use lookupTransformer() instead
getTransformers() - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
getTransformers() - Method in class org.mule.endpoint.AbstractEndpoint
Deprecated.
use getMessageProcessors()
getTransformers() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
getTransformers() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
getTransformers() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
getTransformers() - Method in class org.mule.endpoint.MuleEndpointURI
 
getTransformers() - Method in class org.mule.registry.MuleRegistryHelper
getTransformers() - Method in class org.mule.routing.outbound.FilteringOutboundRouter
 
getTransformers() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
getTransformers(String, MuleContext) - Static method in class org.mule.transformer.TransformerUtils
Builds a list of Transformers.
getTransformers() - Method in interface org.mule.transformer.TransformerUtils.TransformerSource
 
getTransformersFromSource(TransformerUtils.TransformerSource) - Static method in class org.mule.transformer.TransformerUtils
 
getTransformersFromUri(EndpointURI) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
getTransport() - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
getTransportClass(String) - Static method in class org.mule.transport.soap.axis.extensions.MuleTransport
 
getTransportErrorMapping(String, Class, MuleContext) - Static method in class org.mule.config.ExceptionHelper
Maps an exception thrown for a certain protocol to an error.
getTransportName() - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
getTrimmedValue(String) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method getTrimmedValue.
getTrustManagerAlgorithm() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getTrustManagerAlgorithm() - Method in interface org.mule.api.security.TlsDirectTrustStore
 
getTrustManagerAlgorithm() - Method in class org.mule.transport.http.HttpsConnector
 
getTrustManagerAlgorithm() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getTrustManagerFactory() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getTrustManagerFactory() - Method in interface org.mule.api.security.TlsDirectTrustStore
 
getTrustManagerFactory() - Method in class org.mule.transport.http.HttpsConnector
 
getTrustManagerFactory() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getTrustStore() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getTrustStore() - Method in interface org.mule.api.security.TlsIndirectTrustStore
 
getTrustStore() - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
getTrustStore() - Method in class org.mule.transport.email.SmtpsConnector
 
getTrustStore() - Method in class org.mule.transport.http.HttpsConnector
 
getTrustStore() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getTrustStorePassword() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getTrustStorePassword() - Method in interface org.mule.api.security.TlsIndirectTrustStore
 
getTrustStorePassword() - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
getTrustStorePassword() - Method in class org.mule.transport.email.SmtpsConnector
 
getTrustStorePassword() - Method in class org.mule.transport.http.HttpsConnector
 
getTrustStorePassword() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getTrustStoreType() - Method in class org.mule.api.security.tls.TlsConfiguration
 
getTrustStoreType() - Method in interface org.mule.api.security.TlsDirectTrustStore
 
getTrustStoreType() - Method in class org.mule.transport.http.HttpsConnector
 
getTrustStoreType() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
getTxCollection() - Method in interface org.mule.transaction.TransactionCollection
 
getTxId() - Method in interface org.mule.util.journal.JournalEntry
 
getTxId() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
getTxManager() - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
getType() - Method in class org.mule.api.context.notification.ServerNotification
 
getType() - Method in class org.mule.api.debug.FieldDebugInfo
 
getType() - Method in interface org.mule.api.expression.PropertyConverter
 
getType() - Method in interface org.mule.api.model.Model
Deprecated.
Returns the model type name.
getType() - Method in interface org.mule.api.transformer.DataType
The object type of the source object to transform.
getType() - Method in class org.mule.config.converters.FilterConverter
 
getType() - Method in class org.mule.config.converters.PropertiesConverter
 
getType() - Method in class org.mule.config.converters.TransformerConverter
 
getType() - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
getType() - Method in class org.mule.config.support.InheritedModel
Deprecated.
 
getType() - Method in class org.mule.context.notification.BaseConnectorMessageNotification
 
getType() - Method in class org.mule.context.notification.ComponentMessageNotification
 
getType() - Method in class org.mule.context.notification.ConnectionNotification
 
getType() - Method in class org.mule.context.notification.ExceptionNotification
 
getType() - Method in class org.mule.context.notification.RoutingNotification
 
getType() - Method in class org.mule.context.notification.SecurityNotification
 
getType() - Method in class org.mule.lifecycle.LifecycleObject
 
getType() - Method in class org.mule.model.seda.SedaModel
Deprecated.
Returns the model type name.
getType(Element) - Method in class org.mule.module.db.internal.config.domain.param.AbstractParamDefinitionDefinitionParser
 
getType() - Method in class org.mule.module.db.internal.domain.param.AbstractQueryParam
 
getType() - Method in interface org.mule.module.db.internal.domain.param.QueryParam
Returns the parameter's type.
getType() - Method in class org.mule.module.db.internal.domain.query.QueryTemplate
Returns the type of SQL query.
getType() - Method in class org.mule.module.extension.internal.capability.metadata.ExtendingOperationCapability
 
getType() - Method in class org.mule.module.extension.internal.capability.metadata.TypeRestrictionCapability
 
getType() - Method in class org.mule.module.extension.internal.introspection.ParameterGroup
 
getType() - Method in class org.mule.module.http.internal.domain.request.HttpRequestAuthentication
 
getType() - Method in class org.mule.module.http.internal.HttpParam
 
getType() - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
getType() - Method in class org.mule.module.launcher.util.ElementEvent
 
getType() - Method in class org.mule.module.management.mbean.FlowConstructService
 
getType() - Method in interface org.mule.module.management.mbean.FlowConstructServiceMBean
The type of flow construct
getType() - Method in class org.mule.module.management.mbean.ModelService
Deprecated.
 
getType() - Method in interface org.mule.module.management.mbean.ModelServiceMBean
 
getType() - Method in class org.mule.module.rss.transformers.RssParser
 
getType() - Method in class org.mule.transformer.types.CollectionDataType
 
getType() - Method in class org.mule.transformer.types.SimpleDataType
 
getType() - Method in class org.mule.transport.soap.axis.NamedParameter
 
getType() - Method in class org.mule.util.annotation.AnnotationMetaData
 
getType() - Method in interface org.mule.util.counters.Counter
Accessor for the counter type.
getType() - Method in class org.mule.util.counters.impl.AbstractCounter
 
getTypeAsString() - Method in class org.mule.module.launcher.util.ElementEvent
 
getTypedProperty(String, MuleMessage) - Static method in class org.mule.expression.ExpressionUtils
 
getTypedProperty(String, MuleMessage, PropertyScope) - Static method in class org.mule.expression.ExpressionUtils
 
getTypeIndexForCurrentLevel() - Method in class org.mule.util.generics.MethodParameter
Return the type index for the current nesting level.
getTypeIndexForLevel(int) - Method in class org.mule.util.generics.MethodParameter
Return the type index for the specified nesting level.
getTypeMap() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
getTypeMap() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getTypeMap() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getUnacceptedMessageProcessor() - Method in class org.mule.processor.AbstractFilteringMessageProcessor
 
getUnderstoodHeaders() - Method in class org.mule.module.cxf.support.MuleHeadersInInterceptor
 
getUniqueId() - Method in interface org.mule.api.MuleMessage
gets the unique identifier for the message.
getUniqueId() - Method in class org.mule.DefaultMuleMessage
gets the unique identifier for the message.
getUniqueIdString() - Method in interface org.mule.api.MuleContext
Generate a unique ID string; this will begin with the cluster node ID followed by a dash, e.g.
getUniqueIdString() - Method in class org.mule.DefaultMuleContext
 
getUniqueName(Element, String) - Static method in class org.mule.config.spring.parsers.generic.AutoIdUtils
 
getUniqueName(String) - Method in class org.mule.util.ObjectNameHelper
 
getUntilSuccessfulConfiguration() - Method in class org.mule.routing.AbstractUntilSuccessfulProcessingStrategy
 
getUpdate() - Method in class org.mule.util.JdkVersionUtils.JdkVersion
 
getUpdatedValue(MuleEvent) - Method in class org.mule.transport.polling.watermark.selector.SelectorWatermark
Returns the SelectorWatermark.selectorBroker value and resets it so that its reusable.
getUpdatedValue(MuleEvent) - Method in class org.mule.transport.polling.watermark.UpdateExpressionWatermark
Returns the new watermark value by evaluating UpdateExpressionWatermark.updateExpression on the flowVar of the given name
getUpdatedValue(MuleEvent) - Method in class org.mule.transport.polling.watermark.Watermark
This method is executed once the flow containing the poll has been executed.
getUpperCase() - Method in class org.mule.transformer.simple.ByteArrayToHexString
 
getUpperVersion() - Method in class org.mule.util.VersionRange
 
getUri() - Method in interface org.mule.api.endpoint.EndpointURI
 
getUri() - Method in class org.mule.endpoint.MuleEndpointURI
 
getUri() - Method in class org.mule.module.http.internal.domain.request.DefaultHttpRequest
 
getUri() - Method in interface org.mule.module.http.internal.domain.request.HttpRequest
 
getUri() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyHttpRequestAdapter
 
getUri() - Method in class org.mule.transport.http.RequestLine
 
getURI(MuleMessage) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
getUriPrefixes() - Method in class org.mule.module.cxf.transport.MuleUniversalTransport
 
getUriResolver() - Method in class org.mule.module.xml.transformer.XsltTransformer
 
getUriTemplate() - Method in class org.mule.endpoint.DynamicURIBuilder
 
getUrl() - Method in interface org.mule.api.callback.HttpCallback
 
getUrl() - Method in class org.mule.config.ConfigResource
 
getUrl() - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
getUrl() - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
getUrl() - Method in class org.mule.module.http.internal.request.client.HttpRequestCacheKey
 
getUrl() - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
getUrl() - Method in class org.mule.object.JndiObjectFactory
 
getUrl() - Method in class org.mule.security.oauth.DefaultHttpCallback
Retrieves url
getUrl() - Method in class org.mule.transport.email.SessionDetails
 
getUrl() - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
getUrlPrefix() - Method in class org.mule.module.db.internal.config.domain.database.AbstractVendorConfigResolverFactoryBean
 
getURLs() - Method in class org.mule.module.boot.DefaultMuleClassPathConfig
 
getURLs() - Method in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
getUrlWithoutParams() - Method in class org.mule.transport.http.HttpRequest
 
getUrlWithoutParams() - Method in class org.mule.transport.http.RequestLine
 
getUrlWithoutRequestParams() - Method in class org.mule.transport.http.HttpServerConnection
Returns the path of the http request without the http parameters encoded in the URL
getUse() - Method in class org.mule.transport.soap.axis.component.WebServiceWrapperComponent
 
getUsedNamespaces() - Method in class org.mule.module.xml.stax.MapNamespaceContext
 
getUser() - Method in interface org.mule.api.endpoint.EndpointURI
Returns the decoded user component of this EndpointURI.
getUser() - Method in class org.mule.endpoint.MuleEndpointURI
 
getUser() - Method in class org.mule.endpoint.URIBuilder
 
getUser() - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
getUser() - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
getUser() - Method in class org.mule.transport.xmpp.XmppConnector
 
getUserDir() - Method in class org.mule.el.context.ServerContext
 
getUserHome() - Method in class org.mule.el.context.ServerContext
 
getUserInfo() - Method in interface org.mule.api.endpoint.EndpointURI
Returns the decoded user-information component of this EndpointURI.
getUserInfo() - Method in class org.mule.endpoint.MuleEndpointURI
 
getUserLibFolder() - Static method in class org.mule.module.launcher.MuleFoldersUtil
 
getUsername() - Method in interface org.mule.api.security.Credentials
 
getUserName() - Method in class org.mule.el.context.ServerContext
 
getUsername() - Method in interface org.mule.module.http.api.requester.proxy.ProxyConfig
 
getUsername() - Method in class org.mule.module.http.internal.domain.request.HttpRequestAuthentication
 
getUsername() - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
getUsername() - Method in class org.mule.module.http.internal.request.DefaultProxyConfig
 
getUsername() - Method in class org.mule.module.ws.security.WssUsernameTokenSecurityStrategy
 
getUsername() - Method in class org.mule.security.MuleCredentials
 
getUsername() - Method in class org.mule.security.UsernamePasswordAuthenticationFilter
 
getUsername() - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
getUsername() - Method in class org.mule.transport.jms.CustomCachingConnectionFactory
 
getUsername() - Method in class org.mule.transport.jms.JmsConnector
 
getUsername() - Method in class org.mule.transport.sftp.config.SftpProxyConfig
 
getUserOAuthContext() - Method in interface org.mule.module.oauth2.internal.authorizationcode.AuthorizationCodeGrantType
 
getUserOAuthContext() - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
getUserObjectStore(String, boolean) - Method in class org.mule.util.store.MuleObjectStoreManager
 
getUserObjectStore(String, boolean, int, int, int) - Method in class org.mule.util.store.MuleObjectStoreManager
 
getUserParams() - Method in interface org.mule.api.endpoint.EndpointURI
A reduced version of getParams() - drops some system parameters
getUserParams() - Method in class org.mule.endpoint.MuleEndpointURI
 
getUserPrincipal() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
getUUID() - Static method in class org.mule.util.UUID
 
getValidatorFeatures() - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
getValidatorFeatures() - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
getValidatorFeatures() - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
getValidatorFeatures() - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
getValidatorProperties() - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
getValidatorProperties() - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
getValidatorProperties() - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
getValidatorProperties() - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
getValidQueryTypes() - Method in class org.mule.module.db.internal.processor.AbstractBulkUpdateMessageProcessor
 
getValidQueryTypes() - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
getValidQueryTypes() - Method in class org.mule.module.db.internal.processor.BulkExecuteMessageProcessor
 
getValidQueryTypes() - Method in class org.mule.module.db.internal.processor.ExecuteDdlMessageProcessor
 
getValidQueryTypes() - Method in class org.mule.module.db.internal.processor.SelectMessageProcessor
 
getValidQueryTypes() - Method in class org.mule.module.db.internal.processor.StoredProcedureMessageProcessor
 
getValidQueryTypes() - Method in class org.mule.module.db.internal.processor.UpdateMessageProcessor
 
getValue() - Method in class org.mule.api.debug.FieldDebugInfo
 
getValue(String) - Method in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
getValue(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration.NamedValueMap
 
getValue() - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
getValue() - Method in class org.mule.config.spring.parsers.collection.ChildListEntryDefinitionParser.ListEntry
 
getValue() - Method in class org.mule.config.spring.parsers.collection.ChildMapEntryDefinitionParser.KeyValuePair
 
getValue(String, Map) - Method in class org.mule.expression.MapPayloadExpressionEvaluator
 
getValue(Element) - Method in class org.mule.module.db.internal.config.domain.param.AbstractParamDefinitionDefinitionParser
 
getValue() - Method in class org.mule.module.db.internal.domain.param.DefaultInOutQueryParam
 
getValue() - Method in class org.mule.module.db.internal.domain.param.DefaultInputQueryParam
 
getValue() - Method in interface org.mule.module.db.internal.domain.param.InputQueryParam
 
getValue() - Method in class org.mule.module.db.internal.domain.query.QueryParamValue
 
getValue() - Method in class org.mule.module.oauth2.internal.ParameterExtractor
 
getValue() - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
Use getExpectedValue().
getValue() - Method in class org.mule.transformer.types.TypedValue
 
getValue(Object, int) - Method in class org.mule.transport.http.multipart.MultiMap
Get a value from a multiple value.
getValue() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
getValue() - Method in class org.mule.util.store.PersistentObjectStorePartition.StoreValue
 
getValueExpression() - Method in class org.mule.routing.IdempotentMessageFilter
 
getValueForEvent(MuleEvent) - Method in class org.mule.routing.IdempotentMessageFilter
 
getValues() - Method in class org.mule.module.http.internal.request.RangeStatusCodeValidator
 
getValues() - Method in class org.mule.module.launcher.util.ElementsClearedEvent
 
getValues() - Method in class org.mule.module.launcher.util.MultiElementAddedEvent
 
getValues() - Method in class org.mule.module.launcher.util.MultiElementRemovedEvent
 
getValues(Object) - Method in class org.mule.transport.http.multipart.MultiMap
Get multiple values.
getVariable(String) - Method in interface org.mule.api.el.ExpressionLanguageContext
 
getVariable(String, Class<T>) - Method in interface org.mule.api.el.ExpressionLanguageContext
 
getVariable(String) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
getVariable(String, Class<T>) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
getVariableName() - Method in class org.mule.module.jbpm.MuleReceiveActivity
 
getVariableResolver(String) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
getVariableResolver(String) - Method in class org.mule.el.mvel.EventVariableResolverFactory
 
getVariableResolver(String) - Method in class org.mule.el.mvel.MessageVariableResolverFactory
 
getVariableResolver(String) - Method in class org.mule.el.mvel.MuleBaseVariableResolverFactory
 
getVariableResolver(String) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
getVariableResolver(String) - Method in class org.mule.el.mvel.NullVariableResolverFactory
 
getVariableResolver(String) - Method in class org.mule.el.mvel.VariableVariableResolverFactory
 
getVariables() - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Method getVariables.
getVariables() - Method in class com.javaforge.bobber.archetype.model.Variable
Method getVariables.
getVariables() - Method in class org.mule.api.debug.DebuggerFrame
Returns the list of variables active in this frame
getVendor() - Method in class org.mule.module.management.mbean.MuleService
 
getVendor() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getVendorDataTypes() - Method in class org.mule.module.db.internal.domain.database.GenericDbConfigFactory
 
getVendorDataTypes() - Method in class org.mule.module.db.internal.domain.database.OracleDbConfigFactory
 
getVendorName() - Static method in class org.mule.config.MuleManifest
 
getVendorUrl() - Static method in class org.mule.config.MuleManifest
 
getVerboseMessage() - Method in exception org.mule.api.MuleException
 
getVerifierRegex() - Method in interface org.mule.security.oauth.OAuth1Connector
 
getVerifierRegex() - Method in interface org.mule.security.oauth.OAuth2Connector
 
getVersion() - Method in class org.mule.el.context.MuleInstanceContext
 
getVersion() - Method in class org.mule.module.management.mbean.MuleService
 
getVersion() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
getVersion() - Method in enum org.mule.module.ws.consumer.SoapVersion
 
getVersion() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
getVersion() - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
getVirtualHost() - Method in class org.apache.commons.httpclient.HttpConnection
Deprecated.
no longer applicable
getVirtualHostName(AbstractNetworkConnector) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
Returns the virtual host name required to map contexts to a specific connector.
getWaitTime() - Method in class org.mule.tck.functional.FunctionalTestComponent
 
getWarnings() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
getWarnings() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getWarnings() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getWebappsConfiguration() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
getWeekOfMonth() - Method in interface org.mule.api.el.datetime.Date
 
getWeekOfMonth() - Method in class org.mule.el.datetime.DateTime
 
getWeekOfYear() - Method in interface org.mule.api.el.datetime.Date
 
getWeekOfYear() - Method in class org.mule.el.datetime.DateTime
 
getWeighting(int, Class, Class) - Method in class org.mule.transformer.TransformerWeighting
This is a very basic algorithm for creating a match rating for two classes.
getWhenExhaustedAction() - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
Returns the action to take when the KeyedObjectPool.borrowObject(K) method is invoked when the pool is exhausted.
getWhenExhaustedAction() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
getWireFormat() - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
getWireFormat() - Method in class org.mule.module.client.remoting.RemoteDispatcherAgent
Deprecated.
 
getWireFormat() - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
getWireFormatClass() - Method in class org.mule.module.client.remoting.ServerHandshake
Deprecated.
 
getWorkDescription() - Method in interface org.mule.api.retry.RetryCallback
 
getWorkDir() - Method in class org.mule.el.context.AppContext
 
getWorkDirectory() - Method in class org.mule.transport.file.FileConnector
 
getWorkerCoreSize() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
getWorkException() - Method in class org.mule.work.WorkerContext
Gets the WorkException, if any, thrown during the execution.
getWorkFileNamePattern() - Method in class org.mule.transport.file.FileConnector
 
getWorkingDirectory() - Method in interface org.mule.api.config.MuleConfiguration
 
getWorkingDirectory() - Method in class org.mule.config.DefaultMuleConfiguration
 
getWorkingDirectory() - Method in class org.mule.module.management.mbean.MuleConfigurationService
 
getWorkingDirectory() - Method in interface org.mule.module.management.mbean.MuleConfigurationServiceMBean
 
getWorkListener() - Method in interface org.mule.api.MuleContext
 
getWorkListener() - Method in class org.mule.context.DefaultMuleContextBuilder
 
getWorkListener() - Method in class org.mule.DefaultMuleContext
 
getWorkManager() - Method in interface org.mule.api.context.WorkManagerSource
 
getWorkManager() - Method in interface org.mule.api.MuleContext
Obtains a workManager instance that can be used to schedule work in a thread pool.
getWorkManager() - Method in class org.mule.construct.Flow
 
getWorkManager() - Method in class org.mule.context.DefaultMuleContextBuilder
 
getWorkManager() - Method in class org.mule.DefaultMuleContext
Obtains a workManager instance that can be used to schedule work in a thread pool.
getWorkManager() - Method in class org.mule.transport.AbstractMessageDispatcher
 
getWorkManager() - Method in class org.mule.transport.AbstractMessageReceiver
 
getWorkManager() - Method in class org.mule.transport.AbstractMessageRequester
 
getWorkManager() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
getWorkManager() - Method in class org.mule.transport.DispatcherWorkManagerSource
 
getWorkManager() - Method in interface org.mule.transport.WorkManagerHolder
 
getWorkManagerFactory() - Method in interface org.mule.api.config.ThreadingProfile
 
getWorkManagerFactory() - Method in class org.mule.config.ChainedThreadingProfile
 
getWorkManagerFactory() - Method in class org.mule.config.ImmutableThreadingProfile
 
getWorkManagerFactory() - Method in class org.mule.config.MutableThreadingProfile
 
getWorkOwner() - Method in interface org.mule.api.retry.RetryCallback
 
getWorkspaceManager(RequestContext) - Method in class org.mule.module.atom.MuleProvider
 
getWorkstation() - Method in class org.mule.module.http.internal.domain.request.HttpRequestAuthentication
 
getWorkstation() - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
getWrapped() - Method in class org.mule.util.store.ProvidedObjectStoreWrapper
 
getWrapped() - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
getWrappedMessageProcessor() - Method in class org.mule.module.cxf.config.FlowConfiguringMessageProcessor
The MessageProcessor that this class built.
getWrapperPID() - Static method in class org.mule.module.management.agent.WrapperManagerAgent
This method is a copy of the implementation of WrapperManagerMBean.getWrapperPID() and it is here because that method is not present in the WrapperManagerMBean until version 3.2.3.
getWriter() - Method in class org.mule.transport.http.HttpServerConnection
Returns the ResponseWriter used to write the output to the socket.
getWriter() - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
getWriter() - Method in class org.mule.transport.soap.axis.AxisStringWriter
 
getWriteToDirectory() - Method in class org.mule.transport.file.FileConnector
 
getWsdlEndpoint() - Method in class org.mule.module.cxf.WSProxyService
Deprecated.
 
getWsdlFile() - Method in class org.mule.module.cxf.WSProxyService
Deprecated.
 
getWsdlLocation() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getWsdlLocation() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
getWsdlLocation() - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
getWsdlPort() - Method in class org.mule.module.cxf.component.WebServiceWrapperComponent
Deprecated.
 
getWSDLQueryHandler() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
getWSDLQueryHandler() - Method in class org.mule.module.cxf.builder.ProxyServiceMessageProcessorBuilder
 
getXaDataSource() - Method in class org.mule.module.db.internal.domain.xa.DataSourceWrapper
 
getXaDataSource() - Method in class org.mule.transport.jdbc.xa.DataSourceWrapper
 
getXAResource() - Method in class org.mule.transport.jms.xa.SessionInvocationHandler
 
getXAResource() - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
getXAResource() - Method in class org.mule.util.xa.DefaultXASession
 
getXAResourceFromXATransaction() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
getXAResourceFromXATransaction() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
getXATerminator() - Method in class org.mule.work.MuleWorkManager
 
getXaTxQueueTransactionJournal() - Method in class org.mule.util.xa.XaTransactionRecoverer
 
getXmlInputFactory() - Method in class org.mule.module.cxf.support.StaxFeature
 
getXMLInputFactory() - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
getXMLInputFactory() - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
getXMLInputFactory() - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
getXMLInputFactory() - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
getXMLInputFactory() - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
getXMLInputFactory() - Method in class org.mule.util.xmlsecurity.XMLSecureFactories
 
getXMLInputFactory(DefaultXMLSecureFactories) - Method in class org.mule.util.xmlsecurity.XMLSecureFactoriesCache
 
getXmlOutputFactory() - Method in class org.mule.module.cxf.support.StaxFeature
 
getXMLOutputFactory() - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
getXMLStreamReader(MuleMessage) - Method in class org.mule.module.sxc.SxcFilteringOutboundRouter
Gets an XMLStreamReader for this message.
getXMLStreamReader() - Method in class org.mule.module.xml.stax.StaxSource
 
getXmlTypeClass() - Static method in class org.mule.module.db.internal.domain.type.oracle.OracleXmlType
Looks for the OracleXmlType.ORACLE_XMLTYPE_CLASS class in the classpath and returns a reference to it
getXmppConnection() - Method in class org.mule.transport.xmpp.XmppConnector
 
getXPath(String, Object) - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
getXPath(String) - Method in class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
 
getXPathClassName(Object) - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
getXPathClassName(Object) - Method in class org.mule.module.xml.expression.XPathExpressionEvaluator
Deprecated.
 
getXpathEvaluator() - Method in class org.mule.module.xml.transformer.XPathExtractor
 
getXquery() - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
getXqueryFile() - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
getXslFile() - Method in class org.mule.module.xml.transformer.XsltTransformer
 
getXslFilePath() - Method in class org.mule.module.management.agent.Mx4jAgent
 
getXslt() - Method in class org.mule.module.xml.transformer.XsltTransformer
 
getXslTransformerFactory() - Method in class org.mule.module.xml.transformer.XsltTransformer
Returns the name of the currently configured javax.xml.transform.Transformer factory class used to create XSLT Transformers.
getXStream() - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
getYear() - Method in interface org.mule.api.el.datetime.Date
 
getYear() - Method in class org.mule.el.datetime.DateTime
 
giveMeAnOrange() - Static method in class org.mule.tck.testmodels.fruit.FloridaSunnyOrangeFactory
 
GLOBAL_ENDPOINT - Static variable in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
GLOBAL_STORE_CAPACITY - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
globalContext - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
globalFunctions - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
GlobalFunctionsDefintionParser - Class in org.mule.config.spring.parsers.specific
 
GlobalFunctionsDefintionParser(String) - Constructor for class org.mule.config.spring.parsers.specific.GlobalFunctionsDefintionParser
 
globalFunctionsFile - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
globalFunctionsString - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
globalName - Variable in class org.mule.exception.AbstractExceptionListener
 
globalName - Variable in class org.mule.exception.ChoiceMessagingExceptionStrategy
 
GlobalNameableObject - Interface in org.mule.api
Beans implementing GlobalNameableObject have globalName set during initialization to the bean name defined in the configuration
GlobalNamePostProcessor - Class in org.mule.config.spring
Injects the bean name to beans implementing @{link GlobalNameableObject}
GlobalNamePostProcessor() - Constructor for class org.mule.config.spring.GlobalNamePostProcessor
 
GlobalPropertyDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
GlobalPropertyDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.GlobalPropertyDefinitionParser
 
globalTransactions - Variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
globalTransactions - Variable in class org.mule.util.xa.AbstractResourceManager
 
GlobalVariableResolverFactory - Class in org.mule.el.mvel
 
GlobalVariableResolverFactory(Map<String, String>, Map<String, Function>, ParserConfiguration, MuleContext) - Constructor for class org.mule.el.mvel.GlobalVariableResolverFactory
 
GmailSmtpConnector - Class in org.mule.transport.email
This class just sets some extra SMTP properties so it works with GMail.
GmailSmtpConnector(MuleContext) - Constructor for class org.mule.transport.email.GmailSmtpConnector
 
GoodCitizenClassLoader - Class in org.mule.module.launcher
Fixes major classloader woes by: Providing a GoodCitizenClassLoader.dispose() method to release any connections to resources. Disabling caching of jar resources fix e.g.
GoodCitizenClassLoader(URL[], ClassLoader) - Constructor for class org.mule.module.launcher.GoodCitizenClassLoader
 
GoodCitizenClassLoader.NonCachingURLStreamHandlerFactory - Class in org.mule.module.launcher
 
GoodCitizenClassLoader.NonCachingURLStreamHandlerFactory() - Constructor for class org.mule.module.launcher.GoodCitizenClassLoader.NonCachingURLStreamHandlerFactory
 
GrandchildDefinitionParser - Class in org.mule.config.spring.parsers.generic
Same as ChildDefinitionParser but injects the child element into the grandparent object (2 levels up in the XML tree).
GrandchildDefinitionParser(String, Class) - Constructor for class org.mule.config.spring.parsers.generic.GrandchildDefinitionParser
 
GrandchildDefinitionParser(String, Class, Class, boolean) - Constructor for class org.mule.config.spring.parsers.generic.GrandchildDefinitionParser
 
GRANT_TYPE_AUTHENTICATION_CODE - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
GRANT_TYPE_CLIENT_CREDENTIALS - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
GRANT_TYPE_PARAMETER - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
GRANT_TYPE_REFRESH_TOKEN - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
graphTransformerResolver - Variable in class org.mule.registry.TypeBasedTransformerResolver
 
GraphTransformerResolver - Class in org.mule.transformer.graph
 
GraphTransformerResolver() - Constructor for class org.mule.transformer.graph.GraphTransformerResolver
 
GRIZZLY_MEMORY_MANAGER_SYSTEM_PROPERTY - Static variable in class org.mule.module.http.api.HttpConstants.HttpProperties
 
GrizzlyAddressDelegateFilter<F extends org.glassfish.grizzly.filterchain.BaseFilter> - Class in org.mule.module.http.internal.listener.grizzly
Grizzly filter to delegate to the right {link @BaseFilter} based on the Connection.
GrizzlyAddressDelegateFilter() - Constructor for class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
 
GrizzlyHttpClient - Class in org.mule.module.http.internal.request.grizzly
 
GrizzlyHttpClient(HttpClientConfiguration) - Constructor for class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
GrizzlyHttpClient.RequestConfigurer - Interface in org.mule.module.http.internal.request.grizzly
 
GrizzlyHttpRequestAdapter - Class in org.mule.module.http.internal.listener.grizzly
 
GrizzlyHttpRequestAdapter(FilterChainContext, HttpContent) - Constructor for class org.mule.module.http.internal.listener.grizzly.GrizzlyHttpRequestAdapter
 
GrizzlyRequestDispatcherFilter - Class in org.mule.module.http.internal.listener.grizzly
Grizzly filter that dispatches the request to the right request handler
GrizzlyServer - Class in org.mule.module.http.internal.listener.grizzly
 
GrizzlyServer(ServerAddress, TCPNIOTransport, HttpListenerRegistry) - Constructor for class org.mule.module.http.internal.listener.grizzly.GrizzlyServer
 
GrizzlyServerManager - Class in org.mule.module.http.internal.listener.grizzly
 
GrizzlyServerManager(String, HttpListenerRegistry, TcpServerSocketProperties) - Constructor for class org.mule.module.http.internal.listener.grizzly.GrizzlyServerManager
 
Groovy - Annotation Type in org.mule.api.annotations.expression
This allows Groovy codes to be executed on the current message.
GroovyAnnotationParser - Class in org.mule.module.scripting.config
 
GroovyAnnotationParser() - Constructor for class org.mule.module.scripting.config.GroovyAnnotationParser
 
GroovyExpressionEvaluator - Class in org.mule.module.scripting.expression
An ExpressionEvaluator that allows the user to define Groovy expressions to extract data from the current message.
GroovyExpressionEvaluator() - Constructor for class org.mule.module.scripting.expression.GroovyExpressionEvaluator
 
GroovyRefreshableBeanBuilder - Class in org.mule.module.scripting.component
 
GroovyRefreshableBeanBuilder() - Constructor for class org.mule.module.scripting.component.GroovyRefreshableBeanBuilder
 
GroovyRefreshableBeanBuilderParser - Class in org.mule.module.scripting.config
 
GroovyRefreshableBeanBuilderParser(boolean) - Constructor for class org.mule.module.scripting.config.GroovyRefreshableBeanBuilderParser
 
groupsLock - Variable in class org.mule.routing.correlation.EventCorrelator
 
groupTimeToLive - Variable in class org.mule.routing.correlation.EventCorrelator
 
GroupValueSetter - Class in org.mule.module.extension.internal.util
An implementation of ValueSetter for parameter groups.
GroupValueSetter(ParameterGroup) - Constructor for class org.mule.module.extension.internal.util.GroupValueSetter
Creates a new instance that can set values defined in the given group
GuiceConfigurationBuilder - Class in org.mule.module.guice
Deprecated.
Guice module is deprecated and will be removed in Mule 4.
GuiceConfigurationBuilder() - Constructor for class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
GuiceConfigurationBuilder(ClassLoader) - Constructor for class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
GuiceConfigurationBuilder(String) - Constructor for class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
GuiceConfigurationBuilder(String, ClassLoader) - Constructor for class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
GuiceConfigurationBuilder(Module...) - Constructor for class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
GuiceConfigurationBuilder(Stage, Module...) - Constructor for class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
GuiceMessages - Class in org.mule.module.guice.i18n
i18n Guice messages
GuiceMessages() - Constructor for class org.mule.module.guice.i18n.GuiceMessages
 
GuiceModuleFactory - Interface in org.mule.module.guice
Deprecated.
Guice module is deprecated and will be removed in Mule 4.
GuiceRegistry - Class in org.mule.module.guice
Deprecated.
Guice module is deprecated and will be removed in Mule 4.
GuiceRegistry(MuleContext) - Constructor for class org.mule.module.guice.GuiceRegistry
Deprecated.
 
GuiInstallerLibraryDownloader - Class in org.mule.module.boot
 
GuiInstallerLibraryDownloader() - Constructor for class org.mule.module.boot.GuiInstallerLibraryDownloader
 
GuiInstallerLicenseHandler - Class in org.mule.module.boot
 
GuiInstallerLicenseHandler() - Constructor for class org.mule.module.boot.GuiInstallerLicenseHandler
 
GZIP - Static variable in class org.mule.module.http.api.HttpHeaders.Values
GZIP - Static variable in class org.mule.util.Base64
Specify that data should be gzip-compressed.
GZipCompression - Class in org.mule.util.compression
GZipCompression is a CompressionStrategy implementation using the GZip library included in the JDK java.util.zip.
GZipCompression() - Constructor for class org.mule.util.compression.GZipCompression
 
GZIPCompressorInputStream - Class in org.mule.util.compression
Implements an input stream for compressing input data in the GZIP compression format.
GZIPCompressorInputStream(InputStream) - Constructor for class org.mule.util.compression.GZIPCompressorInputStream
Creates a new GZIPCompressorInputStream from an uncompressed InputStream.
GZipCompressTransformer - Class in org.mule.transformer.compression
GZipCompressTransformer is a transformer compressing objects into byte arrays.
GZipCompressTransformer() - Constructor for class org.mule.transformer.compression.GZipCompressTransformer
 
GZipUncompressTransformer - Class in org.mule.transformer.compression
GZipCompressTransformer will uncompress a byte[] or InputStream
GZipUncompressTransformer() - Constructor for class org.mule.transformer.compression.GZipUncompressTransformer
 

H

handle(Callback[]) - Method in class org.mule.module.jaas.MuleCallbackHandler
The handle() method handles the callbacks to be passed to the Jaas security.
handle(Callback[]) - Method in class org.mule.module.ws.security.CompositeCallbackHandler
 
handle(Callback[]) - Method in class org.mule.module.ws.security.WSPasswordCallbackHandler
 
handle(WSPasswordCallback) - Method in class org.mule.module.ws.security.WSPasswordCallbackHandler
Handles a password callback.
handleAccept(FilterChainContext) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
 
handleAttribute() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleCDATA() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleCharacters() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleClose(FilterChainContext) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
 
handleComment() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleConnect(FilterChainContext) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
 
handleCookie(String, String, Hashtable, MessageContext) - Method in class org.mule.transport.soap.axis.extensions.MuleHttpSender
Deprecated.
little helper function for cookies
handled() - Method in exception org.mule.api.MessagingException
Signals if exception has been handled or not
handleDTD() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleEndDocument() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleEndElement() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleEntityDecl() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleEntityReference() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleEvent(MuleEvent) - Method in class org.mule.module.bpm.Process
 
handleEvent(MuleEvent) - Method in class org.mule.module.bpm.Rules
 
handleEvent(FilterChainContext, FilterChainEvent) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
 
handleEventException(Throwable, long, Object) - Method in class org.mule.module.launcher.log4j2.AsyncLoggerExceptionHandler
 
handleEventResults(List<MuleEvent>) - Method in class org.mule.transport.AbstractReceiverWorker
 
handleException(Exception, MuleEvent) - Method in interface org.mule.api.exception.MessagingExceptionHandler
Take some action when a messaging exception has occurred (i.e., there was a message in play when the exception occurred).
handleException(Exception, RollbackSourceCallback) - Method in interface org.mule.api.exception.SystemExceptionHandler
Take some action when a system exception has occurred (i.e., there was no message in play when the exception occurred).
handleException(Exception) - Method in interface org.mule.api.exception.SystemExceptionHandler
Take some action when a system exception has occurred (i.e., there was no message in play when the exception occurred).
handleException(Exception, RollbackSourceCallback) - Method in interface org.mule.api.MuleContext
 
handleException(Exception) - Method in interface org.mule.api.MuleContext
 
handleException(Exception, RollbackSourceCallback) - Method in class org.mule.DefaultMuleContext
 
handleException(Exception) - Method in class org.mule.DefaultMuleContext
 
handleException(Exception, MuleEvent) - Method in class org.mule.exception.AbstractMessagingExceptionStrategy
 
handleException(Exception, RollbackSourceCallback) - Method in class org.mule.exception.AbstractSystemExceptionStrategy
 
handleException(Exception) - Method in class org.mule.exception.AbstractSystemExceptionStrategy
 
handleException(Exception, MuleEvent) - Method in class org.mule.exception.ChoiceMessagingExceptionStrategy
 
handleException(Exception, MuleEvent) - Method in class org.mule.exception.MessagingExceptionHandlerToSystemAdapter
 
handleException(Exception, MuleEvent) - Method in class org.mule.exception.MessagingExceptionStrategyAcceptorDelegate
 
handleException(Exception, MuleEvent) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
handleException(MuleMessage, Throwable) - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
Wraps an exception into a MuleMessage with an Exception payload and returns the Xml representation of it
handleException(RestServiceException, MuleMessage) - Method in class org.mule.transport.http.components.RestServiceWrapper
 
handleException(Throwable, String, HttpServletResponse) - Method in class org.mule.transport.servlet.AbstractReceiverServlet
 
handleException(Throwable, String, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
handleGroupExpiry(EventGroup) - Method in class org.mule.routing.correlation.EventCorrelator
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.CopyAttachmentInInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.CopyAttachmentOutInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.MuleHeadersInInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.MuleHeadersOutInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.MuleProtocolHeadersOutInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.OutputPayloadInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.ProxyFaultOutInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.ProxyGZIPInInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.ProxyGZIPOutInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.ProxyRPCInInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.ProxySchemaValidationInInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.ResetStaxInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.ReversibleStaxInterceptor
 
handleMessage(Message) - Method in class org.mule.module.cxf.support.StreamClosingInterceptor
 
handleMessage(SoapMessage) - Method in class org.mule.module.ws.consumer.InputSoapHeadersInterceptor
 
handleMessage(Message) - Method in class org.mule.module.ws.consumer.NamespaceRestorerStaxInterceptor
 
handleMessage(Message) - Method in class org.mule.module.ws.consumer.NamespaceSaverStaxInterceptor
 
handleMessage(SoapMessage) - Method in class org.mule.module.ws.consumer.OutputSoapHeadersInterceptor
 
handleMessage(Message) - Method in class org.mule.module.ws.consumer.SoapActionInterceptor
 
handleMultiTx(Session) - Method in class org.mule.transport.jms.JmsMessageDispatcher
Deprecated.
handleNamespace() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleNotationDecl() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleNotAuthorized(Object, NotAuthorizedException, MuleEvent) - Method in enum org.mule.security.oauth.OnNoTokenPolicy
This method handles a NotAuthorizedException according to each policy
handleNotification(Notification, Object) - Method in class org.mule.module.management.agent.JmxServerNotificationAgent.NotificationListener
 
handleNotificationListeners() - Method in class org.mule.context.notification.MessageProcessingFlowTraceManager
 
handleOnShutdownException(Throwable) - Method in class org.mule.module.launcher.log4j2.AsyncLoggerExceptionHandler
 
handleOnStartException(Throwable) - Method in class org.mule.module.launcher.log4j2.AsyncLoggerExceptionHandler
 
handlePI() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handler - Variable in class org.mule.module.xml.stax.StaxSource
 
handler - Variable in class org.mule.transport.jms.redelivery.CountingRedeliveryHandlerFactory
 
Handler - Class in org.mule.transport.soap.axis.transport.jms
A Dummy Url handler for handling jms.
Handler() - Constructor for class org.mule.transport.soap.axis.transport.jms.Handler
 
Handler - Class in org.mule.transport.soap.axis.transport.pop3
A Dummy Url handler for handling pop3.
Handler() - Constructor for class org.mule.transport.soap.axis.transport.pop3.Handler
 
Handler - Class in org.mule.transport.soap.axis.transport.smtp
A Dummy Url handler for handling smtp.
Handler() - Constructor for class org.mule.transport.soap.axis.transport.smtp.Handler
 
Handler - Class in org.mule.transport.soap.axis.transport.vm
A Dummy Url handler for handling vm.
Handler() - Constructor for class org.mule.transport.soap.axis.transport.vm.Handler
 
handleRead(FilterChainContext) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
 
handleRead(FilterChainContext) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyRequestDispatcherFilter
 
handleRead(FilterChainContext) - Method in class org.mule.module.http.internal.listener.grizzly.MuleSslFilter
 
handleReconnection(ConnectException) - Method in class org.mule.exception.AbstractSystemExceptionStrategy
 
handleRedelivery(Message, InboundEndpoint, FlowConstruct) - Method in class org.mule.transport.jms.redelivery.AbstractRedeliveryHandler
 
handleRedelivery(Message, InboundEndpoint, FlowConstruct) - Method in class org.mule.transport.jms.redelivery.CountingRedeliveryHandler
process the redelivered message.
handleRedelivery(Message, InboundEndpoint, FlowConstruct) - Method in class org.mule.transport.jms.redelivery.JmsXRedeliveryHandler
process the redelivered message.
handleRedelivery(Message, InboundEndpoint, FlowConstruct) - Method in interface org.mule.transport.jms.redelivery.RedeliveryHandler
Process the redelivered message.
handleRedirect(HttpMethod, MuleEvent) - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
handleRequest(HttpRequestContext, HttpResponseReadyCallback) - Method in interface org.mule.module.http.internal.listener.async.RequestHandler
Called to handle an incoming http request
handleRequest(HttpRequestContext, HttpResponseReadyCallback) - Method in class org.mule.module.http.internal.listener.ErrorRequestHandler
 
handleResults(List) - Method in class org.mule.transport.AbstractReceiverWorker
When Mule has finished processing the current messages, there may be zero or more messages to process by the receiver if request/response messaging is being used.
handleResults(List) - Method in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
handleSpace() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleSpringElements(Element, BeanDefinition) - Method in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
handleSSLException(SSLHandshakeException) - Method in class org.mule.module.http.internal.listener.grizzly.MuleSslFilter
 
handleStartDocument() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleStartElement() - Method in class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
 
handleTransaction(Throwable) - Method in class org.mule.exception.AbstractExceptionListener
Deprecated.
this method should not be used anymore. Transactions must be handled by provided ExceptionStrategy
handleTypeCoercion(Class<T>, Object) - Static method in class org.mule.el.mvel.DataConversion
 
handleUnaccepted(MuleEvent) - Method in class org.mule.construct.AbstractPipeline.ProcessIfPipelineStartedMessageProcessor
 
handleUnaccepted(MuleEvent) - Method in class org.mule.lifecycle.processor.ProcessIfStartedMessageProcessor
 
handleUnaccepted(MuleEvent) - Method in class org.mule.processor.AbstractFilteringMessageProcessor
 
handleUnacceptedFilter(MuleMessage) - Method in class org.mule.transport.AbstractMessageReceiver
 
handleUnacceptedFilter(MuleMessage) - Method in class org.mule.transport.email.RetrieveMessageReceiver
 
handleUnacceptedFilter(MuleMessage) - Method in class org.mule.transport.http.HttpMessageReceiver
 
handleUnacceptedFilter(MuleMessage) - Method in class org.mule.transport.http.OldHttpMessageReceiver
 
handleUnacceptedFilter(MuleMessage) - Method in class org.mule.transport.sftp.SftpMessageReceiver
SFTP-35
handleWorkException(WorkEvent, String) - Method in class org.mule.processor.AsyncWorkListener
 
handleWorkException(WorkEvent, String) - Method in class org.mule.transport.AbstractConnector
 
handleWorkException(WorkEvent, String) - Method in class org.mule.work.DefaultWorkListener
 
handleWrite(FilterChainContext) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
 
handshakeCompleted(HandshakeCompletedEvent) - Method in class org.mule.transport.http.HttpServerConnection
 
hasAckStatement() - Method in class org.mule.transport.jdbc.JdbcMessageReceiver
 
hasAnnotation(Class<? super Annotation>, Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
Deprecated.
hasAnnotationWithPackage(String, Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
 
hasAnyDynamic(Iterable<ValueResolver<T>>) - Static method in class org.mule.module.extension.internal.util.MuleExtensionUtils
Returns true if any of the items in resolvers return true for the ValueResolver.isDynamic() method
hasAttribute(Element, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
hasBeenAuthorized(OAuth1Adapter) - Method in class org.mule.security.oauth.BaseOAuth1Manager
Determines if the adapter has been authorized or not by checking its access token
hasBeenAuthorized(OAuth2Adapter) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Validates that there's an access token for the given adapter.
hasBeenAuthorized(OAuth1Adapter) - Method in interface org.mule.security.oauth.OAuth1Manager
Determines if the adapter has been authorized or not by checking its access token
hasBeenAuthorized(OAuth2Adapter) - Method in interface org.mule.security.oauth.OAuth2Manager
Validates that there's an access token for the given adapter.
hasBeenAuthorized() - Method in interface org.mule.security.oauth.OAuthAdapter
Checks if the adapter has been authorized.
hasBody() - Method in class org.mule.transport.http.HttpResponse
 
hasCapability(Class<T>) - Method in class org.mule.config.spring.DefaultMuleArtifact
 
hasCode() - Method in class org.mule.module.jaas.MuleJaasPrincipal
 
hasCommandLineOption(String, String[], String[][]) - Static method in class org.mule.util.SystemUtils
Checks whether a command line option is set.
hasContentLength() - Method in class org.mule.module.http.internal.domain.InputStreamHttpEntity
 
hasCustomContentDisposition() - Method in class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
hasCustomContentType() - Method in class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
hasDefaultConstructor(Class<?>) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
hasDeployed(String) - Static method in class org.mule.test.infrastructure.process.matchers.Deployment
 
hasEnded(Object) - Method in interface org.mule.module.bpm.BPMS
 
hasEnded(Object) - Method in class org.mule.module.jbpm.Jbpm
 
hasEndpoints() - Method in interface org.mule.api.routing.OutboundRouterCollection
Deprecated.
Determines if any targets have been set on this router.
hasEndpoints() - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
hasError() - Method in class org.mule.api.model.InvocationResult
Returns true if an error message has been set on this result, false otherwise
hasErrorExpression() - Method in class org.mule.construct.builder.ValidatorBuilder
 
hasErrorExpression() - Method in class org.mule.construct.Validator
 
hasExecution(String) - Method in class org.mule.module.jbpm.EndedProcess
 
hasFlag(Object, int) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
hasFlag(int, int) - Method in class org.mule.util.scan.ClasspathScanner
Deprecated.
 
hash(Object) - Method in class org.mule.util.CaseInsensitiveHashMap
Creates a hash value from the lower case value of the key.
hash(Object[]) - Static method in class org.mule.util.ClassUtils
 
hashCode() - Method in exception org.mule.api.MuleException
 
hashCode() - Method in class org.mule.api.registry.AbstractServiceDescriptor.Key
 
hashCode() - Method in class org.mule.api.security.tls.TlsConfiguration
 
hashCode() - Method in class org.mule.api.security.tls.TlsProperties
 
hashCode() - Method in class org.mule.api.transport.PropertyScope
 
hashCode() - Method in class org.mule.client.SimpleOptions
 
hashCode() - Method in class org.mule.config.ConfigResource
 
hashCode() - Method in class org.mule.config.DefaultMuleConfiguration
 
hashCode() - Method in class org.mule.config.transformer.AnnotatedTransformerProxy
 
hashCode() - Method in class org.mule.context.notification.ListenerSubscriptionPair
 
hashCode() - Method in class org.mule.DefaultMuleEvent
 
hashCode() - Method in class org.mule.DefaultMuleMessage
 
hashCode() - Method in class org.mule.endpoint.AbstractEndpoint
 
hashCode() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
hashCode() - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
hashCode() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
hashCode() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
hashCode() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
hashCode() - Method in class org.mule.endpoint.MuleEndpointURI
 
hashCode() - Method in class org.mule.endpoint.URIBuilder
 
hashCode() - Method in class org.mule.interceptor.InterceptorStack
 
hashCode() - Method in class org.mule.module.cxf.support.DelegatingOutputStream
 
hashCode() - Method in class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
hashCode() - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
hashCode() - Method in class org.mule.module.extension.internal.runtime.resolver.ResolverSetResult
A hashCode calculated based on the results
hashCode() - Method in class org.mule.module.http.internal.listener.ServerAddress
 
hashCode() - Method in class org.mule.module.http.internal.ParameterMap
 
hashCode() - Method in class org.mule.module.http.internal.request.client.DefaultHttpRequestOptions
 
hashCode() - Method in class org.mule.module.http.internal.request.client.HttpRequestCacheKey
 
hashCode() - Method in class org.mule.module.json.JsonData
 
hashCode() - Method in class org.mule.module.launcher.util.ObservableList
 
hashCode() - Method in class org.mule.module.ognl.filters.OGNLFilter
 
hashCode() - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
hashCode() - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
hashCode() - Method in class org.mule.module.sxc.SxcFilter
 
hashCode() - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
hashCode() - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
hashCode() - Method in class org.mule.module.xml.filters.XPathFilter
 
hashCode() - Method in class org.mule.routing.EventGroup
The hashCode of an EventGroup is derived from the object returned by EventGroup.getGroupId().
hashCode() - Method in class org.mule.routing.filters.ExpressionFilter
 
hashCode() - Method in class org.mule.routing.filters.logic.AbstractFilterCollection
 
hashCode() - Method in class org.mule.routing.filters.logic.NotFilter
 
hashCode() - Method in class org.mule.routing.filters.MessagePropertyFilter
 
hashCode() - Method in class org.mule.routing.filters.PayloadTypeFilter
 
hashCode() - Method in class org.mule.routing.filters.RegExFilter
 
hashCode() - Method in class org.mule.routing.filters.WildcardFilter
 
hashCode() - Method in class org.mule.tck.logging.TestAppender.Expectation
 
hashCode() - Method in class org.mule.transaction.MuleTransactionConfig
 
hashCode() - Method in class org.mule.transformer.TransformerWeighting
 
hashCode() - Method in class org.mule.transformer.types.CollectionDataType
 
hashCode() - Method in class org.mule.transformer.types.SimpleDataType
 
hashCode() - Method in class org.mule.transport.email.filters.MailSubjectRegExFilter
 
hashCode() - Method in class org.mule.transport.http.multipart.MultiMap
 
hashCode() - Method in class org.mule.transport.jms.filters.JmsPropertyFilter
 
hashCode() - Method in class org.mule.transport.jms.filters.JmsSelectorFilter
 
hashCode() - Method in class org.mule.transport.NullPayload
 
hashCode() - Method in class org.mule.transport.tcp.TcpSocketKey
 
hashCode() - Method in class org.mule.transport.xmpp.filters.XmppAndFilter
 
hashCode() - Method in class org.mule.transport.xmpp.filters.XmppFromContainsFilter
 
hashCode() - Method in class org.mule.transport.xmpp.filters.XmppNotFilter
 
hashCode() - Method in class org.mule.transport.xmpp.filters.XmppPacketTypeFilter
 
hashCode() - Method in class org.mule.util.annotation.AnnotationMetaData
 
hashCode() - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
hashCode() - Method in class org.mule.util.concurrent.WaitableBoolean
 
hashCode() - Method in class org.mule.util.JdkVersionUtils.JdkVersion
 
hashCode() - Method in class org.mule.util.MapCombiner
 
hashCode() - Method in class org.mule.util.queue.DefaultQueueStore
 
hashCode() - Method in class org.mule.util.queue.objectstore.QueueConfiguration
Deprecated.
 
hashCode() - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
hashCode() - Method in class org.mule.util.queue.objectstore.QueueKey
Deprecated.
 
hashCode() - Method in class org.mule.util.scan.annotations.AnnotationInfo
Deprecated.
 
hashCode() - Method in class org.mule.util.scan.annotations.AnnotationInfo.NameValue
Deprecated.
 
hashCode() - Method in class org.mule.util.store.InMemoryObjectStore.StoredObject
 
hashCode() - Method in class org.mule.util.xa.MuleXid
 
hashCode() - Method in class org.mule.util.xmlsecurity.XMLFactoryConfig
 
hashCode() - Method in class org.mule.VoidResult
 
hasJaxbAnnotations(Class) - Method in class org.mule.module.xml.transformer.jaxb.JAXBTransformerResolver
 
HasLifecycleInterceptor - Interface in org.mule.api.lifecycle
Contract interface for an object on which a LifecycleInterceptor can be set into
hasLine(Matcher<String>) - Static method in class org.mule.test.infrastructure.FileContainsInLine
 
hasListeners(String) - Method in class org.mule.module.launcher.util.ObservableList
 
hasMaxRedeliveryAttempts() - Method in class org.mule.exception.RollbackMessagingExceptionStrategy
 
hasMessages() - Method in class org.mule.transport.email.RetrieveMessageRequester
Optimised check to se whether to return the message count and retrieve the messages.
hasMoreElements() - Method in class org.mule.module.launcher.application.EnumerationAdapter
 
hasMoreMessages(Object) - Method in class org.mule.transport.AbstractReceiverResourceWorker
 
hasMoreMessages(Object) - Method in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
hasName() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
hasName() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
hasNext() - Method in class org.mule.module.db.internal.result.resultset.ResultSetIterator
 
hasNext() - Method in class org.mule.module.db.internal.result.statement.StatementResultIterator
 
hasNext() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
hasNext() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
hasNext() - Method in class org.mule.processor.BlockingProcessorExecutor
 
hasNext() - Method in interface org.mule.routing.MessageSequence
Whether this sequence has more elements.
hasNext() - Method in class org.mule.routing.outbound.ArrayMessageSequence
 
hasNext() - Method in class org.mule.routing.outbound.CollectionMessageSequence
 
hasNext() - Method in class org.mule.routing.outbound.IteratorMessageSequence
 
hasNext() - Method in class org.mule.routing.outbound.NodeListMessageSequence
 
hasNext() - Method in class org.mule.routing.outbound.PartitionedMessageSequence
 
hasNext() - Method in class org.mule.streaming.ConsumerIterator
Returns true as long as the underlying consumer is not fully consumed nor closed
hasNode(String) - Method in class org.mule.module.json.JsonData
 
hasNoMessages() - Method in class org.mule.transport.TransactedPollingMessageReceiver
Return true if it can be determined that there are currently no messages to process
hasNoMessages() - Method in class org.mule.transport.vm.VMMessageReceiver
 
hasParameters() - Method in class org.mule.module.db.internal.domain.logger.DebugSingleQueryLogger
 
hasPendingLocks() - Method in class org.mule.util.lock.InstanceLockGroup.LockEntry
 
hasPrevious() - Method in class org.mule.module.launcher.util.ObservableList.ObservableListIterator
 
HasRegex - Class in org.mule.test.infrastructure
 
hasRegex(String) - Static method in class org.mule.test.infrastructure.HasRegex
 
hasResource(Object) - Method in interface org.mule.api.transaction.Transaction
 
hasResource(Object) - Method in class org.mule.module.spring.transaction.SpringTransactionFactory.SpringTransaction
 
hasResource(Object) - Method in class org.mule.processor.DelegateTransaction
 
hasResource(Object) - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
hasResource(Object) - Method in class org.mule.transaction.XaTransaction
 
hasResponse() - Method in enum org.mule.MessageExchangePattern
 
hasResponseTransformers() - Method in class org.mule.construct.AbstractConfigurationPattern
 
hasStrategies() - Method in class org.mule.module.ws.security.WSSecurity
 
hasText() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
hasText() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
hasTlsConfig() - Method in interface org.mule.module.http.api.listener.HttpListenerConfig
 
hasTlsConfig() - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
hasTokenExpired() - Method in interface org.mule.security.oauth.OAuth2Adapter
 
hasTransformers() - Method in class org.mule.construct.AbstractConfigurationPattern
 
hasWildcards() - Method in class org.mule.util.WildcardAttributeEvaluator
 
header - Variable in class org.mule.util.SplashScreen
 
HEADER_ACCEPT - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_ACCEPT_CHARSET - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_ACCEPT_ENCODING - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_ACCEPT_LANGUAGE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_ACCEPT_RANGES - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_AGE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_ALLOW - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_AUTHORIZATION - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_CACHE_CONTROL - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_CONNECTION - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_CONTENT_DISPOSITION - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_CONTENT_ENCODING - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_CONTENT_LANGUAGE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_CONTENT_LENGTH - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_CONTENT_LOCATION - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_CONTENT_MD5 - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_CONTENT_RANGE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_CONTENT_SEPARATOR - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_CONTENT_TYPE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_COOKIE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_COOKIE_SET - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_DATE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_ETAG - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_EXPECT - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_EXPECT_CONTINUE_REQUEST_VALUE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_EXPIRES - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_FROM - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_HOST - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_IF_MATCH - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_IF_MODIFIED_SINCE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_IF_NONE_MATCH - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_IF_RANGE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_IF_UNMODIFIED_SINCE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_KEEP_ALIVE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_LAST_MODIFIED - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_LIST_PREFIX - Static variable in class org.mule.transport.email.MailMuleMessageFactory
 
HEADER_LOCATION - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_MAX_FORWARDS - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_MULE_SESSION - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_PRAGMA - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_PROXY_AUTHENTICATE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_PROXY_AUTHORIZATION - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_RANGE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_REFERER - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_RETRY_AFTER - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_SERVER - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_SLUG - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_TE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_TRAILER - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_TRANSFER_ENCODING - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_UPGRADE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_USER_AGENT - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_VARY - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_VIA - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_WARNING - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_WWW_AUTHENTICATE - Static variable in class org.mule.transport.http.HttpConstants
 
HEADER_X_FORWARDED_FOR - Static variable in class org.mule.transport.http.HttpConstants
 
headerMalformedValueIs(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
headersToString(MuleMessage) - Static method in class org.mule.util.StringMessageUtils
 
helper - Variable in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
HexStringToByteArray - Class in org.mule.transformer.simple
Converts a Hex String to a Byte array
HexStringToByteArray() - Constructor for class org.mule.transformer.simple.HexStringToByteArray
 
hexStringToByteArray(String) - Static method in class org.mule.util.StringUtils
Convert a hexadecimal string into its byte representation.
HIDDEN_KEY - Static variable in class org.mule.config.spring.parsers.specific.properties.NestedListDefinitionParser
 
HIDDEN_KEY - Static variable in class org.mule.config.spring.parsers.specific.properties.NestedMapDefinitionParser
 
HIDDEN_VALUE - Static variable in class org.mule.config.spring.parsers.specific.properties.NestedListDefinitionParser
 
HiddenCapability - Class in org.mule.module.extension.internal.capability.metadata
A metadata capability to signal that a given component should not be advertised
HiddenCapability() - Constructor for class org.mule.module.extension.internal.capability.metadata.HiddenCapability
 
holders - Variable in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
HOST - Static variable in class org.mule.endpoint.URIBuilder
 
HOST - Static variable in class org.mule.module.http.api.HttpHeaders.Names
host - Variable in class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
host - Variable in class org.mule.transport.jdbc.config.OracleDataSourceFactoryBean
 
HOST_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
HOST_ATTRIBUTES - Static variable in class org.mule.endpoint.URIBuilder
 
HOST_SEPARATOR - Static variable in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
HOSTNAME_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 
HostNameFactory - Class in org.mule.config.factories
Extracts the local hostname from the local system
HostNameFactory() - Constructor for class org.mule.config.factories.HostNameFactory
 
hours() - Static method in class org.mule.config.i18n.CoreMessages
 
HTML - Static variable in interface org.mule.transformer.types.MimeTypes
 
HTML_STRING - Static variable in class org.mule.transformer.types.DataTypeFactory
 
HtmlTablePrinter - Class in org.mule.management.stats.printers
HtmlTablePrinter prints event processing stats as a HTML table
HtmlTablePrinter(Writer) - Constructor for class org.mule.management.stats.printers.HtmlTablePrinter
 
HtmlTablePrinter(OutputStream) - Constructor for class org.mule.management.stats.printers.HtmlTablePrinter
 
HTTP - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP10 - Static variable in class org.mule.transport.http.HttpConstants
 
HTTP11 - Static variable in class org.mule.transport.http.HttpConstants
 
HTTP1X - Static variable in class org.mule.transport.http.HttpConstants
 
HTTP_ADAPTER_OBJECT_NAME - Static variable in class org.mule.module.management.agent.Mx4jAgent
 
HTTP_CLIENT_CERTIFICATE - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_CLIENT_SSL_SESSION - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_CONTEXT_PATH_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
The context path of the endpoint being accessed.
HTTP_CONTEXT_URI_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
The context URI of the endpoint being accessed.
HTTP_COOKIE_SPEC_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_COOKIES_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_CUSTOM_HEADERS_MAP_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
Deprecated.
Instead users can now add properties to the outgoing request using the OUTBOUND property scope on the message.
HTTP_DISABLE_STATUS_CODE_EXCEPTION_CHECK - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_ENABLE_COOKIES_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_ENCODE_PARAMVALUE - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_GET_BODY_PARAM_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_HEADERS - Static variable in class org.mule.transport.http.HttpConnector
Encapsulates all the HTTP headers
HTTP_INBOUND_PROPERTIES - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_LISTENER_CONNECTION_MANAGER - Static variable in class org.mule.module.http.internal.listener.HttpListenerConnectionManager
 
HTTP_LISTENER_PATH - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_METHOD - Static variable in class org.mule.transport.http.components.RestServiceWrapper
 
HTTP_METHOD_PROPERTY - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_METHOD_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_PARAMS_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
Allows the user to set a HttpMethodParams object in the client request to be set on the HttpMethod request object
HTTP_POST_BODY_PARAM_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_PREFIX - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_PREFIX - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_QUERY_PARAMS - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_QUERY_PARAMS - Static variable in class org.mule.transport.http.HttpConnector
Stores the HTTP query parameters received, supports multiple values per key and both query parameter key and value are unescaped
HTTP_QUERY_STRING - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_QUERY_STRING - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_REASON_PROPERTY - Static variable in class org.mule.module.http.api.HttpConstants.ResponseProperties
 
HTTP_RELATIVE_PATH - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_RELATIVE_PATH_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
The relative path of the URI being accessed in relation to the context path
HTTP_REMOTE_ADDRESS - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_REQUEST_PATH_PROPERTY - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_REQUEST_PATH_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
The path portion of the URL being accessed.
HTTP_REQUEST_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
The path and query portions of the URL being accessed.
HTTP_REQUEST_URI - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_SCHEME - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_SERVLET_REQUEST_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_SERVLET_RESPONSE_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_STATUS - Static variable in interface org.mule.security.oauth.OAuthProperties
 
HTTP_STATUS_PROPERTY - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_STATUS_PROPERTY - Static variable in class org.mule.module.http.api.HttpConstants.ResponseProperties
 
HTTP_STATUS_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
MuleEvent property to pass back the status for the response
HTTP_TRANSPORT_DEPRECATION_MESSAGE - Static variable in class org.mule.transport.http.config.HttpNamespaceHandler
 
HTTP_URI_PARAMS - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_URL_PROTOCOL - Static variable in class org.mule.transport.http.HttpConnector
 
HTTP_VERSION_PROPERTY - Static variable in class org.mule.module.http.api.HttpConstants.RequestProperties
 
HTTP_VERSION_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
 
HttpAuthentication - Interface in org.mule.module.http.api
An object that authenticates an HTTP request.
HttpAuthenticationDefinitionParser - Class in org.mule.module.http.internal.config
 
HttpAuthenticationDefinitionParser(HttpAuthenticationType) - Constructor for class org.mule.module.http.internal.config.HttpAuthenticationDefinitionParser
 
HttpAuthenticationType - Enum in org.mule.module.http.internal.request
 
HttpBasicAuthenticationFilter - Class in org.mule.module.spring.security.filters.http
Deprecated.
HttpBasicAuthenticationFilter() - Constructor for class org.mule.module.spring.security.filters.http.HttpBasicAuthenticationFilter
Deprecated.
 
HttpBasicAuthenticationFilter - Class in org.mule.transport.http.filters
HttpBasicAuthenticationFilter TODO
HttpBasicAuthenticationFilter() - Constructor for class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
 
HttpBasicAuthenticationFilter(String) - Constructor for class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
 
HttpCallback - Interface in org.mule.api.callback
Base interface for components that publish a http callback.
HttpCallbackAdapter - Interface in org.mule.security.oauth.callback
Adapter interface for Http callbacks
HttpCallbackFactory - Interface in org.mule.api.callback
Factory class for instances of HttpCallback that are used on the OAuth dance
HttpClient - Interface in org.mule.module.http.internal.request
Object that sends an HTTP request, and returns the response.
HttpClientConfiguration - Class in org.mule.module.http.internal.request
 
HttpClientConfiguration.Builder - Class in org.mule.module.http.internal.request
 
HttpClientConfiguration.Builder() - Constructor for class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
HttpClientFactory - Interface in org.mule.module.http.internal.request
Factory object for HttpClient mule-to-httpLibrary adapters.
HttpClientMessageDispatcher - Class in org.mule.transport.http
HttpClientMessageDispatcher dispatches Mule events over HTTP.
HttpClientMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.http.HttpClientMessageDispatcher
 
HttpClientMessageDispatcherFactory - Class in org.mule.transport.http
Creates a HttpClientMessageDispatcher to make client requests
HttpClientMessageDispatcherFactory() - Constructor for class org.mule.transport.http.HttpClientMessageDispatcherFactory
 
HttpClientMessageRequester - Class in org.mule.transport.http
Rquests Mule events over HTTP.
HttpClientMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.http.HttpClientMessageRequester
 
HttpClientMessageRequesterFactory - Class in org.mule.transport.http
Creates a HttpClientMessageDispatcher to make client requests
HttpClientMessageRequesterFactory() - Constructor for class org.mule.transport.http.HttpClientMessageRequesterFactory
 
HttpClientMethodResponseToObject - Class in org.mule.transport.http.transformers
HttpClientMethodResponseToObject transforms a http client response to a DefaultMuleMessage.
HttpClientMethodResponseToObject() - Constructor for class org.mule.transport.http.transformers.HttpClientMethodResponseToObject
 
HttpConfiguration - Class in org.mule.module.http.internal.config
HTTP global configuration.
HttpConfiguration() - Constructor for class org.mule.module.http.internal.config.HttpConfiguration
 
HttpConnection - Class in org.apache.commons.httpclient
This is a modified version of the HttpConnection class from commons-httpclient that doesn't limit the size of the input/output buffers to 2KB.
HttpConnection(String, int) - Constructor for class org.apache.commons.httpclient.HttpConnection
Creates a new HTTP connection for the given host and port.
HttpConnection(String, int, Protocol) - Constructor for class org.apache.commons.httpclient.HttpConnection
Creates a new HTTP connection for the given host and port using the given protocol.
HttpConnection(String, String, int, Protocol) - Constructor for class org.apache.commons.httpclient.HttpConnection
Creates a new HTTP connection for the given host with the virtual alias and port using given protocol.
HttpConnection(String, int, String, int) - Constructor for class org.apache.commons.httpclient.HttpConnection
Creates a new HTTP connection for the given host and port via the given proxy host and port using the default protocol.
HttpConnection(HostConfiguration) - Constructor for class org.apache.commons.httpclient.HttpConnection
Creates a new HTTP connection for the given host configuration.
HttpConnection(String, int, String, String, int, Protocol) - Constructor for class org.apache.commons.httpclient.HttpConnection
Deprecated.
use #HttpConnection(String, int, String, int, Protocol)
HttpConnection(String, int, String, int, Protocol) - Constructor for class org.apache.commons.httpclient.HttpConnection
Creates a new HTTP connection for the given host with the virtual alias and port via the given proxy host and port using the given protocol.
httpConnector - Variable in class org.mule.transport.http.HttpClientMessageDispatcher
 
HttpConnector - Class in org.mule.transport.http
HttpConnector provides a way of receiving and sending http requests and responses.
HttpConnector(MuleContext) - Constructor for class org.mule.transport.http.HttpConnector
 
HttpConnectorMessageProcessorProvider - Class in org.mule.module.http.internal.request.client
Provider for operations of the HTTP module.
HttpConnectorMessageProcessorProvider() - Constructor for class org.mule.module.http.internal.request.client.HttpConnectorMessageProcessorProvider
 
HttpConstants - Class in org.mule.module.http.api
General purpose HTTP constants
HttpConstants() - Constructor for class org.mule.module.http.api.HttpConstants
 
HttpConstants - Class in org.mule.transport.http
HttpConstants for request and response headers
HttpConstants() - Constructor for class org.mule.transport.http.HttpConstants
 
HttpConstants.HttpProperties - Class in org.mule.module.http.api
 
HttpConstants.HttpProperties() - Constructor for class org.mule.module.http.api.HttpConstants.HttpProperties
 
HttpConstants.HttpStatus - Enum in org.mule.module.http.api
 
HttpConstants.Methods - Enum in org.mule.module.http.api
 
HttpConstants.Protocols - Enum in org.mule.module.http.api
 
HttpConstants.RequestProperties - Class in org.mule.module.http.api
 
HttpConstants.RequestProperties() - Constructor for class org.mule.module.http.api.HttpConstants.RequestProperties
 
HttpConstants.ResponseProperties - Class in org.mule.module.http.api
 
HttpConstants.ResponseProperties() - Constructor for class org.mule.module.http.api.HttpConstants.ResponseProperties
 
HttpCookiesDefinitionParser - Class in org.mule.transport.http.builder
 
HttpCookiesDefinitionParser(String, Class<?>) - Constructor for class org.mule.transport.http.builder.HttpCookiesDefinitionParser
 
HttpEntity - Interface in org.mule.module.http.internal.domain
Marker interface for a http message entity.
HttpHeaderDefinitionParser - Class in org.mule.transport.http.builder
The header element may appear either inside a request-builder element of the HTTP module, a response-builder element of the HTTP module, or a response-builder element of the HTTP transport.
HttpHeaderDefinitionParser() - Constructor for class org.mule.transport.http.builder.HttpHeaderDefinitionParser
 
HttpHeaders - Class in org.mule.module.http.api
Provides the constants for the standard HTTP header names and values
HttpHeaders() - Constructor for class org.mule.module.http.api.HttpHeaders
 
HttpHeaders.Names - Class in org.mule.module.http.api
Standard HTTP header names.
HttpHeaders.Values - Class in org.mule.module.http.api
Standard HTTP header values.
HttpListener - Interface in org.mule.module.http.api.listener
Represents an listener for HTTP requests.
HttpListenerBuilder - Class in org.mule.module.http.api.listener
Builder for creating http listeners pragmatically.
HttpListenerBuilder(MuleContext) - Constructor for class org.mule.module.http.api.listener.HttpListenerBuilder
 
HttpListenerConfig - Interface in org.mule.module.http.api.listener
 
HttpListenerConfigBuilder - Class in org.mule.module.http.internal.listener
 
HttpListenerConfigBuilder(String, MuleContext) - Constructor for class org.mule.module.http.internal.listener.HttpListenerConfigBuilder
 
HttpListenerConfigBuilder(MuleContext) - Constructor for class org.mule.module.http.internal.listener.HttpListenerConfigBuilder
 
HttpListenerConnectionManager - Class in org.mule.module.http.internal.listener
 
HttpListenerConnectionManager() - Constructor for class org.mule.module.http.internal.listener.HttpListenerConnectionManager
 
HttpListenerRegistry - Class in org.mule.module.http.internal.listener
 
HttpListenerRegistry() - Constructor for class org.mule.module.http.internal.listener.HttpListenerRegistry
 
HttpListenerRegistry.PathMap - Class in org.mule.module.http.internal.listener
 
HttpListenerRegistry.PathMap() - Constructor for class org.mule.module.http.internal.listener.HttpListenerRegistry.PathMap
 
HttpListenerRegistry.RequestHandlerMatcherPair - Class in org.mule.module.http.internal.listener
 
HttpListenerRegistry.ServerAddressRequestHandlerRegistry - Class in org.mule.module.http.internal.listener
 
HttpListenerRegistry.ServerAddressRequestHandlerRegistry() - Constructor for class org.mule.module.http.internal.listener.HttpListenerRegistry.ServerAddressRequestHandlerRegistry
 
HttpMapParam - Class in org.mule.module.http.internal
 
HttpMapParam(HttpParamType) - Constructor for class org.mule.module.http.internal.HttpMapParam
 
HttpMessage - Interface in org.mule.module.http.internal.domain
Represents common parts of an http message
HttpMessageBuilder - Class in org.mule.module.http.internal
 
HttpMessageBuilder() - Constructor for class org.mule.module.http.internal.HttpMessageBuilder
 
HttpMessageBuilderRef - Class in org.mule.module.http.internal
Object that holds a reference to an HttpMessageBuilder, it represents the <http:builder ref="..." /> element for composing request/response builders.
HttpMessageBuilderRef() - Constructor for class org.mule.module.http.internal.HttpMessageBuilderRef
 
HttpMessageLogger - Class in org.mule.module.http.internal
Logger for plain HTTP request and response.
HttpMessageLogger(HttpMessageLogger.LoggerType) - Constructor for class org.mule.module.http.internal.HttpMessageLogger
 
HttpMessageLogger.LoggerType - Enum in org.mule.module.http.internal
 
HttpMessageProcessContext - Class in org.mule.module.http.internal.listener
 
HttpMessageProcessorTemplate - Class in org.mule.module.http.internal.listener
 
HttpMessageProcessorTemplate(MuleEvent, MessageProcessor, HttpResponseReadyCallback, HttpResponseBuilder, HttpResponseBuilder) - Constructor for class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
HttpMessageProcessTemplate - Class in org.mule.transport.http
 
HttpMessageProcessTemplate(HttpMessageReceiver, HttpServerConnection) - Constructor for class org.mule.transport.http.HttpMessageProcessTemplate
 
HttpMessagePropertiesResolver - Class in org.mule.module.http.internal.listener
 
HttpMessagePropertiesResolver() - Constructor for class org.mule.module.http.internal.listener.HttpMessagePropertiesResolver
 
HttpMessageReceiver - Class in org.mule.transport.http
HttpMessageReceiver is a simple http server that can be used to listen for HTTP requests on a particular port.
HttpMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.http.HttpMessageReceiver
 
HttpMessageReceiver.EmptyRequestException - Exception in org.mule.transport.http
 
HttpMessageReceiver.EmptyRequestException() - Constructor for exception org.mule.transport.http.HttpMessageReceiver.EmptyRequestException
 
HttpMessageReceiver.FailureProcessingRequestException - Exception in org.mule.transport.http
 
HttpMessageReceiver.FailureProcessingRequestException() - Constructor for exception org.mule.transport.http.HttpMessageReceiver.FailureProcessingRequestException
 
HttpMessages - Class in org.mule.transport.http.i18n
 
HttpMessages() - Constructor for class org.mule.transport.http.i18n.HttpMessages
 
HttpMessageSingleParamDefinitionParser - Class in org.mule.module.http.internal.config
Bean definition parser for query parameters, URI parameters and headers, for both the request-builder and the response-builder elements.
HttpMessageSingleParamDefinitionParser(Class<? extends HttpParam>, HttpParamType) - Constructor for class org.mule.module.http.internal.config.HttpMessageSingleParamDefinitionParser
 
HttpMimeMultipart - Class in org.mule.module.http.internal.multipart
 
HttpMimeMultipart(String, String) - Constructor for class org.mule.module.http.internal.multipart.HttpMimeMultipart
 
HttpMuleMessageFactory - Class in org.mule.transport.http
 
HttpMuleMessageFactory() - Constructor for class org.mule.transport.http.HttpMuleMessageFactory
 
HttpMuleMessageFactory(MuleContext) - Constructor for class org.mule.transport.http.HttpMuleMessageFactory
HttpMultipartEncoder - Class in org.mule.module.http.internal.multipart
Creates multipart
HttpMultipartMuleMessageFactory - Class in org.mule.transport.http
 
HttpMultipartMuleMessageFactory() - Constructor for class org.mule.transport.http.HttpMultipartMuleMessageFactory
 
HttpNamespaceHandler - Class in org.mule.module.http.internal.config
 
HttpNamespaceHandler() - Constructor for class org.mule.module.http.internal.config.HttpNamespaceHandler
 
HttpNamespaceHandler - Class in org.mule.transport.http.config
Reigsters a Bean Definition Parser for handling elements.
HttpNamespaceHandler() - Constructor for class org.mule.transport.http.config.HttpNamespaceHandler
 
HttpParam - Class in org.mule.module.http.internal
 
HttpParam(HttpParamType) - Constructor for class org.mule.module.http.internal.HttpParam
 
httpParameterNotSet(String) - Static method in class org.mule.transport.http.i18n.HttpMessages
 
HttpParameters - Interface in org.mule.module.http.api
HTTP parameters map.
HttpParamType - Enum in org.mule.module.http.internal
 
HttpParser - Class in org.mule.module.http.internal
 
HttpParser() - Constructor for class org.mule.module.http.internal.HttpParser
 
HttpPart - Class in org.mule.module.http.internal.multipart
 
HttpPart(String, byte[], String, int) - Constructor for class org.mule.module.http.internal.multipart.HttpPart
 
HttpPart(String, String, byte[], String, int) - Constructor for class org.mule.module.http.internal.multipart.HttpPart
 
HttpPartDataSource - Class in org.mule.module.http.internal.multipart
 
HttpPollingConnector - Class in org.mule.transport.http
The HttpPollingConnectors allows for inbound Http endpoints to be configured with an address which it shall use to poll for a result.
HttpPollingConnector(MuleContext) - Constructor for class org.mule.transport.http.HttpPollingConnector
 
HttpProtocol - Enum in org.mule.module.http.internal.domain
Represents the http message protocol.
HttpProxy - Class in org.mule.transport.http.construct
A simple HTTP proxy that supports transformation and caching.
HttpProxy(String, MuleContext, MessageSource, OutboundEndpoint, List<MessageProcessor>, List<MessageProcessor>, CachingStrategy) - Constructor for class org.mule.transport.http.construct.HttpProxy
 
HttpProxyBuilder - Class in org.mule.transport.http.construct.builder
 
HttpProxyBuilder() - Constructor for class org.mule.transport.http.construct.builder.HttpProxyBuilder
 
HttpProxyDefinitionParser - Class in org.mule.transport.http.config.spring.parsers.specific
 
HttpProxyDefinitionParser() - Constructor for class org.mule.transport.http.config.spring.parsers.specific.HttpProxyDefinitionParser
 
HttpProxyFactoryBean - Class in org.mule.transport.http.config.spring.factories
 
HttpProxyFactoryBean() - Constructor for class org.mule.transport.http.config.spring.factories.HttpProxyFactoryBean
 
HttpRequest - Interface in org.mule.module.http.internal.domain.request
 
HttpRequest - Class in org.mule.transport.http
A http request wrapper
HttpRequest(RequestLine, Header[], String) - Constructor for class org.mule.transport.http.HttpRequest
 
HttpRequest(RequestLine, Header[], InputStream, String) - Constructor for class org.mule.transport.http.HttpRequest
 
HttpRequestAuthentication - Class in org.mule.module.http.internal.domain.request
 
HttpRequestAuthentication(HttpAuthenticationType) - Constructor for class org.mule.module.http.internal.domain.request.HttpRequestAuthentication
 
HttpRequestBodyToParamMap - Class in org.mule.transport.http.transformers
 
HttpRequestBodyToParamMap() - Constructor for class org.mule.transport.http.transformers.HttpRequestBodyToParamMap
 
HttpRequestBuilder - Class in org.mule.module.http.internal.domain.request
 
HttpRequestBuilder() - Constructor for class org.mule.module.http.internal.domain.request.HttpRequestBuilder
 
HttpRequestBuilderDefinitionParser - Class in org.mule.module.http.internal.config
 
HttpRequestBuilderDefinitionParser() - Constructor for class org.mule.module.http.internal.config.HttpRequestBuilderDefinitionParser
 
HttpRequestCacheKey<OptionsType extends OperationOptions> - Class in org.mule.module.http.internal.request.client
Cache key used to locale an DefaultHttpRequester in a map based on a URL and operation options.
HttpRequestCacheKey(String, OptionsType, MessageExchangePattern) - Constructor for class org.mule.module.http.internal.request.client.HttpRequestCacheKey
 
HttpRequestConfigDefinitionParser - Class in org.mule.module.http.internal.config
 
HttpRequestConfigDefinitionParser() - Constructor for class org.mule.module.http.internal.config.HttpRequestConfigDefinitionParser
 
HttpRequestContext - Class in org.mule.module.http.internal.domain.request
Holds the input from an http request.
HttpRequestContext(HttpRequest, ClientConnection, String) - Constructor for class org.mule.module.http.internal.domain.request.HttpRequestContext
 
HttpRequestDispatcherWork - Class in org.mule.transport.http
Dispatches HttpRequest to the appropriate MessageReceiver
HttpRequestDispatcherWork(HttpConnector, Socket) - Constructor for class org.mule.transport.http.HttpRequestDispatcherWork
 
HttpRequesterBuilder - Class in org.mule.module.http.internal.request.client
 
HttpRequesterBuilder(MuleContext) - Constructor for class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
HttpRequesterConfig - Interface in org.mule.module.http.api.requester
Configuration object for an HttpRequester.
HttpRequesterConfigBuilder - Class in org.mule.module.http.api.requester
Builder for creating http request configs pragmatically.
HttpRequesterConfigBuilder(MuleContext) - Constructor for class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
HttpRequesterRequestBuilder - Class in org.mule.module.http.internal.request
 
HttpRequesterRequestBuilder() - Constructor for class org.mule.module.http.internal.request.HttpRequesterRequestBuilder
 
HttpRequesterWsdlRetrieverStrategy - Class in org.mule.module.ws.consumer
A wsdl retriever strategy implementation to get the wsdl through a proxy.
HttpRequesterWsdlRetrieverStrategy(TlsContextFactory, ProxyConfig, MuleContext) - Constructor for class org.mule.module.ws.consumer.HttpRequesterWsdlRetrieverStrategy
 
HttpRequesterWsdlRetrieverStrategyFactory - Class in org.mule.module.ws.consumer.wsdl.strategy.factory
Factory to create HttpRequesterWsdlRetrieverStrategy
HttpRequesterWsdlRetrieverStrategyFactory(TlsContextFactory, ProxyConfig, MuleContext) - Constructor for class org.mule.module.ws.consumer.wsdl.strategy.factory.HttpRequesterWsdlRetrieverStrategyFactory
 
HttpRequestOperationConfig<BuilderType> - Interface in org.mule.module.http.api.requester
Common configuration for an HTTP request operation
HttpRequestOptions - Interface in org.mule.module.http.api.client
Options that can be configured for making an HTTP request using MuleClient Implementations of this class must redefine Object.hashCode() and Object.equals(Object) since the may be used as key in a map
HttpRequestOptionsBuilder - Class in org.mule.module.http.api.client
Builder object for HttpRequestOptions
HttpRequestParsingException - Exception in org.mule.module.http.internal.listener
Exception thrown when there is a problem processing an incoming HttpRequest to generate a MuleEvent.
HttpRequestParsingException(String, Throwable) - Constructor for exception org.mule.module.http.internal.listener.HttpRequestParsingException
 
HttpRequestPropertyManager - Class in org.mule.module.cxf
 
HttpRequestPropertyManager() - Constructor for class org.mule.module.cxf.HttpRequestPropertyManager
 
HttpRequestToByteArray - Class in org.mule.transport.servlet.transformers
Converts an HttpServletRequest into an array of bytes by extracting the payload of the request.
HttpRequestToByteArray() - Constructor for class org.mule.transport.servlet.transformers.HttpRequestToByteArray
 
HttpRequestToInputStream - Class in org.mule.transport.servlet.transformers
Converts a HttpServletRequest into an InputStream.
HttpRequestToInputStream() - Constructor for class org.mule.transport.servlet.transformers.HttpRequestToInputStream
 
HttpRequestToMuleEvent - Class in org.mule.module.http.internal.listener
 
HttpRequestToMuleEvent() - Constructor for class org.mule.module.http.internal.listener.HttpRequestToMuleEvent
 
HttpRequestToParameter - Class in org.mule.transport.servlet.transformers
 
HttpRequestToParameter() - Constructor for class org.mule.transport.servlet.transformers.HttpRequestToParameter
 
HttpRequestToParameterMap - Class in org.mule.transport.servlet.transformers
Returns a simple Map of the parameters sent with the HTTP Request.
HttpRequestToParameterMap() - Constructor for class org.mule.transport.servlet.transformers.HttpRequestToParameterMap
 
HttpRequestWildcardFilter - Class in org.mule.transport.http.filters
HttpRequestWildcardFilter filters out wildcard URL expressions.
HttpRequestWildcardFilter() - Constructor for class org.mule.transport.http.filters.HttpRequestWildcardFilter
 
HttpRequestWildcardFilter(String) - Constructor for class org.mule.transport.http.filters.HttpRequestWildcardFilter
 
HttpResponse - Interface in org.mule.module.http.internal.domain.response
 
HttpResponse - Class in org.mule.transport.http
A generic HTTP response wrapper.
HttpResponse() - Constructor for class org.mule.transport.http.HttpResponse
 
HttpResponse(StatusLine, Header[], InputStream) - Constructor for class org.mule.transport.http.HttpResponse
 
HttpResponseBuilder - Class in org.mule.module.http.internal.domain.response
 
HttpResponseBuilder() - Constructor for class org.mule.module.http.internal.domain.response.HttpResponseBuilder
 
HttpResponseBuilder - Class in org.mule.module.http.internal.listener
 
HttpResponseBuilder() - Constructor for class org.mule.module.http.internal.listener.HttpResponseBuilder
 
HttpResponseBuilder - Class in org.mule.transport.http.components
 
HttpResponseBuilder() - Constructor for class org.mule.transport.http.components.HttpResponseBuilder
 
HttpResponseBuilderDefinitionParser - Class in org.mule.module.http.internal.config
 
HttpResponseBuilderDefinitionParser(String) - Constructor for class org.mule.module.http.internal.config.HttpResponseBuilderDefinitionParser
 
HttpResponseBuilderDefinitionParser - Class in org.mule.transport.http.config
 
HttpResponseBuilderDefinitionParser(String) - Constructor for class org.mule.transport.http.config.HttpResponseBuilderDefinitionParser
 
HttpResponseDefinitionParser - Class in org.mule.transport.http.builder
 
HttpResponseDefinitionParser(String) - Constructor for class org.mule.transport.http.builder.HttpResponseDefinitionParser
 
HttpResponseException - Exception in org.mule.transport.http
A wrapper exceptin for any http client return codes over the 400 range
HttpResponseException(String, int) - Constructor for exception org.mule.transport.http.HttpResponseException
 
HttpResponseHeaderBuilder - Class in org.mule.module.http.internal.listener
 
HttpResponseHeaderBuilder() - Constructor for class org.mule.module.http.internal.listener.HttpResponseHeaderBuilder
 
HttpResponseReadyCallback - Interface in org.mule.module.http.internal.listener.async
Handler for sending an http response asynchronously
HttpResponseToMuleEvent - Class in org.mule.module.http.internal.request
Maps an HTTP response into a Mule event.
HttpResponseToMuleEvent(DefaultHttpRequester, MuleContext, AttributeEvaluator) - Constructor for class org.mule.module.http.internal.request.HttpResponseToMuleEvent
 
HttpResponseToString - Class in org.mule.transport.http.transformers
Converts an Http Response object to String.
HttpResponseToString() - Constructor for class org.mule.transport.http.transformers.HttpResponseToString
 
HTTPS - Static variable in class org.mule.transport.http.HttpConnector
 
HTTPS - Static variable in class org.mule.transport.http.HttpsConnector
 
HTTPS - Static variable in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
HTTPS_URL_PROTOCOL - Static variable in class org.mule.transport.http.HttpConnector
 
HttpsClientMessageDispatcher - Class in org.mule.transport.http
 
HttpsClientMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.http.HttpsClientMessageDispatcher
 
HttpsClientMessageDispatcherFactory - Class in org.mule.transport.http
Creates a HttpsClientMessageDispatcher to make client requests
HttpsClientMessageDispatcherFactory() - Constructor for class org.mule.transport.http.HttpsClientMessageDispatcherFactory
 
HttpsConnector - Class in org.mule.transport.http
HttpsConnector provides Secure http connectivity on top of what is already provided with the Mule HttpConnector.
HttpsConnector(MuleContext) - Constructor for class org.mule.transport.http.HttpsConnector
 
HttpSendBodyMode - Enum in org.mule.module.http.api.requester
 
HttpServerConnection - Class in org.mule.transport.http
A connection to the SimpleHttpServer.
HttpServerConnection(Socket, String, HttpConnector) - Constructor for class org.mule.transport.http.HttpServerConnection
 
HttpServerManager - Interface in org.mule.module.http.internal.listener
A Server managers is in charge to handle all ServerSocket connections and to handle incoming requests to an Execution Service for processing.
HttpSingleParam - Class in org.mule.module.http.internal
 
HttpSingleParam(HttpParamType) - Constructor for class org.mule.module.http.internal.HttpSingleParam
 
HttpsMessageProcessTemplate - Class in org.mule.transport.http
 
HttpsMessageProcessTemplate(HttpMessageReceiver, HttpServerConnection, WorkManager) - Constructor for class org.mule.transport.http.HttpsMessageProcessTemplate
 
HttpsMessageReceiver - Class in org.mule.transport.http
 
HttpsMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.http.HttpsMessageReceiver
 
HttpsNamespaceHandler - Class in org.mule.transport.http.config
Reigsters a Bean Definition Parser for handling elements.
HttpsNamespaceHandler() - Constructor for class org.mule.transport.http.config.HttpsNamespaceHandler
 
HttpsPollingConnector - Class in org.mule.transport.http
HttpsPollingConnector provides Secure http connectivity on top of what is already provided with the Mule HttpPollingConnector.
HttpsPollingConnector(MuleContext) - Constructor for class org.mule.transport.http.HttpsPollingConnector
 
HttpStreamingType - Enum in org.mule.module.http.api.requester
Streaming mode for HTTP.
HttpThreadingProfileDefinitionParser - Class in org.mule.module.http.internal.config
Threading profile definition parser for HTTP, that sets a custom default value for the maxThreadsActive property.
HttpThreadingProfileDefinitionParser(String, String) - Constructor for class org.mule.module.http.internal.config.HttpThreadingProfileDefinitionParser
 
HttpThreadingProfileDefinitionParser(String, String, Class<? extends ThreadingProfile>) - Constructor for class org.mule.module.http.internal.config.HttpThreadingProfileDefinitionParser
 
HttpThrottlingHeadersMapBuilder - Class in org.mule.module.http.internal.listener
Creates the corresponding http headers based on the throttling statistics.
HttpThrottlingHeadersMapBuilder() - Constructor for class org.mule.module.http.internal.listener.HttpThrottlingHeadersMapBuilder
 
HttpUtil - Interface in org.mule.security.oauth.util
Internal util class for Devkit's use only.
HttpUtilImpl - Class in org.mule.security.oauth.util
Default implementation for HttpUtil
HttpUtilImpl() - Constructor for class org.mule.security.oauth.util.HttpUtilImpl
 
hyphenize(String) - Static method in class org.mule.module.extension.internal.util.NameUtils
Transforms a camel case value into a hyphenizedone.

I

id - Variable in class org.mule.module.db.internal.domain.type.AbstractDbType
 
id - Variable in class org.mule.transaction.AbstractTransaction
 
id - Variable in class org.mule.util.queue.objectstore.QueueKey
Deprecated.
 
id - Variable in class org.mule.util.queue.objectstore.xa.AbstractTransactionContext
Deprecated.
 
id - Variable in class org.mule.util.xa.AbstractTransactionContext
 
IdAttribute - Class in org.mule.config.spring.parsers.processors
 
IdAttribute(String) - Constructor for class org.mule.config.spring.parsers.processors.IdAttribute
 
IdempotentMessageFilter - Class in org.mule.routing
IdempotentMessageFilter ensures that only unique messages are passed on.
IdempotentMessageFilter() - Constructor for class org.mule.routing.IdempotentMessageFilter
 
IdempotentRedeliveryPolicy - Class in org.mule.processor
Implement a retry policy for Mule.
IdempotentRedeliveryPolicy() - Constructor for class org.mule.processor.IdempotentRedeliveryPolicy
 
IdempotentSecureHashMessageFilter - Class in org.mule.routing
IdempotentSecureHashMessageFilter ensures that only unique messages are received by a service.
IdempotentSecureHashMessageFilter() - Constructor for class org.mule.routing.IdempotentSecureHashMessageFilter
 
IdentifiableDynamicRouteResolver - Interface in org.mule.routing
SPI for identifiable dynamic route resolvers
IDENTITY - Static variable in class org.mule.module.http.api.HttpHeaders.Values
identityToShortString(Object) - Static method in class org.mule.util.ObjectUtils
Like ObjectUtils.identityToString(Object) but without the object's full package name.
idExpression - Variable in class org.mule.routing.IdempotentMessageFilter
 
IdUtils - Class in org.mule.utils
 
IF_MATCH - Static variable in class org.mule.module.http.api.HttpHeaders.Names
IF_MODIFIED_SINCE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
IF_NONE_MATCH - Static variable in class org.mule.module.http.api.HttpHeaders.Names
IF_RANGE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
IF_UNMODIFIED_SINCE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
ignore(Throwable) - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
IGNORED_METHOD - Static variable in class org.mule.config.spring.parsers.specific.IgnoreObjectMethodsDefinitionParser
 
ignoredPackages - Static variable in class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
 
ignoredPackages - Static variable in class org.mule.module.xml.transformer.jaxb.JAXBTransformerResolver
 
ignoredPropertyOverrides - Variable in class org.mule.DefaultMuleEvent
 
IgnoreObjectMethodsDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
IgnoreObjectMethodsDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.IgnoreObjectMethodsDefinitionParser
 
ignoreProperty(String) - Method in class org.mule.DefaultMuleEvent
This method is used to determine if a property on the previous event should be ignored for the next event.
ignoreProperty(MuleMessage, String) - Method in class org.mule.endpoint.outbound.OutboundEndpointPropertyMessageProcessor
 
ignoreType(Class<?>) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
ILLEGAL_EVALUATOR_MESSAGE - Static variable in class org.mule.expression.IllegalExpressionEvaluator
 
IllegalDependencyInjectionException - Exception in org.mule.api.registry
Thrown to indicate that an object has an illegal dependency injection reference against another object
IllegalDependencyInjectionException(String) - Constructor for exception org.mule.api.registry.IllegalDependencyInjectionException
 
IllegalExpressionEvaluator - Class in org.mule.expression
Defines an ExpressionEvaluator that can never be evaluated.
IllegalExpressionEvaluator() - Constructor for class org.mule.expression.IllegalExpressionEvaluator
 
illegalMIMEType(String) - Static method in class org.mule.config.i18n.CoreMessages
 
IllegalTransactionStateException - Exception in org.mule.transaction
IllegalTransactionStateException TODO (document class)
IllegalTransactionStateException(Message) - Constructor for exception org.mule.transaction.IllegalTransactionStateException
 
IllegalTransactionStateException(Message, Throwable) - Constructor for exception org.mule.transaction.IllegalTransactionStateException
 
IMAP - Static variable in class org.mule.transport.email.ImapConnector
 
ImapConnector - Class in org.mule.transport.email
Receives messages from an IMAP mailbox
ImapConnector(MuleContext) - Constructor for class org.mule.transport.email.ImapConnector
 
ImapNamespaceHandler - Class in org.mule.transport.email.config
Registers a Bean Definition Parser for handling elements.
ImapNamespaceHandler() - Constructor for class org.mule.transport.email.config.ImapNamespaceHandler
 
IMAPS - Static variable in class org.mule.transport.email.ImapsConnector
 
ImapsConnector - Class in org.mule.transport.email
Creates a secure IMAP connection
ImapsConnector(MuleContext) - Constructor for class org.mule.transport.email.ImapsConnector
 
ImapsNamespaceHandler - Class in org.mule.transport.email.config
Registers a Bean Definition Parser for handling elements.
ImapsNamespaceHandler() - Constructor for class org.mule.transport.email.config.ImapsNamespaceHandler
 
ImapsSocketFactory - Class in org.mule.transport.email
A socket factor that reads "indirect" configuration (see TlsConfiguration) for IMAPS from System properties.
ImapsSocketFactory() - Constructor for class org.mule.transport.email.ImapsSocketFactory
 
ImmutableEndpoint - Interface in org.mule.api.endpoint
ImmutableEndpoint describes a Message endpoint where data is sent or received.
immutableList(Collection<T>) - Static method in class org.mule.util.CollectionUtils
Returns an immutable copy of collection.
ImmutableThreadingProfile - Class in org.mule.config
 
ImmutableThreadingProfile(int, int, int, long, long, int, boolean, RejectedExecutionHandler, ThreadFactory) - Constructor for class org.mule.config.ImmutableThreadingProfile
 
ImmutableThreadingProfile(ThreadingProfile) - Constructor for class org.mule.config.ImmutableThreadingProfile
 
ImmutableThreadingProfile.DefaultWorkManagerFactory - Class in org.mule.config
 
ImmutableThreadingProfile.DefaultWorkManagerFactory() - Constructor for class org.mule.config.ImmutableThreadingProfile.DefaultWorkManagerFactory
 
ImplementationClassScanner - Class in org.mule.util.scan
Deprecated.
ImplementationClassScanner(Class) - Constructor for class org.mule.util.scan.ImplementationClassScanner
Deprecated.
 
ImplementationClassScanner(Class, ClassLoader) - Constructor for class org.mule.util.scan.ImplementationClassScanner
Deprecated.
 
importClass(Class<?>) - Method in interface org.mule.api.el.ExpressionLanguageContext
 
importClass(String, Class<?>) - Method in interface org.mule.api.el.ExpressionLanguageContext
 
importClass(Class<?>) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
importClass(String, Class<?>) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
ImportMapEntryDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
ImportMapEntryDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.specific.ImportMapEntryDefinitionParser
 
imports - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
importStaticMethod(String, Method) - Method in interface org.mule.api.el.ExpressionLanguageContext
 
importStaticMethod(String, Method) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
 
IN_FAULT_INTERCEPTORS - Static variable in class org.mule.module.cxf.CxfConstants
 
IN_INTERCEPTORS - Static variable in class org.mule.module.cxf.CxfConstants
 
IN_PARAM_ELEMENT - Static variable in class org.mule.module.db.internal.config.domain.query.QueryTemplateBeanDefinitionParser
 
IN_PARAM_TAG - Static variable in class org.mule.module.db.internal.config.domain.query.QueryDefinitionParser
 
inappropriateMessageTypeForAttachments(Message) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
INBOUND - Static variable in class org.mule.api.transport.PropertyScope
This scope holds all inbound headers when a message is received.
INBOUND_ADDRESS_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
INBOUND_ENDPOINT - Static variable in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
INBOUND_ENDPOINT_CHILD - Static variable in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
INBOUND_ENDPOINT_REF_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
INBOUND_NAME - Static variable in class org.mule.api.transport.PropertyScope
 
INBOUND_OPERATION - Static variable in class org.mule.module.cxf.CxfConstants
 
INBOUND_SERVICE - Static variable in class org.mule.module.cxf.CxfConstants
 
inboundAddress(String) - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundEndpointBuilder
 
InboundAttachmentMapContext - Class in org.mule.el.context
 
InboundAttachmentMapContext(MuleMessage) - Constructor for class org.mule.el.context.InboundAttachmentMapContext
 
InboundAttachments - Annotation Type in org.mule.api.annotations.param
Used on component and transformer methods that have a Transformer annotation.
InboundAttachmentsAnnotationParser - Class in org.mule.config.parsers
Responsible for parsing the InboundAttachments annotation.
InboundAttachmentsAnnotationParser() - Constructor for class org.mule.config.parsers.InboundAttachmentsAnnotationParser
 
InboundAttachmentsMap - Class in org.mule.expression
Creates a wrapper around Mule Message with a MAp facade used for allowing developers to add attachments to an outgoing message in a transformer of component without needing to access the Mule API directly
InboundAttachmentsMap(MuleMessage) - Constructor for class org.mule.expression.InboundAttachmentsMap
 
InboundEndpoint - Interface in org.mule.api.endpoint
 
inboundEndpoint(InboundEndpoint) - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundEndpointBuilder
 
inboundEndpoint(EndpointBuilder) - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundEndpointBuilder
 
inboundEndpoint - Variable in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
InboundEndpointFactoryBean - Class in org.mule.config.spring.factories
Spring FactoryBean used to create concrete instances of inbound endpoints
InboundEndpointFactoryBean(EndpointURIEndpointBuilder) - Constructor for class org.mule.config.spring.factories.InboundEndpointFactoryBean
 
InboundEndpointFactoryBean() - Constructor for class org.mule.config.spring.factories.InboundEndpointFactoryBean
 
InboundEndpointMimeTypeCheckingMessageProcessor - Class in org.mule.endpoint.inbound
Verify that the inbound mime type is acceptable by this endpoint.
InboundEndpointMimeTypeCheckingMessageProcessor(InboundEndpoint) - Constructor for class org.mule.endpoint.inbound.InboundEndpointMimeTypeCheckingMessageProcessor
 
InboundEndpointPropertyMessageProcessor - Class in org.mule.endpoint.inbound
Sets the inbound endpoint uri on as a property of the message using the following key: MuleProperties.MULE_ORIGINATING_ENDPOINT_PROPERTY.
InboundEndpointPropertyMessageProcessor(InboundEndpoint) - Constructor for class org.mule.endpoint.inbound.InboundEndpointPropertyMessageProcessor
 
InboundEndpointWrapper - Class in org.mule.tck.util.endpoint
Wraps an InboundEndpoint enabling subclasses to override only those methods which add extra behaviour.
InboundEndpointWrapper(InboundEndpoint) - Constructor for class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
InboundExceptionDetailsMessageProcessor - Class in org.mule.endpoint.inbound
Sets error message properties as specified by the transport based on the exception type of the exception payload.
InboundExceptionDetailsMessageProcessor(Connector) - Constructor for class org.mule.endpoint.inbound.InboundExceptionDetailsMessageProcessor
 
InboundHeaders - Annotation Type in org.mule.api.annotations.param
Used on component methods, this annotation marks the method parameter that will be used to pass in one or more of the headers received.
InboundHeadersAnnotationParser - Class in org.mule.config.parsers
Responsible for parsing the InboundHeaders annotation.
InboundHeadersAnnotationParser() - Constructor for class org.mule.config.parsers.InboundHeadersAnnotationParser
 
InboundLoggingMessageProcessor - Class in org.mule.endpoint.inbound
 
InboundLoggingMessageProcessor(InboundEndpoint) - Constructor for class org.mule.endpoint.inbound.InboundLoggingMessageProcessor
 
inboundMap - Variable in class org.mule.MessagePropertiesContext
 
inboundMessageAttachmentsImmutable(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
inboundMessageAttachmentsImmutable() - Static method in class org.mule.config.i18n.CoreMessages
 
inboundMessagePropertiesImmutable(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
inboundMessagePropertiesImmutable() - Static method in class org.mule.config.i18n.CoreMessages
 
InboundNotificationMessageProcessor - Class in org.mule.endpoint.inbound
Publishes a EndpointMessageNotification's when a message is received.
InboundNotificationMessageProcessor(InboundEndpoint) - Constructor for class org.mule.endpoint.inbound.InboundNotificationMessageProcessor
 
InboundRouterDefinitionParser - Class in org.mule.config.spring.parsers.specific
Generic router definition parser for parsing all Router elements.
InboundRouterDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.InboundRouterDefinitionParser
 
InboundRouterDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.InboundRouterDefinitionParser
 
inboundTransformer - Variable in class org.mule.transformer.wire.TransformerPairWireFormat
 
inc() - Method in class org.mule.tck.testmodels.services.TestComponent
 
inc() - Method in class org.mule.tck.testmodels.services.TestReceiver
 
incCallbackCount() - Method in class org.mule.tck.functional.CounterCallback
Increment callback count.
incExecutionError() - Method in class org.mule.management.stats.FlowConstructStatistics
 
incFatalError() - Method in class org.mule.management.stats.FlowConstructStatistics
 
INCLUDE_ABSTRACT - Static variable in class org.mule.util.scan.ClasspathScanner
Deprecated.
 
INCLUDE_ANONYMOUS - Static variable in class org.mule.util.scan.ClasspathScanner
Deprecated.
 
INCLUDE_INNER - Static variable in class org.mule.util.scan.ClasspathScanner
Deprecated.
 
INCLUDE_INTERFACE - Static variable in class org.mule.util.scan.ClasspathScanner
Deprecated.
 
includeBranchInXid() - Method in class org.mule.util.queue.objectstore.xa.AbstractXAResourceManager
Deprecated.
 
incorrectlyFormattedEndpointUri(String) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
incQueuedEvent() - Method in class org.mule.management.stats.FlowConstructStatistics
 
incQueuedEvent() - Method in interface org.mule.management.stats.QueueStatistics
 
incQueuedEvent() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
increaseNestingLevel() - Method in class org.mule.util.generics.MethodParameter
Increase this parameter's nesting level.
incReceivedEventASync() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
 
incReceivedEventSync() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
 
increment() - Method in interface org.mule.util.counters.Counter
Increment the counter's value by 1.0.
increment() - Method in class org.mule.util.counters.impl.AbstractCounter
 
increment() - Method in class org.mule.util.counters.impl.AggregateCounter
 
increment() - Method in class org.mule.util.counters.impl.Number
 
incrementBy(double) - Method in interface org.mule.util.counters.Counter
Increment the counter's value by the specified amount.
incrementBy(double) - Method in class org.mule.util.counters.impl.AbstractCounter
 
incrementBy(double) - Method in class org.mule.util.counters.impl.AggregateCounter
 
incrementBy(double) - Method in class org.mule.util.counters.impl.Number
 
incrementCaughtMessage() - Method in class org.mule.management.stats.RouterStatistics
Increment no routed message
incrementLockCount() - Method in class org.mule.util.lock.InstanceLockGroup.LockEntry
 
incrementNoRoutedMessage() - Method in class org.mule.management.stats.RouterStatistics
Increment no routed message
incrementRoutedMessage(Collection) - Method in class org.mule.management.stats.RouterStatistics
Increment routed message for multiple targets
incrementRoutedMessage(Object) - Method in class org.mule.management.stats.RouterStatistics
Increment routed message for an endpoint
incSentEventASync() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
incSentEventSync() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
incSentReplyToEvent() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
IndependentDefinitionParser - Class in org.mule.config.spring.parsers
 
IndependentDefinitionParser() - Constructor for class org.mule.config.spring.parsers.IndependentDefinitionParser
 
indexOf(Object) - Method in class org.mule.module.launcher.util.ObservableList
 
inetAddress - Variable in class org.mule.transport.udp.UdpMessageReceiver
 
inFaultInterceptors - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
INFINITY_CAPACTY - Static variable in class org.mule.util.queue.objectstore.QueueConfiguration
Deprecated.
 
info(Throwable) - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
info(String, Object...) - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
info(String, Throwable) - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
info(Object) - Method in class org.mule.util.MuleLogger
 
info(Object, Throwable) - Method in class org.mule.util.MuleLogger
 
INFO_LOCATION_KEY - Static variable in exception org.mule.api.LocatedMuleException
 
INFO_SOURCE_XML_KEY - Static variable in exception org.mule.api.LocatedMuleException
 
INHERIT - Static variable in class org.mule.config.spring.parsers.delegate.InheritDefinitionParser
 
InheritDefinitionParser - Class in org.mule.config.spring.parsers.delegate
This encapsulates two definition parsers - orphan and named - and returns the named definition parser if the "inherit" attribute is set.
InheritDefinitionParser(OrphanDefinitionParser, NamedDefinitionParser) - Constructor for class org.mule.config.spring.parsers.delegate.InheritDefinitionParser
 
InheritDefinitionParser(boolean, OrphanDefinitionParser, NamedDefinitionParser) - Constructor for class org.mule.config.spring.parsers.delegate.InheritDefinitionParser
 
InheritedModel - Class in org.mule.config.support
Deprecated.
InheritedModel() - Constructor for class org.mule.config.support.InheritedModel
Deprecated.
 
InheritedModelDefinitionParser - Class in org.mule.config.spring.parsers.specific
Allows the Inherited model type to be used.
InheritedModelDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.InheritedModelDefinitionParser
 
inInterceptors - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
init() - Method in class org.mule.config.builders.MuleXmlBuilderContextServlet
 
init() - Method in class org.mule.config.spring.handlers.MuleDomainNamespaceHandler
 
init() - Method in class org.mule.config.spring.handlers.MuleNamespaceHandler
 
init() - Method in class org.mule.module.atom.config.AtomNamespaceHandler
 
init() - Method in class org.mule.module.bpm.config.BpmNamespaceHandler
 
init() - Method in class org.mule.module.client.config.ClientNamespaceHandler
Invoked by the DefaultBeanDefinitionDocumentReader after construction but before any custom elements are parsed.
init() - Method in class org.mule.module.cxf.config.CxfNamespaceHandler
 
init() - Method in class org.mule.module.db.config.DbNamespaceHandler
 
init(MuleContext) - Method in class org.mule.module.db.internal.domain.xa.CompositeDataSourceDecorator
 
init() - Method in class org.mule.module.http.internal.config.HttpNamespaceHandler
 
init() - Method in class org.mule.module.jaas.config.JaasNamespaceHandler
 
init() - Static method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider.JaasConfig
Initializes and sets the Jaas Configuration
init() - Method in class org.mule.module.jboss.config.JbossTSNamespaceHandler
 
init() - Method in class org.mule.module.jersey.config.JerseyNamespaceHandler
 
init() - Method in class org.mule.module.json.config.JsonNamespaceHandler
 
init() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
init() - Method in interface org.mule.module.launcher.artifact.Artifact
Initialise the artifact resources
init() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
init() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
init(String[]) - Method in class org.mule.module.launcher.MuleContainer
 
init() - Method in class org.mule.module.management.config.ManagementNamespaceHandler
 
init() - Method in class org.mule.module.oauth2.internal.authorizationcode.AbstractAuthorizationCodeTokenRequestHandler
initialization method after configuration.
init() - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
init() - Method in class org.mule.module.oauth2.internal.authorizationcode.AutoAuthorizationCodeTokenRequestHandler
Starts the http listener for the redirect url callback.
init() - Method in class org.mule.module.oauth2.internal.config.OAuth2NamespaceHandler
 
init() - Method in class org.mule.module.ognl.config.OGNLNamespaceHandler
 
init() - Method in class org.mule.module.pgp.config.PgpNamespaceHandler
 
init(File, File) - Method in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
init() - Method in class org.mule.module.rss.config.RssNamespaceHandler
 
init() - Method in class org.mule.module.scripting.config.ScriptingNamespaceHandler
 
init() - Method in class org.mule.module.spring.security.config.SpringSecurityNamespaceHandler
 
init() - Method in class org.mule.module.sxc.SxcNamespaceHandler
 
init() - Method in class org.mule.module.ws.config.WSNamespaceHandler
 
init() - Method in class org.mule.module.xml.config.XmlNamespaceHandler
 
init() - Method in class org.mule.modules.schedulers.config.SchedulersNamespaceHandler
 
init(String[]) - Method in class org.mule.MuleServer
 
init() - Method in class org.mule.pattern.core.config.CorePatternNamespaceHandler
 
init() - Method in class org.mule.tck.config.TestNamespaceHandler
 
init() - Method in class org.mule.transport.ajax.config.AjaxNamespaceHandler
 
init() - Method in class org.mule.transport.ajax.container.MuleAjaxServlet
 
init() - Method in class org.mule.transport.ejb.config.EjbNamespaceHandler
 
init() - Method in class org.mule.transport.email.config.EmailNamespaceHandler
 
init() - Method in class org.mule.transport.email.config.ImapNamespaceHandler
 
init() - Method in class org.mule.transport.email.config.ImapsNamespaceHandler
 
init() - Method in class org.mule.transport.email.config.Pop3NamespaceHandler
 
init() - Method in class org.mule.transport.email.config.Pop3sNamespaceHandler
 
init() - Method in class org.mule.transport.email.config.SmtpNamespaceHandler
 
init() - Method in class org.mule.transport.email.config.SmtpsNamespaceHandler
 
init() - Method in class org.mule.transport.file.config.FileNamespaceHandler
 
init() - Method in class org.mule.transport.ftp.config.FtpNamespaceHandler
 
init() - Method in class org.mule.transport.http.config.HttpNamespaceHandler
 
init() - Method in class org.mule.transport.http.config.HttpsNamespaceHandler
 
init() - Method in class org.mule.transport.jdbc.config.JdbcNamespaceHandler
 
init(MuleContext) - Method in class org.mule.transport.jdbc.xa.CompositeDataSourceDecorator
 
init(MuleContext) - Method in class org.mule.transport.jms.CompositeConnectionFactoryDecorator
 
init() - Method in class org.mule.transport.jms.config.JmsNamespaceHandler
 
init() - Method in class org.mule.transport.jnp.config.JnpNamespaceHandler
 
init() - Method in class org.mule.transport.multicast.config.MulticastNamespaceHandler
 
init() - Method in class org.mule.transport.quartz.config.QuartzNamespaceHandler
 
init() - Method in class org.mule.transport.rmi.config.RmiNamespaceHandler
 
init(Properties) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
init() - Method in class org.mule.transport.servlet.AbstractReceiverServlet
 
init() - Method in class org.mule.transport.servlet.config.ServletNamespaceHandler
 
init() - Method in class org.mule.transport.servlet.JarResourceServlet
 
init() - Method in class org.mule.transport.servlet.jetty.config.JettyNamespaceHandler
 
init() - Method in class org.mule.transport.servlet.jetty.config.JettySslNamespaceHandler
 
init() - Method in class org.mule.transport.sftp.config.SftpNamespaceHandler
 
init() - Method in class org.mule.transport.soap.axis.config.AxisNamespaceHandler
 
init() - Method in class org.mule.transport.stdio.config.StdioNamespaceHandler
 
init() - Method in class org.mule.transport.tcp.config.TcpNamespaceHandler
 
init() - Method in class org.mule.transport.udp.config.UdpNamespaceHandler
 
init() - Method in class org.mule.transport.vm.config.VmNamespaceHandler
 
init() - Method in class org.mule.transport.xmpp.config.XmppNamespaceHandler
 
init() - Method in class org.mule.util.monitor.ExpiryMonitor
 
init(Object, MuleContext) - Static method in class org.mule.util.store.DeserializationPostInitialisable.Implementation
 
INIT_PARAMETER_MULE_APP_CONFIG - Static variable in class org.mule.config.builders.MuleXmlBuilderContextListener
 
INIT_PARAMETER_MULE_CONFIG - Static variable in class org.mule.config.builders.MuleXmlBuilderContextListener
One or more Mule config files.
INIT_PROPERTY_ENABLE_LIST - Static variable in class org.mule.transport.soap.axis.AxisServiceComponent
 
INIT_PROPERTY_TRANSPORT_NAME - Static variable in class org.mule.transport.soap.axis.AxisServiceComponent
 
INIT_PROPERTY_USE_SECURITY - Static variable in class org.mule.transport.soap.axis.AxisServiceComponent
 
initAfterDeserialisation(MuleContext) - Method in class org.mule.DefaultMessageCollection
 
initAfterDeserialisation(MuleContext) - Method in class org.mule.DefaultMuleMessage
Invoked after deserialization.
initAfterDeserialisation(MuleContext) - Method in class org.mule.routing.EventGroup
 
initAfterDeserialisation(MuleContext) - Method in class org.mule.transport.DefaultReplyToHandler
 
initAfterDeserialisation(MuleContext) - Method in class org.mule.transport.jms.JmsReplyToHandler
 
initCache(Object, MuleEventContext) - Method in class org.mule.impl.model.resolvers.AnnotatedEntryPointResolver
 
initEventGroupsObjectStore() - Method in class org.mule.routing.AbstractAggregator
 
initEventsStore(PartitionableObjectStore<MuleEvent>) - Method in class org.mule.routing.EventGroup
 
initExchangePatternFromConnectorDefault(TransportServiceDescriptor) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
initFromServiceDescriptor() - Method in class org.mule.transport.AbstractConnector
Initialises this connector from its TransportServiceDescriptor This will be called before the AbstractConnector.doInitialise() method is called.
INITIAL_RETRY_COUNT - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
INITIAL_STATE_PAUSED - Static variable in class org.mule.service.AbstractService
Deprecated.
 
INITIAL_STATE_STARTED - Static variable in interface org.mule.api.endpoint.ImmutableEndpoint
 
INITIAL_STATE_STARTED - Static variable in class org.mule.construct.AbstractFlowConstruct
 
INITIAL_STATE_STARTED - Static variable in class org.mule.service.AbstractService
Deprecated.
 
INITIAL_STATE_STOPPED - Static variable in interface org.mule.api.endpoint.ImmutableEndpoint
 
INITIAL_STATE_STOPPED - Static variable in class org.mule.construct.AbstractFlowConstruct
The initial states that the flow can be started in
INITIAL_STATE_STOPPED - Static variable in class org.mule.service.AbstractService
Deprecated.
The initial states that the service can be started in
Initialisable - Interface in org.mule.api.lifecycle
Initialisable is a lifecycle interface that gets called at the initialise lifecycle stage of the implementing service.
InitialisationCallback - Interface in org.mule.api.lifecycle
InitialisationCallback is used to provide customised initialiation for more complex components.
initialisationCallbacks - Variable in class org.mule.object.AbstractObjectFactory
 
InitialisationException - Exception in org.mule.api.lifecycle
InitialisationException is thrown by the initialise method defined in the org.mule.api.lifecycle.Initialisable interface.
InitialisationException(Message, Initialisable) - Constructor for exception org.mule.api.lifecycle.InitialisationException
 
InitialisationException(Message, Throwable, Initialisable) - Constructor for exception org.mule.api.lifecycle.InitialisationException
 
InitialisationException(Throwable, Initialisable) - Constructor for exception org.mule.api.lifecycle.InitialisationException
 
initialisationFailure(String) - Static method in class org.mule.config.i18n.CoreMessages
 
initialise() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
initialise() - Method in interface org.mule.api.lifecycle.Initialisable
Method used to perform any initialisation work.
initialise(Object) - Method in interface org.mule.api.lifecycle.InitialisationCallback
 
initialise() - Method in exception org.mule.api.MuleException
 
initialise() - Method in class org.mule.api.processor.LoggerMessageProcessor
 
initialise(boolean, String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
initialise() - Method in class org.mule.component.AbstractComponent
 
initialise() - Method in class org.mule.component.DefaultComponentLifecycleAdapter
Propagates initialise() life-cycle to component object implementations if they implement the mule Initialisable interface.
initialise() - Method in class org.mule.component.DefaultInterfaceBinding
 
initialise() - Method in class org.mule.component.NullLifecycleAdapter
 
initialise() - Method in class org.mule.component.PooledJavaComponent.LifeCycleAdapterFactory
 
initialise() - Method in class org.mule.component.simple.StaticComponent
 
initialise() - Method in class org.mule.config.bootstrap.AbstractRegistryBootstrap
TODO Optimize me! MULE-9343 Method used to perform any initialisation work.
initialise() - Method in class org.mule.config.spring.factories.AbstractEndpointFactoryBean
 
initialise() - Method in class org.mule.config.spring.factories.ConstantFactoryBean
 
initialise() - Method in class org.mule.config.spring.factories.FlowRefFactoryBean
 
initialise() - Method in class org.mule.config.spring.SpringRegistryBootstrap
 
initialise() - Method in class org.mule.config.spring.util.SpringBeanLookup
 
initialise() - Method in class org.mule.config.transformer.AnnotatedTransformerProxy
 
initialise() - Method in class org.mule.connector.MuleConnectorOperationLocator
 
initialise() - Method in class org.mule.construct.AbstractFlowConstruct
 
initialise() - Method in class org.mule.context.notification.MessageProcessingFlowTraceManager
 
initialise() - Method in class org.mule.DefaultMuleContext
 
initialise() - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
Obtains the expression manager from the Mule context and initialises the connector.
initialise() - Method in class org.mule.el.ExpressionLanguageComponent
 
initialise() - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
initialise() - Method in class org.mule.el.mvel.MVELExpressionLanguageWrapper
 
initialise() - Method in class org.mule.endpoint.MuleEndpointURI
 
initialise() - Method in class org.mule.exception.AbstractExceptionListener
The initialise method is call every time the Exception stategy is assigned to a service or connector.
initialise() - Method in class org.mule.exception.ChoiceMessagingExceptionStrategy
 
initialise() - Method in class org.mule.exception.RedeliveryExceeded
 
initialise() - Method in class org.mule.execution.MuleMessageProcessingManager
 
initialise() - Method in class org.mule.expression.DefaultExpressionManager
 
initialise() - Method in class org.mule.expression.transformers.AbstractExpressionTransformer
Template method were deriving classes can do any initialisation after the properties have been set on this transformer
initialise() - Method in class org.mule.expression.transformers.BeanBuilderTransformer
Template method were deriving classes can do any initialisation after the properties have been set on this transformer
initialise() - Method in class org.mule.interceptor.InterceptorStack
 
initialise() - Method in class org.mule.model.AbstractModel
Deprecated.
 
initialise() - Method in class org.mule.model.seda.SedaModel
Deprecated.
 
initialise() - Method in class org.mule.module.bpm.Process
 
initialise() - Method in class org.mule.module.bpm.Rules
 
initialise() - Method in class org.mule.module.client.remoting.RemoteDispatcherAgent
Deprecated.
 
initialise() - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
initialise() - Method in class org.mule.module.cxf.config.FlowConfiguringMessageProcessor
 
initialise() - Method in class org.mule.module.cxf.CxfConfiguration
 
initialise() - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
initialise() - Method in class org.mule.module.cxf.WSProxyService
Deprecated.
 
initialise(DbConnection) - Method in class org.mule.module.db.internal.domain.type.MetadataDbTypeManager
 
initialise() - Method in class org.mule.module.db.internal.el.DbModuleElExtension
 
initialise() - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
initialise() - Method in class org.mule.module.extension.internal.manager.DefaultExtensionManager
 
initialise() - Method in class org.mule.module.extension.internal.runtime.processor.OperationMessageProcessor
 
initialise() - Method in class org.mule.module.extension.internal.runtime.ReflectiveMethodOperationExecutor
 
initialise() - Method in class org.mule.module.http.internal.HttpMessageBuilder
 
initialise() - Method in class org.mule.module.http.internal.HttpSingleParam
 
initialise() - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
initialise() - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
initialise() - Method in class org.mule.module.http.internal.listener.HttpListenerConnectionManager
 
initialise() - Method in class org.mule.module.http.internal.listener.HttpResponseBuilder
 
initialise() - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
initialise() - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
initialise() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
initialise() - Method in class org.mule.module.jbpm.Jbpm
 
initialise() - Method in class org.mule.module.json.transformers.AbstractJsonTransformer
 
initialise() - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
initialise() - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
initialise() - Method in class org.mule.module.json.transformers.JsonSchemaXsdValidationFilter
Deprecated.
 
initialise() - Method in class org.mule.module.json.transformers.JsonToObject
 
initialise() - Method in class org.mule.module.json.transformers.ObjectToJson
 
initialise() - Method in class org.mule.module.json.validation.ValidateJsonSchemaMessageProcessor
 
initialise() - Method in class org.mule.module.launcher.coreextension.DefaultMuleCoreExtensionManager
 
initialise() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
initialise() - Method in class org.mule.module.launcher.log4j2.MuleLog4jContextFactory
 
initialise() - Method in class org.mule.module.management.agent.AbstractJmxAgent
Method used to perform any initialisation work.
initialise() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
Method used to perform any initialisation work.
initialise() - Method in class org.mule.module.management.agent.JdmkAgent
 
initialise() - Method in class org.mule.module.management.agent.Log4jAgent
Deprecated.
 
initialise() - Method in class org.mule.module.management.agent.Mx4jAgent
 
initialise() - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
initialise() - Method in class org.mule.module.management.agent.WrapperManagerAgent
 
initialise() - Method in class org.mule.module.management.agent.YourKitProfilerAgent
 
initialise() - Method in class org.mule.module.management.mbean.ConnectorService
 
initialise() - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
initialise() - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
initialise() - Method in class org.mule.module.oauth2.internal.mel.OAuthExpressionLanguageExtension
 
initialise() - Method in class org.mule.module.oauth2.internal.tokenmanager.InvalidateOauthContextMessageProcessor
 
initialise() - Method in class org.mule.module.oauth2.internal.tokenmanager.TokenManagerConfig
 
initialise() - Method in class org.mule.module.pgp.KeyBasedEncryptionStrategy
 
initialise() - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
initialise() - Method in class org.mule.module.scripting.component.Scriptable
 
initialise() - Method in class org.mule.module.scripting.filter.ScriptFilter
 
initialise() - Method in class org.mule.module.scripting.transformer.ScriptTransformer
 
initialise() - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
 
initialise() - Method in class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
initialise() - Method in class org.mule.module.sxc.SxcFilteringOutboundRouter
 
initialise() - Method in class org.mule.module.ws.consumer.WSConsumer
 
initialise() - Method in class org.mule.module.xml.el.XMLExpressionLanguageExtension
 
initialise() - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
initialise() - Method in class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
 
initialise() - Method in class org.mule.module.xml.filters.AbstractJaxpFilter
 
initialise() - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
initialise(JXPathContext) - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
Initializes the JXPathContext based on any relevant properties set for the filter.
initialise() - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
initialise() - Method in class org.mule.module.xml.filters.XPathFilter
 
initialise() - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
initialise() - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
initialise() - Method in class org.mule.module.xml.transformer.jaxb.JAXBMarshallerTransformer
 
initialise() - Method in class org.mule.module.xml.transformer.jaxb.JAXBUnmarshallerTransformer
 
initialise() - Method in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
Template method where deriving classes can do any initialisation after the properties have been set on this transformer
initialise() - Method in class org.mule.module.xml.transformer.XPathExtractor
 
initialise() - Method in class org.mule.module.xml.util.NamespaceManager
 
initialise() - Method in class org.mule.modules.schedulers.cron.CronScheduler
 
initialise() - Method in class org.mule.object.AbstractObjectFactory
 
initialise() - Method in class org.mule.object.JndiObjectFactory
 
initialise() - Method in class org.mule.processor.AbstractMuleObjectOwner
 
initialise() - Method in class org.mule.processor.AbstractRedeliveryPolicy
 
initialise() - Method in class org.mule.processor.AsyncDelegateMessageProcessor
 
initialise() - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
initialise() - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
initialise() - Method in class org.mule.processor.InvokerMessageProcessor
 
initialise() - Method in class org.mule.processor.ResponseMessageProcessorAdapter
 
initialise() - Method in class org.mule.processor.SecurityFilterMessageProcessor
 
initialise() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
initialise() - Method in class org.mule.processor.TransactionalInterceptingMessageProcessor
 
initialise() - Method in class org.mule.registry.AbstractRegistry
 
initialise() - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
initialise() - Method in class org.mule.registry.MuleRegistryHelper
Method used to perform any initialisation work.
initialise() - Method in class org.mule.registry.TypeBasedTransformerResolver
 
initialise() - Method in class org.mule.routing.AbstractAggregator
 
initialise() - Method in class org.mule.routing.AbstractMatchingRouter
 
initialise() - Method in class org.mule.routing.AbstractSelectiveRouter
 
initialise() - Method in class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
 
initialise() - Method in class org.mule.routing.DynamicAll
 
initialise() - Method in class org.mule.routing.DynamicFirstSuccessful
 
initialise() - Method in class org.mule.routing.DynamicRoundRobin
 
initialise() - Method in class org.mule.routing.ExpressionSplitter
 
initialise() - Method in class org.mule.routing.filters.RegExFilter
 
initialise() - Method in class org.mule.routing.FirstSuccessful
 
initialise() - Method in class org.mule.routing.Foreach
 
initialise() - Method in class org.mule.routing.ForwardingCatchAllStrategy
Deprecated.
 
initialise() - Method in class org.mule.routing.IdempotentMessageFilter
 
initialise() - Method in class org.mule.routing.MessageFilter
 
initialise() - Method in class org.mule.routing.MessageProcessorFilterPair
 
initialise() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
initialise() - Method in class org.mule.routing.outbound.AbstractRoundRobinMessageSplitter
 
initialise() - Method in class org.mule.routing.outbound.ChainingRouter
Deprecated.
 
initialise() - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
initialise() - Method in class org.mule.routing.outbound.ExpressionMessageSplitter
Deprecated.
 
initialise() - Method in class org.mule.routing.outbound.FilteringOutboundRouter
 
initialise() - Method in class org.mule.routing.outbound.MulticastingRouter
Deprecated.
 
initialise() - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
initialise() - Method in class org.mule.routing.Resequencer
 
initialise() - Method in class org.mule.routing.ScatterGatherRouter
 
initialise() - Method in class org.mule.routing.SynchronousUntilSuccessfulProcessingStrategy
 
initialise() - Method in class org.mule.routing.UntilSuccessful
 
initialise() - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
initialise() - Method in class org.mule.security.AbstractSecurityFilter
 
initialise() - Method in class org.mule.security.AbstractSecurityProvider
 
initialise() - Method in class org.mule.security.MuleSecurityManager
 
initialise() - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
initialise() - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
 
initialise() - Method in class org.mule.security.PasswordBasedEncryptionStrategy
 
initialise() - Method in class org.mule.security.SecretKeyEncryptionStrategy
Deprecated.
 
initialise() - Method in class org.mule.service.AbstractService
Deprecated.
Initialise the service.
initialise() - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
initialise() - Method in class org.mule.source.ClusterizableMessageSourceWrapper
 
initialise() - Method in class org.mule.source.StartableCompositeMessageSource
 
initialise() - Method in class org.mule.tck.functional.FunctionalTestComponent
 
initialise() - Method in class org.mule.tck.functional.InvocationCountMessageProcessor
 
initialise() - Method in class org.mule.tck.security.MockEncryptionStrategy
 
initialise() - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
Method used to perform any initialisation work.
initialise() - Method in class org.mule.transformer.AbstractTransformer
Template method where deriving classes can do any initialisation after the properties have been set on this transformer
initialise() - Method in class org.mule.transformer.CompositeConverter
 
initialise() - Method in class org.mule.transformer.encryption.AbstractEncryptionTransformer
Template method were deriving classes can do any initialisation after the properties have been set on this transformer
initialise() - Method in class org.mule.transformer.simple.AbstractAddVariablePropertyTransformer
 
initialise() - Method in class org.mule.transformer.simple.AbstractRemoveVariablePropertyTransformer
 
initialise() - Method in class org.mule.transformer.simple.AddAttachmentTransformer
 
initialise() - Method in class org.mule.transformer.simple.AutoTransformer
Template method where deriving classes can do any initialisation after the properties have been set on this transformer
initialise() - Method in class org.mule.transformer.simple.CopyAttachmentsTransformer
 
initialise() - Method in class org.mule.transformer.simple.CopyPropertiesTransformer
 
initialise() - Method in class org.mule.transformer.simple.MapToBean
 
initialise() - Method in class org.mule.transformer.simple.ParseTemplateTransformer
 
initialise() - Method in class org.mule.transformer.simple.RemoveAttachmentTransformer
 
initialise() - Method in class org.mule.transformer.simple.SetPayloadMessageProcessor
 
initialise() - Method in class org.mule.transformer.simple.SetPayloadTransformer
 
initialise() - Method in class org.mule.transformer.TransformerChain
 
initialise() - Method in class org.mule.transport.AbstractConnector
 
initialise() - Method in class org.mule.transport.AbstractMessageReceiver
Method used to perform any initialisation work.
initialise() - Method in class org.mule.transport.AbstractMessageRequester
Method used to perform any initialisation work.
initialise() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
initialise() - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
initialise() - Method in class org.mule.transport.http.components.StaticResourceMessageProcessor
 
initialise() - Method in class org.mule.transport.http.transformers.MuleMessageToHttpResponse
 
initialise() - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
initialise() - Method in class org.mule.transport.jms.jndi.CachedJndiNameResolver
 
initialise() - Method in class org.mule.transport.jms.jndi.SimpleJndiNameResolver
 
initialise() - Method in class org.mule.transport.polling.schedule.FixedFrequencyScheduler
Creates the FixedFrequencyScheduler.executor that is going to be used to launch schedules
initialise() - Method in class org.mule.transport.polling.watermark.selector.SelectorWatermark
 
initialise() - Method in class org.mule.transport.polling.watermark.UpdateExpressionWatermark
 
initialise() - Method in class org.mule.transport.quartz.jobs.PollEndpointJob
 
initialise() - Method in class org.mule.transport.servlet.jetty.JettyWebappServerAgent
 
initialise(SOAPService) - Method in interface org.mule.transport.soap.axis.AxisInitialisable
 
initialise(Object) - Method in class org.mule.transport.soap.axis.AxisInitialisationCallback
 
initialise() - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
initialise(Map) - Static method in class org.mule.util.JndiContextHelper
Create a new initial context.
initialise() - Method in class org.mule.util.lock.MuleLockFactory
 
initialise() - Method in class org.mule.util.pool.CommonsPoolObjectPool
 
initialise() - Method in class org.mule.util.queue.DelegateQueueManager
 
initialise() - Method in class org.mule.util.queue.TransactionalQueueManager
 
initialise() - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
initialise() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
initialise() - Method in class org.mule.util.store.MuleObjectStoreManager
 
initialise() - Method in class org.mule.util.store.TextFileObjectStore
 
INITIALISE_ALL - Static variable in class org.mule.config.PoolingProfile
Tells the object pool to initialise all components on startup.
INITIALISE_NONE - Static variable in class org.mule.config.PoolingProfile
Tells the object pool not to initialise any components on startup.
INITIALISE_ONE - Static variable in class org.mule.config.PoolingProfile
Tells the object pool only to initialise one service on startup.
initialiseAll(Iterator<? extends Initialisable>) - Static method in class org.mule.api.lifecycle.LifecycleTransitionResult
 
initialiseAllTransformers(List<Transformer>) - Static method in class org.mule.transformer.TransformerUtils
 
initialised - Variable in class org.mule.exception.AbstractExceptionListener
 
initialised - Variable in class org.mule.routing.outbound.AbstractOutboundRouter
 
initialised - Variable in class org.mule.source.StartableCompositeMessageSource
 
initialiseFromConfigFile() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
initialiseFromUrl(EndpointURI) - Method in class org.mule.transport.AbstractConnector
When this connector is created via the TransportFactory the endpoint used to determine the connector type is passed to this method so that any properties set on the endpoint that can be used to initialise the connector are made available.
initialiseIfInitialisable(Object) - Method in class org.mule.construct.AbstractFlowConstruct
 
initialiseIfInitialisable(Object) - Method in class org.mule.service.AbstractService
Deprecated.
 
initialiseIfNeeded(Object) - Static method in class org.mule.api.lifecycle.LifecycleUtils
Invokes Initialisable.initialise() on object if it implements the Initialisable interface.
initialiseIfNeeded(Object, MuleContext) - Static method in class org.mule.api.lifecycle.LifecycleUtils
The same as LifecycleUtils.initialiseIfNeeded(Object), only that before checking for object being Initialisable, it also checks if it implements MuleContextAware, in which case it will invoke MuleContextAware.setMuleContext(MuleContext) with the given muleContext
initialiseIfNeeded(Collection<? extends Object>) - Static method in class org.mule.api.lifecycle.LifecycleUtils
For each item in the objects collection, it invokes Initialisable.initialise() if it implements the Initialisable interface.
initialiseProcessingStrategy() - Method in class org.mule.construct.AbstractPipeline
 
initialize(ServletContext) - Method in class org.mule.config.builders.DeployableMuleXmlContextListener
 
initialize(ServletContext) - Method in class org.mule.config.builders.MuleXmlBuilderContextListener
 
initialize(Client, Bus) - Method in class org.mule.module.cxf.support.StaxFeature
 
initialize(Server, Bus) - Method in class org.mule.module.cxf.support.StaxFeature
 
initialize(Bus) - Method in class org.mule.module.cxf.support.StaxFeature
 
initialize(Subject, CallbackHandler, Map, Map) - Method in class org.mule.module.jaas.loginmodule.DefaultLoginModule
Initialises the callbackHandler, the credentials and the credentials list
initialize() - Method in class org.mule.MuleServer
Initializes this daemon.
initialize(ExpressionManager) - Method in class org.mule.util.AttributeEvaluator
 
initializeAdded() - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
initializeAdded() - Method in class org.mule.util.queue.TransientQueueTransactionContext
 
initializeClass(Class<?>) - Static method in class org.mule.util.ClassUtils
Ensure that the given class is properly initialized when the argument is passed in as .class literal.
initializeFaultInterceptors() - Method in class org.mule.module.cxf.support.ProxyServiceFactoryBean
 
initializeFromProperties(MuleConfiguration, Map) - Static method in class org.mule.config.PropertiesMuleConfigurationFactory
 
initializeMessageFactory() - Method in class org.mule.transport.AbstractTransportMessageHandler
Subclasses can override this method to create a custom MuleMessageFactory instead of re-using the instance from the connector.
initializeMessageFactory() - Method in class org.mule.transport.ftp.FtpMessageReceiver
 
initializeMessageFactory() - Method in class org.mule.transport.ftp.FtpMessageRequester
 
initializeMessageFactory() - Method in class org.mule.transport.http.HttpMessageReceiver
 
initializeMessageFactory() - Method in class org.mule.transport.http.OldHttpMessageReceiver
 
initializeMessageProcessor(Object) - Method in class org.mule.endpoint.EndpointMessageProcessorChainBuilder
 
initializeMessageProcessor(Object) - Method in class org.mule.endpoint.OutboundEndpointMessageProcessorChainBuilder
 
initializeMessageProcessor(Object) - Method in class org.mule.processor.chain.AbstractMessageProcessorChainBuilder
 
initializeOtherResources(List<?>, Set<Class<?>>) - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
initializeProvider(InterceptorProvider, Bus) - Method in class org.mule.module.cxf.feature.PrettyLoggingFeature
 
initializeProvider(InterceptorProvider, Bus) - Method in class org.mule.module.cxf.feature.ProxyGZIPFeature
 
initializeRemoved() - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
initializeRemoved() - Method in class org.mule.util.queue.TransientQueueTransactionContext
 
initializeResources(ResourceConfig) - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
initializeRetryPolicy() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
initializeScheduler() - Method in class org.mule.transport.quartz.QuartzConnector
Initializes scheduler
initializeWSDLOperations() - Method in class org.mule.module.cxf.support.ProxyServiceFactoryBean
 
initializeWSDLOperationsForProvider() - Method in class org.mule.module.cxf.support.ProxyServiceFactoryBean
 
initialState - Variable in class org.mule.construct.AbstractFlowConstruct
Determines the initial state of this flow when the mule starts.
initialState - Variable in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
initialState(String) - Method in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
initialState - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
initialState - Variable in class org.mule.service.AbstractService
Deprecated.
Determines the initial state of this service when the model starts.
initialStateStopped - Variable in class org.mule.transport.AbstractConnector
The will cause the connector not to start when AbstractConnector.start() is called.
initialValue() - Method in class org.mule.retry.policies.SimpleRetryPolicy.RetryCounter
 
initialValue() - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver.ThreadContextLocal
 
initInboundExchangePatterns(Properties) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
initJndiContext() - Method in class org.mule.transport.AbstractJndiConnector
 
initLogger() - Method in class org.mule.api.processor.LoggerMessageProcessor
 
initLogger() - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
initMethod - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
initOutboundExchangePatterns(Properties) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
initParameterNameDiscovery(ParameterNameDiscoverer) - Method in class org.mule.util.generics.MethodParameter
Initialize parameter name discovery for this method parameter.
initProcessedGroupsObjectStore() - Method in class org.mule.routing.AbstractAggregator
 
initQueueStore(MuleContext) - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
initRMI() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
initWorkManagers() - Method in class org.mule.transport.AbstractConnector
 
inject(T) - Method in interface org.mule.api.Injector
Injects dependencies into the given object
inject(T) - Method in class org.mule.config.spring.SpringRegistry
 
inject() - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
inject(T) - Method in class org.mule.registry.RegistryDelegatingInjector
Injects dependencies into the given object
inject(T) - Method in class org.mule.registry.SimpleRegistry
 
INJECT_PROCESSORS_BYPASS_FLAG - Static variable in interface org.mule.api.registry.MuleRegistry
Determines whether Inject processors should get executed on an object added to the registry Inject processors are responsible for processing inject interfaces such as MuleContextAware
injectAfter(MessageProcessor...) - Method in interface org.mule.api.processor.DynamicPipelineBuilder
Helper builder for injecting message processors to be executed after the ones specified in the flow.
injectAfter(List<MessageProcessor>) - Method in interface org.mule.api.processor.DynamicPipelineBuilder
Helper builder for injecting message processors to be executed after the ones specified in the flow.
injectBefore(MessageProcessor...) - Method in interface org.mule.api.processor.DynamicPipelineBuilder
Helper builder for injecting message processors to be executed before the ones specified in the flow.
injectBefore(List<MessageProcessor>) - Method in interface org.mule.api.processor.DynamicPipelineBuilder
Helper builder for injecting message processors to be executed before the ones specified in the flow.
injectExceptionHandler(Object) - Method in class org.mule.construct.AbstractFlowConstruct
 
injectFlowConstructMuleContext(Object) - Method in class org.mule.construct.AbstractFlowConstruct
 
injectFlowConstructMuleContext(Object) - Method in class org.mule.service.AbstractService
Deprecated.
 
injectFlowConstructMuleContextExceptionHandler(Object) - Method in class org.mule.service.AbstractService
Deprecated.
 
injectMuleContextIfRequired(T, MuleContext) - Method in class org.mule.context.DefaultMuleContextBuilder
 
Injector - Interface in org.mule.api
Component capable of injecting dependencies into a given object
InjectProcessor - Interface in org.mule.api.registry
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)
injectService() - Method in class org.mule.component.AbstractJavaComponent
 
InMemoryContext - Class in org.mule.tck.jndi
Simple in-memory JNDI context for unit testing.
InMemoryContext() - Constructor for class org.mule.tck.jndi.InMemoryContext
 
InMemoryContextFactory - Class in org.mule.tck.jndi
Simple in-memory JNDI context for unit testing.
InMemoryContextFactory() - Constructor for class org.mule.tck.jndi.InMemoryContextFactory
 
InMemoryObjectStore<T extends Serializable> - Class in org.mule.util.store
InMemoryObjectStore implements an optionally bounded in-memory store for message IDs with periodic expiry of old entries.
InMemoryObjectStore() - Constructor for class org.mule.util.store.InMemoryObjectStore
 
InMemoryObjectStore.StoredObject<T> - Class in org.mule.util.store
Represents the object stored in the store.
InMemoryObjectStore.StoredObject(Serializable, T) - Constructor for class org.mule.util.store.InMemoryObjectStore.StoredObject
 
innerProcessNonBlocking(MuleEvent, CompletionHandler, int) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
InOutParamDefinitionDefinitionParser - Class in org.mule.module.db.internal.config.domain.param
 
InOutParamDefinitionDefinitionParser() - Constructor for class org.mule.module.db.internal.config.domain.param.InOutParamDefinitionDefinitionParser
 
InOutQueryParam - Interface in org.mule.module.db.internal.domain.param
Defines a parameter that provides an input value and returns an output value
INPUT_PARAMS_DEBUG_FIELD - Static variable in class org.mule.module.db.internal.processor.DbDebugInfoUtils
 
INPUT_STREAM - Static variable in class org.mule.transformer.types.DataTypeFactory
 
InputParamDefinitionDefinitionParser - Class in org.mule.module.db.internal.config.domain.param
 
InputParamDefinitionDefinitionParser() - Constructor for class org.mule.module.db.internal.config.domain.param.InputParamDefinitionDefinitionParser
 
InputParamValueBeanDefinitionParser - Class in org.mule.module.db.internal.config.domain.param
 
InputParamValueBeanDefinitionParser() - Constructor for class org.mule.module.db.internal.config.domain.param.InputParamValueBeanDefinitionParser
 
InputQueryParam - Interface in org.mule.module.db.internal.domain.param
Defines a parameter that provides an input value
InputSoapHeadersInterceptor - Class in org.mule.module.ws.consumer
CXF interceptor that adds Soap headers to the SoapMessage based on outbound properties from the Mule message that start with the soap prefix.
InputSoapHeadersInterceptor(MuleContext) - Constructor for class org.mule.module.ws.consumer.InputSoapHeadersInterceptor
 
inputStream - Variable in class org.mule.transport.stdio.StdioConnector
 
InputStreamCloseListener - Interface in org.mule.transport.file
Listener to be called once a file gets closed
InputStreamDataSource - Class in org.mule.message.ds
DataSource wapper for an InputStream.
InputStreamDataSource(InputStream, String, String) - Constructor for class org.mule.message.ds.InputStreamDataSource
 
InputStreamHttpEntity - Class in org.mule.module.http.internal.domain
 
InputStreamHttpEntity(Integer, InputStream) - Constructor for class org.mule.module.http.internal.domain.InputStreamHttpEntity
 
InputStreamHttpEntity(InputStream) - Constructor for class org.mule.module.http.internal.domain.InputStreamHttpEntity
 
InputStreamToByteArray - Class in org.mule.transport.sftp.transformers
TODO
InputStreamToByteArray() - Constructor for class org.mule.transport.sftp.transformers.InputStreamToByteArray
 
InsensitiveMapRowHandler - Class in org.mule.module.db.internal.result.row
Maps a row using returning a case insensitive map
InsensitiveMapRowHandler() - Constructor for class org.mule.module.db.internal.result.row.InsensitiveMapRowHandler
 
insertBean(BeanAssembler, Object, Element, Element) - Method in class org.mule.config.spring.parsers.processors.AbstractChildElementIterator
 
insertBean(BeanAssembler, Object, Element, Element) - Method in class org.mule.config.spring.parsers.processors.NamedSetterChildElementIterator
 
insertBeanInTarget(String) - Method in class org.mule.config.spring.parsers.assembly.AttributeMapBeanAssembler
We override this method to insert a map instead of the definition.
insertBeanInTarget(String) - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
Insert the bean we have built into the target (typically the parent bean).
insertBeanInTarget(String) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
Insert the bean we have built into the target (typically the parent bean).
insertBeanInTarget(String) - Method in class org.mule.config.spring.parsers.assembly.TwoStageMapBeanAssembler
We overwrite this method to populate a map instead of inserting the definition.
insertDefinitionAsMap(String) - Method in class org.mule.config.spring.parsers.assembly.AbstractMapBeanAssembler
 
insertInTarget(String) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
insertIntoTest(String, int) - Method in class org.mule.tck.util.MuleDerbyTestDatabase
Inserts a record in the TEST table.
InsertProcessorBeanDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
InsertProcessorBeanDefinitionParser() - Constructor for class org.mule.module.db.internal.config.processor.InsertProcessorBeanDefinitionParser
 
insertSingletonBeanInTarget(String, String) - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
 
insertSingletonBeanInTarget(String, String) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
install() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
install() - Method in interface org.mule.module.launcher.artifact.Artifact
Install the artifact.
install() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
install() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
installArtifact(URL) - Method in class org.mule.module.launcher.ArtifactArchiveInstaller
Installs an artifact in the mule container.
InstallException - Exception in org.mule.module.launcher
 
InstallException(Message) - Constructor for exception org.mule.module.launcher.InstallException
 
InstallException(Message, Throwable) - Constructor for exception org.mule.module.launcher.InstallException
 
installLicense(String) - Method in class org.mule.test.infrastructure.process.Controller
 
installLicense(String) - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
installUrlStreamHandlerFactory() - Static method in class org.mule.util.MuleUrlStreamHandlerFactory
Install an instance of this class as UrlStreamHandlerFactory.
instance() - Method in class org.mule.module.http.internal.domain.EmptyHttpEntity
 
instance() - Static method in class org.mule.module.http.internal.listener.matcher.AcceptsAllMethodsRequestMatcher
 
INSTANCE - Static variable in class org.mule.routing.filters.AcceptAllFilter
 
instance - Variable in class org.mule.transport.jdbc.config.OracleDataSourceFactoryBean
 
InstanceLockGroup - Class in org.mule.util.lock
LockGroup implementation for holding references to created locks inside a mule instance.
InstanceLockGroup(LockProvider) - Constructor for class org.mule.util.lock.InstanceLockGroup
 
InstanceLockGroup.LockEntry - Class in org.mule.util.lock
 
InstanceLockGroup.LockEntry(Lock) - Constructor for class org.mule.util.lock.InstanceLockGroup.LockEntry
 
instanciateClass(Class<? extends T>, Object...) - Static method in class org.mule.util.ClassUtils
 
instanciateClass(String, Object...) - Static method in class org.mule.util.ClassUtils
 
instanciateClass(String, Object[], Class<?>) - Static method in class org.mule.util.ClassUtils
 
instanciateClass(String, Object[], ClassLoader) - Static method in class org.mule.util.ClassUtils
 
Instant - Interface in org.mule.api.el.datetime
 
INSTANT_RATE - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter representing the instant rate of a counter
instantiate(RootBeanDefinition, String, BeanFactory) - Method in class org.mule.config.spring.util.LaxInstantiationStrategyWrapper
 
instantiate(RootBeanDefinition, String, BeanFactory, Constructor<?>, Object...) - Method in class org.mule.config.spring.util.LaxInstantiationStrategyWrapper
 
instantiate(RootBeanDefinition, String, BeanFactory, Object, Method, Object...) - Method in class org.mule.config.spring.util.LaxInstantiationStrategyWrapper
 
instantiateAdapter() - Method in class org.mule.security.oauth.BaseOAuth2Manager
Creates a concrete instance of the OAuth2Adapter that corresponds with this OAuthManager
instantiateObject() - Method in class org.mule.module.extension.internal.runtime.ConfigurationObjectBuilder
Creates a new instance by calling Configuration#getInstantiator()#instantiateObject() Returns the instance to be returned before the properties have been applied to it
instantiateObject() - Method in class org.mule.module.extension.internal.runtime.DefaultObjectBuilder
Creates a new instance by calling the default constructor on DefaultObjectBuilder.prototypeClass Returns the instance to be returned before the properties have been applied to it
InstantRate - Class in org.mule.util.counters.impl
 
InstantRate(String, AbstractCounter) - Constructor for class org.mule.util.counters.impl.InstantRate
 
INT_VALUE_NOT_SET - Static variable in interface org.mule.api.transport.Connector
 
INTEGER_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
INTEGER_ERROR - Static variable in class org.mule.util.NumberUtils
 
INTEGER_SIZE_IN_BYTES - Static variable in class org.mule.util.queue.QueueControlDataFile
 
INTERACT_WTH_EXTERNAL - Static variable in class org.mule.config.spring.parsers.specific.TransactionDefinitionParser
 
InterceptingChainLifecycleWrapper - Class in org.mule.processor.chain
Builder needs to return a composite rather than the first MessageProcessor in the chain.
InterceptingChainLifecycleWrapper(MessageProcessorChain, List<MessageProcessor>, String) - Constructor for class org.mule.processor.chain.InterceptingChainLifecycleWrapper
 
InterceptingChainLifecycleWrapperPathSkip - Class in org.mule.processor.chain
When adding path elements to the MessageProcessors, the chains add a level to this path.
InterceptingChainLifecycleWrapperPathSkip(MessageProcessorChain, List<MessageProcessor>, String) - Constructor for class org.mule.processor.chain.InterceptingChainLifecycleWrapperPathSkip
 
InterceptingMessageProcessor - Interface in org.mule.api.processor
Processes MuleEvent's intercepting another listener MessageProcessor.
Interceptor - Interface in org.mule.api.interceptor
Interceptor is based on a similar concept of servlet filters and works much the same way.
INTERCEPTOR - Static variable in class org.mule.config.spring.parsers.specific.InterceptorDefinitionParser
 
interceptor() - Method in class org.mule.transport.polling.MessageProcessorPollingOverride
Returns an interceptor instance.
interceptor() - Method in class org.mule.transport.polling.watermark.selector.SelectorWatermark
Returns an interceptor instance.
interceptor() - Method in class org.mule.transport.polling.watermark.UpdateExpressionWatermark
 
INTERCEPTOR_STACK - Static variable in class org.mule.config.spring.parsers.specific.InterceptorStackDefinitionParser
 
interceptorChain - Variable in class org.mule.component.AbstractComponent
 
InterceptorDefinitionParser - Class in org.mule.config.spring.parsers.specific
This allows a interceptor to be defined on a global interceptor stack or on a service.
InterceptorDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.InterceptorDefinitionParser
 
InterceptorDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.InterceptorDefinitionParser
For custom transformers
interceptors - Variable in class org.mule.component.AbstractComponent
 
InterceptorStack - Class in org.mule.interceptor
Maintains a list of interceptors that can be applied to components.
InterceptorStack() - Constructor for class org.mule.interceptor.InterceptorStack
 
InterceptorStack(List<Interceptor>) - Constructor for class org.mule.interceptor.InterceptorStack
 
InterceptorStackDefinitionParser - Class in org.mule.config.spring.parsers.specific
This allows a interceptor-stack to be defined globally, or configured on a service.
InterceptorStackDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.InterceptorStackDefinitionParser
For custom transformers
INTERFACE - Static variable in class org.mule.config.spring.parsers.specific.NotificationDefinitionParser
 
INTERFACE_ATTRIBUTES - Static variable in class org.mule.config.spring.parsers.specific.NotificationDefinitionParser
 
INTERFACE_CLASS - Static variable in class org.mule.config.spring.parsers.specific.NotificationDefinitionParser
 
INTERFACE_MAP - Static variable in class org.mule.config.spring.parsers.specific.NotificationDefinitionParser
 
InterfaceBinding - Interface in org.mule.api.component
 
InterfaceClassScanner - Class in org.mule.util.scan
Deprecated.
InterfaceClassScanner(Class) - Constructor for class org.mule.util.scan.InterfaceClassScanner
Deprecated.
 
InterfaceClassScanner(Class, ClassLoader) - Constructor for class org.mule.util.scan.InterfaceClassScanner
Deprecated.
 
internalBind(String, Object) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
internalBind is intended for use only during setup or possibly by suitably synchronized superclasses.
internalBind(String, Object, boolean) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
internalCreateCounter(String, String, String, CounterFactory.Type, boolean) - Static method in class org.mule.util.counters.impl.CounterFactoryImpl
 
internalCreatePool(String, ThreadingProfile, BlockingQueue) - Method in class org.mule.config.pool.DefaultThreadPoolFactory
 
internalCreateScheduledPool(ThreadingProfile) - Method in class org.mule.config.pool.DefaultThreadPoolFactory
 
internalCreateStore(ListableObjectStore<? extends Serializable>, String, int, int, int) - Method in class org.mule.util.store.MuleObjectStoreManager
 
internalEventsGroupsObjectStoreFactory() - Method in class org.mule.routing.AbstractAggregator
 
internalLookupByType(Class<T>, boolean, boolean) - Method in class org.mule.config.spring.SpringRegistry
 
internalLookupByTypeWithoutAncestors(Class<T>, boolean, boolean) - Method in class org.mule.config.spring.SpringRegistry
 
InternalMessageListener - Interface in org.mule.api.transport
A listener used to receive Muleevents from a transport receiver.
InternalMessageProcessor - Interface in org.mule.api.processor
Marker interface that tells that a Message Processor is for internal use only.
internalObjectStoreFactory() - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
internalObjectStoreFactory() - Method in class org.mule.security.oauth.DefaultRefreshTokenManager
 
internalProcessedGroupsObjectStoreFactory() - Method in class org.mule.routing.AbstractAggregator
 
internalRewriteEvent(MuleMessage, boolean) - Static method in class org.mule.RequestContext
Deprecated.
 
internalSetEvent(MuleEvent) - Static method in class org.mule.RequestContext
Deprecated.
 
internetAddressesToString(InternetAddress[]) - Static method in class org.mule.transport.email.MailUtils
 
internetAddressesToString(InternetAddress) - Static method in class org.mule.transport.email.MailUtils
 
interruptedQueuingEventFor(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
interruptedWaitingForPaused(String) - Static method in class org.mule.config.i18n.CoreMessages
 
intersection(String[], String[]) - Static method in class org.mule.util.ArrayUtils
Calculates the intersection between two arrays, as if they were sets.
intersectsWith(MethodRequestMatcher) - Method in class org.mule.module.http.internal.listener.matcher.AcceptsAllMethodsRequestMatcher
 
intersectsWith(MethodRequestMatcher) - Method in class org.mule.module.http.internal.listener.matcher.MethodRequestMatcher
Determines if there's an intersection between the allowed methods by two request matcher
IntrospectionUtils - Class in org.mule.module.extension.internal.util
Set of utility operations to get insights about objects and their operations
intValue() - Method in enum org.mule.transport.sftp.SftpClient.WriteMode
 
INVALID_ARGUMENT_NUMBER - Static variable in class org.mule.module.db.internal.el.AbstractDbFunction
 
INVALID_CRL_ALGORITHM - Static variable in class org.mule.api.security.tls.TlsConfiguration
 
INVALID_DB_CONFIG_ARGUMENT - Static variable in class org.mule.module.db.internal.el.AbstractDbFunction
 
INVALID_KEY_ERROR_MESSAGE - Static variable in class org.mule.module.pgp.DecryptStreamTransformer
 
INVALID_PASS_PHRASE_ERROR_MESSAGE - Static variable in class org.mule.module.pgp.DecryptStreamTransformer
 
INVALID_PGP_MESSAGE_ERROR - Static variable in class org.mule.module.pgp.DecryptStreamTransformer
 
INVALID_STRUCT_VALUES_ARGUMENT - Static variable in class org.mule.module.db.internal.el.AbstractDbFunction
 
INVALID_TYPE_NAME_ARGUMENT - Static variable in class org.mule.module.db.internal.el.AbstractDbFunction
 
InvalidatableCachingStrategy - Interface in org.mule.api.cache
Provides invalidation capability to a CachingStrategy
invalidate() - Method in interface org.mule.api.cache.InvalidatableCachingStrategy
Invalidates all the entries in the cache
invalidate(Serializable) - Method in interface org.mule.api.cache.InvalidatableCachingStrategy
Invalidates a given entry from the cache if it exists, otherwise ignores it.
invalidate() - Method in class org.mule.transport.soap.axis.extensions.AxisMuleSession
 
InvalidateCacheException - Exception in org.mule.api.cache
Thrown to indicate an error during a cache invalidation action
InvalidateCacheException(String) - Constructor for exception org.mule.api.cache.InvalidateCacheException
 
InvalidateCacheException(String, Throwable) - Constructor for exception org.mule.api.cache.InvalidateCacheException
 
InvalidateOauthContextMessageProcessor - Class in org.mule.module.oauth2.internal.tokenmanager
Clears the oauth context for a token manager and a resource owner id.
InvalidateOauthContextMessageProcessor() - Constructor for class org.mule.module.oauth2.internal.tokenmanager.InvalidateOauthContextMessageProcessor
 
invalidateObject(Object, Object) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
invalidConversationType(XmppMessageType) - Static method in class org.mule.transport.xmpp.i18n.XmppMessages
 
invalidCronExpression() - Static method in class org.mule.modules.schedulers.i18n.SchedulerMessages
 
InvalidExpressionException - Exception in org.mule.api.expression
Is thrown explicitly when an expression is Malformed or invalid.
InvalidExpressionException(String, String) - Constructor for exception org.mule.api.expression.InvalidExpressionException
 
invalidFileFilter(EndpointURI) - Static method in class org.mule.transport.file.i18n.FileMessages
 
invalidFilter(Object) - Static method in class org.mule.transport.file.i18n.FileMessages
 
invalidFrontend(String) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
invalidJdk(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
invalidJobObject() - Static method in class org.mule.transport.quartz.i18n.QuartzMessages
 
invalidMessageTypeInUri() - Static method in class org.mule.transport.xmpp.i18n.XmppMessages
 
invalidOrMissingNamespace(QName, List<QName>, List<QName>) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
invalidPayloadToArgumentsParameter(String) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
invalidPayloadType() - Static method in class org.mule.transport.quartz.i18n.QuartzMessages
 
InvalidPublicKeyException - Exception in org.mule.module.pgp
 
InvalidPublicKeyException(Message) - Constructor for exception org.mule.module.pgp.InvalidPublicKeyException
 
invalidResourceType(Class<?>, Object) - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
invalidReturnTypeForTransformer(Class) - Static method in class org.mule.module.xml.i18n.XmlMessages
 
invalidSignature() - Static method in class org.mule.module.pgp.i18n.PGPMessages
 
invalidStreamingOutputType(Class) - Static method in class org.mule.transport.tcp.i18n.TcpMessages
 
INVOCATION - Static variable in class org.mule.api.transport.PropertyScope
This scope is defined from the point that a Message is created until a service has processed the message.
INVOCATION_NAME - Static variable in class org.mule.api.transport.PropertyScope
 
InvocationCountMessageProcessor - Class in org.mule.tck.functional
Test message processor to keep count of number of invocations.
InvocationCountMessageProcessor() - Constructor for class org.mule.tck.functional.InvocationCountMessageProcessor
 
invocationMap - Variable in class org.mule.MessagePropertiesContext
 
InvocationResult - Class in org.mule.api.model
Tracks the state of an invocation on a component using an EntryPointResolver
InvocationResult(EntryPointResolver, InvocationResult.State) - Constructor for class org.mule.api.model.InvocationResult
Will construct an InvocationResult with a given state.
InvocationResult(EntryPointResolver, Object, Method) - Constructor for class org.mule.api.model.InvocationResult
Creates a result with the result payload set.
InvocationResult.State - Enum in org.mule.api.model
 
invocationSuccessfulCantSetError() - Static method in class org.mule.config.i18n.CoreMessages
 
invoke(MuleEvent) - Method in interface org.mule.api.component.LifecycleAdapter
 
invoke(Object, MuleEventContext) - Method in interface org.mule.api.model.EntryPoint
 
invoke(Object, MuleEventContext) - Method in interface org.mule.api.model.EntryPointResolver
 
invoke(Object, MuleEventContext) - Method in interface org.mule.api.model.EntryPointResolverSet
Will attempt to invoke the component by looping through all EntryPointResolver instances registered on this set until a match is found
invoke(Object, Method, Object[]) - Method in class org.mule.component.BindingInvocationHandler
 
invoke(MuleEvent) - Method in class org.mule.component.DefaultComponentLifecycleAdapter
 
invoke(Object, MuleEventContext) - Method in class org.mule.impl.model.resolvers.AnnotatedEntryPointResolver
 
invoke(Object, MuleEventContext) - Method in class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
 
invoke(Object, MuleEventContext) - Method in class org.mule.model.resolvers.CallableEntryPointResolver
 
invoke(Object, MuleEventContext) - Method in class org.mule.model.resolvers.DefaultEntryPointResolverSet
 
invoke(Object, MuleEventContext) - Method in class org.mule.model.resolvers.ExplicitMethodEntryPointResolver
 
invoke(Object, MuleEventContext) - Method in class org.mule.model.resolvers.MethodHeaderPropertyEntryPointResolver
 
invoke(Object, MuleEventContext) - Method in class org.mule.model.resolvers.ReflectionEntryPointResolver
Will discover the entrypoint on the service using the payload type to figure out the method to call.
invoke(Exchange, Object) - Method in class org.mule.module.cxf.MuleInvoker
 
invoke(Exchange, Object, Method, List<Object>) - Method in class org.mule.module.cxf.MuleJAXWSInvoker
 
invoke(Source) - Method in interface org.mule.module.cxf.support.ProxyService
 
invoke(Object, Method, Object[]) - Method in class org.mule.module.db.internal.domain.xa.StatementInvocationHandler
 
invoke(String, Object[], String[]) - Method in class org.mule.module.management.agent.ClassloaderSwitchingMBeanWrapper
 
invoke(Object, Method, Object[]) - Method in class org.mule.transport.jdbc.xa.StatementInvocationHandler
 
invoke(Object, Method, Object[]) - Method in class org.mule.transport.jms.xa.ConnectionInvocationHandler
 
invoke(Object, Method, Object[]) - Method in class org.mule.transport.jms.xa.ConsumerProducerInvocationHandler
 
invoke(Object, Method, Object[]) - Method in class org.mule.transport.jms.xa.SessionInvocationHandler
 
invoke(MessageContext) - Method in class org.mule.transport.soap.axis.extensions.MuleHttpSender
Deprecated.
invoke creates a socket connection, sends the request SOAP message and then reads the response SOAP message back from the SOAP server
invoke(MessageContext) - Method in class org.mule.transport.soap.axis.extensions.MuleMsgProvider
 
invoke(MessageContext) - Method in class org.mule.transport.soap.axis.extensions.MuleRPCProvider
 
invoke(MessageContext) - Method in class org.mule.transport.soap.axis.extensions.MuleSoapHeadersHandler
 
invoke(MessageContext) - Method in class org.mule.transport.soap.axis.extensions.UniversalSender
 
invokeAction(RemoteDispatcherNotification, MuleEventContext) - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
invokeComponentInstance(MuleEvent) - Method in class org.mule.component.AbstractJavaComponent
 
invokeComponentInstance(MuleEvent) - Method in class org.mule.component.SimpleCallableJavaComponent
 
invokedMethod - Variable in class org.mule.transport.rmi.RmiMessageDispatcher
 
invokeEndpointFromGet(MessageContext, AxisStringWriter, String, String) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
invokeMethod(Object, Method, Object[]) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
invokeMethod - Variable in class org.mule.transport.rmi.RmiMessageReceiver
 
invokePhase(String, Object, LifecycleCallback) - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
InvokerMessageProcessor - Class in org.mule.processor
InvokerMessageProcessor invokes a specified method of an object.
InvokerMessageProcessor() - Constructor for class org.mule.processor.InvokerMessageProcessor
 
InvokerMessageProcessorDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
InvokerMessageProcessorDefinitionParser(String, Class<?>, String, String[]) - Constructor for class org.mule.config.spring.parsers.specific.InvokerMessageProcessorDefinitionParser
 
InvokerMessageProcessorUtil - Class in org.mule.api.processor.util
 
invokeTokenUrl(MuleEvent) - Method in class org.mule.module.oauth2.internal.AbstractTokenRequestHandler
 
IOStrategyTransportCustomizer - Class in org.mule.module.http.internal.request.grizzly
Transport customizer that sets the IO strategy to SameThreadIOStrategy and sets appropriate names for the threads that are used.
IOStrategyTransportCustomizer(String, Integer, Integer, Integer, Integer, Integer) - Constructor for class org.mule.module.http.internal.request.grizzly.IOStrategyTransportCustomizer
 
IOUtils - Class in org.mule.util
Mule input/output utilities.
IOUtils() - Constructor for class org.mule.util.IOUtils
 
IP_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 
IS_JAVA_1_7 - Static variable in class org.mule.util.SystemUtils
 
IS_REUSE_OBJECT_METHOD_NAME - Static variable in interface org.mule.transaction.XaTransaction.MuleXaObject
 
isAbsolute() - Method in class org.mule.endpoint.MuleEndpointURI
 
isAcceptMuleMessage() - Method in class org.mule.module.xml.transformer.ObjectToXml
 
isAcceptMuleMessage() - Method in class org.mule.transformer.simple.SerializableToByteArray
 
isAcceptNull() - Method in interface org.mule.api.transformer.Transformer
Does this transformer allow null input?
isAcceptNull() - Method in class org.mule.tck.transformer.NoActionTransformer
Deprecated.
 
isAcceptNull() - Method in class org.mule.transformer.AbstractTransformer
 
isAcceptNull() - Method in class org.mule.transformer.CompositeConverter
 
isAcceptNull() - Method in class org.mule.transport.http.transformers.HttpRequestBodyToParamMap
 
isAcceptNull() - Method in class org.mule.transport.http.transformers.MuleMessageToHttpResponse
 
isAcceptVoidMethods() - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
isAcceptWithoutUpdateDate() - Method in class org.mule.module.atom.routing.EntryLastUpdatedFilter
 
isAcceptWithoutUpdateDate() - Method in class org.mule.module.atom.routing.FeedLastUpdatedFilter
 
isAcceptWithoutUpdateDate() - Method in class org.mule.module.rss.routing.EntryLastUpdatedFilter
 
isAcceptWithoutUpdateDate() - Method in class org.mule.module.rss.routing.FeedLastUpdatedFilter
 
isActive(String) - Method in class org.mule.module.jbpm.EndedProcess
 
isAdd() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
isAddCreated() - Method in class org.mule.module.ws.security.WssUsernameTokenSecurityStrategy
 
isAddFirst() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
isAddNonce() - Method in class org.mule.module.ws.security.WssUsernameTokenSecurityStrategy
 
isAddressFromMessage() - Method in class org.mule.module.cxf.component.AbstractWebServiceWrapperComponent
 
isAfter(Instant) - Method in interface org.mule.api.el.datetime.Instant
 
isAfter(Instant) - Method in class org.mule.el.datetime.AbstractInstant
 
isAgedFile(File, long) - Method in class org.mule.transport.file.FileMessageReceiver
Indicates whether or not file is older than the specified age
isAgentRegistered(Agent) - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
isAllInterfaces() - Method in class org.mule.module.http.internal.listener.ServerAddress
 
isAllowBeanDefinitionOverriding() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Return whether it should be allowed to override bean definitions by registering a different definition with the same name, automatically replacing the former.
isAllowClassAttribute() - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
isAllowEagerClassLoading() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Return whether the factory is allowed to eagerly load bean classes even for bean definitions that are marked as "lazy-init".
isAllowNonBlocking() - Method in interface org.mule.api.MuleEvent
Indicates if the current event allows non-blocking execution and IO.
isAllowNonBlocking() - Method in class org.mule.DefaultMuleEvent
 
isAllowNonBlocking() - Method in class org.mule.VoidMuleEvent
 
isAllowNullReturn() - Method in class org.mule.transformer.AbstractTransformer
 
isAllowPartial() - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Get the allowPartial field.
isAlreadyProcessed(Object) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
isAlwaysCreateConnector() - Method in class org.mule.endpoint.AbstractEndpointBuilder
Some endpoint may always require a new connector to be created for every endpoint
isAnnotationsPropertyAvailable(Class<?>) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
isAnnotationsPropertyAvailable(String) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
isAppleJDK() - Static method in class org.mule.util.SystemUtils
 
isApplicableTo(Throwable) - Method in class org.mule.retry.policies.SimpleRetryPolicy
Indicates if the policy is applicable for the cause that caused the policy invocation.
isArray() - Method in class org.mule.module.json.JsonData
 
isAssertMessageAccess() - Static method in class org.mule.api.ThreadSafeAccess.AccessControl
 
isAssignableFrom(Type, Class) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
 
isAsynchronous() - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
Determines whether events will be processed asynchronously
isAsyncStarted() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
isAsyncSupported() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
isAttributeSpecified(int) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
isAttributeSpecified(int) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
isAuthenticate() - Method in class org.mule.security.AbstractAuthenticationFilter
 
isAuthenticated() - Method in interface org.mule.api.security.Authentication
 
isAuthenticated() - Method in class org.mule.module.jaas.JaasAuthentication
 
isAuthenticated() - Method in class org.mule.module.pgp.PGPAuthentication
 
isAuthenticated() - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
isAuthenticated() - Method in class org.mule.security.DefaultMuleAuthentication
 
isAutoDelete() - Method in class org.mule.transport.file.FileConnector
 
isAutoDelete() - Method in class org.mule.transport.sftp.SftpConnector
 
isAutowireCandidate(String, DependencyDescriptor) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
isAutowireCandidate(String, DependencyDescriptor, AutowireCandidateResolver) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Determine whether the specified bean definition qualifies as an autowire candidate, to be injected into other beans which declare a dependency of matching type.
isAutowireCandidate(String, RootBeanDefinition, DependencyDescriptor, AutowireCandidateResolver) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Determine whether the specified bean definition qualifies as an autowire candidate, to be injected into other beans which declare a dependency of matching type.
isAutoWireObject() - Method in interface org.mule.api.object.ObjectFactory
Return true if the created object should get its dependencies wired from the registry automatically.
isAutoWireObject() - Method in class org.mule.component.PooledJavaComponent.LifeCycleAdapterFactory
 
isAutoWireObject() - Method in class org.mule.config.spring.util.SpringBeanLookup
 
isAutoWireObject() - Method in class org.mule.object.AbstractObjectFactory
 
isAutoWireObject() - Method in class org.mule.object.JndiObjectFactory
 
isAutoWrapMessageAwareTransform() - Method in interface org.mule.api.config.MuleConfiguration
 
isAutoWrapMessageAwareTransform() - Method in class org.mule.config.DefaultMuleConfiguration
 
isBackupEnabled() - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
isBase64Encoding() - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
isBeanEligibleForMetadataCaching(String) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Considers all beans as eligible for metadata caching if the factory's configuration has been marked as frozen.
isBeanReference(String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
isBeansNamespace(Element) - Static method in class org.mule.config.spring.util.SpringXMLUtils
 
isBefore(Instant) - Method in interface org.mule.api.el.datetime.Instant
 
isBefore(Instant) - Method in class org.mule.el.datetime.AbstractInstant
 
isBegun() - Method in interface org.mule.api.transaction.Transaction
 
isBegun() - Method in class org.mule.processor.DelegateTransaction
 
isBegun() - Method in class org.mule.transaction.AbstractTransaction
 
isBinary() - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
isBinary() - Method in class org.mule.transport.ftp.FtpConnector
Getter for FTP transfer type.
isBindingLocalhostToAllLocalInterfaces() - Static method in class org.mule.transport.tcp.TcpPropertyHelper
Returns whether localhost should be bound to all local interfaces or not.
isBlocked(String) - Method in class org.mule.module.launcher.FineGrainedControlClassLoader
 
isBroadcast() - Method in class org.mule.transport.udp.UdpConnector
 
isCacheable() - Method in class org.apache.maven.enforcer.rule.EnforcerPortRule
This tells the system if the results are cacheable at all.
isCacheJmsSessions() - Method in class org.mule.transport.jms.Jms102bSupport
CachingConnectionFactory only supports JMS 1.1 connection factories currently.
isCacheJmsSessions() - Method in class org.mule.transport.jms.Jms11Support
 
isCacheJmsSessions() - Method in class org.mule.transport.jms.JmsConnector
 
isCacheJmsSessions() - Method in interface org.mule.transport.jms.JmsSupport
 
isCacheMessageAsBytes() - Method in interface org.mule.api.config.MuleConfiguration
 
isCacheMessageAsBytes() - Method in class org.mule.config.DefaultMuleConfiguration
 
isCacheMessageOriginalPayload() - Method in interface org.mule.api.config.MuleConfiguration
 
isCacheMessageOriginalPayload() - Method in class org.mule.config.DefaultMuleConfiguration
 
isCacheProducers() - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
isCacheXsl() - Method in class org.mule.module.management.agent.Mx4jAgent
 
isCapableOf(ModuleCapability) - Method in interface org.mule.api.devkit.capability.Capabilities
Returns true if this module implements such capability
isCapableOf(Class<?>) - Method in class org.mule.module.extension.internal.introspection.ParameterGroup
isCapableOf(Set<?>, Class<?>) - Static method in class org.mule.module.extension.internal.util.CapabilityUtils
Returns true if {code capabilities} contains at least one item which is an instance of capabilityType
isCapableOf(ModuleCapability) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Returns true if this module implements such capability
isCaseSensitive() - Method in class org.mule.routing.filters.MessagePropertyFilter
 
isCaseSensitive() - Method in class org.mule.routing.filters.WildcardFilter
 
isCepMode() - Method in class org.mule.module.bpm.Rules
 
isCepMode() - Method in class org.mule.module.bpm.RulesComponent
 
isCharacters() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
isCharacters() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
isCheckEtag() - Method in class org.mule.transport.http.HttpPollingConnector
 
isCheckEtag() - Method in class org.mule.transport.http.HttpsPollingConnector
 
isCheckKeyExpirity() - Method in class org.mule.module.pgp.KeyBasedEncryptionStrategy
 
isCheckpointOperation(byte) - Static method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
isCheckResponseTimestamp() - Method in class org.mule.module.ws.security.WssTimestampSecurityStrategy
 
isChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.generic.OptionalChildDefinitionParser
 
isChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.RetryNotifierDefinitionParser
 
isChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.RetryPolicyDefinitionParser
 
isClassOnPath(String, Class) - Static method in class org.mule.util.ClassUtils
Can be used by serice endpoints to select which service to use based on what's loaded on the classpath
isClientMode() - Method in interface org.mule.api.config.MuleConfiguration
 
isClientMode() - Method in class org.mule.config.DefaultMuleConfiguration
 
isClientMode() - Method in class org.mule.module.management.mbean.MuleConfigurationService
 
isClientProxyAvailable() - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
isClosed() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
isClosed() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
isClosed() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
isClosed() - Method in class org.mule.transport.sftp.SftpFileArchiveInputStream
 
isClosed() - Method in class org.mule.transport.sftp.SftpInputStream
 
isCollection(String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
isCollection(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
isCollection(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
isCollection() - Method in interface org.mule.config.spring.parsers.assembly.configuration.SingleProperty
 
isCollection() - Method in class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyLiteral
 
isCollection() - Method in class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyWrapper
 
isCollection(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
isCollection(String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
isCommit() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
isCommitted() - Method in interface org.mule.api.transaction.Transaction
 
isCommitted() - Method in class org.mule.processor.DelegateTransaction
 
isCommitted() - Method in class org.mule.transaction.AbstractTransaction
 
isCommitted() - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
isCompatibleWith(DataType) - Method in interface org.mule.api.transformer.DataType
Used to determine if this data type is compatible with the data type passed in.
isCompatibleWith(DataType) - Method in class org.mule.transformer.types.CollectionDataType
 
isCompatibleWith(DataType) - Method in class org.mule.transformer.types.SimpleDataType
 
isComplete() - Method in class org.mule.transport.http.ntlm.NTLMScheme
Tests if the NTLM authentication process has been completed.
isCompressed(byte[]) - Method in interface org.mule.util.compression.CompressionStrategy
Checks whether a byte array has been compressed or not.
isCompressed(byte[]) - Method in class org.mule.util.compression.GZipCompression
Determines if a byte array is compressed.
isConcrete(Class<?>) - Static method in class org.mule.util.ClassUtils
 
isConfigElement(Element) - Method in class org.mule.config.spring.parsers.specific.RetryPolicyDefinitionParser
 
isConfigurationFrozen() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
isConfigured() - Method in interface org.mule.api.config.ConfigurationBuilder
Indicate whether this ConfigurationBulder has been configured yet
isConfigured() - Method in interface org.mule.api.transaction.TransactionConfig
 
isConfigured() - Method in class org.mule.config.builders.AbstractConfigurationBuilder
Has this builder been configured already
isConfigured() - Method in class org.mule.transaction.MuleTransactionConfig
 
isConnected() - Method in interface org.mule.api.transport.Connectable
Determines if this object is connected or not
isConnected() - Method in interface org.mule.api.transport.Connector
 
isConnected() - Method in class org.mule.module.management.mbean.EndpointService
 
isConnected() - Method in interface org.mule.module.management.mbean.EndpointServiceMBean
 
isConnected() - Method in class org.mule.tck.util.ftp.FtpClient
Check if the ftp client is connected
isConnected() - Method in class org.mule.transport.AbstractConnector
 
isConnected() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
isConnected() - Method in class org.mule.transport.sftp.SftpClient
 
isConnecting() - Method in class org.mule.transport.AbstractConnector
 
isConnectionBased() - Method in class org.mule.transport.http.ntlm.NTLMScheme
Returns true.
isConnectionFactoryWrapper(ConnectionFactory) - Method in class org.mule.transport.jms.AbstractConnectionFactoryDecorator
 
isConsumable() - Method in class org.mule.DefaultMuleMessage
Deprecated.
since 3.8.0. Use ClassUtils.isConsumable(Class) instead. Determines if the payload of this message is consumable i.e. it can't be read more than once.
isConsumable(Class<?>) - Static method in class org.mule.util.ClassUtils
Determines if the payload of this message is consumable i.e.
isConsumed() - Method in class org.mule.streaming.AbstractConsumer
Returns true if no more items are available or if the consumer was closed.
isConsumed() - Method in interface org.mule.streaming.Consumer
Returns true if no more items are available or if the consumer was closed.
isConsumed(Class<?>) - Method in class org.mule.transformer.AbstractTransformer
 
isContainerMode() - Method in interface org.mule.api.config.MuleConfiguration
A container mode implies multiple Mule apps running.
isContainerMode() - Method in class org.mule.config.DefaultMuleConfiguration
 
isContainerMode() - Method in class org.mule.module.management.mbean.MuleConfigurationService
 
isContainerMode() - Method in interface org.mule.module.management.mbean.MuleConfigurationServiceMBean
 
isContainsTemplate(String) - Method in class org.mule.util.TemplateParser
 
isCreate() - Method in class org.mule.transport.jdbc.config.DerbyDataSourceFactoryBean
 
isCreateAccount() - Method in class org.mule.transport.xmpp.XmppConnector
 
isCreateDispatcherPerRequest() - Method in interface org.mule.api.transport.MessageDispatcherFactory
Controls whether dispatchers are cached or created per request.
isCreateDispatcherPerRequest() - Method in class org.mule.transport.AbstractMessageDispatcherFactory
This default implementation of MessageDispatcherFactory.isCreateDispatcherPerRequest() returns false, which means that dispatchers are pooled according to their lifecycle as described in MessageDispatcher.
isCreateDispatcherPerRequest() - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
isCreateMultipleTransactedReceivers() - Method in class org.mule.transport.AbstractConnector
For better throughput when using TransactedMessageReceivers this will enable a number of concurrent receivers, based on the value returned by AbstractConnector.getNumberOfConcurrentTransactedReceivers().
isCreateRegistry() - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
isCreateRequesterPerRequest() - Method in interface org.mule.api.transport.MessageRequesterFactory
Controls whether dispatchers are cached or created per request.
isCreateRequesterPerRequest() - Method in class org.mule.transport.AbstractMessageRequesterFactory
This default implementation of MessageDispatcherFactory.isCreateDispatcherPerRequest() returns false, which means that dispatchers are pooled according to their lifecycle as described in MessageRequester.
isCreateRequesterPerRequest() - Method in class org.mule.transport.email.RetrieveMessageRequesterFactory
By default client connections are closed after the request.
isCreateRequesterPerRequest() - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
isCreateRmiRegistry() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
isCreateRmiRegistry() - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
isCreateServer() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
isCreateServer() - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
isDebugEnabled() - Method in interface org.mule.api.debug.Debuggeable
If it is already enabled or not.
isDebugEnabled() - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
isDebugEnabled() - Method in class org.mule.util.MuleLogger
 
isDefaultAutoGeneratedConnector(Connector) - Static method in class org.mule.util.ObjectNameHelper
 
isDefaultSecurityModel() - Static method in class org.mule.util.SecurityUtils
 
isDeleteReadMessages() - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
isDeleteUnacceptedMessages() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
If a filter is configured on this endpoint, this property will determine if message that are not excepted by the filter are deleted
isDeleteUnacceptedMessages() - Method in class org.mule.endpoint.AbstractEndpoint
 
isDeleteUnacceptedMessages() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
isDeleteUnacceptedMessages() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
isDeleteUnacceptedMessages() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
isDeleteUnacceptedMessages() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
isDeployed(MuleProcessController, String) - Static method in class org.mule.test.infrastructure.process.AppDeploymentProbe
 
isDeployed(String) - Method in class org.mule.test.infrastructure.process.Controller
 
isDeployed(String) - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
isDeterministic() - Method in class org.mule.routing.outbound.AbstractRoundRobinMessageSplitter
If this option is true (the default) then the first message part is routed to the first endpoint, the second part to the second endpoint, etc, with the nth part going to the (n modulo number of targets) endpoint.
isDirectDeliver() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
isDirectTransition(String) - Method in interface org.mule.api.lifecycle.LifecycleManager
 
isDirectTransition(String) - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
isDirectTransition(String, String) - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
isDisabled() - Method in class org.mule.DefaultMuleMessage
 
isDisableReplyTo() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
isDisableRoundRobin() - Method in class org.mule.routing.outbound.AbstractRoundRobinMessageSplitter
The default behaviour for splitter routers is to round-robin across targets.
isDisableTemporaryDestinations() - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
isDisableTemporaryReplyToDestinations() - Method in class org.mule.transport.jms.JmsConnector
 
isDisableTimeouts() - Method in interface org.mule.api.config.MuleConfiguration
 
isDisableTimeouts() - Method in class org.mule.config.DefaultMuleConfiguration
 
isDisableTransportTransformer() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
 
isDisableTransportTransformer() - Method in class org.mule.endpoint.AbstractEndpoint
 
isDisableTransportTransformer() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
isDisableTransportTransformer() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
isDisableTransportTransformer() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
isDisableTransportTransformer() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
isDisableTransportTransformer() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
isDiscarded(String) - Method in class org.mule.config.spring.CompositeOptionalObjectsController
 
isDiscarded(String) - Method in class org.mule.config.spring.DefaultOptionalObjectsController
 
isDiscarded(String) - Method in interface org.mule.config.spring.OptionalObjectsController
 
isDiscardEmptyContent() - Method in class org.mule.transport.http.HttpPollingConnector
 
isDiscardEmptyContent() - Method in class org.mule.transport.http.HttpsPollingConnector
 
isDiscOnClusterFailure() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
isDisposable - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
isDisposed() - Method in interface org.mule.api.component.LifecycleAdapter
 
isDisposed() - Method in interface org.mule.api.lifecycle.LifecycleState
 
isDisposed() - Method in interface org.mule.api.MuleContext
 
isDisposed() - Method in interface org.mule.api.transport.Connector
 
isDisposed() - Method in class org.mule.component.DefaultComponentLifecycleAdapter
 
isDisposed() - Method in class org.mule.component.NullLifecycleAdapter
 
isDisposed() - Method in class org.mule.DefaultMuleContext
 
isDisposed() - Method in class org.mule.lifecycle.DefaultLifecycleState
 
isDisposed() - Method in class org.mule.module.management.mbean.ConnectorService
 
isDisposed() - Method in interface org.mule.module.management.mbean.ConnectorServiceMBean
 
isDisposed() - Method in class org.mule.transport.AbstractConnector
 
isDisposing() - Method in interface org.mule.api.lifecycle.LifecycleState
 
isDisposing() - Method in interface org.mule.api.MuleContext
 
isDisposing() - Method in class org.mule.DefaultMuleContext
 
isDisposing() - Method in class org.mule.lifecycle.DefaultLifecycleState
 
isDoAutoTypes() - Method in class org.mule.transport.soap.axis.AxisConnector
 
isDoInboundTransform() - Method in class org.mule.tck.functional.FunctionalTestComponent
 
isDoThreading() - Method in interface org.mule.api.config.ThreadingProfile
 
isDoThreading() - Method in class org.mule.config.ChainedThreadingProfile
 
isDoThreading() - Method in class org.mule.config.ImmutableThreadingProfile
 
isDoThreading() - Method in class org.mule.config.MutableThreadingProfile
 
isDoThreading() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
isDurable() - Method in class org.mule.transport.jms.JmsConnector
 
isDynamic() - Method in interface org.mule.api.endpoint.OutboundEndpoint
 
isDynamic() - Method in class org.mule.endpoint.DefaultOutboundEndpoint
 
isDynamic() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
isDynamic() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
isDynamic() - Method in class org.mule.endpoint.MuleEndpointURI
 
isDynamic() - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
isDynamic() - Method in class org.mule.module.db.internal.domain.query.Query
 
isDynamic() - Method in class org.mule.module.db.internal.domain.query.QueryTemplate
Indicates whether or not the query is dynamic.
isDynamic() - Method in interface org.mule.module.extension.internal.runtime.ObjectBuilder
Whether any of the registered ValueResolvers are dynamic
isDynamic() - Method in class org.mule.module.extension.internal.runtime.resolver.CachingValueResolverWrapper
returns false since the same value will be returned in each invocation
isDynamic() - Method in class org.mule.module.extension.internal.runtime.resolver.CollectionValueResolver
 
isDynamic() - Method in class org.mule.module.extension.internal.runtime.resolver.NestedProcessorValueResolver
 
isDynamic() - Method in class org.mule.module.extension.internal.runtime.resolver.ObjectBuilderValueResolver
 
isDynamic() - Method in class org.mule.module.extension.internal.runtime.resolver.RegistryLookupValueResolver
 
isDynamic() - Method in class org.mule.module.extension.internal.runtime.resolver.ResolverSet
Whether at least one of the given ValueResolver are dynamic
isDynamic() - Method in class org.mule.module.extension.internal.runtime.resolver.StaticValueResolver
 
isDynamic() - Method in class org.mule.module.extension.internal.runtime.resolver.TypeSafeExpressionValueResolver
 
isDynamic() - Method in interface org.mule.module.extension.internal.runtime.resolver.ValueResolver
returns false if subsequent invocations to ValueResolver.resolve(MuleEvent) will return the same value.
isDynamic(AccessibleObject) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
isDynamicRoutes() - Method in interface org.mule.api.routing.OutboundRouter
Determines whether this router supports dynamic route.
isDynamicRoutes() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
isDynamicRoutes() - Method in class org.mule.routing.outbound.AbstractRecipientList
 
isEagerConsumer() - Method in class org.mule.transport.jms.JmsConnector
Getter for property 'eagerConsumer'.
isEagerInit() - Method in class org.mule.config.spring.DefaultObjectSerializerFactoryBean
 
isEagerInit() - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
isEagerInit() - Method in class org.mule.config.spring.ServerNotificationManagerConfigurator
 
isEmbeddedMode() - Method in class org.mule.transport.jms.JmsConnector
 
isEmpty() - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
isEmpty() - Method in class org.mule.el.context.AbstractMapContext
 
isEmpty() - Method in class org.mule.expression.InboundAttachmentsMap
 
isEmpty() - Method in class org.mule.expression.OutboundAttachmentsMap
 
isEmpty() - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
isEmpty() - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
isEmpty() - Method in class org.mule.module.http.internal.ParameterMap
 
isEmpty() - Method in class org.mule.module.launcher.util.ObservableList
 
isEmpty() - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
isEmpty() - Method in class org.mule.routing.AbstractMessageSequence
 
isEmpty() - Method in interface org.mule.routing.MessageSequence
If the sequence is empty
isEmpty() - Method in class org.mule.routing.outbound.PartitionedMessageSequence
 
isEmpty() - Method in class org.mule.transport.http.multipart.MultiMap
 
isEmpty() - Method in class org.mule.util.CaseInsensitiveMapWrapper
 
isEmpty() - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
isEmpty() - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
isEmpty() - Method in class org.mule.util.MapCombiner
 
isEmpty() - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
 
isEmpty() - Method in class org.mule.util.queue.DefaultQueueStoreDelegate
 
isEmpty() - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
isEmpty() - Method in class org.mule.util.store.ObjectStoreToMapAdapter
 
isEnableCookies() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
isEnableCookies() - Method in class org.mule.transport.http.HttpConnector
 
isEnabled() - Method in interface org.mule.api.management.stats.Statistics
Are statistics logged
isEnabled(Log) - Method in enum org.mule.api.processor.LoggerMessageProcessor.LogLevel
 
isEnabled() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
Are statistics logged
isEnabled() - Method in class org.mule.management.stats.AllStatistics
Are statistics logged
isEnabled() - Method in class org.mule.management.stats.ComponentStatistics
Returns true if this stats collector is enabled.
isEnabled() - Method in class org.mule.management.stats.FlowConstructStatistics
Are statistics logged
isEnabled() - Method in class org.mule.management.stats.RouterStatistics
 
isEnabled() - Method in class org.mule.module.management.mbean.StatisticsService
 
isEnabled() - Method in class org.mule.util.PropertyChecker
 
isEnableDiscovery() - Method in class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
 
isEnableList() - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
isEnableMessageEvents() - Method in class org.mule.transport.AbstractConnector
 
isEnableMessageEvents(MuleEvent) - Method in class org.mule.transport.AbstractConnector
Indicates if notifications are enabled for the given event
isEnableMessageHistory() - Method in class org.mule.tck.functional.FunctionalTestComponent
 
isEnableMuleSoapHeaders() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
isEnableMuleSoapHeaders() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
isEnableMuleSoapHeaders() - Method in class org.mule.module.cxf.CxfConfiguration
 
isEnableMultiplexedConnections() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
isEnableNotifications() - Method in class org.mule.exception.AbstractExceptionListener
 
isEnableNotifications() - Method in class org.mule.tck.functional.FunctionalTestComponent
 
isEnableSharedDurable() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
isEnableStatistics() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
isEnableStatistics() - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
isEnableStreaming() - Method in interface org.mule.api.config.MuleConfiguration
 
isEnableStreaming() - Method in class org.mule.config.DefaultMuleConfiguration
 
isEncoded(MuleMessage) - Method in class org.mule.module.cxf.support.AbstractProxyGZIPInterceptor
 
isEnded() - Method in class org.mule.module.jbpm.EndedProcess
 
isEndElement() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
isEndElement() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
isEnlisted() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
isEnlisted() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
isEnlisted() - Method in class org.mule.transport.jms.xa.SessionInvocationHandler
 
isEnricherExpression(String) - Method in class org.mule.expression.DefaultExpressionManager
 
isEnricherPropagatesSessionVariableChanges() - Method in interface org.mule.api.config.MuleConfiguration
 
isEnricherPropagatesSessionVariableChanges() - Method in class org.mule.config.DefaultMuleConfiguration
 
isEnricherRegistered(String) - Method in interface org.mule.api.expression.ExpressionManager
Deprecated.
isEnricherRegistered(String) - Method in class org.mule.expression.DefaultExpressionManager
Checks whether an enricher is registered with the manager
isEqualKey(Object, Object) - Method in class org.mule.util.CaseInsensitiveHashMap
Overloads the default behaviour to compare the keys without case sensitivity
isError() - Method in class org.mule.module.xml.transformer.XsltTransformer.DefaultErrorListener
 
isErrorEnabled() - Method in class org.mule.util.MuleLogger
 
isErrorPayload(MuleMessage) - Method in class org.mule.transport.http.components.RestServiceWrapper
 
isEvaluatorExpression(String) - Method in class org.mule.expression.DefaultExpressionManager
 
isEvaluatorRegistered(String) - Method in interface org.mule.api.expression.ExpressionManager
Checks whether an evaluator is registered with the manager
isEvaluatorRegistered(String) - Method in class org.mule.expression.DefaultExpressionManager
Checks whether an evaluator is registered with the manager
isEventValid(MuleEvent) - Method in class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
isExactMatch() - Method in class org.mule.transformer.TransformerWeighting
 
isExceptionHandled(Exception) - Method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
isExceptionThrown() - Method in class org.mule.util.ExceptionHolder
 
isExhausted() - Method in class org.mule.retry.policies.SimpleRetryPolicy
Determines if the policy is exhausted or not comparing the original configuration against the current state.
isExhausted() - Method in class org.mule.retry.PolicyStatus
 
isExpandEmptyElements() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
isExpectTransaction() - Method in class org.mule.tck.functional.TransactionalFunctionalTestComponent
 
isExpirationNeeded() - Method in class org.mule.util.store.InMemoryObjectStore
 
isExplicitTrustStoreOnly() - Method in class org.mule.api.security.tls.TlsConfiguration
 
isExplicitTrustStoreOnly() - Method in interface org.mule.api.security.TlsDirectTrustStore
If the trust store is undefined and the trust store generated via System properties then the key store certificates defined via TODO can be used as a source of trust information.
isExplicitTrustStoreOnly() - Method in class org.mule.transport.http.HttpsConnector
 
isExplicitTrustStoreOnly() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
isExpression(String) - Method in interface org.mule.api.expression.ExpressionManager
Determines if the string is an expression.
isExpression(String) - Method in class org.mule.expression.DefaultExpressionManager
 
isExpression() - Method in class org.mule.util.AttributeEvaluator
 
isExternallyManagedLifecycle() - Method in interface org.mule.api.object.ObjectFactory
Returns true if Mule should not manage the life-cycle the object instance returned from the ObjectFactory.
isExternallyManagedLifecycle() - Method in class org.mule.component.PooledJavaComponent.LifeCycleAdapterFactory
 
isExternallyManagedLifecycle() - Method in class org.mule.config.spring.util.SpringBeanLookup
 
isExternallyManagedLifecycle() - Method in class org.mule.object.AbstractObjectFactory
 
isExternallyManagedLifecycle() - Method in class org.mule.object.JndiObjectFactory
 
isFailIfNoMatch() - Method in class org.mule.routing.outbound.AbstractRoundRobinMessageSplitter
If none of the targets match a split message part i.e.
isFailOnMessageScribbling() - Static method in class org.mule.api.ThreadSafeAccess.AccessControl
Should we fail when we detect "message scribbling"? (see AbstractMessageAdapter#checkMutable())
isFailOnTimeout() - Method in class org.mule.routing.AbstractAggregator
 
isFailOnTimeout() - Method in class org.mule.routing.correlation.EventCorrelator
 
isFailOnTimeout() - Method in class org.mule.service.ServiceAsyncReplyCompositeMessageSource
Deprecated.
 
isFailOnUnresolvedHost() - Method in class org.mule.transport.tcp.TcpConnector
 
isFatalEnabled() - Method in class org.mule.util.MuleLogger
 
isFile(ImmutableEndpoint, FTPClient) - Method in class org.mule.transport.ftp.FtpConnector
 
isFile(URL) - Static method in class org.mule.util.FileUtils
 
isFilteredMetaScheme(String) - Static method in class org.mule.api.registry.ServiceDescriptorFactory
 
isFipsSecurityModel() - Static method in class org.mule.util.SecurityUtils
 
isFlowEndingWithOneWayEndpointReturnsNull() - Method in interface org.mule.api.config.MuleConfiguration
 
isFlowEndingWithOneWayEndpointReturnsNull() - Method in class org.mule.config.DefaultMuleConfiguration
 
isFlowStackElement(String, String) - Static method in class org.mule.tck.util.FlowTraceUtils
 
isFlowTrace() - Static method in class org.mule.config.DefaultMuleConfiguration
 
isFollowsRedirect() - Method in interface org.mule.module.http.api.client.HttpRequestOptions
 
isFollowsRedirect() - Method in class org.mule.module.http.internal.request.client.DefaultHttpRequestOptions
 
isForceJndiDestinations() - Method in class org.mule.transport.jms.JmsConnector
 
isFreeze() - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
isFullStackTraces() - Method in class org.mule.module.management.mbean.MuleConfigurationService
 
isFullStackTraces() - Method in interface org.mule.module.management.mbean.MuleConfigurationServiceMBean
 
isGracefulShutdown() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
isGroupAlreadyProcessed(Object) - Method in class org.mule.routing.correlation.EventCorrelator
 
isHandleException() - Method in class org.mule.module.json.transformers.ObjectToJson
 
isHandleReplyTo(Message, MuleEvent) - Method in class org.mule.transport.jms.JmsMessageDispatcher
Some JMS implementations do not support ReplyTo or require some further fiddling of the message
isHonorQosHeaders() - Method in class org.mule.transport.jms.JmsConnector
Gets the value of honorQosHeaders property.
isHttpMultipartRequest(HttpRequest) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
isIbmJDK() - Static method in class org.mule.util.SystemUtils
 
isIgnoreAdminNotifications() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
isIgnoreBadInput() - Method in interface org.mule.api.transformer.Transformer
By default, Mule will throw an exception if a transformer is invoked with a source object that is not compatible with the transformer.
isIgnoreBadInput() - Method in class org.mule.transformer.AbstractTransformer
 
isIgnoreBadInput() - Method in class org.mule.transformer.CompositeConverter
 
isIgnoreComponentMessageNotifications() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
isIgnoreComponentNotifications() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
isIgnoreConnectionNotifications() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
isIgnoreCustomNotifications() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
isIgnored(String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
isIgnored(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
isIgnored(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
isIgnored() - Method in interface org.mule.config.spring.parsers.assembly.configuration.SingleProperty
 
isIgnored() - Method in class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyLiteral
 
isIgnored() - Method in class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyWrapper
 
isIgnored(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
isIgnored(String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
isIgnored(AccessibleObject) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
isIgnoreEndpointMessageNotifications() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
isIgnoreManagementNotifications() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
isIgnoreManagerNotifications() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
isIgnoreMessageNotifications() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
isIgnoreMessageProcessorNotifications() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
isIgnoreModelNotifications() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
isIgnoreSecurityNotifications() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
isInbound() - Method in class org.mule.management.stats.RouterStatistics
 
isInbound() - Method in class org.mule.module.management.mbean.EndpointService
 
isInbound() - Method in interface org.mule.module.management.mbean.EndpointServiceMBean
 
isIncludeConfigNamespaces() - Method in class org.mule.module.xml.util.NamespaceManager
 
isInCluster() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
isIndexedFactory() - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
isInfoEnabled() - Method in class org.mule.util.MuleLogger
 
isInitialisable - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
isInitialised() - Method in interface org.mule.api.lifecycle.LifecycleState
 
isInitialised() - Method in interface org.mule.api.MuleContext
Determines if the server has been initialised
isInitialised() - Method in class org.mule.DefaultMuleContext
Determines if the server has been initialised
isInitialised() - Method in class org.mule.exception.AbstractExceptionListener
 
isInitialised() - Method in class org.mule.lifecycle.DefaultLifecycleState
 
isInitialised() - Method in class org.mule.module.management.mbean.MuleService
 
isInitialised() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
isInitialised() - Method in class org.mule.registry.AbstractRegistry
 
isInitialised() - Method in class org.mule.routing.EventGroup
 
isInitialised() - Method in class org.mule.transport.AbstractConnector
 
isInitialising() - Method in interface org.mule.api.lifecycle.LifecycleState
 
isInitialising() - Method in interface org.mule.api.MuleContext
Determines if the server is being initialised
isInitialising() - Method in class org.mule.DefaultMuleContext
Determines if the server is being initialised
isInitialising() - Method in class org.mule.lifecycle.DefaultLifecycleState
 
isInitialized() - Method in class org.mule.module.cxf.WSProxyService
Deprecated.
 
isInitializeStaticBusInstance() - Method in class org.mule.module.cxf.CxfConfiguration
 
isInitialStateStopped() - Method in class org.mule.transport.AbstractConnector
The will cause the connector not to start when AbstractConnector.start() is called.
isInstance(Class<T>, Object) - Static method in class org.mule.util.ClassUtils
Checks that value is an instance of type.
isInteractWithExternal() - Method in interface org.mule.api.transaction.TransactionConfig
 
isInteractWithExternal() - Method in class org.mule.transaction.MuleTransactionConfig
 
isInvalidatedPayload() - Method in class org.mule.DefaultMessageCollection
 
isJdkDynamicProxy(Object) - Static method in class org.mule.module.cxf.MuleInvoker
Return whether the given object is a J2SE dynamic proxy.
isJndiDestinations() - Method in class org.mule.transport.jms.JmsConnector
 
isJsonCommented() - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
isJsonCommented() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
IsJsonFilter - Class in org.mule.module.json.filters
A filter that will determine if the current message payload is a JSON encoded message.
IsJsonFilter() - Constructor for class org.mule.module.json.filters.IsJsonFilter
 
isJsonSchema(String) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
isKeepAlive() - Method in class org.mule.transport.http.HttpResponse
 
isKeepAlive() - Method in class org.mule.transport.http.HttpServerConnection
 
isKeepAlive() - Method in class org.mule.transport.tcp.TcpConnector
 
isKeepFileOnError() - Method in class org.mule.transport.sftp.SftpConnector
 
isKeepFileOnError() - Method in class org.mule.transport.sftp.SftpUtil
 
isKeepSendSocketOpen() - Method in class org.mule.transport.http.HttpConnector
Deprecated.
Use keepAlive property in the outbound endpoint.
isKeepSendSocketOpen() - Method in class org.mule.transport.tcp.TcpConnector
 
isKeepSendSocketOpen() - Method in class org.mule.transport.udp.UdpConnector
 
isLastPhaseExecutionFailed() - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
isLenient() - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
isList(Type) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
 
isListClass(Class) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
Checks whether the specified class parameter is an instance of List
isListenerRegistered(ServerNotificationListener) - Method in interface org.mule.api.context.notification.ServerNotificationHandler
 
isListenerRegistered(ServerNotificationListener) - Method in class org.mule.context.notification.OptimisedNotificationHandler
 
isListenerRegistered(ServerNotificationListener) - Method in class org.mule.context.notification.ServerNotificationManager
 
isListHeader(String) - Static method in class org.mule.transport.email.MailUtils
Check whether a property name has the format associated with a list of header values
isLoadJdmkAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
isLoadLog4jAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
isLoadMx4jAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
isLoadProfilerAgent() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
isLocalName(Element, String) - Static method in class org.mule.util.XMLUtils
 
isLocateServer() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
isLocateServer() - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
isLocked() - Method in class org.apache.commons.httpclient.HttpConnection
Tests if the connection is locked.
isLogException() - Method in class org.mule.exception.AbstractExceptionListener
Determines whether the handled exception will be logged to its standard logger in the ERROR level before being handled.
isLogMessageDetails() - Method in class org.mule.tck.functional.FunctionalTestComponent
 
isLookupOnEachCall() - Method in class org.mule.object.JndiObjectFactory
 
isLoopback() - Method in class org.mule.transport.multicast.MulticastConnector
 
isLowerBoundInclusive() - Method in class org.mule.util.VersionRange
 
isMap(Type) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
 
isMapClass(Class) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
Checks whether the specified class parameter is an instance of Map
isMatch(MuleMessage) - Method in interface org.mule.api.routing.Matchable
Determines if the event should be processed
isMatch(MuleMessage) - Method in class org.mule.config.dsl.routers.ContentBasedRouter
Deprecated.
 
isMatch(String, String, boolean) - Method in class org.mule.el.function.WildcardExpressionLanguageFuntion
 
isMatch(MuleMessage) - Method in class org.mule.module.sxc.SxcFilteringOutboundRouter
 
isMatch(MuleMessage) - Method in class org.mule.routing.FirstSuccessful
 
isMatch(MuleMessage) - Method in class org.mule.routing.outbound.FilteringOutboundRouter
 
isMatch(MuleMessage) - Method in class org.mule.routing.outbound.TransformerRouter
Deprecated.
 
isMatch(MuleMessage) - Method in class org.mule.routing.RoundRobin
 
isMatch(MuleMessage) - Method in class org.mule.routing.UntilSuccessful
 
isMatch() - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
isMatch() - Method in interface org.mule.util.scan.ClassScanner
Deprecated.
 
isMatch() - Method in class org.mule.util.scan.ImplementationClassScanner
Deprecated.
 
isMatch() - Method in class org.mule.util.scan.InterfaceClassScanner
Deprecated.
 
isMatchAll() - Method in interface org.mule.api.routing.OutboundRouterCollection
Deprecated.
 
isMatchAll() - Method in class org.mule.routing.AbstractMatchingRouter
 
isMatchAll() - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
isMissingParser(Problem) - Method in class org.mule.config.spring.MissingParserProblemReporter
 
isModernSpecAvailable() - Method in class org.mule.module.management.support.AutoDiscoveryJmxSupportFactory
Is JMX 1.2 and up available for use?
isMtomEnabled() - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
isMtomEnabled() - Method in class org.mule.module.ws.consumer.WSConsumer
 
isMuleExpression(String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
isMuleNamespace(Element) - Static method in class org.mule.config.spring.util.SpringXMLUtils
 
isMuleUri(String) - Static method in class org.mule.endpoint.MuleEndpointURI
 
isMyType(Document) - Method in class org.mule.module.rss.transformers.RssParser
 
isNewFile() - Method in class org.mule.util.queue.QueueFileProvider
 
isNewLineAfterDeclaration() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
isNewlines() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
isNewMessage(MuleEvent) - Method in class org.mule.routing.IdempotentMessageFilter
 
isNewMessage(MuleEvent) - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
 
isNoLocal() - Method in class org.mule.transport.jms.JmsConnector
 
isNonBlocking(MuleEvent) - Method in class org.mule.processor.AbstractNonBlockingMessageProcessor
 
isNonBlocking(MuleEvent) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
 
isNonMatching(DataType, DataType) - Method in class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
 
isNotificationDynamic() - Method in interface org.mule.api.context.notification.ServerNotificationHandler
 
isNotificationDynamic() - Method in class org.mule.context.notification.OptimisedNotificationHandler
 
isNotificationDynamic() - Method in class org.mule.context.notification.ServerNotificationManager
 
isNotificationEnabled(Class<? extends ServerNotification>) - Method in interface org.mule.api.context.notification.ServerNotificationHandler
This returns a very "conservative" value - it is true if the notification or any subclass would be accepted.
isNotificationEnabled() - Method in class org.mule.context.notification.NotificationHelper
isNotificationEnabled(MuleEvent) - Method in class org.mule.context.notification.NotificationHelper
Checks if the ServerNotificationHandler associated to the given event is enabled to fire instances of NotificationHelper.notificationClass
isNotificationEnabled(Class<? extends ServerNotification>) - Method in class org.mule.context.notification.OptimisedNotificationHandler
This returns a very "conservative" value - it is true if the notification or any subclass would be accepted.
isNotificationEnabled(Class<? extends ServerNotification>) - Method in class org.mule.context.notification.ServerNotificationManager
 
isNotificationsEnabled() - Method in interface org.mule.api.MuleEvent
Indicates if notifications should be fired when processing this message.
isNotificationsEnabled() - Method in class org.mule.DefaultMuleEvent
 
isNotificationsEnabled() - Method in class org.mule.VoidMuleEvent
 
isNotMatch() - Method in class org.mule.transformer.TransformerWeighting
 
isNotRunning(MuleProcessController) - Static method in class org.mule.test.infrastructure.process.MuleStatusProbe
 
isNullReturnsTrue() - Method in class org.mule.routing.filters.ExpressionFilter
 
isNullSubscription() - Method in class org.mule.context.notification.ListenerSubscriptionPair
 
ISO_8859_1 - Static variable in class org.mule.transport.http.ResponseWriter
 
isOk() - Method in interface org.mule.api.retry.RetryContext
Note that it's possible for an implementation to return false and have no failure specified, thus the subsequent RetryContext.getLastFailure() may return null.
isOk() - Method in class org.mule.retry.async.FutureRetryContext
 
isOk() - Method in class org.mule.retry.DefaultRetryContext
 
isOk() - Method in class org.mule.retry.PolicyStatus
 
IsolateCurrentTransactionInterceptor<T> - Class in org.mule.execution
 
IsolateCurrentTransactionInterceptor(ExecutionInterceptor<T>, TransactionConfig) - Constructor for class org.mule.execution.IsolateCurrentTransactionInterceptor
 
isolateTransaction() - Method in class org.mule.transaction.TransactionCoordination
 
isOldModeEnabled() - Static method in class org.mule.util.queue.DelegateQueueManager
 
isOmitEncoding() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
isOneway(Exchange) - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
isOpaque() - Method in class org.mule.endpoint.MuleEndpointURI
 
isOpen - Variable in class org.apache.commons.httpclient.HttpConnection
Whether or not the connection is connected.
isOpen() - Method in class org.apache.commons.httpclient.HttpConnection
Tests if the connection is open.
isOpen() - Method in class org.mule.transport.http.HttpServerConnection
 
isOptional(String) - Method in class org.mule.config.spring.CompositeOptionalObjectsController
 
isOptional(String) - Method in class org.mule.config.spring.DefaultOptionalObjectsController
 
isOptional(String) - Method in interface org.mule.config.spring.OptionalObjectsController
 
isOptional() - Method in class org.mule.expression.transformers.ExpressionArgument
 
isOutbound() - Method in class org.mule.module.management.mbean.EndpointService
 
isOutbound() - Method in interface org.mule.module.management.mbean.EndpointServiceMBean
 
isOutputAppend() - Method in class org.mule.transport.file.FileConnector
 
isOverridden(String) - Method in class org.mule.module.launcher.FineGrainedControlClassLoader
 
isOverwrite() - Method in class org.mule.config.spring.processors.MuleObjectNameProcessor
 
isOverwrite() - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
isPadText() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
isParamTypeACollection(Method, int) - Static method in class org.mule.transformer.types.CollectionDataType
 
isParseExpression() - Method in class org.mule.util.AttributeEvaluator
 
isParseResponseDisabled() - Method in interface org.mule.module.http.api.client.HttpRequestOptions
 
isParseResponseDisabled() - Method in class org.mule.module.http.internal.request.client.DefaultHttpRequestOptions
 
isPassive() - Method in class org.mule.transport.ftp.FtpConnector
Getter for FTP passive mode.
isPaused() - Method in interface org.mule.api.service.Service
Deprecated.
 
isPaused() - Method in class org.mule.lifecycle.processor.ProcessIfStartedWaitIfPausedMessageProcessor
 
isPaused() - Method in class org.mule.module.management.mbean.ServiceService
 
isPaused() - Method in interface org.mule.module.management.mbean.ServiceServiceMBean
Deprecated.
 
isPaused() - Method in class org.mule.service.AbstractService
Deprecated.
Determines if the service is in a paused state
isPayloadConsumed(Class<?>) - Method in class org.mule.DefaultMuleMessage
Checks if the payload has been consumed for this message.
isPersistent() - Method in interface org.mule.api.store.ObjectStore
Is this store persistent?
isPersistent() - Method in class org.mule.tck.util.FakeObjectStore
 
isPersistent() - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
Is this store persistent?
isPersistent() - Method in class org.mule.util.queue.DefaultQueueConfiguration
 
isPersistent() - Method in class org.mule.util.queue.DefaultQueueStore
 
isPersistent() - Method in class org.mule.util.queue.objectstore.QueueConfiguration
Deprecated.
 
isPersistent() - Method in interface org.mule.util.queue.QueueConfiguration
 
isPersistent() - Method in interface org.mule.util.queue.QueueStore
 
isPersistent() - Method in class org.mule.util.store.InMemoryObjectStore
 
isPersistent() - Method in class org.mule.util.store.ManagedObjectStore
 
isPersistent() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
isPersistent() - Method in class org.mule.util.store.ObjectStorePartition
 
isPersistent() - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
isPersistent() - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
 
isPersistent() - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
isPersistent() - Method in class org.mule.util.store.PersistentObjectStorePartition
 
isPersistent() - Method in class org.mule.util.store.ProvidedObjectStoreWrapper
 
isPersistent() - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
Is this store persistent?
isPersistent() - Method in class org.mule.util.store.QueueStoreAdapter
Deprecated.
 
isPersistent() - Method in class org.mule.util.store.SimpleMemoryObjectStore
 
isPersistent() - Method in class org.mule.util.store.TextFileObjectStore
Is this store persistent?
isPersistentDelivery() - Method in class org.mule.transport.jms.JmsConnector
 
isPersistentStores() - Method in class org.mule.routing.AbstractAggregator
 
isPhaseComplete(String) - Method in interface org.mule.api.lifecycle.LifecycleManager
Checks that a phase has completed
isPhaseComplete(String) - Method in interface org.mule.api.lifecycle.LifecycleState
 
isPhaseComplete(String) - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
isPhaseComplete(String) - Method in class org.mule.lifecycle.DefaultLifecycleState
 
isPhaseExecuting(String) - Method in interface org.mule.api.lifecycle.LifecycleState
 
isPhaseExecuting(String) - Method in class org.mule.lifecycle.DefaultLifecycleState
 
isPhaseSupported(String) - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
isPhaseSupported(String) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
isPreemptive() - Method in class org.mule.module.http.internal.domain.request.HttpRequestAuthentication
 
isPrepare() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
isPrimary(String, Object) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Return whether the bean definition for the given bean name has been marked as a primary bean.
isPrimaryPollingInstance() - Method in interface org.mule.api.MuleContext
 
isPrimaryPollingInstance() - Method in class org.mule.DefaultMuleContext
 
isPrimaryPollingInstance() - Method in class org.mule.transport.DefaultPollingController
 
isPrimaryPollingInstance() - Method in interface org.mule.transport.PollingController
 
isPrintHeaders() - Method in class org.mule.management.stats.printers.CSVPrinter
 
isProcess(Object) - Method in interface org.mule.module.bpm.BPMS
 
isProcess(Object) - Method in class org.mule.module.jbpm.Jbpm
 
isProcessAsync(MuleEvent) - Method in class org.mule.processor.AsyncInterceptingMessageProcessor
 
isProcessAsync(MuleEvent) - Method in class org.mule.processor.LaxAsyncInterceptingMessageProcessor
 
isProcessAsync(MuleEvent) - Method in class org.mule.processor.LaxSedaStageInterceptingMessageProcessor
 
isProcessingMessage - Variable in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.SubReceiver
 
isProtected() - Method in class org.mule.security.oauth.callback.ProcessCallback
 
isProtocolSupported(String) - Method in interface org.mule.api.endpoint.ImmutableEndpoint
 
isProtocolSupported(String) - Method in class org.mule.endpoint.AbstractEndpoint
 
isProtocolSupported(String) - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
isProtocolSupported(String) - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
isProtocolSupported(String) - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
isProtocolSupported(String) - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
isPrototype() - Method in class org.mule.config.spring.DefaultObjectSerializerFactoryBean
 
isPrototype() - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
isPrototype() - Method in class org.mule.config.spring.ServerNotificationManagerConfigurator
 
isProxied() - Method in class org.apache.commons.httpclient.HttpConnection
Returns true if the connection is established via a proxy, false otherwise.
isProxy() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
isProxy() - Method in class org.mule.module.cxf.builder.ProxyServiceMessageProcessorBuilder
 
isProxy() - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
isProxy() - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
isProxy() - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
isProxyClass(Class<T>) - Static method in class org.mule.transformer.types.DataTypeFactory
Cache which classes are proxies.
isProxyEnvelope() - Method in class org.mule.module.cxf.builder.ProxyClientMessageProcessorBuilder
 
isProxyEnvelope() - Method in class org.mule.module.cxf.builder.ProxyServiceMessageProcessorBuilder
 
isProxyNtlmAuthentication() - Method in class org.mule.transport.http.HttpConnector
 
isQueuePersistent() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
Are the events in the SEDA queue persistent?
isQueueTransactional() - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
isQueueTransient() - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
isRandomiseRNames() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
isReadOnly() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
 
isReadOnly() - Method in interface org.mule.api.registry.Registry
 
isReadOnly() - Method in class org.mule.config.spring.SpringRegistry
 
isReadOnly() - Method in class org.mule.endpoint.AbstractEndpoint
 
isReadOnly() - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
isReadOnly() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
isReadOnly() - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
isReadOnly() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
isReadOnly() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
isReadOnly() - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
isReadOnly() - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
isReadOnly() - Method in class org.mule.registry.MuleRegistryHelper
isReadOnly() - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
isReadOnly() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
isReadOnly() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
isReady() - Method in class org.mule.retry.async.FutureRetryContext
 
isRealmRequired() - Method in class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
 
isReceiveMessagesInTransaction() - Method in class org.mule.transport.TransactedPollingMessageReceiver
 
isRecognizedQuery(String, String, EndpointInfo, boolean) - Method in class org.mule.module.cxf.support.WSDLQueryHandler
 
isRecognizedQuery(String, String, EndpointInfo) - Method in class org.mule.module.cxf.support.WSDLQueryHandler
 
isRecommendedJdkVersion() - Static method in class org.mule.util.JdkVersionUtils
 
isRecursive() - Method in class org.mule.transport.file.FileConnector
 
isRedeliver() - Method in class org.mule.tck.functional.QuietExceptionStrategy
 
isRedeliveryPolicyConfigured() - Method in class org.mule.construct.AbstractPipeline
 
isRedeploymentEnabled() - Method in class org.mule.module.launcher.descriptor.ArtifactDescriptor
 
isReference(String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
A property can be explicitly registered as a bean reference via registerBeanReference() or it can simply use the "-ref" suffix.
isReference(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
isReference(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
A property can be explicitly registered as a bean reference via registerBeanReference() or it can simply use the "-ref" suffix.
isReference() - Method in interface org.mule.config.spring.parsers.assembly.configuration.SingleProperty
 
isReference() - Method in class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyLiteral
 
isReference() - Method in class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyWrapper
 
isReference(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
isReferenced() - Method in interface org.mule.transport.servlet.jetty.ConnectorHolder
 
isReferenced() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector.MuleReceiverConnectorHolder
 
isRegistered(Expirable) - Method in class org.mule.util.monitor.ExpiryMonitor
 
isRegisterTraceInterceptor() - Method in class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
isRemote() - Method in interface org.mule.api.registry.Registry
 
isRemote() - Method in class org.mule.config.spring.SpringRegistry
 
isRemote() - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
isRemote() - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
isRemote() - Method in class org.mule.registry.MuleRegistryHelper
isRemote() - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
isRemove() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
isRepeat(int, int) - Method in class org.mule.transport.tcp.protocols.DirectProtocol
Decide whether to repeat transfer.
isRepeat(int, int) - Method in class org.mule.transport.tcp.protocols.EOFProtocol
Repeat until end of file
isRepeat(int, int) - Method in class org.mule.transport.tcp.protocols.LengthProtocol
Read all four bytes for initial integer (limit is set in read)
isRepeat(int, int, int) - Method in class org.mule.transport.tcp.protocols.XmlMessageEOFProtocol
Continue reading til EOF or new document found
isRepeat(int, int, int) - Method in class org.mule.transport.tcp.protocols.XmlMessageProtocol
Show we continue reading? This class, following previous implementations, only reads while input is saturated.
isRepeatable() - Method in class org.mule.transport.http.StreamPayloadRequestEntity
 
isRequestAvailable() - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
isRequestAvailable() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
isRequestedSessionIdFromCookie() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
isRequestedSessionIdFromURL() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
isRequestedSessionIdFromUrl() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
isRequestedSessionIdValid() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
isRequireClientAuthentication() - Method in class org.mule.api.security.tls.TlsConfiguration
 
isRequireClientAuthentication() - Method in interface org.mule.api.security.TlsDirectTrustStore
If a server socket is constructed directly (see TlsConfiguration) then this flag will control whether client authenticatin is required.
isRequireClientAuthentication() - Method in class org.mule.transport.http.HttpsConnector
 
isRequireClientAuthentication() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
isRequired(AccessibleObject) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
isRequired(Parameter, boolean) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
isResolveable(String) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
isResolveable(String) - Method in class org.mule.el.mvel.MuleBaseVariableResolverFactory
 
isResourceIdentifierAnUri() - Method in class org.mule.api.context.notification.ServerNotification
 
isResponseAvailable() - Method in class org.apache.commons.httpclient.HttpConnection
Tests if input data avaialble.
isResponseAvailable(int) - Method in class org.apache.commons.httpclient.HttpConnection
Tests if input data becomes available within the given period time in milliseconds.
isResponseEnabled() - Method in interface org.mule.api.transport.Connector
 
isResponseEnabled() - Method in class org.mule.transport.AbstractConnector
 
isResponseEnabled() - Method in class org.mule.transport.jms.JmsConnector
 
isResponseEnabled() - Method in class org.mule.transport.tcp.TcpConnector
 
isResponseEnabled() - Method in class org.mule.transport.vm.VMConnector
 
isResponseEnabled() - Method in class org.mule.transport.xmpp.XmppConnector
 
isResultValid(EnforcerRule) - Method in class org.apache.maven.enforcer.rule.EnforcerPortRule
If the rule is cacheable and the same id is found in the cache, the stored results are passed to this method to allow double checking of the results.
isRethrowExceptionOnRead() - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
 
isRetryCommit() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
isReturnOriginalMessageAsReply() - Method in class org.mule.transport.jms.JmsConnector
 
isReturnResult() - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
isReturnResult() - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
isReturnResult() - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
isReturnResult() - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
isReturnSourceIfNull() - Method in class org.mule.expression.transformers.ExpressionTransformer
 
isReturnTypeACollection(Method) - Static method in class org.mule.transformer.types.CollectionDataType
 
isReuseAddress() - Method in class org.mule.transport.tcp.TcpConnector
 
isReuseObject() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
isReuseObject() - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
 
isReuseObject() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
isReversible() - Method in class org.mule.module.xml.transformer.XmlToXMLStreamReader
 
isRollback(Throwable) - Method in class org.mule.exception.AbstractExceptionListener
 
isRollback() - Method in class org.mule.tck.functional.TransactionalFunctionalTestComponent
 
isRollback() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
isRollbackOnly() - Method in interface org.mule.api.transaction.Transaction
 
isRollbackOnly() - Method in class org.mule.processor.DelegateTransaction
 
isRollbackOnly() - Method in class org.mule.transaction.AbstractTransaction
 
isRolledBack() - Method in interface org.mule.api.transaction.Transaction
 
isRolledBack() - Method in class org.mule.processor.DelegateTransaction
 
isRolledBack() - Method in class org.mule.transaction.AbstractTransaction
 
isRunning() - Method in class org.mule.config.spring.MuleArtifactContext
This implementation returns false if the context hasn't been initialised yet, in opposition to the default implementation which throws an exception
isRunning() - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.RequestHandlerMatcherPair
 
isRunning() - Method in class org.mule.test.infrastructure.process.Controller
 
isRunning() - Static method in class org.mule.test.infrastructure.process.matchers.Running
 
isRunning() - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
isRunning(MuleProcessController) - Static method in class org.mule.test.infrastructure.process.MuleStatusProbe
 
isRunning() - Method in class org.mule.transport.PollingReceiverWorker
 
isSameRM(XAResource) - Method in class org.mule.transport.jms.xa.XAResourceWrapper
 
isSameRM(XAResource) - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
isSameRM(XAResource) - Method in class org.mule.util.queue.TransactionalQueueSession
 
isSameRM(XAResource) - Method in class org.mule.util.xa.DefaultXASession
 
isSatisfied() - Method in class org.mule.test.infrastructure.process.AppDeploymentProbe
 
isSatisfied() - Method in class org.mule.test.infrastructure.process.MuleStatusProbe
 
isSecure() - Method in class org.apache.commons.httpclient.HttpConnection
Returns true if the connection is established over a secure protocol.
isSecure() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
isSendTcpNoDelay() - Method in class org.mule.transport.tcp.TcpConnector
 
isSendTransformed() - Method in class org.mule.routing.ForwardingCatchAllStrategy
Deprecated.
 
isSerialiseObjects() - Method in class org.mule.transport.file.FileConnector
 
isServerReachable(URL, int) - Static method in class org.mule.util.NetworkUtils
 
isServerReachable(String, int, int) - Static method in class org.mule.util.NetworkUtils
 
isSignRequested() - Method in class org.mule.module.pgp.PGPCryptInfo
 
isSignRequired() - Method in class org.mule.module.pgp.filters.PGPSecurityFilter
 
isSingleResult() - Method in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
Should a single value be returned.
isSingleton() - Method in interface org.mule.api.object.ObjectFactory
Returns true if the ObjectFactory implementation always returns the same object instance.
isSingleton() - Method in class org.mule.component.PooledJavaComponent.LifeCycleAdapterFactory
 
isSingleton() - Method in class org.mule.config.spring.DefaultObjectSerializerFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.AbstractEndpointFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.AbstractSelectiveRouterFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.BootstrapObjectFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.CompositeMessageSourceFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.ConstantFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.ExtensionManagerFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.FlowRefFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.MessageProcessorChainFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.MessageProcessorFilterPairFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.ResponseMessageProcessorsFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.ScatterGatherRouterFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.TransactionalMessageProcessorsFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.factories.TransactionManagerFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
isSingleton() - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
isSingleton() - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
isSingleton() - Method in class org.mule.config.spring.ServerNotificationManagerConfigurator
 
isSingleton() - Method in class org.mule.config.spring.util.SpringBeanLookup
 
isSingleton() - Method in class org.mule.module.cxf.config.JaxWsClientFactoryBean
 
isSingleton() - Method in class org.mule.module.cxf.config.ProxyClientFactoryBean
 
isSingleton() - Method in class org.mule.module.cxf.config.ProxyServiceFactoryBean
 
isSingleton() - Method in class org.mule.module.cxf.config.SimpleClientFactoryBean
 
isSingleton() - Method in class org.mule.module.cxf.config.WebServiceFactoryBean
 
isSingleton() - Method in class org.mule.module.db.internal.config.domain.param.AbstractParamDefinitionDefinitionParser
 
isSingleton() - Method in class org.mule.module.db.internal.config.domain.param.DefaultSqlParamResolverFactoryBean
 
isSingleton() - Method in class org.mule.module.db.internal.config.domain.param.InputParamValueBeanDefinitionParser
 
isSingleton() - Method in class org.mule.module.db.internal.config.domain.param.StaticQueryParamResolverFactoryBean
 
isSingleton() - Method in class org.mule.module.db.internal.config.domain.query.BulkQueryResolverFactoryBean
 
isSingleton() - Method in class org.mule.module.db.internal.config.domain.query.DynamicQueryTemplateFactoryBean
 
isSingleton() - Method in class org.mule.module.db.internal.config.domain.query.ParameterizedQueryTemplateFactoryBean
 
isSingleton() - Method in class org.mule.module.db.internal.config.domain.query.QueryFileFactoryBean
 
isSingleton() - Method in class org.mule.module.db.internal.config.domain.query.QueryTemplateBeanDefinitionParser
 
isSingleton() - Method in class org.mule.module.db.internal.config.processor.BulkUpdateMessageProcessorFactoryBean
 
isSingleton() - Method in class org.mule.module.db.internal.config.resolver.database.DefaultDbConfigResolverFactoryBean
 
isSingleton() - Method in class org.mule.module.db.internal.config.resolver.query.QueryResolverFactoryBean
 
isSingleton() - Method in class org.mule.object.AbstractObjectFactory
 
isSingleton() - Method in class org.mule.object.JndiObjectFactory
 
isSingleton() - Method in class org.mule.object.SingletonObjectFactory
 
isSingleton() - Method in class org.mule.tck.testmodels.fruit.FloridaSunnyOrangeFactoryBean
 
isSocketKeepAlive() - Method in class org.mule.transport.http.HttpServerConnection
Tests if SO_KEEPALIVE is enabled in the underlying socket.
isSocketTcpNoDelay() - Method in class org.mule.transport.http.HttpServerConnection
Tests if TCP_NODELAY is enabled in the underlying socket.
isSourceDataTypeSupported(DataType<?>) - Method in interface org.mule.api.transformer.Transformer
Determines if a particular source class can be handled by this transformer
isSourceDataTypeSupported(DataType<?>, boolean) - Method in class org.mule.transformer.AbstractMessageTransformer
 
isSourceDataTypeSupported(DataType<?>) - Method in class org.mule.transformer.AbstractTransformer
 
isSourceDataTypeSupported(DataType<?>, boolean) - Method in class org.mule.transformer.AbstractTransformer
Determines whether that data type passed in is supported by this transformer
isSourceDataTypeSupported(DataType<?>) - Method in class org.mule.transformer.CompositeConverter
 
isSourceTypeSupported(Class<?>) - Method in interface org.mule.api.transformer.Transformer
isSourceTypeSupported(Class<?>) - Method in class org.mule.transformer.AbstractTransformer
Deprecated.
isSourceTypeSupported(Class<MuleMessage>, boolean) - Method in class org.mule.transformer.AbstractTransformer
isSourceTypeSupported(Class<?>) - Method in class org.mule.transformer.CompositeConverter
 
isSourceTypeSupportedByFirst(List<Transformer>, Class) - Static method in class org.mule.transformer.TransformerUtils
 
isSplitRequired(MuleEvent) - Method in class org.mule.routing.MessageChunkSplitter
 
isSplitRequired(MuleEvent) - Method in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
isStale() - Method in class org.apache.commons.httpclient.HttpConnection
Determines whether this connection is "stale", which is to say that either it is no longer open, or an attempt to read the connection would fail.
isStaleCheckingEnabled() - Method in class org.apache.commons.httpclient.HttpConnection
isStandalone() - Method in interface org.mule.api.config.MuleConfiguration
Try to guess if we're embedded.
isStandalone() - Method in class org.mule.config.DefaultMuleConfiguration
 
isStandalone() - Method in class org.mule.el.context.AppContext
 
isStandalone() - Static method in class org.mule.module.boot.MuleBootstrapUtils
Whether Mule is running embedded or standalone.
isStandalone() - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
Whether Mule is running embedded or standalone.
isStandalone() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
isStartable - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
isStarted() - Method in interface org.mule.api.component.LifecycleAdapter
 
isStarted() - Method in interface org.mule.api.context.WorkManager
Is the WorkManager ready to accept work?
isStarted() - Method in interface org.mule.api.lifecycle.LifecycleState
 
isStarted() - Method in interface org.mule.api.MuleContext
Determines if the server has been started
isStarted() - Method in interface org.mule.api.service.Service
Deprecated.
Determines whether this service has been started
isStarted() - Method in interface org.mule.api.transport.Connector
 
isStarted() - Method in class org.mule.component.DefaultComponentLifecycleAdapter
 
isStarted() - Method in class org.mule.component.NullLifecycleAdapter
 
isStarted() - Method in class org.mule.construct.AbstractFlowConstruct
 
isStarted() - Method in class org.mule.DefaultMuleContext
Determines if the server has been started
isStarted() - Method in class org.mule.lifecycle.DefaultLifecycleState
 
isStarted() - Method in class org.mule.module.management.mbean.ConnectorService
 
isStarted() - Method in interface org.mule.module.management.mbean.ConnectorServiceMBean
 
isStarted() - Method in class org.mule.modules.schedulers.cron.CronScheduler
 
isStarted() - Method in class org.mule.service.AbstractService
Deprecated.
 
isStarted() - Method in class org.mule.source.ClusterizableMessageSourceWrapper
 
isStarted() - Method in class org.mule.transport.AbstractConnector
 
isStarted() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
isStarted() - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
isStarted() - Method in class org.mule.transport.polling.schedule.FixedFrequencyScheduler
 
isStarted() - Method in class org.mule.transport.servlet.jetty.util.EmbeddedJettyServer
 
isStarted() - Method in class org.mule.transport.TrackingWorkManager
 
isStarted() - Method in class org.mule.util.timer.EventTimerTask
 
isStarted() - Method in class org.mule.work.MuleWorkManager
 
isStarted() - Method in class org.mule.work.SerialWorkManager
 
isStartElement() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
isStartElement() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
isStarting() - Method in interface org.mule.api.lifecycle.LifecycleState
 
isStarting() - Method in interface org.mule.api.MuleContext
 
isStarting() - Method in class org.mule.DefaultMuleContext
 
isStarting() - Method in class org.mule.lifecycle.DefaultLifecycleState
 
isStarting() - Method in class org.mule.transport.AbstractConnector
 
isStarting() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
isStateful() - Method in class org.mule.transport.quartz.config.AbstractJobConfig
 
isStateless() - Method in class org.mule.module.bpm.Rules
 
isStateless() - Method in class org.mule.module.bpm.RulesComponent
 
isStatsEnabled() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
isStatusCodeValidationDisabled() - Method in interface org.mule.module.http.api.client.HttpRequestOptions
 
isStatusCodeValidationDisabled() - Method in class org.mule.module.http.internal.request.client.DefaultHttpRequestOptions
 
isStopFurtherProcessing() - Method in interface org.mule.api.MuleEvent
Determines whether the default processing for this event will be executed.
isStopFurtherProcessing() - Method in interface org.mule.api.MuleEventContext
Deprecated. 
isStopFurtherProcessing() - Method in class org.mule.DefaultMuleEvent
Determines whether the default processing for this event will be executed
isStopFurtherProcessing() - Method in class org.mule.DefaultMuleEventContext
Determines whether the default processing for this event will be executed.
isStopFurtherProcessing() - Method in class org.mule.VoidMuleEvent
 
isStopMessageProcessing() - Method in class org.mule.exception.AbstractMessagingExceptionStrategy
 
isStoppable - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
isStopped() - Method in interface org.mule.api.lifecycle.LifecycleState
 
isStopped() - Method in interface org.mule.api.MuleContext
 
isStopped() - Method in interface org.mule.api.service.Service
Deprecated.
 
isStopped(String) - Static method in class org.mule.config.i18n.CoreMessages
 
isStopped() - Method in class org.mule.construct.AbstractFlowConstruct
 
isStopped() - Method in class org.mule.DefaultMuleContext
 
isStopped() - Method in class org.mule.lifecycle.DefaultLifecycleState
 
isStopped() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyServer
 
isStopped() - Method in interface org.mule.module.http.internal.listener.Server
 
isStopped() - Method in class org.mule.module.management.mbean.MuleService
 
isStopped() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
isStopped() - Method in class org.mule.module.management.mbean.ServiceService
 
isStopped() - Method in interface org.mule.module.management.mbean.ServiceServiceMBean
Deprecated.
 
isStopped() - Method in class org.mule.service.AbstractService
Deprecated.
 
isStopped() - Method in class org.mule.transport.AbstractConnector
 
isStopped() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
isStopping() - Method in interface org.mule.api.lifecycle.LifecycleState
 
isStopping() - Method in interface org.mule.api.MuleContext
 
isStopping() - Method in class org.mule.construct.AbstractFlowConstruct
 
isStopping() - Method in class org.mule.DefaultMuleContext
 
isStopping() - Method in class org.mule.lifecycle.DefaultLifecycleState
 
isStopping() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyServer
 
isStopping() - Method in interface org.mule.module.http.internal.listener.Server
 
isStopping() - Method in class org.mule.module.management.mbean.ServiceService
 
isStopping() - Method in interface org.mule.module.management.mbean.ServiceServiceMBean
Deprecated.
 
isStopping() - Method in class org.mule.service.AbstractService
Deprecated.
 
isStopping() - Method in class org.mule.transport.AbstractConnector
 
isStopping() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
isStreaming() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
isStreaming() - Method in class org.mule.transport.file.FileConnector
 
isStreaming() - Method in class org.mule.transport.ftp.FtpConnector
 
isStreaming() - Method in class org.mule.transport.tcp.TcpInputStream
 
isStreamOpen() - Method in class org.mule.config.ConfigResource
 
isStreamResponse() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
isSunJDK() - Static method in class org.mule.util.SystemUtils
 
isSupportedJdkVendor() - Static method in class org.mule.util.JdkVersionUtils
 
isSupportedJdkVersion() - Static method in class org.mule.util.JdkVersionUtils
 
isSupportJms102bSpec() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
isSupportsNonBlocking() - Method in class org.mule.transport.AbstractMessageDispatcher
Dispatcher implementations that support non-blocking processing should override this method and return 'true'.
isSupportsNonBlocking() - Method in class org.mule.transport.jms.JmsMessageDispatcher
 
isSuppressDeclaration() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
isSuspended() - Method in class org.mule.module.jbpm.EndedProcess
 
isSynchronizeCall() - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
isSynchronous() - Method in interface org.mule.api.MuleEvent
 
isSynchronous() - Method in interface org.mule.api.processor.ProcessingDescriptor
Whether the processing represented by this instance is synchronous or not
isSynchronous() - Method in interface org.mule.api.retry.RetryPolicyTemplate
 
isSynchronous() - Method in class org.mule.construct.AbstractPipeline
 
isSynchronous() - Method in class org.mule.DefaultMuleEvent
 
isSynchronous() - Method in class org.mule.retry.async.AsynchronousRetryTemplate
 
isSynchronous() - Method in class org.mule.retry.policies.AbstractPolicyTemplate
 
isSynchronous() - Method in class org.mule.VoidMuleEvent
 
isSyncWrites() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
isTarget(String) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
isTarget(String) - Method in class org.mule.el.mvel.EventVariableResolverFactory
 
isTarget(String) - Method in class org.mule.el.mvel.GlobalVariableResolverFactory
 
isTarget(String) - Method in class org.mule.el.mvel.MessageVariableResolverFactory
 
isTarget(String) - Method in class org.mule.el.mvel.MuleBaseVariableResolverFactory
 
isTarget(String) - Method in class org.mule.el.mvel.VariableVariableResolverFactory
 
isThrowException() - Method in class org.mule.tck.functional.FunctionalTestComponent
Sometimes you will want the service to always throw an exception, if this is the case you can set the 'throwException' property to true.
isThrowOnUnaccepted() - Method in class org.mule.processor.AbstractFilteringMessageProcessor
 
isTimedOut() - Method in class org.mule.work.WorkerContext
Used by a Work executor in order to know if this work, which should be accepted but not started has timed out.
isTopic(ImmutableEndpoint) - Method in class org.mule.transport.jms.DefaultJmsTopicResolver
Will use endpoint's resource info to detect a topic, as in jms://topic:trade.PriceUpdatesTopic.
isTopic(ImmutableEndpoint, boolean) - Method in class org.mule.transport.jms.DefaultJmsTopicResolver
Use endpoint configuration to detect a topic.
isTopic(Destination) - Method in class org.mule.transport.jms.DefaultJmsTopicResolver
Will use an instanceof operator.
isTopic(ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsTopicResolver
Use endpoint configuration to detect a topic.
isTopic(ImmutableEndpoint, boolean) - Method in interface org.mule.transport.jms.JmsTopicResolver
Use endpoint configuration to detect a topic.
isTopic(Destination) - Method in interface org.mule.transport.jms.JmsTopicResolver
Use any means suitable to detect a topic.
isTopic(Destination) - Method in class org.mule.transport.jms.weblogic.WeblogicJmsTopicResolver
For Weblogic 8.x (JMS 1.0.2b) will use Weblogic-specific API call to test for topic.
isTopLevel(Element) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
isTraceEnabled() - Method in class org.mule.util.MuleLogger
 
isTracking() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
isTransacted() - Method in interface org.mule.api.MuleEvent
Returns true is this event is being processed in a transaction
isTransacted() - Method in interface org.mule.api.transaction.TransactionConfig
 
isTransacted() - Method in interface org.mule.api.transaction.TransactionFactory
Determines whether this transaction factory creates transactions that are really transacted or if they are being used to simulate batch actions, such as using Jms Client Acknowledge.
isTransacted() - Method in class org.mule.DefaultMuleEvent
 
isTransacted() - Method in class org.mule.module.db.internal.domain.transaction.DbTransactionFactory
 
isTransacted() - Method in class org.mule.module.spring.transaction.SpringTransactionFactory
 
isTransacted() - Method in class org.mule.processor.DelegateTransactionFactory
 
isTransacted() - Method in class org.mule.transaction.MuleTransactionConfig
Will the result, at the end of running the transaction template, be an active transaction?
isTransacted() - Method in class org.mule.transaction.XaTransactionFactory
Determines whether this transaction factory creates transactions that are really transacted or if they are being used to simulate batch actions, such as using Jms Client Acknowledge.
isTransacted() - Method in class org.mule.transport.jdbc.JdbcTransactionFactory
 
isTransacted() - Method in class org.mule.transport.jms.JmsClientAcknowledgeTransactionFactory
 
isTransacted() - Method in class org.mule.transport.jms.JmsTransactionFactory
 
isTransacted() - Method in class org.mule.transport.vm.VMTransactionFactory
 
isTransacted() - Method in class org.mule.VoidMuleEvent
 
isTransactional() - Method in interface org.mule.util.queue.TransactionContextProvider
 
isTransactionComplete(JournalEntry) - Method in interface org.mule.util.journal.TransactionCompletePredicate
 
isTransactionPerMessage() - Method in class org.mule.transport.jdbc.JdbcConnector
 
isTransactionRollback() - Method in class org.mule.endpoint.outbound.OutboundTxRollbackMessageProcessor
Checks to see if the current transaction has been rolled back
isTransformBeforeMatch() - Method in interface org.mule.api.routing.TransformingMatchable
 
isTransformBeforeMatch() - Method in class org.mule.routing.outbound.FilteringOutboundRouter
 
isTransparent() - Method in class org.apache.commons.httpclient.HttpConnection
Indicates if the connection is completely transparent from end to end.
isTransportConnected() - Method in class org.mule.transport.email.SmtpMessageDispatcher
 
isTransportSupported(String) - Static method in class org.mule.transport.soap.axis.extensions.MuleTransport
 
isTreatMapAsNamedParams() - Method in class org.mule.transport.soap.axis.AxisConnector
 
isTrimNeeded(int) - Method in class org.mule.util.store.InMemoryObjectStore
 
isTrimText() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
isUncountable(String) - Static method in class org.mule.module.extension.internal.util.NameUtils
Return true if the word is uncountable.
isUnder(JdkVersionUtils.JdkVersion) - Method in class org.mule.util.JdkVersionUtils.JdkVersionRange
 
isUpdatedZombieArtifact(String) - Method in interface org.mule.module.launcher.ArchiveDeployer
Indicates if a previously failed artifact (zombie) configuration was updated on the file system.
isUpdatedZombieArtifact(String) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
isUpdatedZombieArtifact(String) - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
isUpperBoundInclusive() - Method in class org.mule.util.VersionRange
 
isUseCachedHttpServletRequest() - Method in class org.mule.transport.servlet.ServletConnector
 
isUseConnectorToRetrieveWsdl() - Method in class org.mule.module.ws.consumer.MuleWSDLLocatorConfig
 
isUseConnectorToRetrieveWsdl() - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
isUseContinuations() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
isUseDefaultConfigResource() - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
isUseEventCopy(MuleEvent) - Method in class org.mule.processor.BlockingProcessorExecutor
 
isUseJMSEngine() - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
isUseMultipleTransactedReceivers() - Method in class org.mule.transport.TransactedPollingMessageReceiver
 
isUsePersistentConnections() - Method in class org.mule.module.http.internal.request.HttpClientConfiguration
 
isUserInRole(String) - Method in class org.mule.module.atom.server.MuleRequestContext
 
isUserInRole(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
isUseSecureHash() - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
isUseStaxSource() - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
isUseStaxSource() - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
isUseStaxSource() - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
isUseStaxSource() - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
isUseStaxSource() - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
isUseTempDirInbound() - Method in class org.mule.transport.sftp.SftpUtil
 
isUseTempDirOutbound() - Method in class org.mule.transport.sftp.SftpUtil
 
isUseTempFileTimestampSuffix() - Method in class org.mule.transport.sftp.SftpConnector
 
isUseTempFileTimestampSuffix() - Method in class org.mule.transport.sftp.SftpUtil
 
isUseTemplates() - Method in class org.mule.routing.outbound.FilteringOutboundRouter
 
isUseXaTransactions() - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
isUsingDefaultExpression() - Method in class org.mule.routing.UntilSuccessful
 
isUsingDefaultExpression() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
 
isValid(String) - Method in interface org.mule.api.el.ExpressionLanguage
Validates the expression returning true is the expression is valid, false otherwise..
isValid() - Method in interface org.mule.api.MuleSession
Determines if this session is valid.
isValid(String) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
isValid(int) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
isValid(int) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
isValid() - Method in class org.mule.session.DefaultMuleSession
 
isValid(FTPFile, FilenameFilter) - Method in class org.mule.transport.ftp.FtpMessageRequester
 
isValid(int) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
isValid(String) - Method in class org.mule.util.TemplateParser
 
isValidateConnections() - Method in class org.mule.transport.AbstractConnector
Whether to test a connection on each take from pool.
isValidateExpressions() - Method in interface org.mule.api.config.MuleConfiguration
 
isValidateExpressions() - Method in class org.mule.config.DefaultMuleConfiguration
 
isValidateParsing() - Method in class org.mule.module.json.filters.IsJsonFilter
 
isValidationEnabled() - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
isValidExpression(String) - Method in interface org.mule.api.expression.ExpressionManager
Determines if the expression is valid or not.
isValidExpression(String) - Method in class org.mule.expression.DefaultExpressionManager
Determines if the expression is valid or not.
isValidTransition(String) - Method in interface org.mule.api.lifecycle.LifecycleState
 
isValidTransition(String) - Method in class org.mule.lifecycle.DefaultLifecycleState
 
isVerboseExceptions() - Static method in class org.mule.config.DefaultMuleConfiguration
 
isVoid(Method) - Static method in class org.mule.module.extension.internal.util.IntrospectionUtils
 
isWarnEnabled() - Method in class org.mule.util.MuleLogger
 
isWebServiceOnline() - Static method in class org.mule.tck.util.WebServiceOnlineCheck
 
isWhiteSpace() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
isWhiteSpace() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
isWrapperFor(Class<?>) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
isWrapperFor(Class<?>) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
isWrapperFor(Class<?>) - Method in class org.mule.module.db.internal.domain.xa.DataSourceWrapper
 
isWrapperFor(Class<?>) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
isWrapperFor(Class<?>) - Method in class org.mule.transport.jdbc.xa.DataSourceWrapper
 
isXA() - Method in interface org.mule.api.transaction.Transaction
 
isXA() - Method in class org.mule.processor.DelegateTransaction
 
isXA() - Method in class org.mule.transaction.AbstractTransaction
 
isXA() - Method in class org.mule.transaction.XaTransaction
 
isXaConnectionFactory(ConnectionFactory) - Method in class org.mule.transport.jms.AbstractConnectionFactoryDecorator
 
isXHTML() - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
IsXmlFilter - Class in org.mule.module.xml.filters
IsXmlFilter accepts a String or byte[] if its contents are valid (well-formed) XML.
IsXmlFilter() - Constructor for class org.mule.module.xml.filters.IsXmlFilter
 
iterator() - Method in class org.mule.module.launcher.util.ObservableList
 
iterator() - Method in class org.mule.routing.EventGroup
Returns an iterator over a snapshot copy of this group's collected events sorted by their arrival time.
iterator(boolean) - Method in class org.mule.routing.EventGroup
Returns an iterator over a snapshot copy of this group's collected events., optionally sorted by arrival order.
iterator(Object) - Static method in class org.mule.transport.http.multipart.LazyList
 
iterator() - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
IteratorMessageSequence<T> - Class in org.mule.routing.outbound
A MessageSequence that delegates its IteratorMessageSequence.hasNext() and IteratorMessageSequence.next() methods to an Iterator, and has no estimated size
IteratorMessageSequence(Iterator<T>) - Constructor for class org.mule.routing.outbound.IteratorMessageSequence
 
IteratorResultSetHandler - Class in org.mule.module.db.internal.result.resultset
Processes a ResultSet returning an iterator of maps.
IteratorResultSetHandler(RowHandler, StatementStreamingResultSetCloser) - Constructor for class org.mule.module.db.internal.result.resultset.IteratorResultSetHandler
 
ITestComponent - Interface in org.mule.tck.testmodels.services
Interface for TestComponent (to make it easier to host the service on Axis)

J

JaasAuthentication - Class in org.mule.module.jaas
 
JaasAuthentication(Credentials) - Constructor for class org.mule.module.jaas.JaasAuthentication
 
JaasAuthentication(Object, Object, Subject) - Constructor for class org.mule.module.jaas.JaasAuthentication
 
JaasNamespaceHandler - Class in org.mule.module.jaas.config
 
JaasNamespaceHandler() - Constructor for class org.mule.module.jaas.config.JaasNamespaceHandler
 
JaasSecurityFilter - Class in org.mule.module.jaas.filters
 
JaasSecurityFilter() - Constructor for class org.mule.module.jaas.filters.JaasSecurityFilter
 
JaasSimpleAuthenticationProvider - Class in org.mule.module.jaas
This is the Provider for Mule's Jaas Security.
JaasSimpleAuthenticationProvider() - Constructor for class org.mule.module.jaas.JaasSimpleAuthenticationProvider
 
JaasSimpleAuthenticationProvider.JaasConfig - Class in org.mule.module.jaas
The JaasConfig class extends the Jaas Configuration in order to be able to configure the jaas security programmatically.
JaasSimpleAuthenticationProvider.JaasConfig() - Constructor for class org.mule.module.jaas.JaasSimpleAuthenticationProvider.JaasConfig
 
JAR - Static variable in class org.mule.module.ws.consumer.MuleWSDLLocator
 
JarResourceServlet - Class in org.mule.transport.servlet
A servlet for loading resources loaded in jar files.
JarResourceServlet() - Constructor for class org.mule.transport.servlet.JarResourceServlet
 
JarUtils - Class in org.mule.util
 
JAVA_OBJECT_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
JavaComponent - Interface in org.mule.api.component
JavaComponent is a Java Component implementation used to invoke Java component implementations.
javaComponentRequiredForInboundEndpoint() - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
JavaObjectSerializer - Class in org.mule.serialization.internal
Implementation of ObjectSerializer that uses Java's default serialization mechanism.
JavaObjectSerializer() - Constructor for class org.mule.serialization.internal.JavaObjectSerializer
 
JAX_WS_FRONTEND - Static variable in class org.mule.module.cxf.CxfConstants
 
jaxbContext - Variable in class org.mule.module.xml.transformer.jaxb.JAXBMarshallerTransformer
 
jaxbContext - Variable in class org.mule.module.xml.transformer.jaxb.JAXBUnmarshallerTransformer
 
JaxbContextFactoryBean - Class in org.mule.module.xml.config
TODO
JaxbContextFactoryBean() - Constructor for class org.mule.module.xml.config.JaxbContextFactoryBean
 
JAXBContextResolver - Class in org.mule.module.xml.transformer.jaxb
This resolver is used by the transform engine to inject a JAXBContext into a method that requires it.
JAXBContextResolver() - Constructor for class org.mule.module.xml.transformer.jaxb.JAXBContextResolver
 
JAXBMarshallerTransformer - Class in org.mule.module.xml.transformer.jaxb
Allows marshaling of Java objects to XML using JAXB 2.
JAXBMarshallerTransformer() - Constructor for class org.mule.module.xml.transformer.jaxb.JAXBMarshallerTransformer
 
JAXBMarshallerTransformer(JAXBContext, DataType) - Constructor for class org.mule.module.xml.transformer.jaxb.JAXBMarshallerTransformer
 
JAXBTransformerResolver - Class in org.mule.module.xml.transformer.jaxb
A TransformerResolver implementation used to discover whether the current transform requests requires JAXB.
JAXBTransformerResolver() - Constructor for class org.mule.module.xml.transformer.jaxb.JAXBTransformerResolver
 
JAXBUnmarshallerTransformer - Class in org.mule.module.xml.transformer.jaxb
Allows un-marshaling of XML generated by JAXB to a Java object graph.
JAXBUnmarshallerTransformer() - Constructor for class org.mule.module.xml.transformer.jaxb.JAXBUnmarshallerTransformer
 
JAXBUnmarshallerTransformer(JAXBContext, DataType<?>) - Constructor for class org.mule.module.xml.transformer.jaxb.JAXBUnmarshallerTransformer
 
JaxenFilter - Class in org.mule.module.xml.filters
Deprecated.
This feature is deprecated and will be removed in Mule 4.0. Use xpath-filter instead
JaxenFilter() - Constructor for class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
JaxenFilter(String) - Constructor for class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
JaxenFilter(String, String) - Constructor for class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
JAXP_PROPERTIES_SCHEMA_LANGUAGE - Static variable in class org.mule.module.xml.util.XMLUtils
 
JAXP_PROPERTIES_SCHEMA_LANGUAGE_VALUE - Static variable in class org.mule.module.xml.util.XMLUtils
 
JAXP_PROPERTIES_SCHEMA_SOURCE - Static variable in class org.mule.module.xml.util.XMLUtils
 
JaxpXPathEvaluator - Class in org.mule.module.xml.xpath
This is the preferred base implementation of XPathEvaluator.
JaxpXPathEvaluator() - Constructor for class org.mule.module.xml.xpath.JaxpXPathEvaluator
 
JaxpXPathExpressionEvaluator - Class in org.mule.module.xml.expression
Deprecated.
This expression evaluator is deprecated and will be removed in Mule 4. Use XPath3Function instead
JaxpXPathExpressionEvaluator() - Constructor for class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
 
JaxWsClientFactoryBean - Class in org.mule.module.cxf.config
 
JaxWsClientFactoryBean() - Constructor for class org.mule.module.cxf.config.JaxWsClientFactoryBean
 
JaxWsClientMessageProcessorBuilder - Class in org.mule.module.cxf.builder
Builds a JAX-WS client based CxfOutboundMessageProcessor.
JaxWsClientMessageProcessorBuilder() - Constructor for class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
JBossArjunaTransactionManagerFactory - Class in org.mule.module.jboss.transaction
 
JBossArjunaTransactionManagerFactory() - Constructor for class org.mule.module.jboss.transaction.JBossArjunaTransactionManagerFactory
 
JBossTransactionManagerLookupFactory - Class in org.mule.transaction.lookup
 
JBossTransactionManagerLookupFactory() - Constructor for class org.mule.transaction.lookup.JBossTransactionManagerLookupFactory
 
JbossTSNamespaceHandler - Class in org.mule.module.jboss.config
Registers Bean Definition Parsers for the "jbossts" namespace.
JbossTSNamespaceHandler() - Constructor for class org.mule.module.jboss.config.JbossTSNamespaceHandler
 
Jbpm - Class in org.mule.module.jbpm
An implementation of Mule's generic BPMS interface for JBoss jBPM.
Jbpm() - Constructor for class org.mule.module.jbpm.Jbpm
Creates the Mule wrapper for jBPM
Jbpm(String, Properties) - Constructor for class org.mule.module.jbpm.Jbpm
Creates the Mule wrapper for jBPM
Jbpm(ProcessEngine, Properties) - Constructor for class org.mule.module.jbpm.Jbpm
Creates the Mule wrapper for jBPM
JBPM_WRAPPER_CLASS - Static variable in class org.mule.module.bpm.config.BpmNamespaceHandler
Allows simple configuration of jBPM from the generic "bpm" namespace.
JDBC - Static variable in class org.mule.transport.jdbc.JdbcConnector
 
JdbcConnector - Class in org.mule.transport.jdbc
 
JdbcConnector(MuleContext) - Constructor for class org.mule.transport.jdbc.JdbcConnector
 
JdbcEndpointURIBuilder - Class in org.mule.transport.jdbc
Parses a JDBC style endpoint to a MuleEndpointURI
JdbcEndpointURIBuilder() - Constructor for class org.mule.transport.jdbc.JdbcEndpointURIBuilder
 
JdbcMessageDispatcher - Class in org.mule.transport.jdbc
The Jdbc Message dispatcher is responsible for executing SQL queries against a database.
JdbcMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.jdbc.JdbcMessageDispatcher
 
JdbcMessageDispatcherFactory - Class in org.mule.transport.jdbc
Creates JdbcMessageDispatchers.
JdbcMessageDispatcherFactory() - Constructor for class org.mule.transport.jdbc.JdbcMessageDispatcherFactory
 
JdbcMessageReceiver - Class in org.mule.transport.jdbc
Implements TransactedPollingMessageReceiver reading data from a database.
JdbcMessageReceiver(Connector, FlowConstruct, InboundEndpoint, String, String) - Constructor for class org.mule.transport.jdbc.JdbcMessageReceiver
 
JdbcMessageRequester - Class in org.mule.transport.jdbc
 
JdbcMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.jdbc.JdbcMessageRequester
 
JdbcMessageRequesterFactory - Class in org.mule.transport.jdbc
Creates JdbcMessageDispatchers.
JdbcMessageRequesterFactory() - Constructor for class org.mule.transport.jdbc.JdbcMessageRequesterFactory
 
JdbcMessages - Class in org.mule.transport.jdbc.i18n
 
JdbcMessages() - Constructor for class org.mule.transport.jdbc.i18n.JdbcMessages
 
JdbcNamespaceHandler - Class in org.mule.transport.jdbc.config
Registers Bean Definition Parsers for the "jdbc" namespace.
JdbcNamespaceHandler() - Constructor for class org.mule.transport.jdbc.config.JdbcNamespaceHandler
 
JdbcObjectStore<T extends Serializable> - Class in org.mule.transport.jdbc.store
 
JdbcObjectStore() - Constructor for class org.mule.transport.jdbc.store.JdbcObjectStore
 
JdbcTransaction - Class in org.mule.transport.jdbc
TODO
JdbcTransaction(MuleContext) - Constructor for class org.mule.transport.jdbc.JdbcTransaction
 
JdbcTransactionFactory - Class in org.mule.transport.jdbc
 
JdbcTransactionFactory() - Constructor for class org.mule.transport.jdbc.JdbcTransactionFactory
 
JdbcTypes - Class in org.mule.module.db.internal.domain.type
Defines DbType for JDBC types defined in Types
JdbcTypes() - Constructor for class org.mule.module.db.internal.domain.type.JdbcTypes
 
JdbcUtils - Class in org.mule.transport.jdbc
Utility methods for working with various parts of JDBC.
JDK_VERSION - Static variable in class org.mule.util.JdkVersionUtils
pattern with groups for major, minor, micro, update and milestone (if exists).
JdkVersionUtils - Class in org.mule.util
 
JdkVersionUtils() - Constructor for class org.mule.util.JdkVersionUtils
 
JdkVersionUtils.JdkVersion - Class in org.mule.util
 
JdkVersionUtils.JdkVersion(String) - Constructor for class org.mule.util.JdkVersionUtils.JdkVersion
 
JdkVersionUtils.JdkVersionRange - Class in org.mule.util
 
JdkVersionUtils.JdkVersionRange(String) - Constructor for class org.mule.util.JdkVersionUtils.JdkVersionRange
 
JdmkAgent - Class in org.mule.module.management.agent
JdmkAgent configures an Jdmk Http Adaptor for Jmx management, statistics and configuration viewing of a Mule instance.
JdmkAgent() - Constructor for class org.mule.module.management.agent.JdmkAgent
 
JERSEY_RESPONSE - Static variable in class org.mule.module.jersey.JerseyResourcesComponent
 
JerseyNamespaceHandler - Class in org.mule.module.jersey.config
 
JerseyNamespaceHandler() - Constructor for class org.mule.module.jersey.config.JerseyNamespaceHandler
 
JerseyResourcesComponent - Class in org.mule.module.jersey
Wraps a set of components which can get invoked by Jersey.
JerseyResourcesComponent() - Constructor for class org.mule.module.jersey.JerseyResourcesComponent
 
JETTY - Static variable in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
JETTY_SSL - Static variable in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
JettyContinuationsMessageProcessTemplate - Class in org.mule.transport.servlet.jetty
 
JettyContinuationsMessageProcessTemplate(HttpServletRequest, HttpServletResponse, AbstractMessageReceiver, MuleContext, Continuation) - Constructor for class org.mule.transport.servlet.jetty.JettyContinuationsMessageProcessTemplate
 
JettyContinuationsReceiverServlet - Class in org.mule.transport.servlet.jetty
 
JettyContinuationsReceiverServlet(MuleContext) - Constructor for class org.mule.transport.servlet.jetty.JettyContinuationsReceiverServlet
 
JettyHttpConnector - Class in org.mule.transport.servlet.jetty
The JettyConnector can be using to embed a Jetty server to receive requests on an http inbound endpoint.
JettyHttpConnector(MuleContext) - Constructor for class org.mule.transport.servlet.jetty.JettyHttpConnector
 
JettyHttpConnector.MuleReceiverConnectorHolder - Class in org.mule.transport.servlet.jetty
 
JettyHttpConnector.MuleReceiverConnectorHolder(Connector, JettyReceiverServlet, JettyHttpMessageReceiver) - Constructor for class org.mule.transport.servlet.jetty.JettyHttpConnector.MuleReceiverConnectorHolder
 
JettyHttpMessageReceiver - Class in org.mule.transport.servlet.jetty
JettyHttpMessageReceiver is a simple http server that can be used to listen for http requests on a particular port
JettyHttpMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.servlet.jetty.JettyHttpMessageReceiver
 
JettyHttpMessageReceiver.ContinuationsResponseHandler - Class in org.mule.transport.servlet.jetty
 
JettyHttpMessageReceiver.ContinuationsResponseHandler(JettyContinuationsMessageProcessTemplate) - Constructor for class org.mule.transport.servlet.jetty.JettyHttpMessageReceiver.ContinuationsResponseHandler
 
JettyHttpsConnector - Class in org.mule.transport.servlet.jetty
The JettyHttpsConnector can be using to embed a Jetty server to receive requests on an http inbound endpoint.
JettyHttpsConnector(MuleContext) - Constructor for class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
JettyLogger - Class in org.mule.transport.servlet.jetty
 
JettyLogger() - Constructor for class org.mule.transport.servlet.jetty.JettyLogger
 
JettyMessageProcessTemplate - Class in org.mule.transport.servlet.jetty
 
JettyMessageProcessTemplate(HttpServletRequest, HttpServletResponse, AbstractMessageReceiver, MuleContext) - Constructor for class org.mule.transport.servlet.jetty.JettyMessageProcessTemplate
 
JettyMuleMessageFactory - Class in org.mule.transport.servlet.jetty
 
JettyMuleMessageFactory() - Constructor for class org.mule.transport.servlet.jetty.JettyMuleMessageFactory
 
JettyNamespaceHandler - Class in org.mule.transport.servlet.jetty.config
Registers a Bean Definition Parser for handling elements.
JettyNamespaceHandler() - Constructor for class org.mule.transport.servlet.jetty.config.JettyNamespaceHandler
 
JettyReceiverServlet - Class in org.mule.transport.servlet.jetty
 
JettyReceiverServlet(MuleContext) - Constructor for class org.mule.transport.servlet.jetty.JettyReceiverServlet
 
JettySslNamespaceHandler - Class in org.mule.transport.servlet.jetty.config
Registers a Bean Definition Parser for handling elements.
JettySslNamespaceHandler() - Constructor for class org.mule.transport.servlet.jetty.config.JettySslNamespaceHandler
 
JettyWebappServerAgent - Class in org.mule.transport.servlet.jetty
A 'proxy' agent that displays info about any webapps deployed together with their entry-point url.
JettyWebappServerAgent() - Constructor for class org.mule.transport.servlet.jetty.JettyWebappServerAgent
 
JettyWebappServerAgent(String) - Constructor for class org.mule.transport.servlet.jetty.JettyWebappServerAgent
 
JMS - Static variable in class org.mule.transport.jms.JmsConnector
 
Jms102bSupport - Class in org.mule.transport.jms
Jms102bSupport is a template class to provide an absstraction to to the Jms 1.0.2b api specification.
Jms102bSupport(JmsConnector) - Constructor for class org.mule.transport.jms.Jms102bSupport
 
Jms11Support - Class in org.mule.transport.jms
Jms11Support is a template class to provide an abstraction to to the JMS 1.1 API specification.
Jms11Support(JmsConnector) - Constructor for class org.mule.transport.jms.Jms11Support
 
JMS_ATTRIBUTES - Static variable in class org.mule.transport.jms.config.JmsNamespaceHandler
 
JMS_CORRELATION_ID - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_DELIVERY_MODE - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_DESTINATION - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_EXPIRATION - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_MESSAGE_ID - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_PRIORITY - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_PROPERTY_NAMES - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_REDELIVERED - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_REPLY_TO - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_SELECTOR_PROPERTY - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_SPECIFICATION_102B - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_SPECIFICATION_11 - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_TIMESTAMP - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_TRANSPORT - Static variable in class org.mule.module.cxf.CxfInboundMessageProcessor
 
JMS_TYPE - Static variable in class org.mule.transport.jms.JmsConstants
 
JMS_X_DELIVERY_COUNT - Static variable in class org.mule.transport.jms.JmsConstants
 
JmsClientAcknowledgeTransaction - Class in org.mule.transport.jms
JmsClientAcknowledgeTransaction is a transaction implementation of performing a message acknowledgement.
JmsClientAcknowledgeTransaction(MuleContext) - Constructor for class org.mule.transport.jms.JmsClientAcknowledgeTransaction
 
JmsClientAcknowledgeTransactionFactory - Class in org.mule.transport.jms
JmsClientAcknowledgeTransactionFactory creates a JMS Client Acknowledge Transaction using a JMS Message.
JmsClientAcknowledgeTransactionFactory() - Constructor for class org.mule.transport.jms.JmsClientAcknowledgeTransactionFactory
 
JmsConnector - Class in org.mule.transport.jms
JmsConnector is a JMS 1.0.2b compliant connector that can be used by a Mule endpoint.
JmsConnector(MuleContext) - Constructor for class org.mule.transport.jms.JmsConnector
 
JmsConnectorDefinitionParser - Class in org.mule.transport.jms.config
 
JmsConnectorDefinitionParser() - Constructor for class org.mule.transport.jms.config.JmsConnectorDefinitionParser
 
JmsConnectorDefinitionParser(Class) - Constructor for class org.mule.transport.jms.config.JmsConnectorDefinitionParser
 
JmsConstants - Class in org.mule.transport.jms
 
JmsConstants() - Constructor for class org.mule.transport.jms.JmsConstants
 
JmsEndpointURIBuilder - Class in org.mule.transport.jms
TODO
JmsEndpointURIBuilder() - Constructor for class org.mule.transport.jms.JmsEndpointURIBuilder
 
JmsExceptionReader - Class in org.mule.transport.jms
This reader will ensure that the LinkedException and JMS code is not lost when printing the JMSException.
JmsExceptionReader() - Constructor for class org.mule.transport.jms.JmsExceptionReader
 
JmsMessageDispatcher - Class in org.mule.transport.jms
JmsMessageDispatcher is responsible for dispatching messages to JMS destinations.
JmsMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.jms.JmsMessageDispatcher
 
JmsMessageDispatcher.LatchReplyToListener - Class in org.mule.transport.jms
 
JmsMessageDispatcher.LatchReplyToListener(Latch) - Constructor for class org.mule.transport.jms.JmsMessageDispatcher.LatchReplyToListener
 
JmsMessageDispatcherFactory - Class in org.mule.transport.jms
JmsMessageDispatcherFactory creates a message adapter that will send JMS messages
JmsMessageDispatcherFactory() - Constructor for class org.mule.transport.jms.JmsMessageDispatcherFactory
 
JmsMessageReceiver - Class in org.mule.transport.jms
Deprecated.
use MultiConsumerJmsMessageReceiver (set by default).
JmsMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
JmsMessageReceiver.JmsWorker - Class in org.mule.transport.jms
Deprecated.
 
JmsMessageReceiver.JmsWorker(Message, AbstractMessageReceiver) - Constructor for class org.mule.transport.jms.JmsMessageReceiver.JmsWorker
Deprecated.
 
JmsMessageReceiver.JmsWorker(List<Object>, AbstractMessageReceiver) - Constructor for class org.mule.transport.jms.JmsMessageReceiver.JmsWorker
Deprecated.
 
JmsMessageRequester - Class in org.mule.transport.jms
JmsMessageDispatcher is responsible for dispatching messages to JMS destinations.
JmsMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.jms.JmsMessageRequester
 
JmsMessageRequesterFactory - Class in org.mule.transport.jms
JmsMessageDispatcherFactory creates a message adapter that will send JMS messages
JmsMessageRequesterFactory() - Constructor for class org.mule.transport.jms.JmsMessageRequesterFactory
 
JmsMessages - Class in org.mule.transport.jms.i18n
 
JmsMessages() - Constructor for class org.mule.transport.jms.i18n.JmsMessages
 
JMSMessageToObject - Class in org.mule.transport.jms.transformers
JMSMessageToObject Will convert a javax.jms.Message or sub-type into an object by extracting the message payload.
JMSMessageToObject() - Constructor for class org.mule.transport.jms.transformers.JMSMessageToObject
 
JmsMessageUtils - Class in org.mule.transport.jms
JmsMessageUtils contains helper method for dealing with JMS messages in Mule.
JmsMessageUtils() - Constructor for class org.mule.transport.jms.JmsMessageUtils
 
JmsMuleMessageFactory - Class in org.mule.transport.jms
 
JmsMuleMessageFactory() - Constructor for class org.mule.transport.jms.JmsMuleMessageFactory
 
JmsNamespaceHandler - Class in org.mule.transport.jms.config
Registers Bean Definition Parsers for the "jms" namespace.
JmsNamespaceHandler() - Constructor for class org.mule.transport.jms.config.JmsNamespaceHandler
 
JmsPropertyFilter - Class in org.mule.transport.jms.filters
 
JmsPropertyFilter() - Constructor for class org.mule.transport.jms.filters.JmsPropertyFilter
 
JmsReplyToHandler - Class in org.mule.transport.jms
JmsReplyToHandler will process a JMS replyTo or hand off to the default replyTo handler if the replyTo is a URL.
JmsReplyToHandler(JmsConnector, MuleContext) - Constructor for class org.mule.transport.jms.JmsReplyToHandler
 
JmsSelectorFilter - Class in org.mule.transport.jms.filters
JmsSelectorFilter is a wrapper for a JMS Selector.
JmsSelectorFilter() - Constructor for class org.mule.transport.jms.filters.JmsSelectorFilter
 
JmsSupport - Interface in org.mule.transport.jms
JmsSupport is an interface that provides a polymorphic facade to the JMS 1.0.2b and 1.1 API specifications.
JmsTopicResolver - Interface in org.mule.transport.jms
A strategy interface to detect a javax.jms.Topic in, possibly, a vendor-specific way.
JmsTransaction - Class in org.mule.transport.jms
JmsTransaction is a wrapper for a JMS local transaction.
JmsTransaction(MuleContext) - Constructor for class org.mule.transport.jms.JmsTransaction
 
JmsTransactionFactory - Class in org.mule.transport.jms
JmsTransactionFactory creates a JMS local transaction
JmsTransactionFactory() - Constructor for class org.mule.transport.jms.JmsTransactionFactory
 
JmsXRedeliveryHandler - Class in org.mule.transport.jms.redelivery
A redelivery handler which relies on JMS provider's redelivery count facilities.
JmsXRedeliveryHandler() - Constructor for class org.mule.transport.jms.redelivery.JmsXRedeliveryHandler
 
JmsXRedeliveryHandlerFactory - Class in org.mule.transport.jms.redelivery
 
JmsXRedeliveryHandlerFactory() - Constructor for class org.mule.transport.jms.redelivery.JmsXRedeliveryHandlerFactory
 
JmxAgentConfigurer - Class in org.mule.module.management.agent
Mule now binds to a platform mbeanserver by default and jmx agent is always registered via a bootstrap process.
JmxAgentConfigurer() - Constructor for class org.mule.module.management.agent.JmxAgentConfigurer
 
JmxAgentDefinitionParser - Class in org.mule.module.management.config
 
JmxAgentDefinitionParser() - Constructor for class org.mule.module.management.config.JmxAgentDefinitionParser
 
JmxApplicationAgent - Class in org.mule.module.management.agent
JMX Agent for Mule Applications
JmxApplicationAgent() - Constructor for class org.mule.module.management.agent.JmxApplicationAgent
 
JmxDomainAgent - Class in org.mule.module.management.agent
JMX agent for domain artifacts
JmxDomainAgent() - Constructor for class org.mule.module.management.agent.JmxDomainAgent
 
JmxLegacySupport - Class in org.mule.module.management.support
Support class for JMX 1.1 based systems.
JmxLegacySupport() - Constructor for class org.mule.module.management.support.JmxLegacySupport
 
JmxManagementException - Exception in org.mule.module.management.agent
JmxManagementException is thrown by the Jmx agents if an error occurs while executing an operation.
JmxManagementException(Message) - Constructor for exception org.mule.module.management.agent.JmxManagementException
 
JmxManagementException(Message, Throwable) - Constructor for exception org.mule.module.management.agent.JmxManagementException
 
JmxManagementException(Message, ObjectName) - Constructor for exception org.mule.module.management.agent.JmxManagementException
 
JmxManagementException(Message, ObjectName, Throwable) - Constructor for exception org.mule.module.management.agent.JmxManagementException
 
JmxManagementException(Throwable) - Constructor for exception org.mule.module.management.agent.JmxManagementException
 
JmxModernSupport - Class in org.mule.module.management.support
Support class using JMX 1.2 and newer calls.
JmxModernSupport() - Constructor for class org.mule.module.management.support.JmxModernSupport
 
JmxRegistrationContext - Class in org.mule.module.management.support
Stores JMX info pertinent to the currently intialising Mule manager with JMX management enabled.
JmxServerNotificationAgent - Class in org.mule.module.management.agent
An agent that propergates Mule Server notifications to Jmx.
JmxServerNotificationAgent() - Constructor for class org.mule.module.management.agent.JmxServerNotificationAgent
 
JmxServerNotificationAgent.BroadcastNotificationService - Class in org.mule.module.management.agent
 
JmxServerNotificationAgent.BroadcastNotificationService() - Constructor for class org.mule.module.management.agent.JmxServerNotificationAgent.BroadcastNotificationService
 
JmxServerNotificationAgent.BroadcastNotificationServiceMBean - Interface in org.mule.module.management.agent
 
JmxServerNotificationAgent.NotificationListener - Class in org.mule.module.management.agent
 
JmxServerNotificationAgent.NotificationListener() - Constructor for class org.mule.module.management.agent.JmxServerNotificationAgent.NotificationListener
 
JmxServerNotificationAgent.NotificationListenerMBean - Interface in org.mule.module.management.agent
 
jmxSupport - Variable in class org.mule.module.management.mbean.FlowConstructService
 
JmxSupport - Interface in org.mule.module.management.support
Mule JMX supporting interface.
jmxSupport - Static variable in class org.mule.module.management.util.ManagementUtils
 
jmxSupportFactory - Variable in class org.mule.module.management.mbean.FlowConstructService
 
JmxSupportFactory - Interface in org.mule.module.management.support
Factory for instantiating JMX helper classes.
jmxSupportFactory - Static variable in class org.mule.module.management.util.ManagementUtils
 
jndiContext - Variable in class org.mule.transport.AbstractJndiConnector
 
JndiContextHelper - Class in org.mule.util
Common code for initialising the JNDI context.
jndiInitialFactory - Variable in class org.mule.transport.AbstractJndiConnector
 
JndiNameResolver - Interface in org.mule.transport.jms.jndi
Defines a strategy for lookup objects by name using JNDI.
JndiObjectFactory - Class in org.mule.object
 
JndiObjectFactory() - Constructor for class org.mule.object.JndiObjectFactory
 
JndiObjectFactory(String, String, String) - Constructor for class org.mule.object.JndiObjectFactory
 
JndiObjectFactory(String, String, String, Map) - Constructor for class org.mule.object.JndiObjectFactory
 
jndiProviderProperties - Variable in class org.mule.transport.AbstractJndiConnector
 
jndiProviderUrl - Variable in class org.mule.transport.AbstractJndiConnector
 
jndiResourceNotFound(String) - Static method in class org.mule.transport.jdbc.i18n.JdbcMessages
 
jndiUrlPkgPrefixes - Variable in class org.mule.transport.AbstractJndiConnector
 
JNILIB_EXTENSION - Static variable in class org.mule.module.launcher.nativelib.PerAppNativeLibraryFinder
 
JNP - Static variable in class org.mule.transport.jnp.JnpConnector
 
JnpConnector - Class in org.mule.transport.jnp
JnpConnector uses the Java Naming protocol to bind to remote objects
JnpConnector(MuleContext) - Constructor for class org.mule.transport.jnp.JnpConnector
 
JnpNamespaceHandler - Class in org.mule.transport.jnp.config
Registers a Bean Definition Parser for handling <jnp:connector> elements.
JnpNamespaceHandler() - Constructor for class org.mule.transport.jnp.config.JnpNamespaceHandler
 
job - Variable in class org.mule.transport.polling.schedule.PollScheduler
 
JOB_NAME_ATTRIBUTE - Static variable in class org.mule.transport.quartz.config.QuartzNamespaceHandler
 
JobConfig - Interface in org.mule.transport.quartz.config
The generic interface for Job Configuration endpoints that are described on Quartz endpoints
joinChat() - Method in class org.mule.transport.xmpp.XmppMultiUserChatConversation
 
joinExternalTransaction(MuleContext) - Method in interface org.mule.api.transaction.ExternalTransactionAwareTransactionFactory
Create and begins a new transaction
joinExternalTransaction(MuleContext) - Method in class org.mule.transaction.XaTransactionFactory
Create a Mule transaction that represents a transaction started outside of Mule
JournalEntry<T> - Interface in org.mule.util.journal
Contract for a journal file entry
JournalEntrySerializer<T,K extends JournalEntry<T>> - Interface in org.mule.util.journal
Allows to serialize / deserialize log entries from an OutputStream
JRunTransactionManagerLookupFactory - Class in org.mule.transaction.lookup
 
JRunTransactionManagerLookupFactory() - Constructor for class org.mule.transaction.lookup.JRunTransactionManagerLookupFactory
 
JSON - Static variable in interface org.mule.transformer.types.MimeTypes
 
JSON_MIME_TYPE - Static variable in class org.mule.module.json.transformers.JsonTransformerResolver
 
JSON_STRING - Static variable in class org.mule.transformer.types.DataTypeFactory
 
JsonData - Class in org.mule.module.json
A wrapper for the JsonNode object that allows for nested object keys i.e.
JsonData(JsonNode) - Constructor for class org.mule.module.json.JsonData
 
JsonData(URL) - Constructor for class org.mule.module.json.JsonData
 
JsonData(InputStream) - Constructor for class org.mule.module.json.JsonData
 
JsonData(Reader) - Constructor for class org.mule.module.json.JsonData
 
JsonData(String) - Constructor for class org.mule.module.json.JsonData
 
JsonExpressionEvaluator - Class in org.mule.module.json
An expression evaluator to allow users to define json expressions in their mule configuration, i.e.
JsonExpressionEvaluator() - Constructor for class org.mule.module.json.JsonExpressionEvaluator
 
JsonMapperResolver - Class in org.mule.module.json.transformers
This resolver is used by the transform engine to inject a ObjectMapper into a method that requires it.
JsonMapperResolver() - Constructor for class org.mule.module.json.transformers.JsonMapperResolver
 
JsonMessages - Class in org.mule.module.json.i18n
Internationalised messages for the Json module
JsonMessages() - Constructor for class org.mule.module.json.i18n.JsonMessages
 
JsonNamespaceHandler - Class in org.mule.module.json.config
Registers a Bean Definition Parser for handling elements defined in META-INF/mule-json.xsd
JsonNamespaceHandler() - Constructor for class org.mule.module.json.config.JsonNamespaceHandler
 
JsonNodeExpressionEvaluator - Class in org.mule.module.json
An JSON expression evaluator that returns JsonNode's instead of strings.
JsonNodeExpressionEvaluator() - Constructor for class org.mule.module.json.JsonNodeExpressionEvaluator
 
JsonParser - Interface in org.mule.module.json
Parses Json payloads into different representations of a Json.
JsonPath - Annotation Type in org.mule.api.annotations.expression
 
JsonPathAnnotationParser - Class in org.mule.module.json.config
Responsible for parsing JsonPath parameter annotations
JsonPathAnnotationParser() - Constructor for class org.mule.module.json.config.JsonPathAnnotationParser
 
JsonSchemaDereferencing - Enum in org.mule.module.json.validation
Draft v4 defines two dereferencing modes: JsonSchemaDereferencing.CANONICAL and JsonSchemaDereferencing.INLINE
JsonSchemaFilter - Interface in org.mule.module.json.transformers
Deprecated.
This class is deprecated and will be removed in Mule 4.0. Use JsonSchemaValidator instead
JsonSchemaJsonValidationFilter - Class in org.mule.module.json.transformers
Deprecated.
This class is deprecated and will be removed in Mule 4.0. Use ValidateJsonSchemaMessageProcessor instead
JsonSchemaJsonValidationFilter() - Constructor for class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
JsonSchemaValidationException - Exception in org.mule.module.json.validation
Exception to signal that a given json did not pass validation against a json schema
JsonSchemaValidationException(String, String) - Constructor for exception org.mule.module.json.validation.JsonSchemaValidationException
 
JsonSchemaValidationException(String, String, Exception) - Constructor for exception org.mule.module.json.validation.JsonSchemaValidationException
 
JsonSchemaValidationFilter - Class in org.mule.module.json.transformers
Deprecated.
This class is deprecated and will be removed in Mule 4.0. Use ValidateJsonSchemaMessageProcessor instead
JsonSchemaValidationFilter() - Constructor for class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
JsonSchemaValidator - Class in org.mule.module.json.validation
Validates json payloads against json schemas compliant with drafts v3 and v4.
JsonSchemaValidator.Builder - Class in org.mule.module.json.validation
An implementation of the builder design pattern to create instances of JsonSchemaValidator.
JsonSchemaXsdValidationFilter - Class in org.mule.module.json.transformers
Deprecated.
This class is deprecated and will be removed in Mule 4.0. Use ValidateJsonSchemaMessageProcessor instead
JsonSchemaXsdValidationFilter() - Constructor for class org.mule.module.json.transformers.JsonSchemaXsdValidationFilter
Deprecated.
 
JsonToObject - Class in org.mule.module.json.transformers
A transformer that will convert a JSON encoded object graph to a java object.
JsonToObject() - Constructor for class org.mule.module.json.transformers.JsonToObject
 
JsonToXml - Class in org.mule.module.json.transformers
Convert JSON to an XML document string
JsonToXml() - Constructor for class org.mule.module.json.transformers.JsonToXml
 
JsonTransformerResolver - Class in org.mule.module.json.transformers
A TransformerResolver implementation used to discover whether the current transform requests requires Json mashaling.
JsonTransformerResolver() - Constructor for class org.mule.module.json.transformers.JsonTransformerResolver
 
JsonXsltTransformer - Class in org.mule.module.json.transformers
Convert Json to Json using XSLT
JsonXsltTransformer() - Constructor for class org.mule.module.json.transformers.JsonXsltTransformer
 
JSR250ValidatorProcessor - Class in org.mule.registry
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)
JSR250ValidatorProcessor() - Constructor for class org.mule.registry.JSR250ValidatorProcessor
Deprecated.
 
JSSE_NAMESPACE - Static variable in class org.mule.api.security.tls.TlsConfiguration
 
jToX - Variable in class org.mule.module.json.transformers.JsonSchemaXsdValidationFilter
Deprecated.
 
JXPathExpressionEvaluator - Class in org.mule.module.xml.expression
Deprecated.
Developers should use xpath, bean or groovy instead of this expression evaluator since there are some quirks with JXPath and the performance is not good.
JXPathExpressionEvaluator() - Constructor for class org.mule.module.xml.expression.JXPathExpressionEvaluator
Deprecated.
 
JXPathExtractor - Class in org.mule.module.xml.transformer
Deprecated.
This feature is deprecated and will be removed in Mule 4.0. Use MEL for extracting information out of a Java Object or the xpath3() MEL function in the case of an XML document
JXPathExtractor() - Constructor for class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
 
JXPathFilter - Class in org.mule.module.xml.filters
Deprecated.
This feature is deprecated and will be removed in Mule 4.0. Use an expression-filter for filtering based in a Java Object or the xpath-filter in the case of an XML document
JXPathFilter() - Constructor for class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
JXPathFilter(String) - Constructor for class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
JXPathFilter(String, String) - Constructor for class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 

K

KEEP_ALIVE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
KEEP_SEND_SOCKET_OPEN_PROPERTY - Static variable in class org.mule.transport.tcp.TcpConnector
Property can be set on the endpoint to configure how the socket is managed
KEEP_SEND_SOCKET_OPEN_PROPERTY - Static variable in class org.mule.transport.udp.UdpConnector
 
keepSendSocketOpen - Variable in class org.mule.transport.udp.UdpConnector
 
KEY - Static variable in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
KEY - Static variable in class org.mule.config.spring.parsers.collection.ChildMapEntryDefinitionParser
 
key - Variable in class org.mule.transaction.AbstractSingleResourceTransaction
 
key - Variable in class org.mule.transformer.simple.MapLookup
 
KEY_FINGERPRINT_CALCULATOR - Static variable in class org.mule.module.pgp.util.BouncyCastleUtil
 
KeyBasedEncryptionStrategy - Class in org.mule.module.pgp
 
KeyBasedEncryptionStrategy() - Constructor for class org.mule.module.pgp.KeyBasedEncryptionStrategy
 
KeyedPoolMessageDispatcherFactoryAdapter - Class in org.mule.transport
KeyedPoolMessageDispatcherFactoryAdapter adapts a MessageDispatcherFactory with methods from commons-pool KeyedPoolableObjectFactory.
KeyedPoolMessageDispatcherFactoryAdapter(MessageDispatcherFactory) - Constructor for class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
KeyedPoolMessageRequesterFactoryAdapter - Class in org.mule.transport
KeyedPoolMessageRequesterFactoryAdapter adapts a MessageRequesterFactory with methods from commons-pool KeyedPoolableObjectFactory.
KeyedPoolMessageRequesterFactoryAdapter(MessageRequesterFactory) - Constructor for class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
keySet() - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
keySet() - Method in class org.mule.el.context.InboundAttachmentMapContext
 
keySet() - Method in class org.mule.el.context.MessagePropertyMapContext
 
keySet() - Method in class org.mule.el.context.OutboundAttachmentMapContext
 
keySet() - Method in class org.mule.expression.InboundAttachmentsMap
 
keySet() - Method in class org.mule.expression.OutboundAttachmentsMap
 
keySet() - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
keySet() - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
keySet() - Method in class org.mule.module.http.internal.ParameterMap
 
keySet() - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
keySet() - Method in class org.mule.transport.http.multipart.MultiMap
 
keySet() - Method in class org.mule.util.CaseInsensitiveMapWrapper
 
keySet() - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
keySet() - Method in class org.mule.util.MapCombiner
 
keySet() - Method in class org.mule.util.store.ObjectStoreToMapAdapter
 
keySpec - Variable in class org.mule.security.AbstractJCEEncryptionStrategy
 
KeyStoreDefinitionParser - Class in org.mule.config.spring.parsers.specific.tls
 
KeyStoreDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.tls.KeyStoreDefinitionParser
 

L

last(MuleEvent, ProcessingTime, long, boolean) - Method in class org.mule.interceptor.AbstractEnvelopeInterceptor
This method is always invoked after the event has been processed,
last(MuleEvent, ProcessingTime, long, boolean) - Method in class org.mule.interceptor.LoggingInterceptor
 
last(MuleEvent, ProcessingTime, long, boolean) - Method in class org.mule.interceptor.ProcessingTimeInterceptor
 
LAST_MODIFIED - Static variable in class org.mule.module.http.api.HttpHeaders.Names
lastIndexOf(Object) - Method in class org.mule.module.launcher.util.ObservableList
 
LastItemWatermarkSelector - Class in org.mule.transport.polling.watermark.selector
Implementation of WatermarkSelector that selects the last value of the set.
LastItemWatermarkSelector() - Constructor for class org.mule.transport.polling.watermark.selector.LastItemWatermarkSelector
 
latch - Static variable in class org.mule.tck.util.FlowTraceUtils.FlowStackAsyncAsserter
 
Latch - Class in org.mule.util.concurrent
 
Latch() - Constructor for class org.mule.util.concurrent.Latch
 
LaxAsyncInterceptingMessageProcessor - Class in org.mule.processor
 
LaxAsyncInterceptingMessageProcessor(WorkManagerSource) - Constructor for class org.mule.processor.LaxAsyncInterceptingMessageProcessor
 
LaxAsyncInterceptingMessageProcessor(ThreadingProfile, String, int) - Constructor for class org.mule.processor.LaxAsyncInterceptingMessageProcessor
 
LaxInstantiationStrategyWrapper - Class in org.mule.config.spring.util
A InstantiationStrategy which doesn't fail if a bean cannot be instantiated, as long as such bean has been marked as optional in a OptionalObjectsController.
LaxInstantiationStrategyWrapper(InstantiationStrategy, OptionalObjectsController) - Constructor for class org.mule.config.spring.util.LaxInstantiationStrategyWrapper
 
LaxSedaStageInterceptingMessageProcessor - Class in org.mule.processor
Processes MuleEvent's asynchronously using a MuleWorkManager to schedule asynchronous processing of the next MessageProcessor.
LaxSedaStageInterceptingMessageProcessor(String, String, QueueProfile, int, ThreadingProfile, QueueStatistics, MuleContext) - Constructor for class org.mule.processor.LaxSedaStageInterceptingMessageProcessor
 
lazyInitWrapperManager() - Method in class org.mule.module.management.agent.WrapperManagerAgent
 
LazyList - Class in org.mule.transport.http.multipart
Lazy List creation.
LegacyEntryPointResolverSet - Class in org.mule.model.resolvers
An EntryPointResolverSet that mimics the behaviour of the Mule 1.x DynamicEntryPointResolver.
LegacyEntryPointResolverSet() - Constructor for class org.mule.model.resolvers.LegacyEntryPointResolverSet
 
LegacySessionHandler - Class in org.mule.session
Deprecated.
Since all properties are converted to Strings, this session handler has the issue EE-1705/MULE-4567. Use SerializeAndEncodeSessionHandler or SerializeOnlySessionHandler instead.
LegacySessionHandler() - Constructor for class org.mule.session.LegacySessionHandler
Deprecated.
 
legalizeFileName(String) - Static method in class org.mule.util.SystemUtils
Ensure a generated file name is legal.
LengthProtocol - Class in org.mule.transport.tcp.protocols
The LengthProtocol is an application level tcp protocol that can be used to transfer large amounts of data without risking some data to be loss.
LengthProtocol() - Constructor for class org.mule.transport.tcp.protocols.LengthProtocol
 
LengthProtocol(int) - Constructor for class org.mule.transport.tcp.protocols.LengthProtocol
 
level - Variable in class org.mule.api.processor.LoggerMessageProcessor
 
LF - Static variable in class org.mule.transport.http.multipart.MultiPartInputStream
 
LIB_FOLDER - Static variable in class org.mule.module.launcher.MuleFoldersUtil
 
libsDir - Variable in class org.mule.test.infrastructure.process.Controller
 
Lifecycle - Interface in org.mule.api.lifecycle
DefaultLifecyclePhase adds lifecycle methods start, stop and dispose.
LIFECYCLE_BYPASS_FLAG - Static variable in interface org.mule.api.registry.MuleRegistry
Pass this flag as metadata of the Registry.registerObject(String, Object, Object) method to have lifecycle method calls on the registered objects omitted.
LifecycleAdapter - Interface in org.mule.api.component
LifecycleAdapter is a wrapper around a pojo service that adds Lifecycle methods to the pojo.
LifecycleAdapterFactory - Interface in org.mule.api.component
LifecycleAdapterFactory TODO (document class)
lifecycleAdapterFactory - Variable in class org.mule.component.AbstractJavaComponent
 
lifecycleAdapterPool - Variable in class org.mule.component.PooledJavaComponent
 
LifecycleCallback<O> - Interface in org.mule.api.lifecycle
This callback is used to execute lifecycle behaviour for an object being managed by a LifecycleManager The callback is used so that transitions can be managed consistently outside of an object
lifecycleErrorCannotUseConnector(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
lifecycleEvent(LifecycleEvent) - Method in class org.mule.module.tomcat.MuleTomcatListener
 
LifecycleException - Exception in org.mule.api.lifecycle
LifecycleException TODO
LifecycleException(Message, Object) - Constructor for exception org.mule.api.lifecycle.LifecycleException
 
LifecycleException(Message, Throwable, Object) - Constructor for exception org.mule.api.lifecycle.LifecycleException
 
LifecycleException(Throwable, Object) - Constructor for exception org.mule.api.lifecycle.LifecycleException
 
LifecycleInterceptor - Interface in org.mule.api.lifecycle
Allows intercepting the application of lifecycle phases over each target object.
LifecycleManager - Interface in org.mule.api.lifecycle
The LifecycleManager is responsible for managing the different lifecycle phases of the server and managing the transitions between lifecycle phases.
lifecycleManager - Variable in class org.mule.component.AbstractComponent
 
lifecycleManager - Variable in class org.mule.construct.AbstractFlowConstruct
 
lifecycleManager - Variable in class org.mule.context.DefaultMuleContextBuilder
 
lifecycleManager - Variable in class org.mule.DefaultMuleContext
LifecycleManager for the MuleContext.
lifecycleManager - Variable in class org.mule.model.AbstractModel
Deprecated.
 
lifecycleManager - Variable in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
lifecycleManager - Variable in class org.mule.registry.AbstractRegistry
 
lifecycleManager - Variable in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
lifecycleManager - Variable in class org.mule.service.AbstractService
Deprecated.
 
lifecycleManager - Variable in class org.mule.transport.AbstractConnector
 
lifecycleManager - Variable in class org.mule.transport.AbstractTransportMessageHandler
 
lifecycleManagerId - Variable in class org.mule.lifecycle.AbstractLifecycleManager
 
lifecycleMethodCannotBeStatic(Method) - Static method in class org.mule.config.i18n.CoreMessages
 
lifecycleMethodCannotThrowChecked(Method) - Static method in class org.mule.config.i18n.CoreMessages
 
lifecycleMethodNotVoidOrHasParams(Method) - Static method in class org.mule.config.i18n.CoreMessages
 
LifecycleObject - Class in org.mule.lifecycle
 
LifecycleObject(Class) - Constructor for class org.mule.lifecycle.LifecycleObject
 
LifecyclePhase - Interface in org.mule.api.lifecycle
Encapsulates the notion of a lifecycle phase i.e.
lifecyclePhaseNotRecognised(String) - Static method in class org.mule.config.i18n.CoreMessages
 
LifecycleRegistry - Interface in org.mule.api.registry
A Registry which not only registers and fetches objects, but it's also capable of applying lifecycle and injects dependencies
LifecycleState - Interface in org.mule.api.lifecycle
A safe facade for lifecycle manager that objects can use to monitor its own state
lifecycleState - Variable in class org.mule.lifecycle.processor.ProcessIfStartedMessageProcessor
 
LifecycleStateAware - Interface in org.mule.api.lifecycle
Inject an objects lifecycle state.
LifecycleStateEnabled - Interface in org.mule.api.lifecycle
Objects that have an associated lifecycle manager such as Service or Connector should implement this interface so that the registry lifecycle manager can introspect the lifecycle state of an object.
LifecycleStateInjectorProcessor - Class in org.mule.registry
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)
LifecycleStateInjectorProcessor(LifecycleState) - Constructor for class org.mule.registry.LifecycleStateInjectorProcessor
Deprecated.
 
LifecycleStatePostProcessor - Class in org.mule.config.spring.processors
A BeanPostProcessor which sets a given LifecycleStatePostProcessor.state into instances of LifecycleStateAware
LifecycleStatePostProcessor(LifecycleState) - Constructor for class org.mule.config.spring.processors.LifecycleStatePostProcessor
 
LifecycleTransitionResult - Class in org.mule.api.lifecycle
Restrict possible results - only OK or a retry based on some throwable are currently allowed.
LifecycleTransitionResult() - Constructor for class org.mule.api.lifecycle.LifecycleTransitionResult
 
LifecycleUtils - Class in org.mule.api.lifecycle
 
lifecyleAwareMessageProcessorWrapper(MessageProcessor) - Static method in class org.mule.api.processor.MessageProcessors
 
LifecyleEnabledObjectPool - Interface in org.mule.util.pool
An ObjectPool that allows Start and Stop life-cycle to be propagated pooled object.
LinkedMuleCoreExtensionDependency - Class in org.mule.module.launcher.coreextension
Maps a core extension dependency class to a method in a dependant class
LinkedMuleCoreExtensionDependency(Class<? extends MuleCoreExtension>, Method) - Constructor for class org.mule.module.launcher.coreextension.LinkedMuleCoreExtensionDependency
 
list(String) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
list(Name) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
list(Name) - Method in class org.mule.jndi.SimpleContext
 
list(Attributes.Name) - Method in class org.mule.jndi.SimpleContext
 
list(String) - Method in class org.mule.jndi.SimpleContext
 
list(Name) - Method in class org.mule.tck.jndi.InMemoryContext
 
list(String) - Method in class org.mule.tck.jndi.InMemoryContext
 
LIST - Static variable in class org.mule.util.MapCombiner
 
list - Variable in class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
Deprecated.
 
LIST_PROPERTY - Static variable in interface org.mule.module.cxf.SoapConstants
 
LIST_SEPARATOR - Static variable in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
ListableObjectStore<T extends Serializable> - Interface in org.mule.api.store
 
ListableObjectStoreProducer<T extends Serializable> - Class in org.mule.streaming
Implementation of Producer to stream the contents of a ListableObjectStore
ListableObjectStoreProducer(ListableObjectStore<T>) - Constructor for class org.mule.streaming.ListableObjectStoreProducer
 
listAvailableEngines() - Method in class org.mule.module.scripting.component.Scriptable
 
listBindings(String) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
listBindings(Name) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
listBindings(Name) - Method in class org.mule.jndi.SimpleContext
 
listBindings(String) - Method in class org.mule.jndi.SimpleContext
 
listBindings(Name) - Method in class org.mule.tck.jndi.InMemoryContext
 
listBindings(String) - Method in class org.mule.tck.jndi.InMemoryContext
 
ListConsumer<T> - Class in org.mule.streaming
Implementation of Consumer that obains a List from a Producer and returns the elements one by one.
ListConsumer(Producer<List<T>>) - Constructor for class org.mule.streaming.ListConsumer
 
listCryptoImplementations(String) - Static method in class org.mule.util.DebugUtils
 
ListDataType<T> - Class in org.mule.transformer.types
Defines a List collection type with item type information
ListDataType() - Constructor for class org.mule.transformer.types.ListDataType
 
ListDataType(Class, String) - Constructor for class org.mule.transformer.types.ListDataType
 
ListDataType(Class) - Constructor for class org.mule.transformer.types.ListDataType
 
listDirectories() - Method in class org.mule.transport.sftp.SftpClient
 
listDirectories(String) - Method in class org.mule.transport.sftp.SftpClient
 
listener - Variable in class org.mule.source.StartableCompositeMessageSource
 
listener - Variable in class org.mule.transport.AbstractMessageReceiver
MessageProcessor chain used to process messages once the transport specific MessageReceiver has received transport message and created the MuleEvent
LISTENER_JMX_OBJECT_NAME - Static variable in class org.mule.module.management.agent.JmxServerNotificationAgent
 
listenerAlreadyRegistered(EndpointURI) - Static method in class org.mule.config.i18n.CoreMessages
 
ListenerPath - Class in org.mule.module.http.internal.listener
 
ListenerPath(String, String) - Constructor for class org.mule.module.http.internal.listener.ListenerPath
 
ListenerRequestMatcher - Class in org.mule.module.http.internal.listener.matcher
Request matcher for an http listener that accepts request based on a path and a group of allowed methods.
ListenerRequestMatcher(MethodRequestMatcher, String) - Constructor for class org.mule.module.http.internal.listener.matcher.ListenerRequestMatcher
 
listeners - Variable in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
The set of listeners for this Multicaster
ListenerSubscriptionPair - Class in org.mule.context.notification
A simple tuple that stores a listener with an optional subscription (used to match a resource ID).
ListenerSubscriptionPair() - Constructor for class org.mule.context.notification.ListenerSubscriptionPair
For config - must be constructed using the setters
ListenerSubscriptionPair(ServerNotificationListener) - Constructor for class org.mule.context.notification.ListenerSubscriptionPair
 
ListenerSubscriptionPair(ServerNotificationListener, String) - Constructor for class org.mule.context.notification.ListenerSubscriptionPair
 
listFiles() - Method in class org.mule.transport.ftp.FtpMessageReceiver
 
listFiles(FTPClient) - Method in class org.mule.transport.ftp.FtpMessageRequester
 
listFiles() - Method in class org.mule.transport.sftp.SftpClient
 
listFiles(String) - Method in class org.mule.transport.sftp.SftpClient
 
listItems(Collection<String>, String) - Method in class org.mule.util.SplashScreen
 
listItems(Map<String, String>, String) - Method in class org.mule.util.SplashScreen
 
listIterator() - Method in class org.mule.module.launcher.util.ObservableList
 
listIterator(int) - Method in class org.mule.module.launcher.util.ObservableList
 
listIterator(Object) - Static method in class org.mule.transport.http.multipart.LazyList
 
listJars(File) - Method in class org.mule.module.boot.DefaultMuleClassPathConfig
Find and if necessary filter the jars for classpath.
listJars(File) - Method in class org.mule.module.reboot.DefaultMuleClassPathConfig
Find and if necessary filter the jars for classpath.
listLibraries(ApplicationDescriptor) - Method in class org.mule.module.launcher.application.ApplicationStartedSplashScreen
 
ListMessageSplitter - Class in org.mule.routing.outbound
Deprecated.
ListMessageSplitter() - Constructor for class org.mule.routing.outbound.ListMessageSplitter
Deprecated.
 
listOverrides(ArtifactDescriptor) - Method in class org.mule.module.launcher.artifact.ArtifactStartedSplashScreen
 
ListPropertyDefinitionParser - Class in org.mule.config.spring.parsers.specific.properties
This allows a child element to extends a list of values, via an attribute, on a parent setter.
ListPropertyDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.specific.properties.ListPropertyDefinitionParser
 
ListPropertyDefinitionParser(String, String) - Constructor for class org.mule.config.spring.parsers.specific.properties.ListPropertyDefinitionParser
This method is to explain how things work.
ListResultSetHandler - Class in org.mule.module.db.internal.result.resultset
Processes a ResultSet returning a list of maps.
ListResultSetHandler(RowHandler) - Constructor for class org.mule.module.db.internal.result.resultset.ListResultSetHandler
 
listSecurityServiceTypes() - Static method in class org.mule.util.DebugUtils
 
listStoredFiles(File, List<Serializable>) - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
ListValueMap - Class in org.mule.config.spring.parsers.assembly.configuration
Be careful - this doesn't work with endpoint properties because they need to be converted to a URI.
ListValueMap() - Constructor for class org.mule.config.spring.parsers.assembly.configuration.ListValueMap
 
LiteralMessage - Class in org.mule.module.pgp
 
LiteralMessage(byte[]) - Constructor for class org.mule.module.pgp.LiteralMessage
 
load(String) - Method in class org.mule.api.security.tls.TlsProperties
 
loadAllProperties(String, ClassLoader) - Static method in class org.mule.util.PropertiesUtils
Load all properties files in the classpath with the given properties file name.
loadBeanDefinitions(DefaultListableBeanFactory) - Method in class org.mule.config.spring.MuleArtifactContext
 
loadClass(String) - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
loadClass(String, boolean) - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
loadClass(ClassLoader, String, boolean) - Method in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
loadClass(String, boolean) - Method in class org.mule.module.launcher.FineGrainedControlClassLoader
 
loadClass(String, Class<?>) - Static method in class org.mule.util.ClassUtils
Load a class with a given name.
loadClass(String, Class<?>, T) - Static method in class org.mule.util.ClassUtils
Load a class with a given name.
loadClass(String, ClassLoader) - Static method in class org.mule.util.ClassUtils
Load a class with a given name from the given classloader.
loadClass(String) - Method in class org.mule.util.scan.ClasspathScanner
Deprecated.
 
loadConfigResources(String[]) - Method in class org.mule.config.builders.AbstractResourceConfigurationBuilder
 
loadConfigResources(String[]) - Method in class org.mule.config.builders.WebappMuleXmlConfigurationBuilder
 
loadConfiguration(String) - Static method in class org.mule.tck.util.TestUtils
 
loadContext(Resource, String) - Method in class org.mule.config.spring.jndi.SpringInitialContextFactory
 
loadDatabaseName(String, String) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
 
loaderOverride - Variable in class org.mule.module.launcher.descriptor.ArtifactDescriptor
 
loadFromStore() - Method in class org.mule.util.store.TextFileObjectStore
 
loadGlobalFunctions() - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
loadKeyStore() - Method in class org.mule.api.security.tls.TlsConfiguration
 
loadOverrides() - Method in class org.mule.config.endpoint.ConfigurableTransportFactory
 
loadParentContext(ServletContext) - Method in class org.mule.config.builders.WebappMuleXmlConfigurationBuilder
Used to lookup parent spring ApplicationContext.
loadProperties(String, Class<?>) - Static method in class org.mule.util.PropertiesUtils
Read in the properties from a properties file.
loadProperties(URL) - Static method in class org.mule.util.PropertiesUtils
 
loadProperties(InputStream) - Static method in class org.mule.util.PropertiesUtils
 
loadResource(String) - Method in class org.mule.tck.FunctionalTestCase
Deprecated.
 
loadResource(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
 
loadResourceAsString(String) - Method in class org.mule.tck.FunctionalTestCase
Deprecated.
 
loadResourceAsString(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
 
loadSchemaStream(String) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
loadSource(MuleMessage) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
Load the source from the specified object.
LOCAL_CERTIFICATES - Static variable in class org.mule.transport.http.HttpsConnector
 
LOCAL_CERTIFICATES - Static variable in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
LOCAL_OBJECT_STORE_MANAGER_KEY - Static variable in class org.mule.DefaultMuleContext
 
LOCAL_PERSISTENT_OBJECT_STORE_KEY - Static variable in class org.mule.DefaultMuleContext
 
LOCAL_QUEUE_MANAGER_KEY - Static variable in class org.mule.DefaultMuleContext
 
LOCAL_TRANSIENT_OBJECT_STORE_KEY - Static variable in class org.mule.DefaultMuleContext
TODO: Remove these constants.
LocalClientMessageProcessorBuilder - Class in org.mule.module.cxf.builder
This builder uses a service that is already configured to build a CXF client and it's corresponding MessageProcessor.
LocalClientMessageProcessorBuilder() - Constructor for class org.mule.module.cxf.builder.LocalClientMessageProcessorBuilder
 
localContext - Variable in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
localContext - Variable in class org.mule.util.xa.DefaultXASession
 
locale - Variable in class org.mule.el.datetime.AbstractInstant
 
LocaleMessageHandler - Class in org.mule.config.i18n
The LocaleMessageHandler is essentially a merging of the Message and Messages classes, since there is no good reason to have them separate.
LocaleMessageHandler() - Constructor for class org.mule.config.i18n.LocaleMessageHandler
 
localhostBoundToAllLocalInterfaces() - Static method in class org.mule.transport.tcp.i18n.TcpMessages
 
LocalMuleClient - Interface in org.mule.api.client
Extends MuleClient adding methods that allow the use of an endpoint instance.
localMuleClient - Variable in class org.mule.DefaultMuleContext
 
LocalQueueTransactionContext - Interface in org.mule.util.queue
Specialization of QueueTransactionContext for local queue transactions
LocalQueueTxJournalEntry - Class in org.mule.util.journal.queue
JournalEntry for a local queue transaction
LocalQueueTxJournalEntry(int, byte, String, Serializable) - Constructor for class org.mule.util.journal.queue.LocalQueueTxJournalEntry
 
LocalQueueTxJournalEntry(int, byte) - Constructor for class org.mule.util.journal.queue.LocalQueueTxJournalEntry
 
LocalQueueTxJournalEntry(DataInputStream, MuleContext) - Constructor for class org.mule.util.journal.queue.LocalQueueTxJournalEntry
 
LocalResourceLocator - Interface in org.mule.module.launcher
 
LocalResourceResolverInput - Class in org.mule.module.xml.util
 
LocalResourceResolverInput() - Constructor for class org.mule.module.xml.util.LocalResourceResolverInput
 
LocalSocketTcpMessageDispatcher - Class in org.mule.transport.tcp
LocalSocketTcpMessageDispatcher will send transformed Mule events over TCP.
LocalSocketTcpMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.tcp.LocalSocketTcpMessageDispatcher
 
LocalSocketTcpMessageDispatcherFactory - Class in org.mule.transport.tcp
A factory for LocalSocketTcpMessageDispatcher
LocalSocketTcpMessageDispatcherFactory() - Constructor for class org.mule.transport.tcp.LocalSocketTcpMessageDispatcherFactory
 
LocalTxQueueTransactionContext - Class in org.mule.util.queue
Default LocalQueueTransactionContext implementation for a queue.
LocalTxQueueTransactionContext(LocalTxQueueTransactionJournal, QueueProvider, Lock) - Constructor for class org.mule.util.queue.LocalTxQueueTransactionContext
 
LocalTxQueueTransactionJournal - Class in org.mule.util.journal.queue
Journal for operations done to a queue within a transactional context
LocalTxQueueTransactionJournal(String, MuleContext, Integer) - Constructor for class org.mule.util.journal.queue.LocalTxQueueTransactionJournal
 
LocalTxQueueTransactionJournal(String, MuleContext) - Constructor for class org.mule.util.journal.queue.LocalTxQueueTransactionJournal
 
LocalTxQueueTransactionRecoverer - Class in org.mule.util.journal.queue
Process for recover pending transactions after a server crash.
LocalTxQueueTransactionRecoverer(LocalTxQueueTransactionJournal, QueueProvider) - Constructor for class org.mule.util.journal.queue.LocalTxQueueTransactionRecoverer
 
LocalURIResolver - Class in org.mule.module.xml.util
Will look for the href file on the classpath
LocalURIResolver() - Constructor for class org.mule.module.xml.util.LocalURIResolver
 
LocalURIResolver(String) - Constructor for class org.mule.module.xml.util.LocalURIResolver
 
localXid - Variable in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
localXid - Variable in class org.mule.util.xa.DefaultXASession
 
locateConnectorOperation(String, OperationOptions, MessageExchangePattern) - Method in interface org.mule.api.connector.ConnectorOperationLocator
Lookup for an operation from a connector
locateConnectorOperation(String, OperationOptions, MessageExchangePattern) - Method in class org.mule.connector.MuleConnectorOperationLocator
 
LocatedMuleException - Exception in org.mule.api
LocatedMuleException is a general exception that adds context location about the Exception (i.e.: where it occurred in the application).
LocatedMuleException(Object) - Constructor for exception org.mule.api.LocatedMuleException
 
LocatedMuleException(Message, Object) - Constructor for exception org.mule.api.LocatedMuleException
 
LocatedMuleException(Message, Throwable, Object) - Constructor for exception org.mule.api.LocatedMuleException
 
LocatedMuleException(Throwable, Object) - Constructor for exception org.mule.api.LocatedMuleException
 
locateServer - Variable in class org.mule.module.management.agent.AbstractJmxAgent
Should MBeanServer be discovered.
locateServer - Variable in class org.mule.module.management.agent.JmxAgentConfigurer
Should MBeanServer be discovered.
LOCATION - Static variable in class org.mule.module.http.api.HttpHeaders.Names
LocationExecutionContextProvider - Class in org.mule.api.execution
Provides a standard way to generate a log entry or message that references an element in a flow.
LocationExecutionContextProvider() - Constructor for class org.mule.api.execution.LocationExecutionContextProvider
 
lock - Variable in class org.mule.routing.EventProcessingThread
 
lock() - Method in class org.mule.tck.util.FakeLock
 
lock - Variable in class org.mule.util.concurrent.AbstractSynchronizedVariable
 
lock(String) - Method in class org.mule.util.lock.InstanceLockGroup
 
lock() - Method in class org.mule.util.lock.LockAdapter
 
lock(String) - Method in interface org.mule.util.lock.LockGroup
 
LockAdapter - Class in org.mule.util.lock
Implementation of Lock that delegates the locking mechanism to a LockGroup but looks like a regular lock from the client's perspective
LockAdapter(String, LockGroup) - Constructor for class org.mule.util.lock.LockAdapter
 
LockFactory - Interface in org.mule.util.lock
Factory for creating Lock instances.
lockForReading() - Method in class org.mule.registry.TransientRegistry.RegistryMap
Deprecated.
 
LockGroup - Interface in org.mule.util.lock
Holds reference to all the obtained locks using LockFactory in order to release memory of no longer referenced locks.
lockInterruptibly() - Method in class org.mule.tck.util.FakeLock
 
lockInterruptibly(String) - Method in class org.mule.util.lock.InstanceLockGroup
 
lockInterruptibly() - Method in class org.mule.util.lock.LockAdapter
 
lockInterruptibly(String) - Method in interface org.mule.util.lock.LockGroup
 
LockProvider - Interface in org.mule.util.lock
Provides abstraction in the creation and destruction of Mule locks.
locks - Variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
log(String) - Method in interface org.mule.api.component.simple.LogService
 
log(MuleEvent) - Method in class org.mule.api.processor.LoggerMessageProcessor
 
log(Log, Object) - Method in enum org.mule.api.processor.LoggerMessageProcessor.LogLevel
 
log(String) - Method in class org.mule.component.simple.LogComponent
 
log - Static variable in class org.mule.module.jbpm.Jbpm
 
log - Variable in class org.mule.processor.chain.AbstractMessageProcessorChain
 
log - Static variable in class org.mule.source.StartableCompositeMessageSource
 
log(Matcher<File>) - Static method in class org.mule.test.infrastructure.process.VerifyLogWithMatcher
 
log(String, Matcher<File>) - Static method in class org.mule.test.infrastructure.process.VerifyLogWithMatcher
 
log - Static variable in class org.mule.transport.soap.axis.extensions.MuleHttpSender
Deprecated.
 
log - Variable in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
Log4jAgent - Class in org.mule.module.management.agent
Deprecated.
deprecated since Mule 3.6.0. This will no longer function since log4j2 supports JMX out of the box. Check migration guide for more information
Log4jAgent() - Constructor for class org.mule.module.management.agent.Log4jAgent
Deprecated.
 
Log4jNotificationLoggerAgent - Class in org.mule.agent
AbstractNotificationLoggerAgent Receives Mule server notifications and logs them and can optionally route them to an endpoint
Log4jNotificationLoggerAgent() - Constructor for class org.mule.agent.Log4jNotificationLoggerAgent
 
LOG_CONFIGURATION_FACTORY_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
LOG_CONTEXT_SELECTOR_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
***************************************************************************** Logging properties *****************************************************************************
LOG_PORT_PROPERTY - Static variable in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
logAdd(T, QueueStore, Serializable) - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
 
logAddFirst(T, QueueStore, Serializable) - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
 
logBoilerPlate(List) - Method in class org.mule.util.MuleLogger
 
logBoilerPlate(String[]) - Method in class org.mule.util.MuleLogger
 
logCheckpointOperation(JournalEntry<T>) - Method in class org.mule.util.journal.TransactionJournal
Logs a checkpoint operation over the transactions.
logCommit(T) - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
 
LogComponent - Class in org.mule.component.simple
LogComponent simply logs the content (or content length if it is a large message)
LogComponent() - Constructor for class org.mule.component.simple.LogComponent
 
LogConfigChangeSubject - Interface in org.mule.logging
Observable that dispatches calls to registered listeners when the inner log configuration is changed.
logConfigurationWarning(String, String, Throwable) - Static method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
logContent(MuleEvent) - Method in class org.mule.module.oauth2.internal.MuleEventLogger
Logs the event message payload type, the payload as string and the message properties.
logCreationWarning(String, String, Throwable) - Static method in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
logEvent(ServerNotification) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
logEvent(ServerNotification) - Method in class org.mule.agent.EndpointNotificationLoggerAgent
 
logEvent(ServerNotification) - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
logEvent(ServerNotification) - Method in class org.mule.module.management.agent.JmxServerNotificationAgent
 
logEventCreated(LogEvent) - Method in class org.mule.module.drools.WorkingMemorySLF4JLogger
 
logException - Variable in class org.mule.exception.AbstractExceptionListener
 
logException(Throwable, MuleEvent) - Method in class org.mule.exception.AbstractExceptionListener
Used to log the error passed into this Exception Listener
logFatal(MuleEvent, Throwable) - Method in class org.mule.exception.AbstractExceptionListener
Logs a fatal error message to the logging system.
logger - Variable in class org.glassfish.jersey.message.internal.DocumentBuilderFactoryInjectionProvider
 
logger - Variable in class org.glassfish.jersey.message.internal.SaxParserFactoryInjectionProvider
 
logger - Variable in class org.mule.agent.AbstractNotificationLoggerAgent
The logger used for this class
logger - Variable in class org.mule.api.processor.LoggerMessageProcessor
 
logger - Variable in class org.mule.api.registry.AbstractServiceDescriptor
logger used by this class
logger - Static variable in class org.mule.api.registry.ServiceDescriptorFactory
 
logger - Variable in class org.mule.api.schedule.SchedulerFactory
 
logger - Variable in class org.mule.component.AbstractComponent
logger used by this class
logger - Static variable in class org.mule.component.BindingInvocationHandler
 
logger - Variable in class org.mule.component.ComponentLifecycleManager
logger used by this class
logger - Static variable in class org.mule.component.DefaultComponentLifecycleAdapter
logger used by this class
logger - Static variable in class org.mule.component.DefaultInterfaceBinding
 
logger - Variable in class org.mule.config.bootstrap.AbstractRegistryBootstrap
 
logger - Variable in class org.mule.config.builders.AbstractConfigurationBuilder
 
logger - Variable in class org.mule.config.builders.DeployableMuleXmlContextListener
 
logger - Variable in class org.mule.config.builders.MuleXmlBuilderContextListener
 
logger - Variable in class org.mule.config.builders.WebappMuleXmlConfigurationBuilder
Logger used by this class
logger - Static variable in class org.mule.config.DefaultMuleConfiguration
 
logger - Variable in class org.mule.config.dsl.ModelBuilder
Deprecated.
 
logger - Variable in class org.mule.config.endpoint.RegistryBackedAnnotationsParserFactory
logger used by this class
logger - Static variable in class org.mule.config.ExceptionHelper
logger used by this class
logger - Static variable in class org.mule.config.expression.ExpressionAnnotationsHelper
 
logger - Static variable in class org.mule.config.factories.HostNameFactory
 
logger - Static variable in class org.mule.config.i18n.LocaleMessageHandler
logger used by this class
logger - Variable in class org.mule.config.i18n.MessageFactory
 
logger - Static variable in class org.mule.config.MuleManifest
logger used by this class
logger - Variable in class org.mule.config.pool.DefaultThreadPoolFactory
 
logger - Variable in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
logger used by this class
logger - Variable in class org.mule.config.processors.LookupInjectionProcessor
Deprecated.
logger used by this class
logger - Variable in class org.mule.config.spring.factories.AbstractEndpointFactoryBean
 
logger - Variable in class org.mule.config.spring.factories.AbstractQueueStoreFactoryBean
 
logger - Variable in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
logger - Variable in class org.mule.config.spring.MuleConfigurationConfigurator
 
logger - Static variable in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
logger - Variable in class org.mule.config.spring.MuleResourceLoader
 
logger - Variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
logger used by this class
logger - Variable in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
logger - Variable in class org.mule.config.spring.util.SystemPropertyInitializingBean
 
logger - Variable in class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
logger used by this class
logger - Variable in class org.mule.construct.AbstractFlowConstruct
 
logger - Variable in class org.mule.construct.FlowConstructLifecycleManager
logger used by this class
logger - Static variable in class org.mule.context.DefaultMuleContextBuilder
 
logger - Static variable in class org.mule.context.DefaultMuleContextFactory
 
logger - Static variable in class org.mule.context.notification.BaseConnectorMessageNotification
logger used by this class
logger - Variable in class org.mule.context.notification.ServerNotificationManager
 
logger - Static variable in class org.mule.DefaultMuleEventContext
logger used by this class
logger - Static variable in class org.mule.endpoint.AbstractEndpoint
logger used by this class
logger - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
logger - Static variable in class org.mule.endpoint.DefaultEndpointFactory
logger used by this class
logger - Variable in class org.mule.endpoint.DynamicOutboundEndpoint
 
logger - Variable in class org.mule.endpoint.DynamicURIBuilder
 
logger - Variable in class org.mule.endpoint.inbound.InboundLoggingMessageProcessor
 
logger - Static variable in class org.mule.endpoint.MuleEndpointURI
logger used by this class
logger - Variable in class org.mule.endpoint.outbound.OutboundLoggingMessageProcessor
 
logger - Static variable in class org.mule.endpoint.ResourceNameEndpointURIBuilder
 
logger - Variable in class org.mule.endpoint.URIBuilderBeanInfo
 
logger - Variable in class org.mule.exception.AbstractExceptionListener
 
logger - Variable in class org.mule.execution.AsyncResponseFlowProcessingPhase
 
logger - Variable in class org.mule.execution.FlowProcessingPhase
 
logger - Variable in class org.mule.execution.NotificationFiringProcessingPhase
 
logger - Static variable in class org.mule.expression.DefaultExpressionManager
logger used by this class
logger - Variable in class org.mule.expression.EndpointInfoExpressionEvaluator
logger used by this class
logger - Variable in class org.mule.expression.MessageExpressionEvaluator
logger used by this class
logger - Variable in class org.mule.expression.MessagePayloadExpressionEvaluator
logger used by this class
logger - Variable in class org.mule.expression.MessageProcessorExpressionEvaluator
 
logger - Variable in class org.mule.expression.OutboundAttachmentsExpressionEvaluator
logger used by this class
logger - Variable in class org.mule.expression.OutboundHeadersExpressionEvaluator
logger used by this class
logger - Variable in class org.mule.expression.RegistryExpressionEvaluator
logger used by this class
logger - Variable in class org.mule.keygenerator.ExpressionMuleEventKeyGenerator
 
logger - Variable in class org.mule.keygenerator.MD5MuleEventKeyGenerator
Deprecated.
 
logger - Variable in class org.mule.lifecycle.AbstractLifecycleManager
logger used by this class
logger - Variable in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
logger - Variable in class org.mule.lifecycle.PrimaryNodeLifecycleNotificationListener
 
logger - Variable in class org.mule.model.AbstractModel
Deprecated.
 
logger - Static variable in class org.mule.module.atom.AbderaServiceComponent.AbderaCallable
 
logger - Variable in class org.mule.module.atom.routing.FeedSplitter
logger used by this class
logger - Variable in class org.mule.module.boot.MuleSystemClassLoader
 
logger - Static variable in class org.mule.module.bpm.Process
 
logger - Static variable in class org.mule.module.bpm.Rules
 
logger - Static variable in class org.mule.module.client.MuleClient
logger used by this class
logger - Static variable in class org.mule.module.client.RemoteDispatcher
Deprecated.
logger used by this class
logger - Static variable in class org.mule.module.client.remoting.RemoteDispatcherAgent
Deprecated.
logger used by this class
logger - Static variable in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
logger used by this class
logger - Variable in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
logger - Variable in class org.mule.module.cxf.component.AbstractWebServiceWrapperComponent
 
logger - Variable in class org.mule.module.cxf.CxfConfiguration
 
logger - Variable in class org.mule.module.cxf.CxfInboundMessageProcessor
logger used by this class
logger - Variable in class org.mule.module.cxf.support.ProxyFaultOutInterceptor
 
logger - Static variable in class org.mule.module.cxf.WSProxyService
Deprecated.
 
logger - Variable in class org.mule.module.db.internal.domain.connection.TransactionalDbConnectionFactory
 
logger - Variable in class org.mule.module.db.internal.domain.executor.AbstractExecutor
 
logger - Static variable in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
logger - Static variable in class org.mule.module.db.internal.result.resultset.ResultSetIterator
 
logger - Static variable in class org.mule.module.db.internal.result.statement.AbstractStreamingResultSetCloser
 
logger - Static variable in class org.mule.module.db.internal.result.statement.CloseableMap
 
logger - Static variable in class org.mule.module.drools.Drools
 
logger - Variable in class org.mule.module.drools.WorkingMemorySLF4JLogger
 
logger - Variable in class org.mule.module.json.filters.IsJsonFilter
logger used by this class
logger - Variable in class org.mule.module.json.JsonExpressionEvaluator
logger used by this class
logger - Variable in class org.mule.module.json.transformers.JsonTransformerResolver
logger used by this class
logger - Variable in class org.mule.module.json.transformers.ObjectToJson
logger used by this class
logger - Variable in class org.mule.module.launcher.AbstractFileWatcher
 
logger - Static variable in class org.mule.module.launcher.application.CompositeApplicationClassLoader
 
logger - Variable in class org.mule.module.launcher.application.DefaultMuleApplication
 
logger - Variable in class org.mule.module.launcher.artifact.AbstractArtifactClassLoader
 
logger - Variable in class org.mule.module.launcher.ArtifactArchiveInstaller
 
logger - Static variable in class org.mule.module.launcher.coreextension.DefaultMuleCoreExtensionManager
 
logger - Variable in class org.mule.module.launcher.DefaultArtifactDeployer
 
logger - Variable in class org.mule.module.launcher.DeploymentDirectoryWatcher
 
logger - Variable in class org.mule.module.launcher.domain.DefaultMuleDomain
 
logger - Variable in class org.mule.module.launcher.MuleDeploymentService
 
logger - Variable in class org.mule.module.launcher.nativelib.PerAppCopyNativeLibraryFinder
 
logger - Variable in class org.mule.module.launcher.StartupSummaryDeploymentListener
 
logger - Static variable in class org.mule.module.management.agent.AbstractJmxAgent
Logger used by this class
logger - Variable in class org.mule.module.management.agent.ClassloaderSwitchingMBeanWrapper
 
logger - Static variable in class org.mule.module.management.agent.JmxAgentConfigurer
Logger used by this class
logger - Variable in class org.mule.module.management.agent.RmiRegistryAgent
logger used by this class
logger - Static variable in class org.mule.module.management.agent.YourKitProfilerAgent
Logger used by this class
logger - Variable in class org.mule.module.management.mbean.EndpointService
logger used by this class
logger - Variable in class org.mule.module.management.mbean.MuleService
logger used by this class
logger - Static variable in class org.mule.module.management.mbean.StatisticsService
logger used by this class
logger - Variable in class org.mule.module.management.mbean.YourKitProfilerService
logger used by this class
logger - Static variable in class org.mule.module.management.support.SimplePasswordJmxAuthenticator
Logger used by this class.
logger - Variable in class org.mule.module.oauth2.internal.AbstractTokenRequestHandler
 
logger - Variable in class org.mule.module.oauth2.internal.authorizationcode.AbstractAuthorizationCodeTokenRequestHandler
 
logger - Variable in class org.mule.module.oauth2.internal.TokenResponseProcessor
 
logger - Variable in class org.mule.module.ognl.expression.OgnlExpressionEvaluator
logger used by this class
logger - Variable in class org.mule.module.ognl.filters.OGNLFilter
 
logger - Static variable in class org.mule.module.pgp.KeyBasedEncryptionStrategy
logger used by this class
logger - Static variable in class org.mule.module.pgp.PGPKeyRingImpl
 
logger - Variable in class org.mule.module.rss.routing.FeedSplitter
logger used by this class
logger - Variable in class org.mule.module.scripting.component.Scriptable
 
logger - Static variable in class org.mule.module.spring.events.AsynchronousEventListener
Deprecated.
logger used by this class
logger - Static variable in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
logger used by this class
logger - Variable in class org.mule.module.spring.security.AuthorizationFilter
 
logger - Variable in class org.mule.module.sxc.SxcFilter
 
logger - Variable in class org.mule.module.xml.expression.JXPathExpressionEvaluator
Deprecated.
logger used by this class
logger - Variable in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
logger - Variable in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
logger - Variable in class org.mule.module.xml.filters.SchemaValidationFilter
 
logger - Variable in class org.mule.module.xml.filters.XPathFilter
 
logger - Variable in class org.mule.module.xml.transformer.jaxb.JAXBTransformerResolver
logger used by this class
logger - Variable in class org.mule.modules.schedulers.cron.CronScheduler
 
logger - Variable in class org.mule.object.AbstractObjectFactory
 
logger - Variable in class org.mule.object.JndiObjectFactory
 
logger - Variable in class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
logger - Variable in class org.mule.processor.AsyncDelegateMessageProcessor
 
logger - Variable in class org.mule.processor.AsyncWorkListener
 
logger - Variable in class org.mule.processor.IdempotentRedeliveryPolicy
 
logger - Variable in class org.mule.processor.InvokerMessageProcessor
 
logger - Variable in class org.mule.processor.SedaStageLifecycleManager
logger used by this class
logger - Variable in class org.mule.registry.AbstractRegistry
 
logger - Variable in class org.mule.registry.MuleRegistryHelper
 
logger - Variable in class org.mule.registry.TypeBasedTransformerResolver
logger used by this class
logger - Variable in class org.mule.retry.async.RetryWorker
 
logger - Variable in class org.mule.retry.notifiers.ConnectNotifier
 
logger - Variable in class org.mule.retry.policies.AbstractPolicyTemplate
 
logger - Static variable in class org.mule.retry.policies.SimpleRetryPolicy
 
logger - Variable in class org.mule.retry.policies.SimpleRetryPolicyTemplate
logger used by this class
logger - Variable in class org.mule.routing.AbstractCatchAllStrategy
Deprecated.
logger used by this class
logger - Variable in class org.mule.routing.AbstractMatchingRouter
logger used by this class
logger - Static variable in class org.mule.routing.AbstractRoutingStrategy
logger used by this class
logger - Variable in class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
 
logger - Variable in class org.mule.routing.correlation.CollectionCorrelatorCallback
logger used by this class
logger - Variable in class org.mule.routing.correlation.EventCorrelator
logger used by this class
logger - Variable in class org.mule.routing.EventProcessingThread
 
logger - Variable in class org.mule.routing.filters.ExpressionFilter
logger used by this class
logger - Variable in class org.mule.routing.filters.MessagePropertyFilter
logger used by this class
logger - Variable in class org.mule.routing.filters.RegExFilter
 
logger - Variable in class org.mule.routing.filters.WildcardFilter
 
logger - Variable in class org.mule.routing.Foreach
 
logger - Variable in class org.mule.routing.MulticastingRoutingStrategy
 
logger - Variable in class org.mule.routing.outbound.AbstractOutboundRouter
logger used by this class
logger - Variable in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
logger used by this class
logger - Variable in class org.mule.routing.SynchronousUntilSuccessfulProcessingStrategy
 
logger - Variable in class org.mule.routing.WireTap
 
logger - Variable in class org.mule.security.AbstractJCEEncryptionStrategy
logger used by this class
logger - Variable in class org.mule.security.AbstractSecurityFilter
 
logger - Static variable in class org.mule.security.MuleSecurityManager
logger used by this class
logger - Variable in class org.mule.service.AbstractService
Deprecated.
logger used by this class
logger - Variable in class org.mule.service.processor.ServiceLoggingMessageProcessor
Deprecated.
 
logger - Variable in class org.mule.service.ServiceLifecycleManager
Deprecated.
logger used by this class
logger - Variable in class org.mule.session.LegacySessionHandler
Deprecated.
 
logger - Variable in class org.mule.session.SerializeOnlySessionHandler
 
logger - Variable in class org.mule.session.SimpleSessionHandler
 
logger - Static variable in class org.mule.source.ClusterizableMessageSourceWrapper
 
logger - Variable in class org.mule.tck.functional.FunctionalStreamingTestComponent
 
logger - Variable in class org.mule.tck.functional.FunctionalTestComponent
 
logger - Static variable in class org.mule.tck.security.TestSecurityComponent
 
logger - Variable in class org.mule.tck.security.TestSingleUserSecurityProvider
 
logger - Static variable in class org.mule.tck.testmodels.services.TestComponent
 
logger - Static variable in class org.mule.tck.testmodels.services.TestReceiver
 
logger - Variable in class org.mule.tck.util.ftp.FtpClient
 
logger - Static variable in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
logger - Variable in class org.mule.transaction.AbstractTransaction
 
logger - Variable in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
logger - Static variable in class org.mule.transaction.MuleTransactionConfig
logger used by this class
logger - Static variable in class org.mule.transaction.TransactionCoordination
 
logger - Variable in class org.mule.transformer.AbstractTransformer
 
logger - Variable in class org.mule.transformer.graph.CompositeConverterFilter
 
logger - Variable in class org.mule.transformer.graph.TransformationGraph
 
logger - Variable in class org.mule.transformer.graph.TransformationGraphLookupStrategy
 
logger - Variable in class org.mule.transformer.wire.TransformerPairWireFormat
logger used by this class
logger - Variable in class org.mule.transport.AbstractConnector
logger used by this class
logger - Variable in class org.mule.transport.AbstractTransportMessageHandler
 
logger - Variable in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
logger - Static variable in class org.mule.transport.ConcurrentWorkTracker
 
logger - Variable in class org.mule.transport.DefaultReplyToHandler
logger used by this class
logger - Variable in class org.mule.transport.email.filters.AbstractMailFilter
logger used by this class
logger - Variable in class org.mule.transport.http.components.RestServiceWrapper
logger used by this class
logger - Static variable in class org.mule.transport.http.CookieHelper
logger used by this class
logger - Static variable in class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
logger used by this class
logger - Variable in class org.mule.transport.jdbc.sqlstrategy.SelectSqlStatementStrategy
 
logger - Variable in class org.mule.transport.jdbc.sqlstrategy.SimpleUpdateSqlStatementStrategy
 
logger - Static variable in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
logger - Static variable in class org.mule.transport.jms.DefaultJmsTopicResolver
logger used by this class
logger - Variable in class org.mule.transport.jms.Jms11Support
logger used by this class
logger - Variable in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
logger - Variable in class org.mule.transport.jms.redelivery.AutoDiscoveryRedeliveryHandlerFactory
 
logger - Static variable in class org.mule.transport.jms.redelivery.CountingRedeliveryHandler
logger used by this class
logger - Static variable in class org.mule.transport.jms.redelivery.JmsXRedeliveryHandler
logger used by this class
logger - Variable in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
logger - Variable in class org.mule.transport.jms.ReusableSessionWrapper
 
logger - Variable in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
logger - Static variable in class org.mule.transport.jms.xa.DefaultXAConnectionFactoryWrapper
logger used by this class
logger - Static variable in class org.mule.transport.jms.xa.SessionInvocationHandler
 
logger - Variable in class org.mule.transport.polling.schedule.FixedFrequencyScheduler
 
logger - Variable in class org.mule.transport.quartz.jobs.EndpointPollingJob
The logger used for this class
logger - Variable in class org.mule.transport.quartz.jobs.EventGeneratorJob
The logger used for this class
logger - Variable in class org.mule.transport.quartz.jobs.ScheduledDispatchJob
The logger used for this class
logger - Static variable in class org.mule.transport.service.TransportFactory
logger used by this class
logger - Variable in class org.mule.transport.servlet.AbstractReceiverServlet
logger used by this class
logger - Variable in class org.mule.transport.servlet.jetty.AbstractConnectorHolder
logger used by this class
logger - Static variable in class org.mule.transport.sftp.notification.SftpTransportNotification
logger used by this class
logger - Static variable in class org.mule.transport.sftp.SftpConnector
logger used by this class
logger - Static variable in class org.mule.transport.soap.axis.AxisInitialisationCallback
 
logger - Static variable in class org.mule.transport.soap.axis.AxisServiceComponent
 
logger - Static variable in class org.mule.transport.soap.axis.extensions.MuleSoapHeadersHandler
logger used by this class
logger - Variable in class org.mule.transport.soap.axis.extensions.UniversalSender
logger used by this class
logger - Variable in class org.mule.transport.tcp.TcpServerSocketFactory
 
logger - Static variable in class org.mule.transport.TrackingWorkManager
 
logger - Variable in class org.mule.transport.TransportMessageProcessContext
 
logger - Variable in class org.mule.transport.udp.UdpSocketFactory
logger used by this class
logger - Variable in class org.mule.transport.xmpp.AbstractXmppConversation
 
logger - Variable in class org.mule.util.concurrent.LoggingUncaughtExceptionHandler
 
logger - Variable in class org.mule.util.ExceptionHolder
 
logger - Variable in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
 
logger - Static variable in class org.mule.util.monitor.ExpiryMonitor
logger used by this class
logger - Static variable in class org.mule.util.ObjectUtils
logger used by this class
logger - Static variable in class org.mule.util.pool.CommonsPoolObjectPool
logger used by this class
logger - Static variable in class org.mule.util.pool.DefaultLifecycleEnabledObjectPool
logger used by this class
logger - Variable in class org.mule.util.queue.AbstractQueueManager
 
logger - Variable in class org.mule.util.queue.DelegateQueueManager
 
logger - Variable in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
logger - Variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
logger - Variable in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
logger used by this class
logger - Variable in class org.mule.util.queue.TransactionAwareQueueStore
 
logger - Variable in class org.mule.util.scan.annotations.MetaAnnotationTypeFilter
Deprecated.
logger used by this class
logger - Variable in class org.mule.util.scan.ClasspathScanner
Deprecated.
logger used by this class
logger - Variable in class org.mule.util.store.AbstractMonitoredObjectStore
 
logger - Variable in class org.mule.util.store.AbstractObjectStore
 
logger - Variable in class org.mule.util.store.AbstractPartitionedObjectStore
 
logger - Variable in class org.mule.util.store.PersistentObjectStorePartition
 
logger - Static variable in class org.mule.util.SystemUtils
 
logger - Static variable in class org.mule.util.TemplateParser
logger used by this class
logger - Variable in class org.mule.util.xa.AbstractResourceManager
 
logger - Variable in class org.mule.util.xa.DefaultXASession
 
logger - Variable in class org.mule.util.xa.XaTransactionRecoverer
 
logger - Variable in class org.mule.work.DefaultWorkListener
logger used by this class
logger - Static variable in class org.mule.work.MuleWorkManager
logger used by this class
logger - Static variable in class org.mule.work.WorkerContext
logger used by this class
LoggerMessageProcessor - Class in org.mule.api.processor
MessageProcessor implementation that logs the current element of a value evaluated from it using an expression evaluator.
LoggerMessageProcessor() - Constructor for class org.mule.api.processor.LoggerMessageProcessor
 
LoggerMessageProcessor.LogLevel - Enum in org.mule.api.processor
 
LoggerTransportCustomizer - Class in org.mule.module.http.internal.request.grizzly
Transport customizer that adds a probe for logging HTTP messages.
LoggerTransportCustomizer() - Constructor for class org.mule.module.http.internal.request.grizzly.LoggerTransportCustomizer
 
LoggingCatchAllStrategy - Class in org.mule.routing
Deprecated.
LoggingCatchAllStrategy() - Constructor for class org.mule.routing.LoggingCatchAllStrategy
Deprecated.
 
LoggingInterceptor - Class in org.mule.interceptor
LoggingInterceptor is a simple interceptor that logs a message before and after the event processing.
LoggingInterceptor() - Constructor for class org.mule.interceptor.LoggingInterceptor
 
LoggingUncaughtExceptionHandler - Class in org.mule.util.concurrent
 
LoggingUncaughtExceptionHandler() - Constructor for class org.mule.util.concurrent.LoggingUncaughtExceptionHandler
 
login() - Method in class org.mule.module.jaas.loginmodule.DefaultLoginModule
This method attempts to login the user by checking his credentials against those of the authorised users.
login(String, String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
login(String, String) - Method in class org.mule.transport.sftp.SftpClient
 
login(String, String, String) - Method in class org.mule.transport.sftp.SftpClient
 
LOGIN_TIMEOUT_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
loginTimeout - Variable in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
logout() - Method in class org.mule.module.jaas.loginmodule.DefaultLoginModule
Returns true when authentication succeeds or false when it fails
logout() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
logPrepare(Xid) - Method in class org.mule.util.journal.queue.XaTxQueueTransactionJournal
 
logQuery() - Method in class org.mule.module.db.internal.domain.logger.AbstractDebugQueryLogger
 
logQuery() - Method in class org.mule.module.db.internal.domain.logger.AbstractNullQueryLogger
 
logQuery() - Method in interface org.mule.module.db.internal.domain.logger.QueryLogger
 
logRemove(T, QueueStore, Serializable) - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
 
logRollback(T) - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
 
LogService - Interface in org.mule.api.component.simple
 
logSummary() - Method in class org.mule.management.stats.AllStatistics
 
logSummary(PrintWriter) - Method in class org.mule.management.stats.AllStatistics
 
logSummary() - Method in class org.mule.management.stats.ComponentStatistics
 
logSummary(PrintWriter) - Method in class org.mule.management.stats.ComponentStatistics
 
logSummary() - Method in class org.mule.management.stats.RouterStatistics
 
logSummary(PrintWriter) - Method in class org.mule.management.stats.RouterStatistics
 
logSummary() - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
logSummary(PrintWriter) - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
logSummary() - Method in class org.mule.module.management.mbean.StatisticsService
 
logUpdateOperation(JournalEntry<T>) - Method in class org.mule.util.journal.TransactionJournal
Log an update operation over a transactional resource
logWithLevel(Object) - Method in class org.mule.api.processor.LoggerMessageProcessor
 
LONG_ERROR - Static variable in class org.mule.util.NumberUtils
 
LONGNVARCHAR_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
LONGVARBINARY_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
LONGVARCHAR_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
Lookup - Annotation Type in org.mule.api.annotations.expressions
Allows objects to be found in the registry, either by ty
lookup(String) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
lookup(Name) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
lookup(Name) - Method in class org.mule.jndi.SimpleContext
 
lookup(String) - Method in class org.mule.jndi.SimpleContext
 
lookup(DbConnection, int, String) - Method in class org.mule.module.db.internal.domain.type.CompositeDbTypeManager
 
lookup(DbConnection, String) - Method in class org.mule.module.db.internal.domain.type.CompositeDbTypeManager
Finds a mapping for a given type name using each composed DbTypeManager until a type is found or there are no more managers to use.
lookup(DbConnection, int, String) - Method in interface org.mule.module.db.internal.domain.type.DbTypeManager
Finds a mapping for a given type ID and name
lookup(DbConnection, String) - Method in interface org.mule.module.db.internal.domain.type.DbTypeManager
Finds a mapping for a given type name
lookup(DbConnection, int, String) - Method in class org.mule.module.db.internal.domain.type.MetadataDbTypeManager
 
lookup(DbConnection, String) - Method in class org.mule.module.db.internal.domain.type.MetadataDbTypeManager
 
lookup(DbConnection, int, String) - Method in class org.mule.module.db.internal.domain.type.StaticDbTypeManager
 
lookup(DbConnection, String) - Method in class org.mule.module.db.internal.domain.type.StaticDbTypeManager
 
lookup(Name) - Method in class org.mule.tck.jndi.InMemoryContext
 
lookup(String) - Method in class org.mule.tck.jndi.InMemoryContext
 
lookup(String) - Method in class org.mule.transport.jms.jndi.CachedJndiNameResolver
 
lookup(String) - Method in interface org.mule.transport.jms.jndi.JndiNameResolver
Looks up an object by name.
lookup(String) - Method in class org.mule.transport.jms.jndi.SimpleJndiNameResolver
 
lookupAddedQueue(QueueInfo) - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
lookupAddedQueue(QueueStore) - Method in class org.mule.util.queue.TransientQueueTransactionContext
 
lookupAgent(String) - Method in interface org.mule.api.registry.MuleRegistry
 
lookupAgent(String) - Method in class org.mule.registry.MuleRegistryHelper
LookupAnnotationParser - Class in org.mule.config.expression
Used to parse Expr parameter annotations
LookupAnnotationParser() - Constructor for class org.mule.config.expression.LookupAnnotationParser
 
lookupByType(Class<T>) - Method in interface org.mule.api.registry.Registry
 
lookupByType(Class<T>) - Method in class org.mule.config.spring.SpringRegistry
 
lookupByType(Class<T>) - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
lookupByType(Class<T>) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
lookupByType(Class<T>) - Method in class org.mule.registry.MuleRegistryHelper
 
lookupByType(Class<T>) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
lookupConfig(String, Class<T>) - Method in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
lookupConnector(String) - Method in interface org.mule.api.registry.MuleRegistry
 
lookupConnector(String) - Method in class org.mule.registry.MuleRegistryHelper
lookupConverters(DataType<?>, DataType<?>) - Method in class org.mule.transformer.graph.TransformationGraphLookupStrategy
Looks for Converter to convert from the source to the target data types.
lookupEndpoint(String) - Method in class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
lookupEndpoint(String) - Method in class org.mule.transport.soap.axis.extensions.UniversalSender
 
lookupEndpointBuilder(String) - Method in interface org.mule.api.registry.MuleRegistry
Looks-up endpoint builders which can be used to repeatably create endpoints with the same configuration.
lookupEndpointBuilder(String) - Method in class org.mule.endpoint.DefaultEndpointFactory
 
lookupEndpointBuilder(String) - Method in class org.mule.registry.MuleRegistryHelper
Looks-up endpoint builders which can be used to repeatably create endpoints with the same configuration.
lookupEndpointFactory() - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
lookupEndpointFactory() - Method in class org.mule.registry.MuleRegistryHelper
lookupEntriesForLifecycle(Class<T>) - Method in class org.mule.config.spring.SpringRegistry
 
lookupFailedSeePreviousException(Object) - Static method in class org.mule.config.i18n.AnnotationsMessages
 
lookupFlowConstruct(String) - Method in interface org.mule.api.registry.MuleRegistry
 
lookupFlowConstruct(String) - Method in class org.mule.registry.MuleRegistryHelper
lookupFlowConstruct(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
Retrieve a flow by name from the registry
lookupFlowConstructs() - Method in interface org.mule.api.registry.MuleRegistry
 
lookupFlowConstructs() - Method in class org.mule.registry.MuleRegistryHelper
lookupFromJndi(String) - Method in class org.mule.transport.jms.JmsConnector
 
LookupInjectionProcessor - Class in org.mule.config.processors
Deprecated.
as of 3.7.0. Use a registry which supports Inject annotations instead
LookupInjectionProcessor() - Constructor for class org.mule.config.processors.LookupInjectionProcessor
Deprecated.
 
LookupInjectionProcessor(MuleContext) - Constructor for class org.mule.config.processors.LookupInjectionProcessor
Deprecated.
 
lookupJmxAgent(MuleRegistry) - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
lookupLink(String) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
lookupLink(Name) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
lookupLink(Name) - Method in class org.mule.jndi.SimpleContext
 
lookupLink(Attributes.Name) - Method in class org.mule.jndi.SimpleContext
 
lookupLink(String) - Method in class org.mule.jndi.SimpleContext
 
lookupLink(Name) - Method in class org.mule.tck.jndi.InMemoryContext
 
lookupLink(String) - Method in class org.mule.tck.jndi.InMemoryContext
 
lookupLocalObjects(Class<T>) - Method in interface org.mule.api.registry.Registry
Look up all objects of a given type within the local registry.
lookupLocalObjects(Class<T>) - Method in class org.mule.config.spring.SpringRegistry
 
lookupLocalObjects(Class<T>) - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
lookupLocalObjects(Class<T>) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
lookupLocalObjects(Class<T>) - Method in class org.mule.registry.MuleRegistryHelper
 
lookupLocalObjects(Class<T>) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
lookupMessageProcessor(String, MuleContext) - Method in class org.mule.expression.MessageProcessorExpressionEvaluator
 
lookupModel(String) - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
lookupModel(String) - Method in class org.mule.registry.MuleRegistryHelper
Deprecated.
lookupMuleBase() - Static method in class org.mule.module.boot.MuleBootstrap
 
lookupMuleBase() - Static method in class org.mule.module.reboot.MuleContainerBootstrap
 
lookupMuleHome() - Static method in class org.mule.module.boot.MuleBootstrap
 
lookupMuleHome() - Static method in class org.mule.module.reboot.MuleContainerBootstrap
 
lookupNotFoundInRegistry(Class, String, Class) - Static method in class org.mule.config.i18n.AnnotationsMessages
 
lookupObject(String, boolean) - Method in interface org.mule.api.registry.LifecycleRegistry
Look up a single object by name.
lookupObject(String) - Method in interface org.mule.api.registry.Registry
Look up a single object by name.
lookupObject(Class<T>) - Method in interface org.mule.api.registry.Registry
Look up a single object by type.
lookupObject(String) - Method in class org.mule.config.spring.SpringRegistry
Look up a single object by name.
lookupObject(String, boolean) - Method in class org.mule.config.spring.SpringRegistry
If looks for the bean registered under key.
lookupObject(String) - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
lookupObject(Class<T>) - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
lookupObject(Class<T>) - Method in class org.mule.registry.AbstractRegistry
 
lookupObject(String) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
lookupObject(String, boolean) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
Iterates through RegistryProvider.getRegistries() trying to find the first one which is an instance of LifecycleRegistry.
lookupObject(Class<T>) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
lookupObject(Class<T>) - Method in class org.mule.registry.MuleRegistryHelper
Look up a single object by type.
lookupObject(String) - Method in class org.mule.registry.MuleRegistryHelper
Look up a single object by name.
lookupObject(String, boolean) - Method in class org.mule.registry.MuleRegistryHelper
Look up a single object by name.
lookupObject(String, boolean) - Method in class org.mule.registry.SimpleRegistry
This implementation doesn't support applying lifecycle upon lookup and thus this method simply delegates into TransientRegistry.lookupObject(String)
lookupObject(String) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
lookupObject(Class<T>) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
lookupObjectInstance() - Method in class org.mule.processor.InvokerMessageProcessor
 
lookupObjects(Class<T>) - Method in interface org.mule.api.registry.Registry
Look up all objects of a given type.
lookupObjects(Class<T>) - Method in class org.mule.config.spring.SpringRegistry
 
lookupObjects(Class<T>) - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
lookupObjects(Class<T>) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
lookupObjects(Class<T>) - Method in class org.mule.registry.MuleRegistryHelper
Look up all objects of a given type.
lookupObjects(Class<T>) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
lookupObjectsForLifecycle(Class<T>) - Method in interface org.mule.api.registry.Registry
Look up all objects of a given type that lifecycle should be applied to.
lookupObjectsForLifecycle(Class<T>) - Method in class org.mule.config.spring.SpringRegistry
For lifecycle we only want spring to return singleton objects from it's application context
lookupObjectsForLifecycle(LifecycleObject) - Method in class org.mule.lifecycle.RegistryLifecycleCallback
 
lookupObjectsForLifecycle(Class<T>) - Method in class org.mule.registry.AbstractRegistry
 
lookupObjectsForLifecycle(Class<T>) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
 
lookupObjectsForLifecycle(Class<T>) - Method in class org.mule.registry.MuleRegistryHelper
Look up all objects of a given type that lifecycle should be applied to.
lookupProcess(Object) - Method in interface org.mule.module.bpm.BPMS
Looks up an already-running process.
lookupProcess(Object) - Method in class org.mule.module.jbpm.Jbpm
Look up an already-running process instance.
lookupProperty(MuleMessage, String, String) - Method in class org.mule.transport.email.transformers.StringToEmailMessage
Searches in outbound, then invocation scope.
lookupProviders(Class<T>, ClassLoader) - Method in interface org.mule.api.registry.ServiceRegistry
Searches for implementations of a particular service class using the given class loader.
lookupProviders(Class<T>) - Method in interface org.mule.api.registry.ServiceRegistry
Searches for implementations of a particular service class
lookupProviders(Class<T>, ClassLoader) - Method in class org.mule.registry.SpiServiceRegistry
If classLoader is null, then the current Thread.getContextClassLoader() will be used Searches for implementations of a particular service class using the given class loader.
lookupProviders(Class<T>) - Method in class org.mule.registry.SpiServiceRegistry
Searches for implementations of a particular service class
lookupReceiver(String) - Method in class org.mule.transport.AbstractConnector
 
lookupReceiver(Socket, RequestLine) - Method in class org.mule.transport.http.HttpConnector
 
lookupReceiver(Socket, HttpRequest) - Method in class org.mule.transport.http.HttpConnector
Deprecated.
lookupReceiver(String) - Method in class org.mule.transport.http.HttpConnector
 
lookupReferencedFlowInApplicationContext(String) - Method in class org.mule.config.spring.factories.FlowRefFactoryBean
 
lookupRemovedQueue(QueueInfo) - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
lookupRemovedQueue(QueueStore) - Method in class org.mule.util.queue.TransientQueueTransactionContext
 
lookupScheduler(Predicate<String>) - Method in interface org.mule.api.registry.MuleRegistry
 
lookupScheduler(Predicate<String>) - Method in class org.mule.registry.MuleRegistryHelper
 
lookupService(String) - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
lookupService(String) - Method in class org.mule.registry.MuleRegistryHelper
lookupServiceDescriptor(ServiceType, String, Properties) - Method in interface org.mule.api.registry.MuleRegistry
 
lookupServiceDescriptor(ServiceType, String, Properties) - Method in class org.mule.registry.MuleRegistryHelper
Looks up the service descriptor from a singleton cache and creates a new one if not found.
lookupServices(String) - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
lookupServices() - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
lookupServices() - Method in class org.mule.registry.MuleRegistryHelper
lookupServices(String) - Method in class org.mule.registry.MuleRegistryHelper
lookupSystemModel() - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
lookupSystemModel() - Method in class org.mule.registry.MuleRegistryHelper
Deprecated.
lookupTransformer(String) - Method in interface org.mule.api.registry.MuleRegistry
 
lookupTransformer(Class<?>, Class<?>) - Method in interface org.mule.api.registry.MuleRegistry
lookupTransformer(DataType<?>, DataType<?>) - Method in interface org.mule.api.registry.MuleRegistry
Will find a transformer that is the closest match to the desired input and output.
lookupTransformer(String) - Method in class org.mule.registry.MuleRegistryHelper
lookupTransformer(Class, Class) - Method in class org.mule.registry.MuleRegistryHelper
Deprecated.
use MuleRegistryHelper.lookupTransformer(org.mule.api.transformer.DataType, org.mule.api.transformer.DataType) instead. This method should only be used internally to discover transformers, typically a user does not need ot do this directly
lookupTransformer(DataType, DataType) - Method in class org.mule.registry.MuleRegistryHelper
Will find a transformer that is the closest match to the desired input and output.
lookupTransformers(Class<?>, Class<?>) - Method in interface org.mule.api.registry.MuleRegistry
lookupTransformers(DataType<?>, DataType<?>) - Method in interface org.mule.api.registry.MuleRegistry
This method will return a list of Transformer objects that accept the given input and return the given output type of object
lookupTransformers(Class, Class) - Method in class org.mule.registry.MuleRegistryHelper
Deprecated.
use MuleRegistryHelper.lookupTransformer(org.mule.api.transformer.DataType, org.mule.api.transformer.DataType) instead. This method should only be used internally to discover transformers, typically a user does not need ot do this directly
lookupTransformers(DataType, DataType) - Method in class org.mule.registry.MuleRegistryHelper
This method will return a list of Transformer objects that accept the given input and return the given output type of object
LOWER_BOUND_EXCLUSIVE - Static variable in class org.mule.util.VersionRange
 
LOWER_BOUND_INCLUSIVE - Static variable in class org.mule.util.VersionRange
 

M

magicProperties - Static variable in class org.mule.routing.AbstractRoutingStrategy
These properties are automatically propagated by Mule from inbound to outbound
mailAddressesToString(Address[]) - Static method in class org.mule.transport.email.MailUtils
 
mailAddressesToString(Address) - Static method in class org.mule.transport.email.MailUtils
 
MAILBOX - Static variable in class org.mule.transport.email.AbstractMailConnector
 
MailMuleMessageFactory - Class in org.mule.transport.email
 
MailMuleMessageFactory() - Constructor for class org.mule.transport.email.MailMuleMessageFactory
 
MailProperties - Interface in org.mule.transport.email
Mail properties that are sent on the DefaultMuleMessage when receiving a Mail Message or which can be set on the endpoint or event to be added to outgoing mail
MailSubjectRegExFilter - Class in org.mule.transport.email.filters
MailSubjectRegExFilter applies a regular expression to a Mail Message subject.
MailSubjectRegExFilter() - Constructor for class org.mule.transport.email.filters.MailSubjectRegExFilter
 
MailUtils - Class in org.mule.transport.email
Contains javax.mail helpers.
MailUtils() - Constructor for class org.mule.transport.email.MailUtils
 
main(String[]) - Static method in class org.mule.module.boot.GuiInstallerLibraryDownloader
 
main(String[]) - Static method in class org.mule.module.boot.GuiInstallerLicenseHandler
The main method which is called by the GUI.
main(String[]) - Static method in class org.mule.module.boot.MuleBootstrap
 
main(String[]) - Static method in class org.mule.module.launcher.MuleContainer
Application entry point.
main(String[]) - Static method in class org.mule.module.reboot.MuleContainerBootstrap
 
main(String[]) - Static method in class org.mule.MuleServer
Application entry point.
main(String[]) - Static method in class org.mule.test.infrastructure.process.MuleContextProcessApplication
 
makeDir(String) - Method in class org.mule.tck.util.ftp.FtpClient
Create a directory
makeInitialContext() - Static method in class org.mule.config.spring.jndi.SpringInitialContextFactory
A factory method which can be used to initialise a singleton JNDI context from inside a Spring.xml such that future calls to new InitialContext() will reuse it
makeNewServiceObject(MessageContext, String) - Method in class org.mule.transport.soap.axis.extensions.MuleMsgProvider
 
makeNewServiceObject(MessageContext, String) - Method in class org.mule.transport.soap.axis.extensions.MuleRPCProvider
 
makeObject() - Method in class org.mule.module.xml.transformer.XQueryTransformer.PooledXQueryTransformerFactory
 
makeObject() - Method in class org.mule.module.xml.transformer.XsltTransformer.PooledXsltTransformerFactory
 
makeObject(String) - Method in class org.mule.security.oauth.BaseOAuthClientFactory
This method creates an instance of OAuth2Adapter which concrete type depends on the return of BaseOAuthClientFactory.getAdapterClass() The adapter is fully initialized and interfaces such as Initialisable, MuleContextAware and Startable are respected by invoking the corresponding methods in case the adapter implements them.
makeObject() - Method in class org.mule.transport.ftp.FtpConnectionFactory
 
makeObject(Object) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
makeObject(Object) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
makeObject(Object) - Method in class org.mule.transport.multicast.MulticastSocketFactory
 
makeObject() - Method in class org.mule.transport.sftp.SftpConnectionFactory
 
makeObject(Object) - Method in class org.mule.transport.tcp.AbstractTcpSocketFactory
 
makeObject(Object) - Method in class org.mule.transport.udp.UdpSocketFactory
 
MalformedEndpointException - Exception in org.mule.api.endpoint
MalformedEndpointException is thrown by the MuleEndpointURI class if it fails to parse a Url
MalformedEndpointException(String) - Constructor for exception org.mule.api.endpoint.MalformedEndpointException
 
MalformedEndpointException(Message, String) - Constructor for exception org.mule.api.endpoint.MalformedEndpointException
 
MalformedEndpointException(String, Throwable) - Constructor for exception org.mule.api.endpoint.MalformedEndpointException
 
MalformedEndpointException(Throwable) - Constructor for exception org.mule.api.endpoint.MalformedEndpointException
 
malformedSyntax() - Static method in class org.mule.transport.http.i18n.HttpMessages
 
ManagedAccessTokenProcessInterceptor<T> - Class in org.mule.security.oauth.process
 
ManagedAccessTokenProcessInterceptor(ProcessInterceptor<T, OAuth2Adapter>, OAuth2Manager<OAuth2Adapter>) - Constructor for class org.mule.security.oauth.process.ManagedAccessTokenProcessInterceptor
 
ManagedAccessTokenProcessTemplate<P> - Class in org.mule.security.oauth.process
 
ManagedAccessTokenProcessTemplate(OAuth2Manager<OAuth2Adapter>, MuleContext) - Constructor for class org.mule.security.oauth.process.ManagedAccessTokenProcessTemplate
 
ManagedObjectStore<T extends Serializable> - Class in org.mule.util.store
 
ManagedObjectStore() - Constructor for class org.mule.util.store.ManagedObjectStore
 
ManagedPagingDelegateAdapter<T> - Class in org.mule.streaming.processor
Adapter class to adapt a ProviderAwarePagingDelegate into a PagingDelegate Allows executing paging operations in a managed context defined by an owning ProcessTemplate
ManagedPagingDelegateAdapter(ProviderAwarePagingDelegate<T, Object>, ProcessTemplate<Object, Object>, List<Class<? extends Exception>>, boolean, MessageProcessor, MuleEvent) - Constructor for class org.mule.streaming.processor.ManagedPagingDelegateAdapter
 
MANAGEMENT_COMPONENT_QUEUE_EXHAUSTED - Static variable in class org.mule.context.notification.ManagementNotification
 
MANAGEMENT_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
MANAGEMENT_NODE_PING - Static variable in class org.mule.context.notification.ManagementNotification
 
ManagementException - Exception in org.mule.module.management
ManagementException is a general exception thrown by management extensions.
ManagementException(Message) - Constructor for exception org.mule.module.management.ManagementException
 
ManagementException(Message, Throwable) - Constructor for exception org.mule.module.management.ManagementException
 
ManagementException(Throwable) - Constructor for exception org.mule.module.management.ManagementException
 
ManagementMessages - Class in org.mule.module.management.i18n
 
ManagementMessages() - Constructor for class org.mule.module.management.i18n.ManagementMessages
 
ManagementNamespaceHandler - Class in org.mule.module.management.config
Handles all configuration elements in the Mule Management module.
ManagementNamespaceHandler() - Constructor for class org.mule.module.management.config.ManagementNamespaceHandler
 
ManagementNotification - Class in org.mule.context.notification
ManagementNotification is fired when monitored resources such as internal queues reach capacity
ManagementNotification(Object, int) - Constructor for class org.mule.context.notification.ManagementNotification
 
ManagementNotificationListener<T extends ManagementNotification> - Interface in org.mule.api.context.notification
ManagementNotificationListener is an observer interface that objects can use to receive notifications about the state of the Mule instance and its resources
ManagementUtils - Class in org.mule.module.management.util
 
ManagementUtils() - Constructor for class org.mule.module.management.util.ManagementUtils
 
MANAGER_COMPONENT_NAME - Static variable in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
managerAlreadyStarted() - Static method in class org.mule.config.i18n.CoreMessages
 
managerIsAlreadyConfigured() - Static method in class org.mule.module.client.i18n.ClientMessages
Deprecated.
MANDATORY_TYPE_ERROR_MESSAGE - Static variable in class org.mule.module.http.internal.multipart.HttpMultipartEncoder
 
ManualConstraint - Class in org.mule.transaction.constraints
ManualConstraint always returns false, meaning that the transaction should be committed manually.
ManualConstraint() - Constructor for class org.mule.transaction.constraints.ManualConstraint
 
map - Variable in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration.MapValueMap
 
MAP_ENTRY_KEY - Static variable in class org.mule.routing.MapSplitter
 
mapClass - Variable in class org.mule.config.spring.parsers.collection.OrphanMapDefinitionParser
 
MapCombiner - Class in org.mule.util
This allows a collection (list) of maps to be defined in Spring, via the "list" property, and then presents all the maps as a single combine map at run time.
MapCombiner() - Constructor for class org.mule.util.MapCombiner
 
MapDefinitionParserMutator - Class in org.mule.config.spring.parsers.delegate
This changes a ChildDefinitionParser so that it generates a map instead of a bean definition.
MapDefinitionParserMutator(String, ChildDefinitionParser) - Constructor for class org.mule.config.spring.parsers.delegate.MapDefinitionParserMutator
 
MapEntryCombiner - Class in org.mule.config.spring.parsers.assembly
This is used internally by DefaultBeanAssembler along with ChildSingletonMapDefinitionParser.
MapEntryCombiner() - Constructor for class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
MapLookup - Class in org.mule.transformer.simple
MapLookup looks up and returns an object from a Map based on a key.
MapLookup() - Constructor for class org.mule.transformer.simple.MapLookup
 
MapNamespaceContext - Class in org.mule.module.xml.stax
 
MapNamespaceContext() - Constructor for class org.mule.module.xml.stax.MapNamespaceContext
 
MapNamespaceContext(Map<String, String>) - Constructor for class org.mule.module.xml.stax.MapNamespaceContext
 
MapPayloadExpressionEvaluator - Class in org.mule.expression
If the message payload is a map this extractor will look up the property value in the map
MapPayloadExpressionEvaluator() - Constructor for class org.mule.expression.MapPayloadExpressionEvaluator
 
MappedStructResolvedDbType<T> - Class in org.mule.module.db.internal.domain.type
Defines a structured data type for Struct mapped to a Java class.
MappedStructResolvedDbType(int, String, Class<T>) - Constructor for class org.mule.module.db.internal.domain.type.MappedStructResolvedDbType
Creates a new instance
MapperFactoryBean - Class in org.mule.module.json.config
TODO
MapperFactoryBean() - Constructor for class org.mule.module.json.config.MapperFactoryBean
 
MapSplitter - Class in org.mule.routing
Splits a message that has a map payload invoking the next message processor one for each item in the map in order.
MapSplitter() - Constructor for class org.mule.routing.MapSplitter
 
MapToBean - Class in org.mule.transformer.simple
Creates and object of type AbstractTransformer.getReturnClass() and populates values of a Map as bean properties on the object.
MapToBean() - Constructor for class org.mule.transformer.simple.MapToBean
 
mapUnsupportedSchemas(String) - Static method in class org.mule.module.cxf.support.CxfUtils
 
MapUtils - Class in org.mule.util
 
MapUtils() - Constructor for class org.mule.util.MapUtils
 
mapWithKeysAndValues(Class<? extends Map>, K[], V[]) - Static method in class org.mule.util.MapUtils
Convenience method for CollectionUtil#mapWithKeysAndValues(Class, Iterator, Iterator); keys and values can be null or empty.
mapWithKeysAndValues(Class<? extends Map>, Collection<K>, Collection<V>) - Static method in class org.mule.util.MapUtils
Convenience method for CollectionUtil#mapWithKeysAndValues(Class, Iterator, Iterator); keys and values can be null or empty.
mapWithKeysAndValues(Class<? extends Map>, Iterator<K>, Iterator<V>) - Static method in class org.mule.util.MapUtils
Create & populate a Map of arbitrary class.
mark(int) - Method in class org.mule.model.streaming.DelegatingInputStream
 
markExceptionAsHandled(Exception) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
markSupported() - Method in class org.mule.model.streaming.DelegatingInputStream
 
markTransactionForRollback() - Method in interface org.mule.api.MuleEventContext
Deprecated. 
markTransactionForRollback() - Method in class org.mule.DefaultMuleEventContext
 
markTransactionStart() - Method in class org.mule.execution.ExecutionContext
This method must be called whenever a transaction has been created in the execution context
maskedPropertyValue(Map.Entry<?, ?>) - Static method in class org.mule.util.PropertiesUtils
Returns the String representation of the property value or a masked String if the property key has been registered previously via PropertiesUtils.registerMaskedPropertyName(String).
maskOut(Properties, String) - Static method in class org.hibernate.connection.SimpleConnectionProvider
replace a property by a starred version
maskPasswordAttribute(String) - Static method in class org.mule.api.util.CredentialsMaskUtil
masks password attribute
maskPasswords(String) - Static method in class org.mule.api.util.CredentialsMaskUtil
masks url credentials
maskUrlPassword(String, Pattern) - Static method in class org.mule.api.util.CredentialsMaskUtil
masks password in input
maskUrlUserAndPassword(String, Pattern, Pattern) - Static method in class org.mule.api.util.CredentialsMaskUtil
masks user and password in input
match(Pattern, String, int) - Static method in class org.mule.util.StringUtils
Matches the given value to the given pattern.
match(String) - Method in interface org.mule.util.TemplateParser.TemplateCallback
 
Matchable - Interface in org.mule.api.routing
Enables an artifact to be matched for routing before actually routing to it
MatchableMessageProcessor - Interface in org.mule.api.routing
 
MatchableMessageRouter - Interface in org.mule.api.routing
 
matchableRoutes - Variable in class org.mule.routing.AbstractMatchingRouter
 
matchAll - Variable in class org.mule.routing.AbstractMatchingRouter
 
matchAll - Variable in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
matches(HttpRequest) - Method in class org.mule.module.http.internal.listener.matcher.AcceptsAllMethodsRequestMatcher
 
matches(HttpRequest) - Method in class org.mule.module.http.internal.listener.matcher.ListenerRequestMatcher
 
matches(HttpRequest) - Method in class org.mule.module.http.internal.listener.matcher.MethodRequestMatcher
 
matches(HttpRequest) - Method in interface org.mule.module.http.internal.listener.matcher.RequestMatcher
 
matchesBeanName(String, String) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Determine whether the given candidate name matches the bean name or the aliases stored in this bean definition.
matchesSafely(File) - Method in class org.mule.test.infrastructure.FileContainsInLine
 
matchesSafely(String) - Method in class org.mule.test.infrastructure.HasRegex
 
matchesSafely(MuleProcessController) - Method in class org.mule.test.infrastructure.process.matchers.Deployment
 
matchesSafely(MuleProcessController) - Method in class org.mule.test.infrastructure.process.matchers.Running
 
matchesSafely(MuleProcessController) - Method in class org.mule.test.infrastructure.process.VerifyLogWithMatcher
 
MatchingRouter - Interface in org.mule.api.routing
Routes the message to zero or more MatchableMessageProcessors.
matchReceiverByWildcard(String, MessageReceiver) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
MAX - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter representing the maximum value of a counter
Max - Class in org.mule.util.counters.impl
 
Max(String, AbstractCounter) - Constructor for class org.mule.util.counters.impl.Max
 
MAX_AGE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
MAX_BUFFER_SIZE_PROPERTY - Static variable in class org.mule.api.config.DefaultThreadingProfileConfig
 
MAX_ELEMENTS - Static variable in class org.mule.util.StringMessageUtils
 
MAX_FORWARDS - Static variable in class org.mule.module.http.api.HttpHeaders.Names
MAX_LENGTH_PER_FILE_PROPERTY_KEY - Static variable in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
MAX_PRIORITY_WEIGHTING - Static variable in interface org.mule.api.transformer.Converter
 
MAX_PROCESSED_GROUPS - Static variable in class org.mule.routing.AbstractAggregator
 
MAX_PROCESSED_GROUPS - Static variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
MAX_REDELIVERY - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
MAX_ROWS_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
MAX_STALE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
MAX_THREAD_TTL_PROPERTY - Static variable in class org.mule.api.config.DefaultThreadingProfileConfig
 
MAX_THREADS_ACTIVE_PROPERTY - Static variable in class org.mule.api.config.DefaultThreadingProfileConfig
 
MAX_THREADS_IDLE_PROPERTY - Static variable in class org.mule.api.config.DefaultThreadingProfileConfig
 
MAX_UNACKED_SIZE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
MAX_WAIT_TIMEOUT_PROPERTY - Static variable in class org.mule.api.config.DefaultThreadingProfileConfig
 
maxBufferSize - Variable in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
maxEntries - Variable in class org.mule.util.store.AbstractMonitoredObjectStore
the maximum number of entries that this store keeps around.
maxEntries - Variable in class org.mule.util.store.MonitoredObjectStoreWrapper
the maximum number of entries that this store keeps around.
MAXIMUM_CAPACITY - Static variable in interface org.mule.util.queue.QueueConfiguration
 
MAXIMUM_HEADER_SECTION_SIZE_PROPERTY_KEY - Static variable in class org.mule.module.http.internal.listener.grizzly.GrizzlyServerManager
 
MAXIMUM_PORT_NUMBER - Static variable in class org.mule.module.http.api.requester.proxy.NtlmProxyConfigBuilder
 
MAXIMUM_PORT_NUMBER - Static variable in class org.mule.module.http.api.requester.proxy.ProxyConfigBuilder
 
maxQueueSize - Variable in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
maxRedeliveryCount - Variable in class org.mule.processor.AbstractRedeliveryPolicy
 
maxThreads - Variable in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
MaxValueWatermarkSelector - Class in org.mule.transport.polling.watermark.selector
Implementation of WatermarkSelector that selectes the maximum value of the set.
MaxValueWatermarkSelector() - Constructor for class org.mule.transport.polling.watermark.selector.MaxValueWatermarkSelector
 
mayBeJSON(String) - Method in class org.mule.module.json.filters.IsJsonFilter
Tests if the String possibly represents a valid JSON String.
MBeanServerFactory - Class in org.mule.module.management.mbean
 
MBeanServerFactory() - Constructor for class org.mule.module.management.mbean.MBeanServerFactory
 
MD5MuleEventKeyGenerator - Class in org.mule.keygenerator
Deprecated.
Use SHA256MuleEventKeyGenerator instead.
MD5MuleEventKeyGenerator() - Constructor for class org.mule.keygenerator.MD5MuleEventKeyGenerator
Deprecated.
 
MemberNameCapability - Class in org.mule.module.extension.internal.capability.metadata
A capability to link a Capable object which is also an instance of Described or NamedObject to the actual member in which it was defined.
MemberNameCapability(String) - Constructor for class org.mule.module.extension.internal.capability.metadata.MemberNameCapability
 
MemoryManagerTransportCustomizer - Class in org.mule.module.http.internal.request.grizzly
 
MemoryManagerTransportCustomizer() - Constructor for class org.mule.module.http.internal.request.grizzly.MemoryManagerTransportCustomizer
 
merge(MuleSession) - Method in interface org.mule.api.MuleSession
Merge current session with an updated version Result session will contain all the properties from updatedSession plus those properties in the current session that couldn't be serialized In case updatedSession is null, then no change will be applied.
merge(MuleSession) - Method in class org.mule.session.DefaultMuleSession
 
mergeParserOverrides(MultiMap) - Method in class org.mule.module.launcher.DefaultAppBloodhound
Merge default and discovered overrides for descriptor parsers, taking weight into account
mergeProperties() - Method in class org.mule.config.spring.processors.PropertyPlaceholderProcessor
 
message - Variable in class org.mule.api.processor.LoggerMessageProcessor
 
Message - Class in org.mule.config.i18n
 
Message(String, int, Object...) - Constructor for class org.mule.config.i18n.Message
 
message - Variable in class org.mule.el.context.MessageContext
 
Message - Interface in org.mule.module.pgp
 
message - Variable in class org.mule.tck.functional.AssertionMessageProcessor
 
message - Variable in class org.mule.transport.jms.MessageProcessingCallback
 
MESSAGE_DISCARD_MESSAGE_BODY - Static variable in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
MESSAGE_DISCARD_REASON_PHRASE - Static variable in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
MESSAGE_DISCARD_STATUS_CODE - Static variable in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
MESSAGE_DISCARD_STATUS_CODE - Static variable in class org.mule.transport.http.HttpMessageProcessTemplate
 
MESSAGE_DISPATCH_BEGIN - Static variable in class org.mule.context.notification.EndpointMessageNotification
 
MESSAGE_DISPATCH_END - Static variable in class org.mule.context.notification.EndpointMessageNotification
 
MESSAGE_DISPATCHED - Static variable in class org.mule.context.notification.EndpointMessageNotification
For backwards compatibility.
MESSAGE_ERROR_RESPONSE - Static variable in class org.mule.context.notification.BaseConnectorMessageNotification
 
MESSAGE_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
MESSAGE_EVENT_END_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
MESSAGE_PAYLOAD - Static variable in class org.mule.el.mvel.MessageVariableResolverFactory
 
MESSAGE_PREFIX - Static variable in exception org.mule.tck.testmodels.services.TestComponentException
 
MESSAGE_PROCESSOR_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
MESSAGE_PROCESSOR_POST_INVOKE - Static variable in class org.mule.context.notification.MessageProcessorNotification
 
MESSAGE_PROCESSOR_PRE_INVOKE - Static variable in class org.mule.context.notification.MessageProcessorNotification
 
MESSAGE_PROCESSOR_PRE_INVOKE_ORIGINAL_EVENT - Static variable in class org.mule.context.notification.MessageProcessorNotification
This action should be only used when you need to get the original event and not a copy of it.
MESSAGE_RECEIVED - Static variable in class org.mule.context.notification.BaseConnectorMessageNotification
 
MESSAGE_REQUEST_BEGIN - Static variable in class org.mule.context.notification.BaseConnectorMessageNotification
 
MESSAGE_REQUEST_END - Static variable in class org.mule.context.notification.BaseConnectorMessageNotification
 
MESSAGE_REQUESTED - Static variable in class org.mule.context.notification.EndpointMessageNotification
 
MESSAGE_RESPONSE - Static variable in class org.mule.context.notification.BaseConnectorMessageNotification
 
MESSAGE_SEND_BEGIN - Static variable in class org.mule.context.notification.EndpointMessageNotification
 
MESSAGE_SEND_END - Static variable in class org.mule.context.notification.EndpointMessageNotification
 
MESSAGE_SENT - Static variable in class org.mule.context.notification.EndpointMessageNotification
 
MESSAGE_THREAD_POOL_SIZE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
MESSAGE_THROTTLED_REASON_PHRASE - Static variable in class org.mule.transport.http.HttpMessageProcessTemplate
 
MessageArgumentResolver - Class in org.mule.module.extension.internal.runtime.resolver
An implementation of ArgumentResolver which returns the MuleMessage associated with a given OperationContext.
MessageAttachmentExpressionEvaluator - Class in org.mule.expression
Looks up an attachment with the given name.
MessageAttachmentExpressionEvaluator() - Constructor for class org.mule.expression.MessageAttachmentExpressionEvaluator
 
MessageAttachmentsExpressionEvaluator - Class in org.mule.expression
Looks up the attachment(s) on the message using the expression given.
MessageAttachmentsExpressionEvaluator() - Constructor for class org.mule.expression.MessageAttachmentsExpressionEvaluator
 
MessageAttachmentsListExpressionEvaluator - Class in org.mule.expression
Looks up the attachment(s) on the message using the expression given.
MessageAttachmentsListExpressionEvaluator() - Constructor for class org.mule.expression.MessageAttachmentsListExpressionEvaluator
 
messageCache - Variable in class org.mule.transport.ajax.AjaxMessageDispatcher
 
messageCacheSize - Variable in class org.mule.transport.ajax.AjaxMessageDispatcher
 
MessageChunkAggregator - Class in org.mule.routing
 
MessageChunkAggregator() - Constructor for class org.mule.routing.MessageChunkAggregator
 
MessageChunkingRouter - Class in org.mule.routing.outbound
Deprecated.
MessageChunkingRouter() - Constructor for class org.mule.routing.outbound.MessageChunkingRouter
Deprecated.
 
MessageChunkSplitter - Class in org.mule.routing
A router that breaks up the current message onto smaller parts and sends them to the same destination.
MessageChunkSplitter() - Constructor for class org.mule.routing.MessageChunkSplitter
 
MessageContext - Class in org.mule.el.context
Exposes information about the current Mule message: id The unique message id rootId The root message id.
MessageContext(MuleMessage) - Constructor for class org.mule.el.context.MessageContext
 
MessageDispatcher - Interface in org.mule.api.transport
Combine MessageDispatching with various lifecycle methods for the actual instances doing message sending.
MessageDispatcherFactory - Interface in org.mule.api.transport
MessageDispatcherFactory is a factory interface for managing the lifecycles of a transport's message dispatchers.
MessageDispatcherUtils - Class in org.mule.transport
 
MessageDispatcherUtils() - Constructor for class org.mule.transport.MessageDispatcherUtils
 
MessageDispatching - Interface in org.mule.api.transport
Define generic methods for dispatching events.
MessageEnricher - Class in org.mule.enricher
The Message Enricher allows the current message to be augmented using data from a seperate resource.
MessageEnricher() - Constructor for class org.mule.enricher.MessageEnricher
 
MessageEnricher.EnrichExpressionPair - Class in org.mule.enricher
 
MessageEnricher.EnrichExpressionPair() - Constructor for class org.mule.enricher.MessageEnricher.EnrichExpressionPair
 
MessageEnricher.EnrichExpressionPair(String) - Constructor for class org.mule.enricher.MessageEnricher.EnrichExpressionPair
 
MessageEnricher.EnrichExpressionPair(String, String) - Constructor for class org.mule.enricher.MessageEnricher.EnrichExpressionPair
 
MessageEnricherDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
MessageEnricherDefinitionParser(String, Class) - Constructor for class org.mule.config.spring.parsers.specific.MessageEnricherDefinitionParser
 
messageExchangePattern - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
MessageExchangePattern - Enum in org.mule
 
MessageExchangePatternPropertyEditor - Class in org.mule.config.spring.editors
 
MessageExchangePatternPropertyEditor() - Constructor for class org.mule.config.spring.editors.MessageExchangePatternPropertyEditor
 
MessageExpressionEvaluator - Class in org.mule.expression
Returns properties on the MuleMessage itself.
MessageExpressionEvaluator() - Constructor for class org.mule.expression.MessageExpressionEvaluator
 
MessageFactory - Class in org.mule.config.i18n
 
MessageFactory() - Constructor for class org.mule.config.i18n.MessageFactory
 
MessageFactory - Class in org.mule.module.pgp
 
MessageFactory() - Constructor for class org.mule.module.pgp.MessageFactory
 
MessageFilter - Class in org.mule.routing
Implementation of InterceptingMessageProcessor that filters message flow using a Filter.
MessageFilter() - Constructor for class org.mule.routing.MessageFilter
Deprecated.
Use MessageFilter(Filter filter)
MessageFilter(Filter) - Constructor for class org.mule.routing.MessageFilter
 
MessageFilter(Filter, boolean, MessageProcessor) - Constructor for class org.mule.routing.MessageFilter
 
MessageFilterDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
MessageFilterDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.MessageFilterDefinitionParser
 
MessageFilterDefinitionParser(Class<?>) - Constructor for class org.mule.config.spring.parsers.specific.MessageFilterDefinitionParser
 
MessageHeaderExpressionEnricher - Class in org.mule.expression
 
MessageHeaderExpressionEnricher() - Constructor for class org.mule.expression.MessageHeaderExpressionEnricher
 
MessageHeaderExpressionEvaluator - Class in org.mule.expression
Looks up the property on the message using the property name given.
MessageHeaderExpressionEvaluator() - Constructor for class org.mule.expression.MessageHeaderExpressionEvaluator
 
MessageHeadersExpressionEvaluator - Class in org.mule.expression
Looks up the property on the message using the expression given.
MessageHeadersExpressionEvaluator() - Constructor for class org.mule.expression.MessageHeadersExpressionEvaluator
 
MessageHeadersListExpressionEvaluator - Class in org.mule.expression
Looks up the property on the message using the expression given.
MessageHeadersListExpressionEvaluator() - Constructor for class org.mule.expression.MessageHeadersListExpressionEvaluator
 
MessageInfoMapping - Interface in org.mule.api.routing
This mapping us used by routers to control how Important message information is pulled from the current message.
messageInfoMapping - Variable in class org.mule.construct.AbstractFlowConstruct
 
messageInfoMapping - Variable in class org.mule.routing.AbstractAggregator
 
messageInfoMapping - Variable in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
messageInfoMapping - Variable in class org.mule.service.AbstractService
Deprecated.
 
messageIsOfType(Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
messageMarkedForRedelivery(MuleMessage) - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
messageMarkedForRedelivery(MuleEvent) - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
messageNotSupportedByMuleMessageFactory(Object, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
messageParamServiceMethodNotSet() - Static method in class org.mule.transport.rmi.i18n.RmiMessages
 
MessagePayloadExpressionEvaluator - Class in org.mule.expression
Returns the message payload.
MessagePayloadExpressionEvaluator() - Constructor for class org.mule.expression.MessagePayloadExpressionEvaluator
 
MessageProcessContext - Interface in org.mule.execution
Context for processing one message from a MessageSource.
MessageProcessingCallback<T> - Class in org.mule.transport.jms
 
MessageProcessingCallback(Message) - Constructor for class org.mule.transport.jms.MessageProcessingCallback
 
messageProcessingEnded() - Method in interface org.mule.execution.EndPhaseTemplate
template method call when the message processing ends
messageProcessingEnded() - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
messageProcessingEnded() - Method in class org.mule.transport.servlet.jetty.JettyContinuationsMessageProcessTemplate
 
MessageProcessingFlowTraceManager - Class in org.mule.context.notification
Manager for handling message processing troubleshooting data.
MessageProcessingFlowTraceManager() - Constructor for class org.mule.context.notification.MessageProcessingFlowTraceManager
 
MessageProcessingManager - Interface in org.mule.execution
In charge of processing messages through mule.
MessageProcessor - Interface in org.mule.api.processor
Processes MuleEvent's.
messageProcessor - Variable in class org.mule.config.spring.factories.PollingMessageSourceFactoryBean
 
messageProcessor - Variable in class org.mule.context.notification.AsyncMessageNotification
 
MessageProcessorAnnotationParser - Interface in org.mule.api
An SPI interface used for creating Routers from Annotations.
MessageProcessorBuilder - Interface in org.mule.api.processor
Builds MessageProcessor instances.
MessageProcessorChain - Interface in org.mule.api.processor
 
messageProcessorChain - Variable in class org.mule.service.AbstractService
Deprecated.
 
MessageProcessorChainBuilder - Interface in org.mule.api.processor
Builds MessageProcessorChain instances.
MessageProcessorChainDefinitionParser - Class in org.mule.config.spring.parsers.specific
This allows a message processor to be defined globally, or embedded within an endpoint.
MessageProcessorChainDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.MessageProcessorChainDefinitionParser
 
MessageProcessorChainFactoryBean - Class in org.mule.config.spring.factories
 
MessageProcessorChainFactoryBean() - Constructor for class org.mule.config.spring.factories.MessageProcessorChainFactoryBean
 
MessageProcessorContainer - Interface in org.mule.api.processor
Identifies Constructs that contain Message Processors configured by the user.
MessageProcessorDefinitionParser - Class in org.mule.config.spring.parsers.specific
This allows a message processor to be defined globally, or embedded within an endpoint.
MessageProcessorDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.MessageProcessorDefinitionParser
 
MessageProcessorDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.MessageProcessorDefinitionParser
For custom processors
MessageProcessorExecutionInterceptor - Interface in org.mule.execution
Intercepts a MessageProcessor execution.
MessageProcessorExecutionTemplate - Class in org.mule.execution
Template for executing a MessageProcessor.
messageProcessorExecutionTemplate - Variable in class org.mule.processor.BlockingProcessorExecutor
 
messageProcessorExecutionTemplate - Variable in class org.mule.processor.chain.DefaultMessageProcessorChain
 
MessageProcessorExpressionEvaluator - Class in org.mule.expression
Returns the message result of invoking the specified globally accessible message processor.
MessageProcessorExpressionEvaluator() - Constructor for class org.mule.expression.MessageProcessorExpressionEvaluator
 
MessageProcessorFilterPair - Class in org.mule.routing
A holder for a pair of MessageProcessor and Filter.
MessageProcessorFilterPair(MessageProcessor, Filter) - Constructor for class org.mule.routing.MessageProcessorFilterPair
 
MessageProcessorFilterPairFactoryBean - Class in org.mule.config.spring.factories
 
MessageProcessorFilterPairFactoryBean() - Constructor for class org.mule.config.spring.factories.MessageProcessorFilterPairFactoryBean
 
MessageProcessorNotification - Class in org.mule.context.notification
 
MessageProcessorNotification(FlowConstruct, MuleEvent, MessageProcessor, MessagingException, int) - Constructor for class org.mule.context.notification.MessageProcessorNotification
 
MessageProcessorNotificationListener<T extends MessageProcessorNotification> - Interface in org.mule.api.context.notification
 
MessageProcessorPathElement - Interface in org.mule.api.processor
 
MessageProcessorPathResolver - Interface in org.mule.api.construct
This class handles the resolution of a Processor Path for a given MessageProcessor
MessageProcessorPollingConnector - Class in org.mule.transport.polling
 
MessageProcessorPollingConnector(MuleContext) - Constructor for class org.mule.transport.polling.MessageProcessorPollingConnector
 
MessageProcessorPollingInterceptor - Class in org.mule.transport.polling
Extension point for overriding MessageProcessorPolling functionality.
MessageProcessorPollingInterceptor() - Constructor for class org.mule.transport.polling.MessageProcessorPollingInterceptor
 
MessageProcessorPollingMessageReceiver - Class in org.mule.transport.polling
Polling MessageSource.
MessageProcessorPollingMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
 
MessageProcessorPollingOverride - Class in org.mule.transport.polling
Extension point to hook extra functionality to a message processor polling component.
MessageProcessorPollingOverride() - Constructor for class org.mule.transport.polling.MessageProcessorPollingOverride
 
MessageProcessors - Class in org.mule.api.processor
Some convenience methods for message processors.
messageProcessors - Variable in class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
messageProcessors - Variable in class org.mule.config.spring.factories.ResponseMessageProcessorsFactoryBean
 
messageProcessors - Variable in class org.mule.config.spring.factories.TransactionalMessageProcessorsFactoryBean
 
messageProcessors - Variable in class org.mule.construct.AbstractPipeline
 
messageProcessors - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
messageProcessors - Variable in class org.mule.exception.AbstractExceptionListener
 
messageProcessorsFactory - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
MessageProcessorTextDebugger - Class in org.mule.context.notification
Listener for MessageProcessorNotification that delegates notifications to NotificationTextDebugger
MessageProcessorTextDebugger(MessageProcessingFlowTraceManager) - Constructor for class org.mule.context.notification.MessageProcessorTextDebugger
 
MessageProcessPhase<Template extends MessageProcessTemplate> - Interface in org.mule.execution
Defines a phase that process a message using a MessageProcessTemplate The phase will be part of a chain of responsibility were the phase can define the end of the execution of the set of phases by calling: - PhaseResultNotifier.phaseConsumedMessage() which indicates that the phase has consume the message and it should not be longer processed - PhaseResultNotifier.phaseFailure(Exception) which indicates that there was a failure during message processing.
MessageProcessTemplate - Interface in org.mule.execution
Maker interface for every template that can be used in a MessageProcessPhase A MessageProcessTemplate must contain all the required method that redefines behavior inside a MessageProcessPhase and it's particular from the MessageSource
MessagePropertiesContext - Class in org.mule
This object maintains a scoped map of properties.
MessagePropertiesContext() - Constructor for class org.mule.MessagePropertiesContext
 
MessagePropertiesContext(MessagePropertiesContext) - Constructor for class org.mule.MessagePropertiesContext
 
MessagePropertiesTransformer - Class in org.mule.transformer.simple
A configurable message transformer that allows users to add, overwrite, rename and delete properties on the current message.
MessagePropertiesTransformer() - Constructor for class org.mule.transformer.simple.MessagePropertiesTransformer
 
MessagePropertiesTransformerDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
MessagePropertiesTransformerDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.MessagePropertiesTransformerDefinitionParser
 
MessagePropertyFilter - Class in org.mule.routing.filters
MessagePropertyFilter can be used to filter against properties on an event.
MessagePropertyFilter() - Constructor for class org.mule.routing.filters.MessagePropertyFilter
 
MessagePropertyFilter(String) - Constructor for class org.mule.routing.filters.MessagePropertyFilter
 
MessagePropertyMapContext - Class in org.mule.el.context
 
MessagePropertyMapContext(MuleMessage, PropertyScope) - Constructor for class org.mule.el.context.MessagePropertyMapContext
 
MessageReceiver - Interface in org.mule.api.transport
MessageReceiver is used to receive data from an external system.
messageReceiverNeedsRmiAble() - Static method in class org.mule.transport.rmi.i18n.RmiMessages
 
MessageRedeliveredException - Exception in org.mule.api.exception
 
MessageRedeliveredException(String, int, int, InboundEndpoint, MuleEvent) - Constructor for exception org.mule.api.exception.MessageRedeliveredException
 
MessageRedeliveredException(String, int, int, InboundEndpoint, MuleEvent, Message) - Constructor for exception org.mule.api.exception.MessageRedeliveredException
 
MessageRedeliveredException(String, int, int, InboundEndpoint, MuleEvent, Message, MessageProcessor) - Constructor for exception org.mule.api.exception.MessageRedeliveredException
 
MessageRedeliveredException(String, int, int, InboundEndpoint, MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.exception.MessageRedeliveredException
 
MessageRedeliveredException - Exception in org.mule.transport.jms.redelivery
 
MessageRedeliveredException(String, int, int, InboundEndpoint, FlowConstruct, MuleMessage) - Constructor for exception org.mule.transport.jms.redelivery.MessageRedeliveredException
 
messageRejectedByFilter() - Static method in class org.mule.config.i18n.CoreMessages
 
MessageRequester - Interface in org.mule.api.transport
Combine MessageRequesting with various lifecycle methods for the actual instances doing message sending.
MessageRequesterFactory - Interface in org.mule.api.transport
A factory interface for managing the lifecycles of a transport's message requesters.
MessageRequesting - Interface in org.mule.api.transport
Defines generic methods for receiving events.
MessageRouter - Interface in org.mule.api.processor
A MessageProcessor that routes messages to zero or more destination message processors.
messages - Variable in class org.mule.transport.AbstractReceiverWorker
 
messagesAdded(MessageCountEvent) - Method in class org.mule.transport.email.RetrieveMessageReceiver
 
MessageSequence<T> - Interface in org.mule.routing
A sequence of messages
MessageService - Interface in org.mule.module.bpm
A message-generation service provided by Mule.
messageSize - Variable in class org.mule.routing.MessageChunkSplitter
 
MessageSource - Interface in org.mule.api.source
Implemented by objects that receives or generates messages which are then processed by a MessageProcessor.
messageSource - Variable in class org.mule.construct.AbstractPipeline
 
messageSource - Variable in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
messageSource(MessageSource) - Method in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
messageSource - Variable in class org.mule.service.AbstractService
Deprecated.
 
messagesRemoved(MessageCountEvent) - Method in class org.mule.transport.email.RetrieveMessageReceiver
 
messageStringIsNotJson() - Static method in class org.mule.module.json.i18n.JsonMessages
 
MessageTransformer - Interface in org.mule.api.transformer
A transformer intended to transform Mule messages rather than arbitrary objects
MessageTypeNotSupportedException - Exception in org.mule.api.transport
MessageTypeNotSupportedException is thrown when a MuleMessage instance is to be created with an payload type that is not of supported type by that MuleMessageFactory.
MessageTypeNotSupportedException(Object, Class<?>) - Constructor for exception org.mule.api.transport.MessageTypeNotSupportedException
 
MessageTypeNotSupportedException(Object, Class<?>, Throwable) - Constructor for exception org.mule.api.transport.MessageTypeNotSupportedException
 
MessageVariableResolverFactory - Class in org.mule.el.mvel
 
MessageVariableResolverFactory(ParserConfiguration, MuleContext, MuleMessage) - Constructor for class org.mule.el.mvel.MessageVariableResolverFactory
 
MessageVariableResolverFactory(ParserConfiguration, MuleContext, MuleMessage, VariableResolverFactory) - Constructor for class org.mule.el.mvel.MessageVariableResolverFactory
Convenience constructor to allow for more concise creation of VariableResolverFactory chains without and performance overhead incurred by using a builder.
MessagingException - Exception in org.mule.api
MessagingException is a general message exception thrown when errors specific to Message processing occur..
MessagingException(Message, MuleMessage) - Constructor for exception org.mule.api.MessagingException
Deprecated.
use MessagingException(Message, MuleEvent)
MessagingException(Message, MuleEvent) - Constructor for exception org.mule.api.MessagingException
 
MessagingException(Message, MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.MessagingException
 
MessagingException(Message, MuleMessage, Throwable) - Constructor for exception org.mule.api.MessagingException
Deprecated.
use MessagingException(Message, MuleEvent, Throwable)
MessagingException(Message, MuleEvent, Throwable) - Constructor for exception org.mule.api.MessagingException
 
MessagingException(Message, MuleEvent, Throwable, MessageProcessor) - Constructor for exception org.mule.api.MessagingException
 
MessagingException(MuleEvent, Throwable) - Constructor for exception org.mule.api.MessagingException
 
MessagingException(MuleEvent, Throwable, MessageProcessor) - Constructor for exception org.mule.api.MessagingException
 
MessagingExceptionHandler - Interface in org.mule.api.exception
Take some action when a messaging exception has occurred (i.e., there was a message in play when the exception occurred).
messagingExceptionHandler - Variable in class org.mule.processor.AbstractMuleObjectOwner
 
MessagingExceptionHandlerAcceptor - Interface in org.mule.api.exception
MessagingExceptionHandlers that will only be executed if accepts to manage MuleEvent
MessagingExceptionHandlerAware - Interface in org.mule.api.exception
Objects that need access to the messaging exception handler of the execution context should implement this interface.
MessagingExceptionHandlerToSystemAdapter - Class in org.mule.exception
 
MessagingExceptionHandlerToSystemAdapter() - Constructor for class org.mule.exception.MessagingExceptionHandlerToSystemAdapter
 
MessagingExceptionLocationProvider - Class in org.mule.exception
Generates location info to augment MessagingExceptions with.
MessagingExceptionLocationProvider() - Constructor for class org.mule.exception.MessagingExceptionLocationProvider
 
MessagingExceptionStrategyAcceptorDelegate - Class in org.mule.exception
MessagingExceptionStrategyAcceptorDelegate(MessagingExceptionHandler) - Constructor for class org.mule.exception.MessagingExceptionStrategyAcceptorDelegate
 
META - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.AddressedEndpointDefinitionParser
 
META - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.ChildAddressDefinitionParser
 
META - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.OrphanAddressDefinitionParser
 
META - Static variable in class org.mule.endpoint.URIBuilder
 
MetaAnnotationTypeFilter - Class in org.mule.util.scan.annotations
Deprecated.
MetaAnnotationTypeFilter(Class<? extends Annotation>, ClassLoader) - Constructor for class org.mule.util.scan.annotations.MetaAnnotationTypeFilter
Deprecated.
Creates an Meta Annotation Filter that look for Meta annotation on an annotation class
MetaAnnotationTypeFilter(Class<? extends Annotation>) - Constructor for class org.mule.util.scan.annotations.MetaAnnotationTypeFilter
Deprecated.
Creates an Meta Annotation Filter that look for Meta annotation on an annotation class.
METADATA_ANNOTATIONS_KEY - Static variable in class org.mule.config.spring.parsers.DefaultXmlMetadataAnnotations
 
METADATA_ANNOTATIONS_KEY - Static variable in interface org.mule.config.spring.parsers.XmlMetadataAnnotations
 
MetadataAware - Interface in org.mule.api
This interface is implemented for every org.mule.api.annotations.Module and org.mule.api.annotations.Connector annotated class and its purpose is to define a contract to query the annotated class about its metadata.
MetadataDbTypeManager - Class in org.mule.module.db.internal.domain.type
Manages database types that are discovered using database metadata
MetadataDbTypeManager() - Constructor for class org.mule.module.db.internal.domain.type.MetadataDbTypeManager
 
MetaTransportServiceDescriptor - Class in org.mule.transport.service
Used to describe a Meta transport, one which only defines an endpoint, not a connector, receiver, dispatcher, etc
MetaTransportServiceDescriptor(String, String, Properties, ClassLoader) - Constructor for class org.mule.transport.service.MetaTransportServiceDescriptor
 
method(String) - Method in class org.mule.module.http.api.client.HttpRequestOptionsBuilder
 
method(String) - Method in interface org.mule.module.http.api.requester.HttpRequestOperationConfig
 
method(String) - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
method - Variable in class org.mule.processor.InvokerMessageProcessor
 
METHOD_CONNECT - Static variable in class org.mule.transport.http.HttpConstants
 
METHOD_DELETE - Static variable in class org.mule.transport.http.HttpConstants
 
METHOD_GET - Static variable in class org.mule.transport.http.HttpConstants
 
METHOD_HEAD - Static variable in class org.mule.transport.http.HttpConstants
 
METHOD_NAMESPACE_PROPERTY - Static variable in interface org.mule.module.cxf.SoapConstants
 
METHOD_OPTIONS - Static variable in class org.mule.transport.http.HttpConstants
 
METHOD_PATCH - Static variable in class org.mule.transport.http.HttpConstants
 
METHOD_POST - Static variable in class org.mule.transport.http.HttpConstants
 
METHOD_PUT - Static variable in class org.mule.transport.http.HttpConstants
 
METHOD_TRACE - Static variable in class org.mule.transport.http.HttpConstants
 
methodArguments - Variable in class org.mule.transport.rmi.RmiMessageReceiver
 
methodExists(String, String) - Static method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
methodHasParamAnnotations(Method) - Static method in class org.mule.util.annotation.AnnotationUtils
 
MethodHeaderPropertyEntryPointResolver - Class in org.mule.model.resolvers
This resolver will look for a MuleProperties.MULE_METHOD_PROPERTY property on the incoming event to determine which method to invoke Users can customise the name of the property used to look up the method name on the event
MethodHeaderPropertyEntryPointResolver() - Constructor for class org.mule.model.resolvers.MethodHeaderPropertyEntryPointResolver
 
methodName - Variable in class org.mule.processor.InvokerMessageProcessor
 
methodNotAllowed(String) - Static method in class org.mule.transport.http.i18n.HttpMessages
 
MethodParameter - Class in org.mule.util.generics
Helper class that encapsulates the specification of a method parameter, i.e.
MethodParameter(Method, int) - Constructor for class org.mule.util.generics.MethodParameter
Create a new MethodParameter for the given method, with nesting level 1.
MethodParameter(Method, int, int) - Constructor for class org.mule.util.generics.MethodParameter
Create a new MethodParameter for the given method.
MethodParameter(Constructor, int) - Constructor for class org.mule.util.generics.MethodParameter
Create a new MethodParameter for the given constructor, with nesting level 1.
MethodParameter(Constructor, int, int) - Constructor for class org.mule.util.generics.MethodParameter
Create a new MethodParameter for the given constructor.
MethodParameter(MethodParameter) - Constructor for class org.mule.util.generics.MethodParameter
Copy constructor, resulting in an independent MethodParameter object based on the same metadata and cache state that the original object was in.
MethodRequestMatcher - Class in org.mule.module.http.internal.listener.matcher
Request matcher for http methods.
MethodRequestMatcher(String...) - Constructor for class org.mule.module.http.internal.listener.matcher.MethodRequestMatcher
The list of methods accepted by this matcher
MethodSecurityMetadataSourceEditor - Class in org.mule.module.spring.security.editors
Property editor to assist with the setup of a MethodSecurityMetadataSource.
MethodSecurityMetadataSourceEditor() - Constructor for class org.mule.module.spring.security.editors.MethodSecurityMetadataSourceEditor
 
methodWithNumParamsNotFoundOnObject(String, int, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
methodWithParamsNotFoundOnObject(String, Object, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
MimeMessageToRfc822ByteArray - Class in org.mule.transport.email.transformers
 
MimeMessageToRfc822ByteArray() - Constructor for class org.mule.transport.email.transformers.MimeMessageToRfc822ByteArray
 
mimeType - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
mimeType - Variable in class org.mule.transformer.AbstractTransformer
 
mimeType - Variable in class org.mule.transformer.types.SimpleDataType
 
MimeTypes - Interface in org.mule.transformer.types
Common mime types used in Mule
MIN - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter representing the minimum value of a counter
Min - Class in org.mule.util.counters.impl
 
Min(String, AbstractCounter) - Constructor for class org.mule.util.counters.impl.Min
 
MIN_FRESH - Static variable in class org.mule.module.http.api.HttpHeaders.Values
MIN_PRIORITY_WEIGHTING - Static variable in interface org.mule.api.transformer.Converter
 
miniSplash(String) - Static method in class org.mule.util.SplashScreen
 
minMuleVersionNotMet(String) - Static method in class org.mule.config.i18n.CoreMessages
 
minThreads - Variable in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
MINUS - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter represening the difference of two other counters
minutes() - Static method in class org.mule.config.i18n.CoreMessages
 
MinValueWatermarkSelector - Class in org.mule.transport.polling.watermark.selector
Implementation of WatermarkSelector that selectes the minimum value of the set.
MinValueWatermarkSelector() - Constructor for class org.mule.transport.polling.watermark.selector.MinValueWatermarkSelector
 
MISSED_AGGREGATION_GROUP_EVENT - Static variable in class org.mule.context.notification.RoutingNotification
 
MISSED_ASYNC_REPLY - Static variable in class org.mule.context.notification.RoutingNotification
 
MISSING_NAME_DISPLAY_VALUE - Static variable in class org.mule.config.NamingExceptionReader
Displayed when no remaining or resolved name found.
missingJobDetail(String) - Static method in class org.mule.transport.quartz.i18n.QuartzMessages
 
MissingParserProblemReporter - Class in org.mule.config.spring
A very simple extension to FailFastProblemReporter that intercepts errors related to missing definition parsers to give a more helpful message.
MissingParserProblemReporter() - Constructor for class org.mule.config.spring.MissingParserProblemReporter
 
MissingPGPKeyException - Exception in org.mule.module.pgp.exception
MissingSecretPGPKeyException is the exception in case data regarding the pgp keys is necessary but no provided in the configuration.
MissingPGPKeyException(Message) - Constructor for exception org.mule.module.pgp.exception.MissingPGPKeyException
 
MissingPGPKeyException(Throwable) - Constructor for exception org.mule.module.pgp.exception.MissingPGPKeyException
 
mkdir(String) - Method in class org.mule.transport.sftp.SftpClient
Creates a directory
MockEncryptionStrategy - Class in org.mule.tck.security
Empty mock for tests
MockEncryptionStrategy() - Constructor for class org.mule.tck.security.MockEncryptionStrategy
 
MockKeyFactory - Class in org.mule.tck.security
Empty mock for tests
MockKeyFactory() - Constructor for class org.mule.tck.security.MockKeyFactory
 
MODE_IN - Variable in class org.mule.transport.soap.axis.NamedParameter
 
MODE_INOUT - Variable in class org.mule.transport.soap.axis.NamedParameter
 
MODE_OUT - Variable in class org.mule.transport.soap.axis.NamedParameter
 
Model - Interface in org.mule.api.model
Deprecated.
model - Variable in class org.mule.service.AbstractService
Deprecated.
The model in which this service is registered
MODEL_CLASS - Static variable in class org.mule.api.config.MuleProperties
***************************************************************************** Model Service descriptor properties *****************************************************************************
MODEL_DISPOSED - Static variable in class org.mule.context.notification.ModelNotification
Deprecated.
 
MODEL_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
MODEL_INITIALISED - Static variable in class org.mule.context.notification.ModelNotification
Deprecated.
 
MODEL_STARTED - Static variable in class org.mule.context.notification.ModelNotification
Deprecated.
 
MODEL_STOPPED - Static variable in class org.mule.context.notification.ModelNotification
Deprecated.
 
ModelBuilder - Class in org.mule.config.dsl
Deprecated.
ModelBuilder(MuleContext) - Constructor for class org.mule.config.dsl.ModelBuilder
Deprecated.
 
ModelDefinitionParser - Class in org.mule.config.spring.parsers.specific
Deprecated.
ModelDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.ModelDefinitionParser
Deprecated.
 
modelDeprecated() - Static method in class org.mule.config.i18n.CoreMessages
 
ModelLifecycleManager - Class in org.mule.model
Deprecated.
ModelLifecycleManager(AbstractModel) - Constructor for class org.mule.model.ModelLifecycleManager
Deprecated.
 
ModelNotification - Class in org.mule.context.notification
Deprecated.
ModelNotification(Model, int) - Constructor for class org.mule.context.notification.ModelNotification
Deprecated.
 
ModelNotificationListener<T extends ModelNotification> - Interface in org.mule.api.context.notification
Deprecated.
ModelService - Class in org.mule.module.management.mbean
Deprecated.
ModelService(Model) - Constructor for class org.mule.module.management.mbean.ModelService
Deprecated.
 
ModelServiceDescriptor - Interface in org.mule.api.model
Deprecated.
ModelServiceMBean - Interface in org.mule.module.management.mbean
ModelServiceMBean JMX Service interface for the Model.
ModuleArchetypeMojo - Class in org.mule.tools.maven.archetype
Builds archetype containers.
ModuleArchetypeMojo() - Constructor for class org.mule.tools.maven.archetype.ModuleArchetypeMojo
 
ModuleCapability - Enum in org.mule.api.devkit.capability
Enumeration of possible capabilities of Mule modules.
moduleObject - Variable in class org.mule.devkit.processor.DevkitBasedMessageProcessor
Module object
modules - Variable in class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
MONITOR_PROFILING - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
MonitoredObjectStoreWrapper<T extends Serializable> - Class in org.mule.util.store
The MonitoredObjectStoreWrapper wraps an ObjectStore which does not support direct expiry and adds this behavior
MonitoredObjectStoreWrapper(ListableObjectStore<MonitoredObjectStoreWrapper.StoredObject<T>>) - Constructor for class org.mule.util.store.MonitoredObjectStoreWrapper
 
MonitoredObjectStoreWrapper(ListableObjectStore<MonitoredObjectStoreWrapper.StoredObject<T>>, int, int, int) - Constructor for class org.mule.util.store.MonitoredObjectStoreWrapper
 
MonitoredObjectStoreWrapper.StoredObject<T> - Class in org.mule.util.store
 
MonitoredObjectStoreWrapper.StoredObject(T, Long, Serializable) - Constructor for class org.mule.util.store.MonitoredObjectStoreWrapper.StoredObject
 
moreThanOneConnectorWithProtocol(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
moreThanOneMessageInTransaction(String, String) - Static method in class org.mule.transport.jdbc.i18n.JdbcMessages
 
move(File, File) - Method in class org.mule.transport.file.FileConnector
 
moveFileWithCopyFallback(File, File) - Static method in class org.mule.util.FileUtils
Try to move a file by renaming with backup attempt by copying/deleting via NIO.
moveToDirectoryNotWritable() - Static method in class org.mule.transport.file.i18n.FileMessages
 
MssqlDatasourceFactoryBean - Class in org.mule.transport.jdbc.config
 
MssqlDatasourceFactoryBean() - Constructor for class org.mule.transport.jdbc.config.MssqlDatasourceFactoryBean
 
MTOM_ENABLED - Static variable in class org.mule.module.cxf.CxfConstants
 
mtomEnabled - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
Mule - Annotation Type in org.mule.api.annotations.expressions
TODO
MULE_10_ACTOR - Static variable in class org.mule.module.cxf.MuleSoapHeaders
 
MULE_ARRIVAL_ORDER_PROPERTY - Static variable in class org.mule.routing.EventGroup
 
MULE_CONTEXT_ATTRIBUTE - Static variable in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
MULE_CONTEXT_CONFIGURATION_ID_KEY - Static variable in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
MULE_CONTEXT_INTERNAL_VARIABLE - Static variable in class org.mule.el.mvel.MVELExpressionLanguageContext
 
MULE_CONTEXT_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_CONTEXT_START_TIMEOUT_SYSTEM_PROPERTY - Static variable in class org.mule.transport.AbstractConnector
 
MULE_CONTEXT_STARTED_COMMAND - Static variable in class org.mule.test.infrastructure.process.CommandServer
 
MULE_CONTEXT_WORKMANAGER_MAXTHREADSACTIVE - Static variable in class org.mule.context.DefaultMuleContextBuilder
 
MULE_CORE_EXTENSIONS_PROPERTY - Static variable in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
MULE_CORRELATION_GROUP_SIZE_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_CORRELATION_ID_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_CORRELATION_SEQUENCE_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_CREDENTIALS_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_DEFAULT_NAMESPACE - Static variable in class org.mule.config.spring.util.SpringXMLUtils
 
MULE_DEFAULT_PROCESSING_STRATEGY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_DEFAULTS_CONFIG - Static variable in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
MULE_DIR - Static variable in class org.mule.module.boot.DefaultMuleClassPathConfig
 
MULE_DIR - Static variable in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
MULE_DISABLE_TRANSPORT_TRANSFORMER_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_DOMAIN_FOLDER - Static variable in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
MULE_DOMAIN_REGISTRY_BOOTSTRAP_SPRING_CONFIG - Static variable in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
MULE_ENCODING_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_ENCODING_SYSTEM_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_ENDPOINT_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_ERROR_CODE_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_EVENT - Static variable in class org.mule.module.cxf.CxfConstants
 
MULE_EVENT_INTERNAL_VARIABLE - Static variable in class org.mule.el.mvel.MVELExpressionLanguageContext
 
MULE_EVENT_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
***************************************************************************** MuleEvent Level properties *****************************************************************************
MULE_EVENT_TIMEOUT_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_FLOW_TRACE - Static variable in class org.mule.api.config.MuleProperties
 
MULE_FORCE_CONSOLE_LOG - Static variable in class org.mule.api.config.MuleProperties
 
MULE_FORCE_RECURSE - Static variable in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
MULE_FORCE_SYNC_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_HEADER - Static variable in class org.mule.module.cxf.MuleSoapHeaders
 
MULE_HOME_DIRECTORY_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_IGNORE_METHOD_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_IMAPS_NAMESPACE - Static variable in class org.mule.transport.email.ImapsSocketFactory
 
MULE_JMS_SESSION - Static variable in class org.mule.api.config.MuleProperties
 
MULE_LOCAL_JAR_FILENAME - Static variable in class org.mule.module.boot.MuleBootstrapUtils
 
MULE_LOCAL_JAR_FILENAME - Static variable in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
MULE_LOCAL_JAR_FILENAME - Static variable in class org.mule.util.JarUtils
 
MULE_LOG_CONTEXT_DISPOSE_DELAY_MILLIS - Static variable in class org.mule.api.config.MuleProperties
 
MULE_MANAGEMENT_CONTEXT_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_MESSAGE - Static variable in class org.mule.transformer.types.DataTypeFactory
 
MULE_MESSAGE_DATA_TYPE - Static variable in class org.mule.transformer.AbstractTransformer
 
MULE_MESSAGE_ID_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_MESSAGE_INTERNAL_VARIABLE - Static variable in class org.mule.el.mvel.MVELExpressionLanguageContext
 
MULE_METHOD_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_MINIMAL_SPRING_CONFIG - Static variable in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
MULE_NAMESPACE - Static variable in class org.mule.module.cxf.MuleSoapHeaders
 
MULE_NAMESPACE_PREFIX - Static variable in class org.mule.config.spring.util.SpringXMLUtils
 
MULE_NO_RECURSE - Static variable in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
MULE_NO_REGISTRATION - Static variable in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
MULE_ORIGINATING_ENDPOINT_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_POP3S_NAMESPACE - Static variable in class org.mule.transport.email.Pop3sSocketFactory
 
MULE_POST_CHILDREN - Static variable in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
MULE_PROXY_ADDRESS - Static variable in class org.mule.api.config.MuleProperties
 
MULE_QUEUE_OLD_MODE_KEY - Static variable in class org.mule.util.queue.DelegateQueueManager
 
MULE_REGISTRY_BOOTSTRAP_SPRING_CONFIG - Static variable in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
MULE_REMOTE_CLIENT_ADDRESS - Static variable in class org.mule.api.config.MuleProperties
 
MULE_REMOTE_SYNC_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_REPEAT_PARSE - Static variable in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
MULE_REPLY_TO_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_REPLY_TO_REQUESTOR_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_REPLY_TO_STOP_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
Prevents processing of the ReplyTo property by the Service.
MULE_ROOT_MESSAGE_ID_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_SECURITY_PROVIDER_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_SECURITY_SYSTEM_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_SESSION_ID_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
Deprecated.
This property is no longer needed and will be removed in the next major release
MULE_SESSION_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_SIMPLE_LOG - Static variable in class org.mule.api.config.MuleProperties
 
MULE_SMTPS_NAMESPACE - Static variable in class org.mule.transport.email.SmtpsSocketFactory
 
MULE_SOAP_METHOD - Static variable in class org.mule.api.config.MuleProperties
 
MULE_SPRING_CONFIG - Static variable in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
MULE_STREAMING_BUFFER_SIZE - Static variable in class org.mule.api.config.MuleProperties
 
MULE_TCP_BIND_LOCALHOST_TO_ALL_LOCAL_INTERFACES_PROPERTY - Static variable in class org.mule.transport.tcp.TcpPropertyHelper
 
MULE_TRANSPORT_FILE_SINGLEPOLLINSTANCE - Static variable in class org.mule.transport.file.FileMessageReceiver
 
MULE_USER_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MULE_WAIT_MILLIS - Static variable in class org.mule.transport.TrackingWorkManager
 
MULE_WATERMARK_PARTITION - Static variable in class org.mule.config.spring.factories.WatermarkFactoryBean
 
MULE_WILDCARD_DEPLOY_FILE - Static variable in class org.mule.module.launcher.DefaultAppBloodhound
 
MULE_WORKING_DIRECTORY_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
 
MuleAjaxServlet - Class in org.mule.transport.ajax.container
Wraps the ContinuationCometdServlet servlet and binds the Bayeux object to the Mule AjaxServletConnector.
MuleAjaxServlet() - Constructor for class org.mule.transport.ajax.container.MuleAjaxServlet
 
MuleAjaxServlet.MuleContinuationBayeux - Class in org.mule.transport.ajax.container
We subclass the ContinuationBayeux so tat we can insert a different message implementation that allows us to have better control over the message going across the wire.
MuleAjaxServlet.MuleContinuationBayeux() - Constructor for class org.mule.transport.ajax.container.MuleAjaxServlet.MuleContinuationBayeux
 
MuleAjaxServlet.MuleMessageImpl - Class in org.mule.transport.ajax.container
 
MuleAjaxServlet.MuleMessageImpl(MessagePool) - Constructor for class org.mule.transport.ajax.container.MuleAjaxServlet.MuleMessageImpl
 
MuleAnnotationParser - Class in org.mule.config.expression
Used to parse Mule parameter annotations
MuleAnnotationParser() - Constructor for class org.mule.config.expression.MuleAnnotationParser
 
MuleApplicationBuilder<A extends Application> - Interface in org.mule.module.launcher.application.builder
Interface for building Application
MuleApplicationClassLoader - Class in org.mule.module.launcher
 
MuleApplicationClassLoader(String, ClassLoader, NativeLibraryFinder) - Constructor for class org.mule.module.launcher.MuleApplicationClassLoader
 
MuleApplicationClassLoader(String, ClassLoader, Set<String>, NativeLibraryFinder) - Constructor for class org.mule.module.launcher.MuleApplicationClassLoader
 
MuleApplicationClassLoaderFactory - Class in org.mule.module.launcher.application
Creates MuleApplicationClassLoader instances based on the application descriptor.
MuleApplicationClassLoaderFactory(DomainClassLoaderRepository, NativeLibraryFinderFactory) - Constructor for class org.mule.module.launcher.application.MuleApplicationClassLoaderFactory
 
MuleApplicationContext - Class in org.mule.config.spring
Deprecated.
Use MuleArtifactContext
MuleApplicationContext(MuleContext, ConfigResource[]) - Constructor for class org.mule.config.spring.MuleApplicationContext
Deprecated.
 
MuleApplicationContext(MuleContext, Resource[]) - Constructor for class org.mule.config.spring.MuleApplicationContext
Deprecated.
 
MuleApplicationEvent - Class in org.mule.module.spring.events
Deprecated.
MuleApplicationEvent(Object, String) - Constructor for class org.mule.module.spring.events.MuleApplicationEvent
Deprecated.
 
MuleArtifactContext - Class in org.mule.config.spring
MuleArtifactContext is a simple extension application context that allows resources to be loaded from the Classpath of file system using the MuleBeanDefinitionReader.
MuleArtifactContext(MuleContext, ConfigResource[]) - Constructor for class org.mule.config.spring.MuleArtifactContext
Parses configuration files creating a spring ApplicationContext which is used as a parent registry using the SpringRegistry registry implementation to wraps the spring ApplicationContext
MuleArtifactContext(MuleContext, ConfigResource[], OptionalObjectsController) - Constructor for class org.mule.config.spring.MuleArtifactContext
Parses configuration files creating a spring ApplicationContext which is used as a parent registry using the SpringRegistry registry implementation to wraps the spring ApplicationContext
MuleArtifactContext(MuleContext, Resource[]) - Constructor for class org.mule.config.spring.MuleArtifactContext
 
MuleArtifactContext(MuleContext, Resource[], OptionalObjectsController) - Constructor for class org.mule.config.spring.MuleArtifactContext
Parses configuration files creating a spring ApplicationContext which is used as a parent registry using the SpringRegistry registry implementation to wraps the spring ApplicationContext
MuleBaseVariableResolverFactory - Class in org.mule.el.mvel
 
MuleBaseVariableResolverFactory() - Constructor for class org.mule.el.mvel.MuleBaseVariableResolverFactory
 
MuleBeanDefinitionDocumentReader - Class in org.mule.config.spring
Allows us to hook in our own Hierarchical Parser delegate.
MuleBeanDefinitionDocumentReader() - Constructor for class org.mule.config.spring.MuleBeanDefinitionDocumentReader
 
muleBin - Variable in class org.mule.test.infrastructure.process.Controller
 
MuleBootstrap - Class in org.mule.module.boot
Determine which is the main class to run and delegate control to the Java Service Wrapper.
MuleBootstrap() - Constructor for class org.mule.module.boot.MuleBootstrap
 
MuleBootstrapUtils - Class in org.mule.module.boot
 
MuleBootstrapUtils.ProxyInfo - Class in org.mule.module.boot
 
MuleBootstrapUtils.ProxyInfo(String, String) - Constructor for class org.mule.module.boot.MuleBootstrapUtils.ProxyInfo
 
MuleBootstrapUtils.ProxyInfo(String, String, String, String) - Constructor for class org.mule.module.boot.MuleBootstrapUtils.ProxyInfo
 
MuleCallbackHandler - Class in org.mule.module.jaas
 
MuleCallbackHandler(Authentication) - Constructor for class org.mule.module.jaas.MuleCallbackHandler
 
MuleChildDefinitionParser - Interface in org.mule.config.spring.parsers
Extra functionality exposed by child parsers
MuleClient - Interface in org.mule.api.client
Provides methods for performing send, dispatch and request operations programatically.
MuleClient - Class in org.mule.module.client
MuleClient is a simple interface for Mule clients to send and receive events from a Mule Server.
MuleClient() - Constructor for class org.mule.module.client.MuleClient
Creates a Mule client that will use the default serverEndpoint when connecting to a remote server instance.
MuleClient(boolean) - Constructor for class org.mule.module.client.MuleClient
 
MuleClient(MuleContext) - Constructor for class org.mule.module.client.MuleClient
 
MuleClient(String) - Constructor for class org.mule.module.client.MuleClient
Configures a Mule client instance using the the default SpringXmlConfigurationBuilder to parse configResources.
MuleClient(String, String) - Constructor for class org.mule.module.client.MuleClient
Configures a new Mule client and either uses an existing Manager running in this JVM or creates a new empty MuleContext
MuleClient(String, ConfigurationBuilder) - Constructor for class org.mule.module.client.MuleClient
Configures a Mule client instance
MuleClient(String, ConfigurationBuilder, String, String) - Constructor for class org.mule.module.client.MuleClient
Configures a Mule client instance
MuleConfigProvider - Class in org.mule.transport.soap.axis.extensions
MuleConfigProvider is needed because the Simple Provider does not list services in the defaultConfiguration.
MuleConfigProvider(EngineConfiguration) - Constructor for class org.mule.transport.soap.axis.extensions.MuleConfigProvider
 
MuleConfiguration - Interface in org.mule.api.config
Configuration info.
MuleConfigurationConfigurator - Class in org.mule.config.spring
This class is a "SmartFactoryBean" which allows a few XML attributes to be set on the otherwise read-only MuleConfiguration.
MuleConfigurationConfigurator() - Constructor for class org.mule.config.spring.MuleConfigurationConfigurator
 
MuleConfigurationService - Class in org.mule.module.management.mbean
MuleConfigurationService exposes the MuleConfiguration settings as a management service.
MuleConfigurationService(MuleConfiguration) - Constructor for class org.mule.module.management.mbean.MuleConfigurationService
 
MuleConfigurationServiceMBean - Interface in org.mule.module.management.mbean
MuleConfigurationServiceMBean is a JMx service interface for the Mule server configuration.
MuleConnectorOperationLocator - Class in org.mule.connector
Default ConnectorOperationLocator that will search in the mule registry for registered ConnectorOperationLocator to later provider operations through the use of URLs.
MuleConnectorOperationLocator() - Constructor for class org.mule.connector.MuleConnectorOperationLocator
 
MuleContainer - Class in org.mule.module.launcher
 
MuleContainer(String[]) - Constructor for class org.mule.module.launcher.MuleContainer
 
MuleContainer(DeploymentService, MuleCoreExtensionManager) - Constructor for class org.mule.module.launcher.MuleContainer
 
MuleContainer(String[], DeploymentService, MuleCoreExtensionManager) - Constructor for class org.mule.module.launcher.MuleContainer
Configure the server with command-line arguments.
MuleContainerBootstrap - Class in org.mule.module.reboot
Determine which is the main class to run and delegate control to the Java Service Wrapper.
MuleContainerBootstrap() - Constructor for class org.mule.module.reboot.MuleContainerBootstrap
 
MuleContainerBootstrapUtils - Class in org.mule.module.reboot
 
MuleContainerBootstrapUtils.ProxyInfo - Class in org.mule.module.reboot
 
MuleContainerBootstrapUtils.ProxyInfo(String, String) - Constructor for class org.mule.module.reboot.MuleContainerBootstrapUtils.ProxyInfo
 
MuleContainerBootstrapUtils.ProxyInfo(String, String, String, String) - Constructor for class org.mule.module.reboot.MuleContainerBootstrapUtils.ProxyInfo
 
MuleContainerStartupSplashScreen - Class in org.mule.module.launcher
 
MuleContainerStartupSplashScreen() - Constructor for class org.mule.module.launcher.MuleContainerStartupSplashScreen
 
MuleContainerSystemClassLoader - Class in org.mule.module.reboot
Loads a standard $MULE_HOME/lib/* hierarchy.
MuleContainerSystemClassLoader(DefaultMuleClassPathConfig) - Constructor for class org.mule.module.reboot.MuleContainerSystemClassLoader
 
MuleContainerWrapper - Class in org.mule.module.reboot
 
MuleContainerWrapper() - Constructor for class org.mule.module.reboot.MuleContainerWrapper
 
muleContext - Variable in class org.mule.AbstractAgent
 
muleContext - Variable in class org.mule.api.context.notification.ServerNotification
 
muleContext - Variable in class org.mule.api.FutureMessageResult
 
MuleContext - Interface in org.mule.api
 
muleContext - Variable in class org.mule.api.processor.LoggerMessageProcessor
 
muleContext - Variable in class org.mule.client.DefaultLocalMuleClient
 
muleContext - Variable in class org.mule.component.AbstractComponent
 
muleContext - Variable in class org.mule.component.BindingInvocationHandler
 
muleContext - Variable in class org.mule.component.ComponentLifecycleManager
 
muleContext - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
 
muleContext - Variable in class org.mule.config.bootstrap.AbstractRegistryBootstrap
 
muleContext - Variable in class org.mule.config.builders.MuleXmlBuilderContextListener
 
muleContext - Variable in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
muleContext - Variable in class org.mule.config.endpoint.AnnotatedEndpointHelper
 
muleContext - Variable in class org.mule.config.endpoint.RegistryBackedAnnotationsParserFactory
 
muleContext - Variable in class org.mule.config.ImmutableThreadingProfile.DefaultWorkManagerFactory
 
muleContext - Variable in class org.mule.config.pool.ThreadPoolFactory
 
muleContext - Variable in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
muleContext - Variable in class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
muleContext - Variable in class org.mule.construct.AbstractFlowConstruct
 
muleContext - Variable in class org.mule.construct.FlowConstructLifecycleManager
 
muleContext - Variable in class org.mule.DefaultMuleMessage
 
muleContext - Variable in class org.mule.devkit.processor.DevkitBasedMessageProcessor
Mule Context
muleContext - Variable in class org.mule.el.context.AppContext
 
muleContext - Variable in class org.mule.el.ExpressionLanguageComponent
 
muleContext - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
muleContext - Variable in class org.mule.el.mvel.MVELExpressionLanguageContext
 
muleContext - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
muleContext - Variable in class org.mule.endpoint.DefaultEndpointFactory
 
muleContext - Variable in class org.mule.endpoint.SimpleEndpointCache
 
muleContext - Variable in class org.mule.expression.EndpointInfoExpressionEvaluator
 
muleContext - Variable in class org.mule.expression.MessagePayloadExpressionEvaluator
 
muleContext - Variable in class org.mule.expression.MuleContextExpressionEvaluator
 
muleContext - Variable in class org.mule.lifecycle.RegistryLifecycleManager
 
muleContext - Variable in class org.mule.model.AbstractModel
Deprecated.
 
muleContext - Variable in class org.mule.module.bpm.Process
 
muleContext - Variable in class org.mule.module.bpm.Rules
 
muleContext - Variable in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
muleContext - Variable in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
muleContext - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
muleContext - Variable in class org.mule.module.guice.AbstractMuleGuiceModule
Deprecated.
 
muleContext - Variable in class org.mule.module.guice.MuleSupportModule
Deprecated.
 
muleContext - Variable in class org.mule.module.json.transformers.JsonSchemaXsdValidationFilter
Deprecated.
 
muleContext - Variable in class org.mule.module.launcher.application.DefaultMuleApplication
 
muleContext - Variable in class org.mule.module.management.agent.JmxAgentConfigurer
 
muleContext - Variable in class org.mule.module.management.agent.YourKitProfilerAgent
 
muleContext - Variable in class org.mule.module.management.mbean.FlowConstructService
 
muleContext - Variable in class org.mule.module.scripting.builders.ScriptConfigurationBuilder
Deprecated.
 
muleContext - Variable in class org.mule.module.scripting.expression.AbstractScriptExpressionEvaluator
 
muleContext - Variable in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
 
muleContext - Variable in class org.mule.module.tomcat.MuleTomcatListener
 
muleContext - Variable in class org.mule.module.xml.expression.JXPathExpressionEvaluator
Deprecated.
 
muleContext - Static variable in class org.mule.MuleServer
The MuleContext should contain anything which does not belong in the Registry.
muleContext - Variable in class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
muleContext - Variable in class org.mule.processor.AbstractMuleObjectOwner
 
muleContext - Variable in class org.mule.processor.InvokerMessageProcessor
 
muleContext - Variable in class org.mule.registry.AbstractRegistry
 
muleContext - Variable in class org.mule.routing.AbstractAggregator
 
muleContext - Variable in class org.mule.routing.correlation.CollectionCorrelatorCallback
 
muleContext - Variable in class org.mule.routing.correlation.ResequenceMessagesCorrelatorCallback
 
muleContext - Variable in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
muleContext - Variable in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
muleContext - Variable in class org.mule.security.AbstractSecurityFilter
 
muleContext - Variable in class org.mule.security.oauth.BaseOAuth2Manager
muleContext
muleContext - Variable in class org.mule.security.oauth.process.RetryProcessInterceptor
Mule Context
muleContext - Variable in class org.mule.serialization.internal.AbstractObjectSerializer
 
muleContext - Variable in class org.mule.service.AbstractService
Deprecated.
 
muleContext - Variable in class org.mule.service.ServiceLifecycleManager
Deprecated.
 
muleContext - Variable in class org.mule.source.StartableCompositeMessageSource
 
muleContext - Variable in class org.mule.transaction.AbstractTransaction
 
muleContext - Variable in class org.mule.transformer.AbstractTransformer
 
muleContext - Variable in class org.mule.transformer.wire.TransformerPairWireFormat
 
muleContext - Variable in class org.mule.transport.AbstractConnector
 
muleContext - Variable in class org.mule.transport.AbstractMuleMessageFactory
 
muleContext - Variable in class org.mule.transport.DefaultReplyToHandler
 
muleContext - Variable in class org.mule.transport.file.ExpressionFilenameParser
 
muleContext - Variable in class org.mule.transport.quartz.jobs.AbstractJob
 
muleContext - Variable in class org.mule.transport.service.TransportFactory
 
muleContext - Variable in class org.mule.transport.servlet.AbstractReceiverServlet
 
muleContext - Variable in class org.mule.transport.soap.axis.extensions.UniversalSender
 
muleContext - Variable in class org.mule.util.pool.CommonsPoolObjectPool
 
MuleContextAware - Interface in org.mule.api.context
Objects who want to be aware of the MuleContext should implement this interface.
MuleContextBuilder - Interface in org.mule.api.context
Builder that is used to build instances of MuleContext.
MuleContextDeploymentListener - Class in org.mule.module.launcher.artifact
Delegates MuleContextListener notifications to a DeploymentListener
MuleContextDeploymentListener(String, DeploymentListener) - Constructor for class org.mule.module.launcher.artifact.MuleContextDeploymentListener
 
MuleContextDisposePhase - Class in org.mule.lifecycle.phases
Objects are disposed of via the Registry since the Registry manages the creation/initialisation of the objects it must also take care of disposing them.
MuleContextDisposePhase() - Constructor for class org.mule.lifecycle.phases.MuleContextDisposePhase
 
MuleContextException - Exception in org.mule.api.context
MuleContextException is thrown when an exception occurs with Mule Context objects
MuleContextException(Message) - Constructor for exception org.mule.api.context.MuleContextException
 
MuleContextException(Message, Throwable) - Constructor for exception org.mule.api.context.MuleContextException
 
MuleContextExpressionEvaluator - Class in org.mule.expression
This property extractor exposes mule context information as expressions.
MuleContextExpressionEvaluator() - Constructor for class org.mule.expression.MuleContextExpressionEvaluator
 
MuleContextFactory - Interface in org.mule.api.context
A MuleContextFactory is used to create instances of MuleContext.
MuleContextInitialisePhase - Class in org.mule.lifecycle.phases
The MuleContextInitialisePhase defines the lifecycle behaviour when the Mule context is initialised.
MuleContextInitialisePhase() - Constructor for class org.mule.lifecycle.phases.MuleContextInitialisePhase
 
MuleContextLifecycleManager - Class in org.mule.lifecycle
This is a specialized class that extends RegistryLifecycleManager and will invoke lifecycle on the registry instance for the MuleContext.
MuleContextLifecycleManager() - Constructor for class org.mule.lifecycle.MuleContextLifecycleManager
 
MuleContextListener - Interface in org.mule.api.context.notification
Listens to events raised during the creation of a MuleContext
MuleContextNotification - Class in org.mule.context.notification
MuleContextNotification is fired when an event such as the mule context starting occurs.
MuleContextNotification(MuleContext, String) - Constructor for class org.mule.context.notification.MuleContextNotification
 
MuleContextNotification(MuleContext, int) - Constructor for class org.mule.context.notification.MuleContextNotification
 
MuleContextNotificationListener<T extends MuleContextNotification> - Interface in org.mule.api.context.notification
MuleContextNotificationListener is an observer interface that objects can implement and then register themselves with the Mule manager to be notified when a Manager event occurs.
MuleContextPostProcessor - Class in org.mule.config.spring
Responsible for passing in the MuleContext instance for all objects in the registry that want it.
MuleContextPostProcessor(MuleContext) - Constructor for class org.mule.config.spring.MuleContextPostProcessor
 
MuleContextProcessApplication - Class in org.mule.test.infrastructure.process
 
MuleContextProcessApplication() - Constructor for class org.mule.test.infrastructure.process.MuleContextProcessApplication
 
MuleContextProcessBuilder - Class in org.mule.test.infrastructure.process
 
MuleContextProcessBuilder(File) - Constructor for class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
MuleContextProcessBuilder(MuleContextProcessBuilder) - Constructor for class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
MuleContextProcessor - Class in org.mule.registry
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)
MuleContextProcessor(MuleContext) - Constructor for class org.mule.registry.MuleContextProcessor
Deprecated.
 
MuleContextStartPhase - Class in org.mule.lifecycle.phases
The Start phase for the MuleContext.
MuleContextStartPhase() - Constructor for class org.mule.lifecycle.phases.MuleContextStartPhase
 
MuleContextStartPhase(Class<?>[]) - Constructor for class org.mule.lifecycle.phases.MuleContextStartPhase
 
MuleContextStopPhase - Class in org.mule.lifecycle.phases
The Stop phase for the Management context LifecycleManager.
MuleContextStopPhase() - Constructor for class org.mule.lifecycle.phases.MuleContextStopPhase
 
MuleContextStopPhase(Class<?>[]) - Constructor for class org.mule.lifecycle.phases.MuleContextStopPhase
 
MuleControllerException - Exception in org.mule.test.infrastructure.process
 
MuleControllerException() - Constructor for exception org.mule.test.infrastructure.process.MuleControllerException
Constructs a new runtime exception with null as its detail message.
MuleControllerException(String) - Constructor for exception org.mule.test.infrastructure.process.MuleControllerException
Constructs a new runtime exception with the specified detail message.
MuleControllerException(Throwable) - Constructor for exception org.mule.test.infrastructure.process.MuleControllerException
Constructs a new runtime exception with the specified cause and a detail message of (cause==null ? null : cause.toString()) (which typically contains the class and detail message of cause).
MuleControllerException(String, Throwable) - Constructor for exception org.mule.test.infrastructure.process.MuleControllerException
Constructs a new runtime exception with the specified detail message and cause.
MuleCoreExtension - Interface in org.mule
Allows Mule modules and transports to extend core functionality in an application-independent fashion.
MuleCoreExtensionDependency - Annotation Type in org.mule
Indicates that an annotated method must be used to inject a MuleCoreExtension dependency.
MuleCoreExtensionDependencyDiscoverer - Interface in org.mule.module.launcher.coreextension
Discovers dependencies between MuleCoreExtension instances
MuleCoreExtensionDependencyResolver - Interface in org.mule.module.launcher.coreextension
Resolves dependencies between MuleCoreExtension instances.
MuleCoreExtensionDiscoverer - Interface in org.mule.module.launcher.coreextension
Defines a way to search for available MuleCoreExtension
MuleCoreExtensionManager - Interface in org.mule.module.launcher.coreextension
Manages lifecycle and dependency injection for MuleCoreExtension
MuleCoreExtensionProcessConfigurer - Class in org.mule.test.infrastructure.process
 
MuleCoreExtensionProcessConfigurer(Class<? extends MuleCoreExtension>...) - Constructor for class org.mule.test.infrastructure.process.MuleCoreExtensionProcessConfigurer
 
MuleCredentials - Class in org.mule.security
MuleCredentials can be used to read and set Mule user information that can be stored in a message header.
MuleCredentials(String, char[]) - Constructor for class org.mule.security.MuleCredentials
 
MuleCredentials(String, char[], Object) - Constructor for class org.mule.security.MuleCredentials
 
MuleCredentials(String, SecurityManager) - Constructor for class org.mule.security.MuleCredentials
 
MuleDefaultObjectStoreFactory - Class in org.mule.util.store
 
MuleDefaultObjectStoreFactory() - Constructor for class org.mule.util.store.MuleDefaultObjectStoreFactory
 
MuleDefinitionParser - Interface in org.mule.config.spring.parsers
This is the interface all Mule BDPs implement.
MuleDefinitionParserConfiguration - Interface in org.mule.config.spring.parsers
 
MuleDeploy - Class in org.mule.tools.anttasks
Ant task to deploy a Mule application to the MULE_HOME/apps directory.
MuleDeploy() - Constructor for class org.mule.tools.anttasks.MuleDeploy
 
MuleDeploymentService - Class in org.mule.module.launcher
 
MuleDeploymentService(PluginClassLoaderManager) - Constructor for class org.mule.module.launcher.MuleDeploymentService
 
MuleDerbyTestDatabase - Class in org.mule.tck.util
Helper class for creating a derby database.
MuleDerbyTestDatabase(String) - Constructor for class org.mule.tck.util.MuleDerbyTestDatabase
 
MuleDerbyTestUtils - Class in org.mule.tck.util
 
MuleDomainBeanDefinitionDocumentReader - Class in org.mule.config.spring
Allows us to hook in our own Hierarchical Parser delegate.
MuleDomainBeanDefinitionDocumentReader() - Constructor for class org.mule.config.spring.MuleDomainBeanDefinitionDocumentReader
 
MuleDomainBuilder<A extends Domain> - Interface in org.mule.module.launcher.application.builder
Interface for building Domain
MuleDomainClassLoaderRepository - Class in org.mule.module.launcher.domain
 
MuleDomainClassLoaderRepository() - Constructor for class org.mule.module.launcher.domain.MuleDomainClassLoaderRepository
 
MuleDomainNamespaceHandler - Class in org.mule.config.spring.handlers
This is the domain namespace handler for Mule domains and configures all domains configuration elements under the http://www.mulesoft.org/schema/mule/domain/${version} Namespace.
MuleDomainNamespaceHandler() - Constructor for class org.mule.config.spring.handlers.MuleDomainNamespaceHandler
 
MuleEncryptionEndpointSecurityFilter - Class in org.mule.security.filters
MuleEncryptionEndpointSecurityFilter provides password-based encryption
MuleEncryptionEndpointSecurityFilter() - Constructor for class org.mule.security.filters.MuleEncryptionEndpointSecurityFilter
 
MuleEndpointURI - Class in org.mule.endpoint
MuleEndpointURI is used to determine how a message is sent or received.
MuleEndpointURI(String, String, String, String, String, Properties, URI, MuleContext) - Constructor for class org.mule.endpoint.MuleEndpointURI
 
MuleEndpointURI(EndpointURI) - Constructor for class org.mule.endpoint.MuleEndpointURI
 
MuleEndpointURI(EndpointURI, String) - Constructor for class org.mule.endpoint.MuleEndpointURI
 
MuleEndpointURI(String, MuleContext) - Constructor for class org.mule.endpoint.MuleEndpointURI
 
MuleEndpointURI(String, MuleContext, Properties) - Constructor for class org.mule.endpoint.MuleEndpointURI
 
MuleEndpointURI(String, String, MuleContext) - Constructor for class org.mule.endpoint.MuleEndpointURI
Creates but does not initialize the endpoint URI.
MuleEvent - Interface in org.mule.api
MuleEvent represents any data event occuring in the Mule environment.
MuleEventContext - Interface in org.mule.api
MuleEventContext is the context object for the current request.
MuleEventKeyGenerator - Interface in org.mule.api
Defines a way to generate cache keys for MuleEvent instances.
MuleEventListener - Interface in org.mule.module.spring.events
Deprecated.
MuleEventLogger - Class in org.mule.module.oauth2.internal
Helper class to reuse message content logging for troubleshooting using the logs.
MuleEventLogger(Logger) - Constructor for class org.mule.module.oauth2.internal.MuleEventLogger
 
MuleEventMulticaster - Class in org.mule.module.spring.events
Deprecated.
MuleEventMulticaster() - Constructor for class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
 
MuleEventToHttpRequest - Class in org.mule.module.http.internal.request
 
MuleEventToHttpRequest(DefaultHttpRequester, MuleContext, AttributeEvaluator, AttributeEvaluator) - Constructor for class org.mule.module.http.internal.request.MuleEventToHttpRequest
 
MuleException - Exception in org.mule.api
MuleException is the base exception type for the Mule server any other exceptions thrown by Mule code will be based on this exception,
MuleException(Message) - Constructor for exception org.mule.api.MuleException
 
MuleException(Message, Throwable) - Constructor for exception org.mule.api.MuleException
 
MuleException(Throwable) - Constructor for exception org.mule.api.MuleException
 
MuleException() - Constructor for exception org.mule.api.MuleException
 
MuleExceptionReader - Class in org.mule.config
Grabs all information from the MuleException type
MuleExceptionReader() - Constructor for class org.mule.config.MuleExceptionReader
 
MuleExpressionEvaluator - Class in org.mule.expression
Deprecated.
MuleExpressionEvaluator is a wrapper of the default expression evaluators which ends up redirecting to the DefaultExpressionManager evaluate method. It has been deprecated since it only provides one more way to accomplish the same result. Instead use the default expression evaluators, for example: #[mule:message.headers(foo, bar)] - replaced by #[headers:foo,bar] #[mule:message.attachments-list(attach1, attach2*)] - replaced by #[attachments-list:attach1,attach2*] #[mule:context.serviceName] - replaced by #[context:serviceName] Check the Expressions configuration reference for more examples of the default expression evaluators syntax.
MuleExpressionEvaluator() - Constructor for class org.mule.expression.MuleExpressionEvaluator
Deprecated.
 
MuleExtensionAnnotationParser - Class in org.mule.module.extension.internal.introspection
Utilities for reading annotations as a mean to describe extensions
MuleExtensionAnnotationParser() - Constructor for class org.mule.module.extension.internal.introspection.MuleExtensionAnnotationParser
 
MuleExtensionUtils - Class in org.mule.module.extension.internal.util
Utilities for handling extensions
MuleFoldersUtil - Class in org.mule.module.launcher
Calculates folders for a mule server based on the "mule.home" property
MuleFtplet - Class in org.mule.tck.util.ftp
Ftplet implementation that calls methods on its callback.
MuleFtplet(MuleFtplet.Callback) - Constructor for class org.mule.tck.util.ftp.MuleFtplet
 
MuleFtplet.Callback - Interface in org.mule.tck.util.ftp
 
MuleHeaderCredentialsAccessor - Class in org.mule.security
MuleHeaderCredentialsAccessor obtains and sets the user credentials as Mule property headers.
MuleHeaderCredentialsAccessor() - Constructor for class org.mule.security.MuleHeaderCredentialsAccessor
 
MuleHeadersInInterceptor - Class in org.mule.module.cxf.support
Reads the Mule Soap Header and sets the various header properties on the message.
MuleHeadersInInterceptor() - Constructor for class org.mule.module.cxf.support.MuleHeadersInInterceptor
 
MuleHeadersOutInterceptor - Class in org.mule.module.cxf.support
Writes the Mule Soap Header to the outgoing request.
MuleHeadersOutInterceptor() - Constructor for class org.mule.module.cxf.support.MuleHeadersOutInterceptor
 
MuleHierarchicalBeanDefinitionParserDelegate - Class in org.mule.config.spring
This parser enables Mule to parse heirarchical bean structures using spring Namespace handling There are 4 base DefinitionParsers supplied in Mule that most Parsers will extend from, these are AbstractChildDefinitionParser AbstractMuleBeanDefinitionParser ChildDefinitionParser MuleOrphanDefinitionParser
MuleHierarchicalBeanDefinitionParserDelegate(XmlReaderContext, DefaultBeanDefinitionDocumentReader, ElementValidator...) - Constructor for class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
muleHome - Variable in class org.mule.test.infrastructure.deployment.AbstractFakeMuleServerTestCase
 
muleHome - Variable in class org.mule.test.infrastructure.process.Controller
 
MuleHostConfiguration - Class in org.mule.transport.http
Subclass of httpclient's HostConfiguration that retains its Protocol when a new host is set via the URI.
MuleHostConfiguration() - Constructor for class org.mule.transport.http.MuleHostConfiguration
 
MuleHostConfiguration(HostConfiguration) - Constructor for class org.mule.transport.http.MuleHostConfiguration
 
MuleHttpMethodRetryHandler - Class in org.mule.transport.http
 
MuleHttpMethodRetryHandler() - Constructor for class org.mule.transport.http.MuleHttpMethodRetryHandler
 
MuleHttpSender - Class in org.mule.transport.soap.axis.extensions
Deprecated.
Use the UniversalSender instead
MuleHttpSender() - Constructor for class org.mule.transport.soap.axis.extensions.MuleHttpSender
Deprecated.
 
MuleHttpServletRequest - Class in org.mule.transport.http.servlet
THIS CLASS IS UNSUPPORTED AND THE IMPLEMENTATION DOES NOT CONFORM TO THE SERVLET SPECIFICATION!
MuleHttpServletRequest(MuleEvent) - Constructor for class org.mule.transport.http.servlet.MuleHttpServletRequest
 
MuleHttpServletResponse - Class in org.mule.transport.http.servlet
THIS CLASS IS UNSUPPORTED AND THE IMPLEMENTATION DOES NOT CONFORM TO THE SERVLET SPECIFICATION!
MuleHttpServletResponse(MuleEvent) - Constructor for class org.mule.transport.http.servlet.MuleHttpServletResponse
 
MuleImmutableVariableResolver<T> - Class in org.mule.el.mvel
 
MuleImmutableVariableResolver(String, T, Class<?>) - Constructor for class org.mule.el.mvel.MuleImmutableVariableResolver
 
MuleInitialContextFactory - Class in org.mule.jndi
 
MuleInitialContextFactory() - Constructor for class org.mule.jndi.MuleInitialContextFactory
 
MuleInstallation - Class in org.mule.test.infrastructure.process.rules
This is a JUnit rule to install Mule Runtime during tests.
MuleInstallation(String) - Constructor for class org.mule.test.infrastructure.process.rules.MuleInstallation
 
MuleInstanceContext - Class in org.mule.el.context
Expose information about the Mule instance: clusterid Cluster ID home Home directory nodeid Cluster Node ID version Mule Version
MuleInstanceContext(MuleContext) - Constructor for class org.mule.el.context.MuleInstanceContext
 
MuleInvoker - Class in org.mule.module.cxf
Invokes a Mule Service via a CXF binding.
MuleInvoker(CxfInboundMessageProcessor, Class<?>) - Constructor for class org.mule.module.cxf.MuleInvoker
 
MuleJaasPrincipal - Class in org.mule.module.jaas
 
MuleJaasPrincipal(String) - Constructor for class org.mule.module.jaas.MuleJaasPrincipal
 
MuleJAXWSInvoker - Class in org.mule.module.cxf
 
MuleJAXWSInvoker(Invoker) - Constructor for class org.mule.module.cxf.MuleJAXWSInvoker
 
MuleLockFactory - Class in org.mule.util.lock
 
MuleLockFactory() - Constructor for class org.mule.util.lock.MuleLockFactory
 
MuleLog4jContextFactory - Class in org.mule.module.launcher.log4j2
Implementation of LoggerContextFactory which acts as the bootstrap for mule's logging mechanism.
MuleLog4jContextFactory() - Constructor for class org.mule.module.launcher.log4j2.MuleLog4jContextFactory
Initializes using a ArtifactAwareContextSelector
MuleLog4jContextFactory(ContextSelector) - Constructor for class org.mule.module.launcher.log4j2.MuleLog4jContextFactory
Initializes using contextSelector
MuleLogger - Class in org.mule.util
A Log wrapper that supports boilerplate logging for high impact messages
MuleLogger(Log) - Constructor for class org.mule.util.MuleLogger
 
MuleLoggerContextFactory - Class in org.mule.module.launcher.log4j2
Encapsulates the logic to get the proper log configuration.
MuleLoggerContextFactory() - Constructor for class org.mule.module.launcher.log4j2.MuleLoggerContextFactory
 
MuleManifest - Class in org.mule.config
This is a static class that provides access to the Mule core manifest file.
MuleManifest() - Constructor for class org.mule.config.MuleManifest
 
muleMessage - Variable in exception org.mule.api.MessagingException
The MuleMessage being processed when the error occurred
MuleMessage - Interface in org.mule.api
MuleMessage represents a message payload.
MuleMessageAware - Interface in org.mule.api.context.notification
Signals that a Notification can have a MuleMessage available through it.
MuleMessageCollection - Interface in org.mule.api
An interface that defines a collection of Mule Messages and methods for working with the collection.
MuleMessageDirectProtocol - Class in org.mule.transport.tcp.protocols
This Protocol will send the actual Mule Message over the TCP channel, and in this way we are preserving any headers which might be needed, for example Correlation IDs in order to be able to aggregate messages after chunking.
MuleMessageDirectProtocol() - Constructor for class org.mule.transport.tcp.protocols.MuleMessageDirectProtocol
 
MuleMessageEOFProtocol - Class in org.mule.transport.tcp.protocols
This Protocol will send the actual Mule Message over the TCP channel, and in this way we are preserving any headers which might be needed, for example Correlation IDs in order to be able to aggregate messages after chunking.
MuleMessageEOFProtocol() - Constructor for class org.mule.transport.tcp.protocols.MuleMessageEOFProtocol
 
MuleMessageFactory - Interface in org.mule.api.transport
MuleMessageFactory is a factory for creating a MuleMessage from a transport's native message format (e.g.
muleMessageFactory - Variable in class org.mule.transport.AbstractConnector
Factory used to create new MuleMessage instances
muleMessageFactory - Variable in class org.mule.transport.AbstractTransportMessageHandler
 
MuleMessageInfoMapping - Class in org.mule.routing
A simple facade implementation of MessageInfoMapping that simply grabs the message information from the MuleMessage untouched.
MuleMessageInfoMapping() - Constructor for class org.mule.routing.MuleMessageInfoMapping
 
MuleMessageLengthProtocol - Class in org.mule.transport.tcp.protocols
This Protocol will send the actual Mule Message over the TCP channel, and in this way we are preserving any headers which might be needed, for example Correlation IDs in order to be able to aggregate messages after chunking.
MuleMessageLengthProtocol() - Constructor for class org.mule.transport.tcp.protocols.MuleMessageLengthProtocol
 
MuleMessageProcessingManager - Class in org.mule.execution
Default implementation for MessageProcessingManager.
MuleMessageProcessingManager() - Constructor for class org.mule.execution.MuleMessageProcessingManager
 
MuleMessageSafeProtocol - Class in org.mule.transport.tcp.protocols
This Protocol will send the actual Mule Message over the TCP channel, and in this way we are preserving any headers which might be needed, for example Correlation IDs in order to be able to aggregate messages after chunking.
MuleMessageSafeProtocol() - Constructor for class org.mule.transport.tcp.protocols.MuleMessageSafeProtocol
 
MuleMessageService - Class in org.mule.module.jbpm
Proxy for the message-generation service provided by Mule.
MuleMessageService() - Constructor for class org.mule.module.jbpm.MuleMessageService
 
MuleMessageToByteArray - Class in org.mule.transformer.simple
TODO
MuleMessageToByteArray() - Constructor for class org.mule.transformer.simple.MuleMessageToByteArray
 
MuleMessageToHttpResponse - Class in org.mule.transport.http.transformers
Converts a MuleMessage into an Http response.
MuleMessageToHttpResponse() - Constructor for class org.mule.transport.http.transformers.MuleMessageToHttpResponse
 
MuleModule - Class in org.guiceyfruit.mule
Deprecated.
Guice module is deprecated and will be removed in Mule 4.
MuleModule() - Constructor for class org.guiceyfruit.mule.MuleModule
Deprecated.
 
MULEMQ_CONNECTION_FACTORY_CLASS - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
MULEMQ_XA_CONNECTION_FACTORY_CLASS - Static variable in class org.mule.transport.jms.mulemq.MuleMQXAJmsConnector
 
MuleMQConnectorDefinitionParser - Class in org.mule.transport.jms.config
 
MuleMQConnectorDefinitionParser() - Constructor for class org.mule.transport.jms.config.MuleMQConnectorDefinitionParser
 
MuleMQConnectorDefinitionParser(Class) - Constructor for class org.mule.transport.jms.config.MuleMQConnectorDefinitionParser
 
MuleMQJmsConnector - Class in org.mule.transport.jms.mulemq
 
MuleMQJmsConnector(MuleContext) - Constructor for class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
MuleMQXAJmsConnector - Class in org.mule.transport.jms.mulemq
 
MuleMQXAJmsConnector(MuleContext) - Constructor for class org.mule.transport.jms.mulemq.MuleMQXAJmsConnector
 
MuleMsgProvider - Class in org.mule.transport.soap.axis.extensions
MuleMsgProvider is an Axis service endpoint that builds services from Mule managed components.
MuleMsgProvider(AxisConnector) - Constructor for class org.mule.transport.soap.axis.extensions.MuleMsgProvider
 
MuleNamespaceHandler - Class in org.mule.config.spring.handlers
This is the core namespace handler for Mule and configures all Mule configuration elements under the http://www.mulesoft.org/schema/mule/core/${version} Namespace.
MuleNamespaceHandler() - Constructor for class org.mule.config.spring.handlers.MuleNamespaceHandler
 
MuleObjectNameProcessor - Class in org.mule.config.spring.processors
MuleObjectNameProcessor is used to set spring ids to Mule object names so the the bean id and name property on the object don't both have to be set.
MuleObjectNameProcessor() - Constructor for class org.mule.config.spring.processors.MuleObjectNameProcessor
 
MuleObjectStoreManager - Class in org.mule.util.store
 
MuleObjectStoreManager() - Constructor for class org.mule.util.store.MuleObjectStoreManager
 
MuleOrphanDefinitionParser - Class in org.mule.config.spring.parsers.generic
A parser for direct children of the element.
MuleOrphanDefinitionParser(boolean) - Constructor for class org.mule.config.spring.parsers.generic.MuleOrphanDefinitionParser
This constructor assumes that the class name will be explicitly specified as an attribute on the element.
MuleOrphanDefinitionParser(Class<?>, boolean) - Constructor for class org.mule.config.spring.parsers.generic.MuleOrphanDefinitionParser
 
MulePackage - Class in org.mule.tools.anttasks
Ant task to package a mule application XML format:
MulePackage() - Constructor for class org.mule.tools.anttasks.MulePackage
 
muleParse(Element, ParserContext) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
muleParse(Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.AbstractParallelDelegatingDefinitionParser
 
muleParse(Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
muleParse(Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
muleParse(Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
muleParse(Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.MapDefinitionParserMutator
 
muleParse(Element, ParserContext) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParser
 
MulePluginClassLoaderManager - Class in org.mule.module.launcher
 
MulePluginClassLoaderManager() - Constructor for class org.mule.module.launcher.MulePluginClassLoaderManager
 
MulePluginsClassLoader - Class in org.mule.module.launcher.plugin
 
MulePluginsClassLoader(ClassLoader, PluginDescriptor...) - Constructor for class org.mule.module.launcher.plugin.MulePluginsClassLoader
 
MulePluginsClassLoader(ClassLoader, Collection<PluginDescriptor>) - Constructor for class org.mule.module.launcher.plugin.MulePluginsClassLoader
 
MuleProcessController - Class in org.mule.test.infrastructure.process
 
MuleProcessController(String) - Constructor for class org.mule.test.infrastructure.process.MuleProcessController
 
MuleProcessController(String, int) - Constructor for class org.mule.test.infrastructure.process.MuleProcessController
 
MuleProperties - Class in org.mule.api.config
MuleProperties is a set of constants pertaining to Mule properties.
MuleProperties() - Constructor for class org.mule.api.config.MuleProperties
 
MulePropertyEditorRegistrar - Class in org.mule.config.spring.editors
The preferred way to configure property editors in Spring 2/3 is to implement a registrar
MulePropertyEditorRegistrar() - Constructor for class org.mule.config.spring.editors.MulePropertyEditorRegistrar
 
MuleProtocolHeadersOutInterceptor - Class in org.mule.module.cxf.support
 
MuleProtocolHeadersOutInterceptor() - Constructor for class org.mule.module.cxf.support.MuleProtocolHeadersOutInterceptor
 
MuleProvider - Class in org.mule.module.atom
 
MuleProvider() - Constructor for class org.mule.module.atom.MuleProvider
 
MuleReceiveActivity - Class in org.mule.module.jbpm
 
MuleReceiveActivity(boolean) - Constructor for class org.mule.module.jbpm.MuleReceiveActivity
 
MuleReceiveBinding - Class in org.mule.module.jbpm
 
MuleReceiveBinding() - Constructor for class org.mule.module.jbpm.MuleReceiveBinding
 
MuleReceiverServlet - Class in org.mule.transport.servlet
Receives Http requests via a Servlet and routes them to listeners with servlet:// endpoints

MuleReceiverServlet() - Constructor for class org.mule.transport.servlet.MuleReceiverServlet
 
MuleRegistry - Interface in org.mule.api.registry
Adds lookup/register/unregister methods for Mule-specific entities to the standard Registry interface.
MuleRegistryHelper - Class in org.mule.registry
Adds lookup/register/unregister methods for Mule-specific entities to the standard Registry interface.
MuleRegistryHelper(DefaultRegistryBroker, MuleContext) - Constructor for class org.mule.registry.MuleRegistryHelper
 
MuleRequestContext - Class in org.mule.module.atom.server
 
MuleRequestContext(Provider, MuleEventContext, MuleMessage, String, IRI) - Constructor for class org.mule.module.atom.server.MuleRequestContext
 
MuleResourceLoader - Class in org.mule.config.spring
MuleResourceLoader is a custom Spring resource loader that calls standard Mule methods for loading resource files.
MuleResourceLoader() - Constructor for class org.mule.config.spring.MuleResourceLoader
 
MuleResourceResolver - Class in org.mule.module.xml.util
Attempts to resolve a resource from the file system, from a URL, or from the classpath, in that order.
MuleResourceResolver() - Constructor for class org.mule.module.xml.util.MuleResourceResolver
 
MuleRESTReceiverServlet - Class in org.mule.transport.servlet
MuleRESTReceiverServlet is used for sending and receiving events from the Mule server via a servlet container.
MuleRESTReceiverServlet() - Constructor for class org.mule.transport.servlet.MuleRESTReceiverServlet
 
MuleRPCProvider - Class in org.mule.transport.soap.axis.extensions
MuleProvider is an Axis service endpoint that builds services from Mule managed components.
MuleRPCProvider(AxisConnector) - Constructor for class org.mule.transport.soap.axis.extensions.MuleRPCProvider
 
MuleRuntimeException - Exception in org.mule.api
MuleRuntimeException Is the base runtime exception type for the Mule Server any other runtimes exceptions thrown by Mule code will use or be based on this exception.
MuleRuntimeException(Message) - Constructor for exception org.mule.api.MuleRuntimeException
 
MuleRuntimeException(Message, Throwable) - Constructor for exception org.mule.api.MuleRuntimeException
 
MuleRuntimeException(Throwable) - Constructor for exception org.mule.api.MuleRuntimeException
 
MuleSecureProtocolSocketFactory - Class in org.mule.transport.http
 
MuleSecureProtocolSocketFactory(SSLSocketFactory) - Constructor for class org.mule.transport.http.MuleSecureProtocolSocketFactory
 
MuleSecurityManager - Class in org.mule.security
MuleSecurityManager is a default implementation security manager for a Mule instance.
MuleSecurityManager() - Constructor for class org.mule.security.MuleSecurityManager
 
MuleSecurityManagerValidator - Class in org.mule.module.cxf.support
Integrates mule spring security with CXF ws-security
MuleSecurityManagerValidator() - Constructor for class org.mule.module.cxf.support.MuleSecurityManagerValidator
 
MuleSendActivity - Class in org.mule.module.jbpm
 
MuleSendActivity() - Constructor for class org.mule.module.jbpm.MuleSendActivity
 
MuleSendBinding - Class in org.mule.module.jbpm
 
MuleSendBinding() - Constructor for class org.mule.module.jbpm.MuleSendBinding
 
MuleServer - Class in org.mule
MuleServer is a simple application that represents a local Mule Server daemon.
MuleServer() - Constructor for class org.mule.MuleServer
 
MuleServer(String) - Constructor for class org.mule.MuleServer
 
MuleServer(String[]) - Constructor for class org.mule.MuleServer
Configure the server with command-line arguments.
muleServer - Variable in class org.mule.test.infrastructure.deployment.AbstractFakeMuleServerTestCase
 
MuleServerWrapper - Class in org.mule.module.boot
 
MuleServerWrapper() - Constructor for class org.mule.module.boot.MuleServerWrapper
 
MuleService - Class in org.mule.module.management.mbean
MuleService exposes certain Mule server functions for management
MuleService(MuleContext) - Constructor for class org.mule.module.management.mbean.MuleService
 
MuleServiceConfiguration - Class in org.mule.module.cxf.support
This is the ServiceConfiguration that is associated to the InboundMessageProcessorBuilder, so it can obtain properties directly from it.
MuleServiceConfiguration(AbstractInboundMessageProcessorBuilder) - Constructor for class org.mule.module.cxf.support.MuleServiceConfiguration
 
MuleServiceMBean - Interface in org.mule.module.management.mbean
MuleServiceMBean is a JMX service interface for the MuleContext.
MuleServletContextListener - Class in org.mule.transport.servlet
 
MuleServletContextListener(MuleContext, String) - Constructor for class org.mule.transport.servlet.MuleServletContextListener
 
MuleSession - Interface in org.mule.api
MuleSession is the context in which a request is processed by Mule.
MuleSessionHandler - Class in org.mule.session
Deprecated.
Use an explicit SessionHandler such as SerializeAndEncodeSessionHandler or SerializeOnlySessionHandler
MuleSessionHandler() - Constructor for class org.mule.session.MuleSessionHandler
Deprecated.
 
MuleSharedDomainClassLoader - Class in org.mule.module.launcher
Load $MULE_HOME/lib/shared/ libraries.
MuleSharedDomainClassLoader(String, ClassLoader) - Constructor for class org.mule.module.launcher.MuleSharedDomainClassLoader
 
MuleSharedDomainClassLoader(String, ClassLoader, Set<String>) - Constructor for class org.mule.module.launcher.MuleSharedDomainClassLoader
 
MuleSoapHeaders - Class in org.mule.module.cxf
MuleSoapHeaders is a helper class for extracting and writing Mule header properties to s Soap message
MuleSoapHeaders(MuleEvent) - Constructor for class org.mule.module.cxf.MuleSoapHeaders
Extracts header properties from a Mule event
MuleSoapHeaders(SOAPHeader) - Constructor for class org.mule.module.cxf.MuleSoapHeaders
Extracts Mule header properties from a Soap message
MuleSoapHeaders(Iterator) - Constructor for class org.mule.module.cxf.MuleSoapHeaders
 
MuleSoapHeadersHandler - Class in org.mule.transport.soap.axis.extensions
MuleSoapHeadersHandler is an Axis handler that can read and write Mule header properties to a SOAP message.
MuleSoapHeadersHandler() - Constructor for class org.mule.transport.soap.axis.extensions.MuleSoapHeadersHandler
 
MuleSslFilter - Class in org.mule.module.http.internal.listener.grizzly
Custom SSL filter that configures additional properties in the grizzly context.
MuleSslFilter(SSLEngineConfigurator, SSLEngineConfigurator) - Constructor for class org.mule.module.http.internal.listener.grizzly.MuleSslFilter
 
MuleStandalone - Class in org.mule.test.infrastructure.process.rules
This is a JUnit rule to start and stop Mule Runtime during tests.
MuleStandalone(String) - Constructor for class org.mule.test.infrastructure.process.rules.MuleStandalone
 
MuleStandalone(String, String...) - Constructor for class org.mule.test.infrastructure.process.rules.MuleStandalone
 
MuleStatusProbe - Class in org.mule.test.infrastructure.process
 
MuleSubscriptionEventListener - Interface in org.mule.module.spring.events
Deprecated.
MuleSupportModule - Class in org.mule.module.guice
Deprecated.
Guice module is deprecated and will be removed in Mule 4.
MuleSupportModule(MuleContext) - Constructor for class org.mule.module.guice.MuleSupportModule
Deprecated.
 
MuleSystemClassLoader - Class in org.mule.module.boot
Loads a standard $MULE_HOME/lib/* hierarchy.
MuleSystemClassLoader() - Constructor for class org.mule.module.boot.MuleSystemClassLoader
 
MuleTomcatListener - Class in org.mule.module.tomcat
 
MuleTomcatListener() - Constructor for class org.mule.module.tomcat.MuleTomcatListener
 
MuleTransactionConfig - Class in org.mule.transaction

MuleTransactionConfig defines transaction configuration for a transactional endpoint.

MuleTransactionConfig() - Constructor for class org.mule.transaction.MuleTransactionConfig
 
MuleTransactionConfig(byte) - Constructor for class org.mule.transaction.MuleTransactionConfig
 
MuleTransport - Class in org.mule.transport.soap.axis.extensions
A container for all Mule supported transports for Axis.
MuleTransport() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport
 
MuleTransport(String) - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport
 
MuleTransport.HTTP - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.HTTP() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.HTTP
 
MuleTransport.HTTPS - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.HTTPS() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.HTTPS
 
MuleTransport.IMAP - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.IMAP() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.IMAP
 
MuleTransport.IMAPS - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.IMAPS() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.IMAPS
 
MuleTransport.JMS - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.JMS() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.JMS
 
MuleTransport.POP3 - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.POP3() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.POP3
 
MuleTransport.POP3S - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.POP3S() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.POP3S
 
MuleTransport.SERVLET - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.SERVLET() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.SERVLET
 
MuleTransport.SMTP - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.SMTP() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.SMTP
 
MuleTransport.SMTPS - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.SMTPS() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.SMTPS
 
MuleTransport.SSL - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.SSL() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.SSL
 
MuleTransport.TCP - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.TCP() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.TCP
 
MuleTransport.VM - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.VM() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.VM
 
MuleTransport.XMPP - Class in org.mule.transport.soap.axis.extensions
 
MuleTransport.XMPP() - Constructor for class org.mule.transport.soap.axis.extensions.MuleTransport.XMPP
 
MuleUniversalConduit - Class in org.mule.module.cxf.transport
A Conduit is primarily responsible for sending messages from CXF to somewhere else.
MuleUniversalConduit(MuleUniversalTransport, CxfConfiguration, EndpointInfo, EndpointReferenceType) - Constructor for class org.mule.module.cxf.transport.MuleUniversalConduit
 
MuleUniversalConduit.InterposedMessageObserver - Class in org.mule.module.cxf.transport
Used to set appropriate message properties, exchange etc.
MuleUniversalConduit.InterposedMessageObserver() - Constructor for class org.mule.module.cxf.transport.MuleUniversalConduit.InterposedMessageObserver
 
MuleUniversalDestination - Class in org.mule.module.cxf.transport
 
MuleUniversalDestination(MuleUniversalTransport, EndpointReferenceType, EndpointInfo) - Constructor for class org.mule.module.cxf.transport.MuleUniversalDestination
 
MuleUniversalDestination.ResponseConduit - Class in org.mule.module.cxf.transport
 
MuleUniversalDestination.ResponseConduit(EndpointReferenceType) - Constructor for class org.mule.module.cxf.transport.MuleUniversalDestination.ResponseConduit
 
MuleUniversalTransport - Class in org.mule.module.cxf.transport
 
MuleUniversalTransport(CxfConfiguration) - Constructor for class org.mule.module.cxf.transport.MuleUniversalTransport
 
MuleUrlStreamHandlerFactory - Class in org.mule.util
A factory for loading URL protocol handlers.
MuleUrlStreamHandlerFactory() - Constructor for class org.mule.util.MuleUrlStreamHandlerFactory
 
MuleUtils - Class in org.mule.test.infrastructure.process
 
MuleUtils(String) - Constructor for class org.mule.test.infrastructure.process.MuleUtils
 
MuleWorkManager - Class in org.mule.work
MuleWorkManager is a JCA Work manager implementation used to manage thread allocation for Mule components and connectors.
MuleWorkManager(ThreadingProfile, String, int) - Constructor for class org.mule.work.MuleWorkManager
 
MuleWSDLLocator - Class in org.mule.module.ws.consumer
A custom locator to replicate the context of requester in every step where wsdl4j has to retrieve a resource (imported XSD, WSDL)
MuleWSDLLocator(MuleWSDLLocatorConfig) - Constructor for class org.mule.module.ws.consumer.MuleWSDLLocator
 
MuleWSDLLocatorConfig - Class in org.mule.module.ws.consumer
Configuration class to use with a MuleWSDLLocator.
MuleWSDLLocatorConfig.Builder - Class in org.mule.module.ws.consumer
 
MuleWSDLLocatorConfig.Builder() - Constructor for class org.mule.module.ws.consumer.MuleWSDLLocatorConfig.Builder
 
MuleXid - Class in org.mule.util.xa
Mule Xid implementation
MuleXid(int, byte[], byte[]) - Constructor for class org.mule.util.xa.MuleXid
 
MuleXid(Xid) - Constructor for class org.mule.util.xa.MuleXid
 
MuleXmlBuilderContextListener - Class in org.mule.config.builders
MuleXmlBuilderContextListener is a bootstrap listener used to construct a MuleContext instance.
MuleXmlBuilderContextListener() - Constructor for class org.mule.config.builders.MuleXmlBuilderContextListener
 
MuleXmlBuilderContextServlet - Class in org.mule.config.builders
 
MuleXmlBuilderContextServlet() - Constructor for class org.mule.config.builders.MuleXmlBuilderContextServlet
 
MULTI_ADD - Static variable in class org.mule.module.launcher.util.ElementEvent
 
MULTI_REMOVE - Static variable in class org.mule.module.launcher.util.ElementEvent
 
MULTICAST - Static variable in class org.mule.transport.multicast.MulticastConnector
 
MulticastConnector - Class in org.mule.transport.multicast
MulticastConnector can dispatch mule events using ip multicasting
MulticastConnector(MuleContext) - Constructor for class org.mule.transport.multicast.MulticastConnector
 
Multicaster - Class in org.mule.util
Multicaster is a utility that can call a given method on a collection of objects that implement one or more common interfaces.
Multicaster.InvokeListener - Interface in org.mule.util
 
multicastEvent(ApplicationEvent) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
Method is used to dispatch events to listeners registered with the EventManager or dispatches events to Mule depending on the type and state of the event received.
MulticastingRouter - Class in org.mule.routing.outbound
Deprecated.
MulticastingRouter() - Constructor for class org.mule.routing.outbound.MulticastingRouter
Deprecated.
 
MulticastingRoutingStrategy - Class in org.mule.routing
Routing strategy that will route a message through a set of MessageProcessor and return an aggregation of the results.
MulticastingRoutingStrategy(MuleContext, RouterResultsHandler) - Constructor for class org.mule.routing.MulticastingRoutingStrategy
 
MulticastMessageReceiver - Class in org.mule.transport.multicast
 
MulticastMessageReceiver(AbstractConnector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.multicast.MulticastMessageReceiver
 
MulticastMessageReceiver.MulticastWorker - Class in org.mule.transport.multicast
 
MulticastMessageReceiver.MulticastWorker(DatagramPacket) - Constructor for class org.mule.transport.multicast.MulticastMessageReceiver.MulticastWorker
 
MulticastNamespaceHandler - Class in org.mule.transport.multicast.config
Reigsters a Bean Definition Parser for handling elements.
MulticastNamespaceHandler() - Constructor for class org.mule.transport.multicast.config.MulticastNamespaceHandler
 
MulticastSocketFactory - Class in org.mule.transport.multicast
TODO
MulticastSocketFactory() - Constructor for class org.mule.transport.multicast.MulticastSocketFactory
 
MultiConsumerJmsMessageReceiver - Class in org.mule.transport.jms
In Mule an endpoint corresponds to a single receiver.
MultiConsumerJmsMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.jms.MultiConsumerJmsMessageReceiver
 
MultiConsumerJmsMessageReceiver.JmsWorker - Class in org.mule.transport.jms
 
MultiConsumerJmsMessageReceiver.JmsWorker(Message, AbstractMessageReceiver, MultiConsumerJmsMessageReceiver.SubReceiver) - Constructor for class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.JmsWorker
 
MultiConsumerJmsMessageReceiver.SubReceiver - Class in org.mule.transport.jms
 
MultiConsumerJmsMessageReceiver.SubReceiver() - Constructor for class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.SubReceiver
 
MultiElementAddedEvent - Class in org.mule.module.launcher.util
 
MultiElementAddedEvent(Object, int, List<?>) - Constructor for class org.mule.module.launcher.util.MultiElementAddedEvent
 
MultiElementRemovedEvent - Class in org.mule.module.launcher.util
 
MultiElementRemovedEvent(Object, List<?>) - Constructor for class org.mule.module.launcher.util.MultiElementRemovedEvent
 
MultiMap<K> - Class in org.mule.transport.http.multipart
A multi valued Map.
MultiMap() - Constructor for class org.mule.transport.http.multipart.MultiMap
 
MultiMap(Map) - Constructor for class org.mule.transport.http.multipart.MultiMap
 
MultiMap(int) - Constructor for class org.mule.transport.http.multipart.MultiMap
 
MultiMap(boolean) - Constructor for class org.mule.transport.http.multipart.MultiMap
 
MULTIPART - Static variable in class org.mule.module.http.internal.listener.HttpResponseBuilder
 
MULTIPART_FORM_DATA - Static variable in class org.mule.module.http.api.HttpHeaders.Values
MULTIPART_MIXED - Static variable in interface org.mule.transformer.types.MimeTypes
 
MULTIPART_RELATED - Static variable in interface org.mule.transformer.types.MimeTypes
 
MULTIPART_X_MIXED_REPLACE - Static variable in interface org.mule.transformer.types.MimeTypes
 
MultipartConfiguration - Class in org.mule.transport.http.multipart
Defines configuration object used to control how attachments are processed.
MultipartConfiguration(String) - Constructor for class org.mule.transport.http.multipart.MultipartConfiguration
Constructs an instance with defaults for all but location.
MultipartConfiguration(String, long, long, int) - Constructor for class org.mule.transport.http.multipart.MultipartConfiguration
Constructs an instance with all values specified.
MultipartHttpEntity - Class in org.mule.module.http.internal.domain
 
MultipartHttpEntity(Collection<HttpPart>) - Constructor for class org.mule.module.http.internal.domain.MultipartHttpEntity
 
MultiPartInputStream - Class in org.mule.transport.http.multipart
MultipartInputStream Handle a MultiPart Mime input stream, breaking it up on the boundary into files and strings.
MultiPartInputStream(InputStream, String, MultipartConfiguration) - Constructor for class org.mule.transport.http.multipart.MultiPartInputStream
 
MultiPartInputStream.MultiPart - Class in org.mule.transport.http.multipart
 
MultiPartInputStream.MultiPart(String, String) - Constructor for class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
MultiPartOutputStream - Class in org.mule.transport.http.multipart
Handle a multipart MIME response.
MultiPartOutputStream(OutputStream, String) - Constructor for class org.mule.transport.http.multipart.MultiPartOutputStream
 
MultipleRequestReplierEvent - Class in org.mule.routing.requestreply
 
MultipleRequestReplierEvent() - Constructor for class org.mule.routing.requestreply.MultipleRequestReplierEvent
 
MULTIPLY - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter represening the multiplication of two other counters
MUST_REVALIDATE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
mustCloseConnection() - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
mustCloseConnection() - Method in class org.mule.module.db.internal.processor.SelectMessageProcessor
 
mustCloseConnection() - Method in class org.mule.module.db.internal.processor.StoredProcedureMessageProcessor
 
mustSetMethodNamesOnBinding() - Static method in class org.mule.config.i18n.CoreMessages
 
mustSpecifyContainerRefOrClassAttribute(String, String, String) - Static method in class org.mule.config.builders.i18n.BuildersMessages
 
mustSpecifyPort() - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
MutableThreadingProfile - Class in org.mule.config
Partial mutability for a threading profile.
MutableThreadingProfile(ThreadingProfile) - Constructor for class org.mule.config.MutableThreadingProfile
 
MvelDataTypeResolver - Class in org.mule.el.mvel.datatype
Resolves expression's data type using ExpressionDataTypeResolver
MvelDataTypeResolver() - Constructor for class org.mule.el.mvel.datatype.MvelDataTypeResolver
 
MvelDataTypeResolver(List<ExpressionDataTypeResolver>) - Constructor for class org.mule.el.mvel.datatype.MvelDataTypeResolver
 
MvelEnricherDataTypePropagator - Class in org.mule.el.mvel.datatype
Propagates DataType on enrichment expressions using a list of EnricherDataTypePropagator
MvelEnricherDataTypePropagator() - Constructor for class org.mule.el.mvel.datatype.MvelEnricherDataTypePropagator
 
MvelEnricherDataTypePropagator(List<EnricherDataTypePropagator>) - Constructor for class org.mule.el.mvel.datatype.MvelEnricherDataTypePropagator
 
MVELExpressionExecutor - Class in org.mule.el.mvel
This MVEL executor uses MVEL ReflectiveAccessorOptimizer implementation rather than the default DynamicOptimizer (which generates byte-code accessors using ASM) because we found that, at least with JDK7, the ReflectiveAccessorOptimizer was fastest in typical Mule use cases.
MVELExpressionExecutor(ParserConfiguration) - Constructor for class org.mule.el.mvel.MVELExpressionExecutor
 
MVELExpressionLanguage - Class in org.mule.el.mvel
Expression language that uses MVEL (http://mvel.codehaus.org/).
MVELExpressionLanguage(MuleContext) - Constructor for class org.mule.el.mvel.MVELExpressionLanguage
 
MVELExpressionLanguageContext - Class in org.mule.el.mvel
 
MVELExpressionLanguageContext(ParserConfiguration, MuleContext) - Constructor for class org.mule.el.mvel.MVELExpressionLanguageContext
 
MVELExpressionLanguageContext(MVELExpressionLanguageContext) - Constructor for class org.mule.el.mvel.MVELExpressionLanguageContext
 
MVELExpressionLanguageWrapper - Class in org.mule.el.mvel
Wraps a MVELExpressionLanguage to take care of injecting new instances in the muleContext's DefaultExpressionManager
MVELExpressionLanguageWrapper(MuleContext) - Constructor for class org.mule.el.mvel.MVELExpressionLanguageWrapper
 
Mx4jAgent - Class in org.mule.module.management.agent
Mx4jAgent configures an Mx4J Http Adaptor for Jmx management, statistics and configuration viewing of a Mule instance.
Mx4jAgent() - Constructor for class org.mule.module.management.agent.Mx4jAgent
 
MySqlConfigResolverFactoryBean - Class in org.mule.module.db.internal.config.domain.database
Creates DbConfigResolver for MySql databases
MySqlConfigResolverFactoryBean() - Constructor for class org.mule.module.db.internal.config.domain.database.MySqlConfigResolverFactoryBean
 
MysqlDataSourceFactoryBean - Class in org.mule.transport.jdbc.config
 
MysqlDataSourceFactoryBean() - Constructor for class org.mule.transport.jdbc.config.MysqlDataSourceFactoryBean
 

N

nackExpression - Variable in class org.mule.construct.builder.ValidatorBuilder
 
nackExpression(String) - Method in class org.mule.construct.builder.ValidatorBuilder
 
name - Variable in class org.mule.AbstractAgent
 
name - Variable in class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
name - Variable in class org.mule.config.spring.factories.MessageProcessorChainFactoryBean
 
name - Variable in class org.mule.config.spring.parsers.collection.OrphanMapDefinitionParser
 
name - Variable in class org.mule.construct.AbstractFlowConstruct
 
name - Variable in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
name(String) - Method in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
name - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
NAME - Static variable in class org.mule.expression.AttachmentExpressionEnricher
 
NAME - Static variable in class org.mule.expression.EndpointInfoExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.ExceptionTypeExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.MapPayloadExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.MessageAttachmentExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.MessageAttachmentsExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.MessageAttachmentsListExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.MessageExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.MessageHeaderExpressionEnricher
 
NAME - Static variable in class org.mule.expression.MessageHeaderExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.MessageHeadersExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.MessageHeadersListExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.MessagePayloadExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.MessageProcessorExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.MuleContextExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.MuleExpressionEvaluator
Deprecated.
 
NAME - Static variable in class org.mule.expression.OutboundAttachmentsExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.OutboundHeadersExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.PayloadTypeExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.RegexExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.RegistryExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.StringExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.VariableExpressionEnricher
 
NAME - Static variable in class org.mule.expression.VariableExpressionEvaluator
 
NAME - Static variable in class org.mule.expression.WilcardExpressionEvaluator
 
name - Variable in class org.mule.management.stats.AbstractFlowConstructStatistics
 
name - Variable in class org.mule.message.ds.StringDataSource
 
name - Variable in class org.mule.module.db.internal.domain.type.AbstractDbType
 
name - Variable in class org.mule.module.launcher.descriptor.ArtifactDescriptor
 
NAME - Static variable in class org.mule.module.management.agent.AbstractJmxAgent
 
name - Variable in class org.mule.module.management.mbean.FlowConstructService
 
name - Variable in class org.mule.module.management.mbean.FlowConstructStats
 
NAME - Static variable in class org.mule.module.ognl.expression.OgnlExpressionEvaluator
 
NAME - Static variable in class org.mule.module.scripting.expression.GroovyExpressionEvaluator
 
NAME - Static variable in class org.mule.module.xml.expression.BeanPayloadExpressionEvaluator
Deprecated.
 
NAME - Static variable in class org.mule.module.xml.expression.JXPathExpressionEvaluator
Deprecated.
 
NAME - Static variable in class org.mule.module.xml.expression.XPathBranchExpressionEvaluator
Deprecated.
 
NAME - Static variable in class org.mule.module.xml.expression.XPathExpressionEvaluator
Deprecated.
 
NAME - Static variable in class org.mule.module.xml.expression.XPathNodeExpressionEvaluator
Deprecated.
 
name - Variable in class org.mule.processor.AsyncDelegateMessageProcessor
 
name - Variable in class org.mule.processor.chain.AbstractMessageProcessorChain
 
name - Variable in class org.mule.processor.chain.AbstractMessageProcessorChainBuilder
 
name - Variable in class org.mule.processor.InvokerMessageProcessor
 
name - Variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
name - Variable in class org.mule.service.AbstractService
Deprecated.
The service's name
name - Variable in class org.mule.transformer.AbstractTransformer
The name that identifies this transformer.
name - Variable in class org.mule.transport.AbstractConnector
The name that identifies the endpoint
name - Variable in class org.mule.transport.polling.schedule.PollScheduler
The Scheduler name used as an identifier in the MuleRegistry
NAME - Static variable in class org.mule.transport.servlet.jetty.JettyWebappServerAgent
 
name - Variable in class org.mule.util.scan.annotations.AnnotationInfo.NameValue
Deprecated.
 
name - Variable in class org.mule.util.store.AbstractMonitoredObjectStore
A name for this store, can be used for logging and identification purposes.
name - Variable in class org.mule.util.store.MonitoredObjectStoreWrapper
A name for this store, can be used for logging and identification purposes.
NAME_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.param.InputParamValueBeanDefinitionParser
 
NAME_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.query.QueryDefinitionParser
 
NAME_ATTRIBUTE_NAME - Static variable in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
NAME_TEMPLATE - Static variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
NameableObject - Interface in org.mule.api
NameAttribute - Class in org.mule.config.spring.parsers.processors
 
NameAttribute(String) - Constructor for class org.mule.config.spring.parsers.processors.NameAttribute
 
NameConverterFilter - Class in org.mule.transformer.graph
Filters a list of Converter returning a new list containing only the converters with the lower name using lexical order.
NameConverterFilter() - Constructor for class org.mule.transformer.graph.NameConverterFilter
 
Named - Class in org.mule.tck.security
 
Named() - Constructor for class org.mule.tck.security.Named
 
NamedDefinitionParser - Class in org.mule.config.spring.parsers.generic
Behaves as ParentDefinitionParser, but allows any named bean to be the parent, rather than using the enclosing element in the DOM tree.
NamedDefinitionParser() - Constructor for class org.mule.config.spring.parsers.generic.NamedDefinitionParser
 
NamedDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.generic.NamedDefinitionParser
 
NamedObject - Interface in org.mule.api
Adds NamedObject.getName() method to an object
NamedParameter - Class in org.mule.transport.soap.axis
Representation of a Named parameter in a SOAP call
NamedParameter(QName, QName, String) - Constructor for class org.mule.transport.soap.axis.NamedParameter
 
NamedParameter(QName, QName, ParameterMode) - Constructor for class org.mule.transport.soap.axis.NamedParameter
 
NamedParameter(String, String, ParameterMode) - Constructor for class org.mule.transport.soap.axis.NamedParameter
 
NamedSetterChildElementIterator - Class in org.mule.config.spring.parsers.processors
This iterates over the child elements, generates beans, and sets them on the current bean via the setter given.
NamedSetterChildElementIterator(String, BeanAssemblerFactory, PropertyConfiguration) - Constructor for class org.mule.config.spring.parsers.processors.NamedSetterChildElementIterator
 
NamedStageNameSource - Class in org.mule.api.processor
 
NamedStageNameSource(String, String) - Constructor for class org.mule.api.processor.NamedStageNameSource
 
NamedThreadFactory - Class in org.mule.util.concurrent
 
NamedThreadFactory(String) - Constructor for class org.mule.util.concurrent.NamedThreadFactory
 
NamedThreadFactory(String, ClassLoader) - Constructor for class org.mule.util.concurrent.NamedThreadFactory
 
nameParser - Static variable in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
NamespaceManager - Class in org.mule.module.xml.util
A simple manager that holds a registry of global namespaces that will be recognised by all xml queries and transforms
NamespaceManager() - Constructor for class org.mule.module.xml.util.NamespaceManager
 
NamespaceManagerDefinitionParser - Class in org.mule.module.xml.config
TODO
NamespaceManagerDefinitionParser() - Constructor for class org.mule.module.xml.config.NamespaceManagerDefinitionParser
 
NamespaceRestorerStaxInterceptor - Class in org.mule.module.ws.consumer
CXF Interceptor that makes use of a Namespace Restorer XMLStream to allow the first element of the body to carry all the namespaces from the parent nodes.
NamespaceRestorerStaxInterceptor() - Constructor for class org.mule.module.ws.consumer.NamespaceRestorerStaxInterceptor
 
NamespaceRestorerXMLStreamReader - Class in org.mule.module.ws.consumer
XMLStreamReader decorator that restores XML Namespace declarations.
NamespaceRestorerXMLStreamReader(XMLStreamReader) - Constructor for class org.mule.module.ws.consumer.NamespaceRestorerXMLStreamReader
 
NamespaceSaverStaxInterceptor - Class in org.mule.module.ws.consumer
CXF interceptor that wraps the XML Stream with a decorator that is able to restore namespace declarations for fragments
NamespaceSaverStaxInterceptor() - Constructor for class org.mule.module.ws.consumer.NamespaceSaverStaxInterceptor
 
NameTransferDefinitionParser - Class in org.mule.config.spring.parsers.generic
This extends ParentDefinitionParser so that the "name" attribute is set locally, not on the parent.
NameTransferDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.generic.NameTransferDefinitionParser
 
NameUtils - Class in org.mule.module.extension.internal.util
Utilities for manipulating names of extensions and their components
NamingExceptionReader - Class in org.mule.config
 
NamingExceptionReader() - Constructor for class org.mule.config.NamingExceptionReader
 
nanoTime() - Method in class org.mule.el.context.ServerContext
 
NativeLibraryFinder - Interface in org.mule.module.launcher.nativelib
Finds native libraries in a particular class loading context
NativeLibraryFinderFactory - Interface in org.mule.module.launcher.nativelib
Creates NativeLibraryFinder instances
nativeSQL(String) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
nativeSQL(String) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
nativeSQL(String) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
NCHAR_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
NCLOB_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
needsTransactionResolution() - Method in class org.mule.execution.ExecutionContext
 
needToMatchCount - Variable in class org.mule.tck.functional.AssertionMessageProcessor
 
NestedListDefinitionParser - Class in org.mule.config.spring.parsers.specific.properties
This extends a list that is itself a property (with key mapKey).
NestedListDefinitionParser(String, String, String) - Constructor for class org.mule.config.spring.parsers.specific.properties.NestedListDefinitionParser
 
NestedMapDefinitionParser - Class in org.mule.config.spring.parsers.specific.properties
This extends a map that is itself a property (with key mapKey).
NestedMapDefinitionParser(String, String) - Constructor for class org.mule.config.spring.parsers.specific.properties.NestedMapDefinitionParser
 
NestedMapWithAttributesDefinitionParser - Class in org.mule.config.spring.parsers.specific.properties
This generates a nested map (an element of the parent map, with the key "mapKey", which is a map itself) and then adds any attributes as name/value pairs.
NestedMapWithAttributesDefinitionParser(String, String) - Constructor for class org.mule.config.spring.parsers.specific.properties.NestedMapWithAttributesDefinitionParser
 
NestedProcessor - Interface in org.mule.api
Callback interface used by message processors methods.
NestedProcessorChain - Class in org.mule.api.devkit
Deprecated.
use NestedProcessorChain instead. This class will be removed in Mule 4.0
NestedProcessorChain(MuleEvent, MuleContext, MessageProcessor) - Constructor for class org.mule.api.devkit.NestedProcessorChain
Deprecated.
 
NestedProcessorChain - Class in org.mule.processor.chain
An implementation of NestedProcessor that wraps a MessageProcessor and allows to execute it
NestedProcessorChain(MuleEvent, MuleContext, MessageProcessor) - Constructor for class org.mule.processor.chain.NestedProcessorChain
 
NestedProcessorValueResolver - Class in org.mule.module.extension.internal.runtime.resolver
A ValueResolver which wraps the given MuleEvent in a NestedProcessor.
NestedProcessorValueResolver(MessageProcessor) - Constructor for class org.mule.module.extension.internal.runtime.resolver.NestedProcessorValueResolver
 
nestedRetry() - Static method in class org.mule.config.i18n.CoreMessages
 
NetworkUtils - Class in org.mule.util
 
NEW_LINE - Static variable in class org.mule.util.SimpleLoggingTable
 
newAbstractSelectiveRouter() - Method in class org.mule.config.spring.factories.AbstractSelectiveRouterFactoryBean
 
newAbstractSelectiveRouter() - Method in class org.mule.config.spring.factories.ChoiceRouterFactoryBean
 
newBayeux() - Method in class org.mule.transport.ajax.container.MuleAjaxServlet
 
newBeanAssembler(PropertyConfiguration, BeanDefinitionBuilder, PropertyConfiguration, BeanDefinition) - Method in class org.mule.config.spring.parsers.assembly.AttributeMapBeanAssemblerFactory
 
newBeanAssembler(PropertyConfiguration, BeanDefinitionBuilder, PropertyConfiguration, BeanDefinition) - Method in interface org.mule.config.spring.parsers.assembly.BeanAssemblerFactory
 
newBeanAssembler(PropertyConfiguration, BeanDefinitionBuilder, PropertyConfiguration, BeanDefinition) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssemblerFactory
 
newBeanAssembler(PropertyConfiguration, BeanDefinitionBuilder, PropertyConfiguration, BeanDefinition) - Method in class org.mule.config.spring.parsers.assembly.TwoStageMapBeanAssemblerFactory
 
newBuilder() - Static method in class org.mule.module.extension.internal.runtime.resolver.ResolverSetResult
Creates a new ResolverSetResult.Builder instance.
newClass(String) - Method in class org.springframework.asm.ClassWriter
Adds a class reference to the constant pool of the class being build.
newCondition() - Method in class org.mule.tck.util.FakeLock
 
newCondition() - Method in class org.mule.util.lock.LockAdapter
 
newConst(Object) - Method in class org.springframework.asm.ClassWriter
Adds a number or string constant to the constant pool of the class being build.
newContext() - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
newEvent(MuleEvent, boolean) - Static method in class org.mule.RequestContext
Deprecated.
 
newException(String) - Method in class org.mule.DefaultMuleMessage
 
newField(String, String, String) - Method in class org.springframework.asm.ClassWriter
Adds a field reference to the constant pool of the class being build.
newFile(String) - Static method in class org.mule.util.FileUtils
Workaround for JDK bug 4117557.
newFile(URI) - Static method in class org.mule.util.FileUtils
Workaround for JDK bug 4117557.
newFile(File, String) - Static method in class org.mule.util.FileUtils
Workaround for JDK bug 4117557.
newFile(String, String) - Static method in class org.mule.util.FileUtils
Workaround for JDK bug 4117557.
newHandle(int, String, String, String) - Method in class org.springframework.asm.ClassWriter
Adds a handle to the constant pool of the class being build.
newInstance() - Static method in class org.mule.config.pool.ThreadPoolFactory
 
newInstance(MuleEvent) - Static method in class org.mule.management.stats.ProcessingTime
Create a ProcessingTime for the specified MuleSession.
newInstancePersistingToDefaultMemoryQueueStore(MuleContext) - Static method in class org.mule.config.QueueProfile
 
newInstanceWithPersistentQueueStore(MuleContext) - Static method in class org.mule.config.QueueProfile
 
newInvokeDynamic(String, String, Handle, Object...) - Method in class org.springframework.asm.ClassWriter
Adds an invokedynamic reference to the constant pool of the class being build.
newMessage(MuleMessage, boolean) - Static method in class org.mule.RequestContext
Deprecated.
 
newMessage() - Method in class org.mule.transport.ajax.container.MuleAjaxServlet.MuleContinuationBayeux
 
newMessage(Message) - Method in class org.mule.transport.ajax.container.MuleAjaxServlet.MuleContinuationBayeux
 
newMethod(String, String, String, boolean) - Method in class org.springframework.asm.ClassWriter
Adds a method reference to the constant pool of the class being build.
newMethodType(String) - Method in class org.springframework.asm.ClassWriter
Adds a method type reference to the constant pool of the class being build.
newNamespaceContext() - Method in class org.mule.module.xml.xpath.JaxpXPathEvaluator
 
newNameType(String, String) - Method in class org.springframework.asm.ClassWriter
Adds a name and type to the constant pool of the class being build.
newOptions() - Static method in class org.mule.api.client.SimpleOptionsBuilder
Factory method for the builder.
newOptions() - Static method in class org.mule.module.http.api.client.HttpRequestOptionsBuilder
 
newProviderInstance(WSDDService, EngineConfiguration) - Method in class org.mule.transport.soap.axis.extensions.WSDDJavaMuleProvider
Factory method for creating an MuleRPCProvider.
newSelector() - Method in enum org.mule.transport.polling.watermark.selector.WatermarkSelectorBroker
Returns a new instance of WatermarkSelector.
newSession(ImmutableEndpoint) - Method in class org.mule.transport.email.AbstractMailConnector
 
newStore() - Method in class org.mule.transport.email.SessionDetails
 
newThread(Runnable) - Method in class org.mule.module.launcher.ArtifactDeployerMonitorThreadFactory
 
newThread(Runnable) - Method in class org.mule.module.launcher.ConfigChangeMonitorThreadFactory
 
newThread(Runnable) - Method in class org.mule.util.concurrent.NamedThreadFactory
 
newThreadCopy() - Method in interface org.mule.api.ThreadSafeAccess
 
newThreadCopy() - Method in class org.mule.DefaultMessageCollection
We need to overload this if we find we want to make this class available to users, but the copy will be expensive;
newThreadCopy() - Method in class org.mule.DefaultMuleEvent
 
newThreadCopy() - Method in class org.mule.DefaultMuleMessage
newTransport() - Method in class org.mule.transport.email.SessionDetails
 
newUTF8(String) - Method in class org.springframework.asm.ClassWriter
Adds an UTF8 string to the constant pool of the class being build.
NEWVALUE - Static variable in class org.mule.module.launcher.util.ElementEvent
 
next - Variable in class org.mule.el.mvel.DelegateVariableResolverFactory
 
next() - Method in class org.mule.module.db.internal.result.resultset.ResultSetIterator
 
next() - Method in class org.mule.module.db.internal.result.statement.StatementResultIterator
 
next() - Method in class org.mule.module.ws.consumer.NamespaceRestorerXMLStreamReader
 
next() - Method in class org.mule.module.ws.consumer.ScopeSaverXMLStreamReader
 
next() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
next() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
next - Variable in class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
next() - Method in interface org.mule.routing.MessageSequence
The next element of the sequence.
next() - Method in class org.mule.routing.outbound.ArrayMessageSequence
 
next() - Method in class org.mule.routing.outbound.CollectionMessageSequence
 
next() - Method in class org.mule.routing.outbound.IteratorMessageSequence
 
next() - Method in class org.mule.routing.outbound.NodeListMessageSequence
 
next() - Method in class org.mule.routing.outbound.PartitionedMessageSequence
 
next() - Method in class org.mule.streaming.ConsumerIterator
Gets an item from the consumer and returns it
nextElement() - Method in class org.mule.module.launcher.application.EnumerationAdapter
 
nextIndex() - Method in class org.mule.module.launcher.util.ObservableList.ObservableListIterator
 
nextProcessor() - Method in class org.mule.processor.BlockingProcessorExecutor
 
nextStep() - Method in interface org.mule.api.debug.ExecutionManager
Resumes the execution and stop in the next instruction with same or lower frame level is reached.
nextTag() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
nextTag() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
nextValue() - Method in interface org.mule.util.counters.Counter
Compute and return the value of the counter.
nextValue() - Method in class org.mule.util.counters.impl.AbstractCounter
 
nextValue() - Method in class org.mule.util.counters.impl.AggregateCounter
 
nextValue() - Method in class org.mule.util.counters.impl.Average
 
nextValue() - Method in class org.mule.util.counters.impl.Delta
 
nextValue() - Method in class org.mule.util.counters.impl.InstantRate
 
nextValue() - Method in class org.mule.util.counters.impl.Max
 
nextValue() - Method in class org.mule.util.counters.impl.Min
 
nextValue() - Method in class org.mule.util.counters.impl.Number
 
nextValue() - Method in class org.mule.util.counters.impl.Operator
 
nextValue() - Method in class org.mule.util.counters.impl.RatePerUnit
 
nextValue() - Method in class org.mule.util.counters.impl.Sum
 
nextValue() - Method in class org.mule.util.counters.impl.TimeAverage
 
NO_ACTION_ID - Static variable in class org.mule.api.context.notification.ServerNotification
 
NO_ACTION_NAME - Static variable in class org.mule.api.context.notification.ServerNotification
 
NO_ARGS - Static variable in class org.mule.util.ClassUtils
 
NO_ARGS_TYPE - Static variable in class org.mule.util.ClassUtils
 
NO_AUTHORIZATION_CODE_STATUS - Static variable in class org.mule.module.oauth2.internal.authorizationcode.AutoAuthorizationCodeTokenRequestHandler
 
NO_CACHE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
NO_CORRELATION_ID - Static variable in class org.mule.routing.correlation.EventCorrelator
 
NO_LISTENER_ENTITY_FORMAT - Static variable in class org.mule.module.http.internal.listener.NoListenerRequestHandler
 
NO_MAX_LENGTH - Static variable in class org.mule.transport.tcp.protocols.LengthProtocol
 
NO_METADATA_OBTAINED - Static variable in class org.mule.module.db.internal.resolver.database.DynamicDbConfigResolver
 
NO_OPTIONS - Static variable in class org.mule.util.Base64
No options specified.
NO_PARSER_PREFIX - Static variable in class org.mule.config.spring.MissingParserProblemReporter
 
NO_SIZE - Static variable in class org.mule.module.http.internal.multipart.HttpPart
 
NO_STORE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
NO_STREAM - Static variable in class org.mule.transport.tcp.protocols.AbstractByteProtocol
 
NO_TRANSACTION_ISOLATION_CONFIGURED - Static variable in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
NO_TRANSFORM - Static variable in class org.mule.module.http.api.HttpHeaders.Values
NO_UPDATE_COUNT - Static variable in class org.mule.module.db.internal.result.statement.StatementResultIterator
 
NoActionTransformer - Class in org.mule.tck.transformer
Deprecated.
NoActionTransformer() - Constructor for class org.mule.tck.transformer.NoActionTransformer
Deprecated.
 
noAjaxConnectorWithName(String, String) - Static method in class org.mule.transport.ajax.i18n.AjaxMessages
 
noArgsForProxy() - Static method in class org.mule.module.client.i18n.ClientMessages
Deprecated.
NoArgumentsEntryPointResolver - Class in org.mule.model.resolvers
Allows for arguments with no parameters to be called.
NoArgumentsEntryPointResolver() - Constructor for class org.mule.model.resolvers.NoArgumentsEntryPointResolver
 
NoAutoGeneratedKeyStrategy - Class in org.mule.module.db.internal.domain.autogeneratedkey
 
NoAutoGeneratedKeyStrategy() - Constructor for class org.mule.module.db.internal.domain.autogeneratedkey.NoAutoGeneratedKeyStrategy
 
noCatchAllEndpointSet() - Static method in class org.mule.config.i18n.CoreMessages
 
noComponentForEndpoint() - Static method in class org.mule.config.i18n.CoreMessages
 
noConnectionFactoryConfigured() - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
noConnectorForProtocol(String) - Static method in class org.mule.transport.ajax.i18n.AjaxMessages
 
noConnectorForProtocolServlet() - Static method in class org.mule.transport.servlet.i18n.ServletMessages
 
noConnectorFound(String) - Static method in class org.mule.transport.quartz.i18n.QuartzMessages
 
noCorrelationId() - Static method in class org.mule.config.i18n.CoreMessages
 
noCurrentEventForTransformer() - Static method in class org.mule.config.i18n.CoreMessages
 
noDelegateClassAndMethodProvidedForNoArgsWrapper() - Static method in class org.mule.config.i18n.CoreMessages
 
noDelegateClassIfDelegateInstanceSpecified() - Static method in class org.mule.config.i18n.CoreMessages
 
NodeListMessageSequence - Class in org.mule.routing.outbound
 
NodeListMessageSequence(NodeList) - Constructor for class org.mule.routing.outbound.NodeListMessageSequence
 
NoDevkitInjectorProcessor - Class in org.mule.config.spring.processors
A SelectiveInjectorProcessor used to keep mule from injecting dependencies into components built with Devkit, by skipping injection of objects which are instances of org.mule.api.devkit.ProcessAdapter or org.mule.modules.process.ProcessAdapter
NoDevkitInjectorProcessor() - Constructor for class org.mule.config.spring.processors.NoDevkitInjectorProcessor
 
noEndpointsForRouter() - Static method in class org.mule.config.i18n.CoreMessages
 
noEntryPointFoundForNoArgsMethod(Object, String) - Static method in class org.mule.config.i18n.CoreMessages
 
noEntryPointFoundForNoArgsMethodUsingResolver(Object, String) - Static method in class org.mule.config.i18n.CoreMessages
 
noEntryPointFoundWithArgs(Object, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
noEntryPointFoundWithArgsUsingResolver(Object, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
noFileKeyFound(String) - Static method in class org.mule.module.pgp.i18n.PGPMessages
 
noGrantedAuthority(String) - Static method in class org.mule.module.spring.security.i18n.SpringSecurityMessages
 
noJtaTransactionAvailable(Thread) - Static method in class org.mule.config.i18n.CoreMessages
 
noKeyIdFound(String) - Static method in class org.mule.module.pgp.i18n.PGPMessages
 
NoListenerRequestHandler - Class in org.mule.module.http.internal.listener
Request handle for request calls to paths with no listener configured.
noMatchingMethodsOnObjectCalledUsingResolver(Object, String) - Static method in class org.mule.config.i18n.CoreMessages
 
noMatchingMethodsOnObjectReturning(Object, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
noMatchingMethodsOnObjectReturningUsingResolver(Object, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
noMBeanServerAvailable() - Static method in class org.mule.module.management.i18n.ManagementMessages
 
noMessageBoundForAck() - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
noMessageTypeInUri() - Static method in class org.mule.transport.xmpp.i18n.XmppMessages
 
NoMethodRequestHandler - Class in org.mule.module.http.internal.listener
 
noMuleTransactionAvailable() - Static method in class org.mule.config.i18n.CoreMessages
 
NON_BLOCKING_PROCESSING_STRATEGY - Static variable in class org.mule.config.spring.util.ProcessingStrategyUtils
 
NON_BLOCKING_RESPONSE - Static variable in class org.mule.module.cxf.CxfConstants
 
NonBlockingMessageProcessor - Interface in org.mule.processor
A NonBlockingMessageProcessor differs from other message processors in that it supports both blocking and non-blocking processing.
NonBlockingMessageSource - Interface in org.mule.api.source
NonBlockingMessageSource's create instances of MuleEvent that contain a ReplyToHandler allowing for a response or error to be returned asynchronously by a different thread freeing up the request thread.
NonBlockingProcessingStrategy - Class in org.mule.processor.strategy
Allows Mule to use non-blocking execution model where possible and free up threads when performing IO operations.
NonBlockingProcessingStrategy() - Constructor for class org.mule.processor.strategy.NonBlockingProcessingStrategy
 
NonBlockingProcessorExecutor - Class in org.mule.processor
Specialized BlockingProcessorExecutor that pauses iteration in the case a .mule.processor.NonBlockingMessageProcessor is invoked and the flow is executing using non-blocking.
NonBlockingProcessorExecutor(MuleEvent, List<MessageProcessor>, MessageProcessorExecutionTemplate, boolean) - Constructor for class org.mule.processor.NonBlockingProcessorExecutor
 
NonBlockingReplyToHandler - Interface in org.mule.api.transport
Marker interface for ReplyToHandlers used for non-blocking callbacks rather than for processing the ReplyTo of a MessageExchangePattern.ONE_WAY Flow.
NonBlockingSupported - Interface in org.mule.api
Marker interface for those InterceptingMessageProcessor and MessageRouter implementations that support non-blocking processing.
NonBlockingVoidMuleEvent - Class in org.mule
A NonBlockingVoidMuleEvent represents a void return, but in contrast to VoidMuleEvent while the return up the stack is void, an asynchronous response is expected.
none() - Static method in class org.mule.config.i18n.CoreMessages
 
NONE - Static variable in class org.mule.config.spring.parsers.processors.CheckExclusiveAttribute
 
NONE - Static variable in class org.mule.config.spring.parsers.processors.CheckExclusiveAttributeAndText
 
NONE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
noOperationWasFoundOrSpecified() - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
noOutboundRouterSetOn(String) - Static method in class org.mule.config.i18n.CoreMessages
 
NOP_ARTIFACT_DEPLOYMENT_TEMPLATE - Static variable in interface org.mule.module.launcher.ArtifactDeploymentTemplate
No-op implementation of ArtifactDeploymentTemplate.
noParserFoundForAnnotation(Annotation) - Static method in class org.mule.config.i18n.AnnotationsMessages
 
noPropertyConverterForType(Class) - Static method in class org.mule.config.i18n.AnnotationsMessages
 
noPublicKeyDefined() - Static method in class org.mule.module.pgp.i18n.PGPMessages
 
noPublicKeyForPrincipal(String) - Static method in class org.mule.module.pgp.i18n.PGPMessages
 
noPublicKeyForUser(String) - Static method in class org.mule.module.pgp.i18n.PGPMessages
 
noReceiverForEndpoint(String, Object) - Static method in class org.mule.transport.vm.i18n.VMMessages
 
NoReceiverForEndpointException - Exception in org.mule.api.transport
NoReceiverForEndpointException is thrown when an enpoint is specified for a receiver but no such receiver exists.
NoReceiverForEndpointException(String) - Constructor for exception org.mule.api.transport.NoReceiverForEndpointException
 
NoReceiverForEndpointException(Message) - Constructor for exception org.mule.api.transport.NoReceiverForEndpointException
 
NoReceiverForEndpointException(Message, Throwable) - Constructor for exception org.mule.api.transport.NoReceiverForEndpointException
 
NoReceiverForEndpointException(Throwable) - Constructor for exception org.mule.api.transport.NoReceiverForEndpointException
 
noReceiverFoundForUrl(String) - Static method in class org.mule.transport.http.i18n.HttpMessages
 
noReceiverInConnector(String, String) - Static method in class org.mule.transport.quartz.i18n.QuartzMessages
 
noRecipientInUri() - Static method in class org.mule.transport.xmpp.i18n.XmppMessages
 
noResourceBaseDefined() - Static method in class org.mule.transport.http.i18n.HttpMessages
 
NoRetryPolicyTemplate - Class in org.mule.retry.policies
This policy is basically a placeholder.
NoRetryPolicyTemplate() - Constructor for class org.mule.retry.policies.NoRetryPolicyTemplate
 
NoRetryPolicyTemplate.NoRetryPolicy - Class in org.mule.retry.policies
 
NoRetryPolicyTemplate.NoRetryPolicy() - Constructor for class org.mule.retry.policies.NoRetryPolicyTemplate.NoRetryPolicy
 
normalize() - Method in class org.mule.endpoint.MuleEndpointURI
 
normalizeFilePath(URL, String) - Static method in class org.mule.util.FileUtils
Remove from uri to file prefix file:/ Add if need file separator to begin
normalizePathWithSpacesOrEncodedSpaces(String) - Static method in class org.mule.module.http.internal.HttpParser
Normalize a path that may contains spaces, %20 or +.
normalizeUrl(String) - Static method in class org.mule.transport.http.HttpConnector
Ensures that the supplied URL starts with a '/'.
normalShutdown() - Static method in class org.mule.config.i18n.CoreMessages
 
NoSatisfiableMethodsException - Exception in org.mule.model.resolvers
NoSatisfiableMethodsException is thrown by EntryPointResolvers when the service passed has no methods that meet the criteria of the configured EntryPointResolver.
NoSatisfiableMethodsException(Object, String) - Constructor for exception org.mule.model.resolvers.NoSatisfiableMethodsException
 
NoSatisfiableMethodsException(Object, Class<?>[]) - Constructor for exception org.mule.model.resolvers.NoSatisfiableMethodsException
 
NoSatisfiableMethodsException(Object, Class<?>) - Constructor for exception org.mule.model.resolvers.NoSatisfiableMethodsException
 
noSecretKeyDefined() - Static method in class org.mule.module.pgp.i18n.PGPMessages
 
noSecretPassPhrase() - Static method in class org.mule.module.pgp.i18n.PGPMessages
 
noServiceQueueTimeoutSet(Service) - Static method in class org.mule.config.i18n.CoreMessages
Deprecated.
noServiceTransportDescriptor(String) - Static method in class org.mule.config.i18n.CoreMessages
 
noServletConnectorFound(String) - Static method in class org.mule.transport.servlet.i18n.ServletMessages
 
noSuchFlowConstruct(String) - Static method in class org.mule.module.client.i18n.ClientMessages
Deprecated.
NOT_IN_LIFECYCLE_PHASE - Static variable in interface org.mule.api.lifecycle.LifecycleManager
 
NOT_SET - Static variable in class org.mule.DefaultMuleMessage
 
NOT_SET - Static variable in class org.mule.exception.AbstractExceptionListener
 
notClustered() - Static method in class org.mule.config.i18n.CoreMessages
 
notConnectedYet(String) - Static method in class org.mule.config.i18n.CoreMessages
 
notDeployed(MuleProcessController, String) - Static method in class org.mule.test.infrastructure.process.AppDeploymentProbe
 
NotFilter - Class in org.mule.routing.filters.logic
NotFilter accepts if the filter does not accept.
NotFilter() - Constructor for class org.mule.routing.filters.logic.NotFilter
 
NotFilter(Filter) - Constructor for class org.mule.routing.filters.logic.NotFilter
 
NotificationDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
NotificationDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.NotificationDefinitionParser
 
NotificationDisableDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
NotificationDisableDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.NotificationDisableDefinitionParser
 
NotificationException - Exception in org.mule.context.notification
Thrown by the ServerNotification Manager if unrecognised listeners or events are passed to the manager
NotificationException(Message) - Constructor for exception org.mule.context.notification.NotificationException
 
NotificationException(Message, Throwable) - Constructor for exception org.mule.context.notification.NotificationException
 
NotificationFiringProcessingPhase<Template extends MessageProcessTemplate> - Class in org.mule.execution
Provides a reusable way for concrete MessageProcessPhases to fire notifications.
NotificationFiringProcessingPhase() - Constructor for class org.mule.execution.NotificationFiringProcessingPhase
 
notificationHandler - Variable in class org.mule.component.AbstractComponent
 
notificationHandler - Variable in class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
NotificationHelper - Class in org.mule.context.notification
Simple class to fire notifications of a specified type over a ServerNotificationHandler.
NotificationHelper(ServerNotificationHandler, Class<? extends ServerNotification>, boolean) - Constructor for class org.mule.context.notification.NotificationHelper
Creates a new NotificationHelper that emits instances of notificationClass class.
NotificationLifecycleObject - Class in org.mule.lifecycle
TODO
NotificationLifecycleObject(Class) - Constructor for class org.mule.lifecycle.NotificationLifecycleObject
 
NotificationLifecycleObject(Class, Class) - Constructor for class org.mule.lifecycle.NotificationLifecycleObject
 
NotificationLifecycleObject(Class, Class, int, int) - Constructor for class org.mule.lifecycle.NotificationLifecycleObject
 
NotificationListenerPostProcessor - Class in org.mule.config.spring.processors
A BeanPostProcessor which registers ServerNotificationListener objects into the ServerNotificationManager
NotificationListenerPostProcessor(MuleContext) - Constructor for class org.mule.config.spring.processors.NotificationListenerPostProcessor
 
NotificationListenerProcessor - Class in org.mule.registry
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)
NotificationListenerProcessor(MuleContext) - Constructor for class org.mule.registry.NotificationListenerProcessor
Deprecated.
 
NotificationListenersPostProcessor - Class in org.mule.config.spring
Deprecated.
as of 3.7.0 because it's not being used. Will be removed in Mule 4.0
NotificationListenersPostProcessor(MuleContext) - Constructor for class org.mule.config.spring.NotificationListenersPostProcessor
Deprecated.
 
notificationListenerSubscriptionAlreadyRegistered(ListenerSubscriptionPair) - Static method in class org.mule.config.i18n.CoreMessages
 
notificationManager - Variable in class org.mule.context.DefaultMuleContextBuilder
 
notificationManager - Variable in class org.mule.DefaultMuleContext
 
NotificationUtils - Class in org.mule.util
Contains useful methods for the generation of message processor identifiers used by the notification system
NotificationUtils.FlowMap - Class in org.mule.util
 
NotificationUtils.FlowMap(Map<MessageProcessor, String>) - Constructor for class org.mule.util.NotificationUtils.FlowMap
 
NotificationUtils.PathResolver - Interface in org.mule.util
 
notifier - Variable in class org.mule.retry.policies.AbstractPolicyTemplate
 
notify(EventListenerExecution) - Method in class org.mule.module.jbpm.MuleSendActivity
 
notify(int, String) - Method in class org.mule.transport.sftp.notification.SftpNotifier
 
notify(int, String, long) - Method in class org.mule.transport.sftp.notification.SftpNotifier
 
notify - Variable in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
notifyAuthorizeStart(MuleEvent) - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
notifyCallbackReception(MuleEvent) - Method in class org.mule.security.oauth.processor.FetchAccessTokenMessageProcessor
 
notifyFinish() - Method in class org.mule.util.queue.objectstore.xa.AbstractTransactionContext
Deprecated.
 
notifyFinish() - Method in class org.mule.util.xa.AbstractTransactionContext
 
notifyListeners(ServerNotification) - Method in class org.mule.context.notification.ServerNotificationManager
 
notifyTransformerResolvers(Transformer, TransformerResolver.RegistryAction) - Method in class org.mule.registry.MuleRegistryHelper
 
notifyTransition(String) - Method in class org.mule.construct.FlowConstructLifecycleManager
 
notifyTransition(String) - Method in class org.mule.lifecycle.AbstractLifecycleManager
Allows any for any state adjustments in sub classes.
notifyTransition(String) - Method in class org.mule.processor.SedaStageLifecycleManager
 
notifyTransition(String) - Method in class org.mule.service.ServiceLifecycleManager
Deprecated.
 
NotInLifecyclePhase - Class in org.mule.lifecycle.phases
This lifecycle phase marks the 'pre-lifecycle' phase of an object.
NotInLifecyclePhase() - Constructor for class org.mule.lifecycle.phases.NotInLifecyclePhase
 
notMuleXaTransaction(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
NotPermittedException - Exception in org.mule.api.security
NotPermittedException is thrown if the user isn't authorized to perform an action.
NotPermittedException(Message) - Constructor for exception org.mule.api.security.NotPermittedException
 
NotPermittedException(Message, Throwable, MessageProcessor) - Constructor for exception org.mule.api.security.NotPermittedException
 
NotPermittedException(Message, MuleEvent) - Constructor for exception org.mule.api.security.NotPermittedException
 
NotPermittedException(Message, MuleEvent, Throwable, MessageProcessor) - Constructor for exception org.mule.api.security.NotPermittedException
 
NotPermittedException(MuleEvent, SecurityContext, SecurityFilter) - Constructor for exception org.mule.api.security.NotPermittedException
 
noTransformerFoundForMessage(DataType<?>, DataType<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
notRunning() - Static method in class org.mule.test.infrastructure.process.matchers.Running
 
notSerializableWatermark(String) - Static method in class org.mule.config.i18n.CoreMessages
 
notSet() - Static method in class org.mule.config.i18n.CoreMessages
 
NOW_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 
NtlmMessageFactory - Class in org.mule.transport.http.ntlm
 
NtlmMessageFactory() - Constructor for class org.mule.transport.http.ntlm.NtlmMessageFactory
 
NtlmProxyConfig - Class in org.mule.module.http.internal.request
A Proxy configuration for NTLM authentication proxies.
NtlmProxyConfig() - Constructor for class org.mule.module.http.internal.request.NtlmProxyConfig
 
NtlmProxyConfigBuilder - Class in org.mule.module.http.api.requester.proxy
Builder for an http proxy using NTLM.
NtlmProxyConfigBuilder() - Constructor for class org.mule.module.http.api.requester.proxy.NtlmProxyConfigBuilder
 
NTLMScheme - Class in org.mule.transport.http.ntlm
Reimplements NTLMScheme using JCIFS org.apache.commons.httpclient.auth.NTLMScheme.
NTLMScheme() - Constructor for class org.mule.transport.http.ntlm.NTLMScheme
 
NULL_ACTION - Static variable in class org.mule.api.context.notification.ServerNotification
 
NULL_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
NULL_RESOURCE - Static variable in class org.mule.api.context.notification.ServerNotification
 
NULL_SUBSCRIPTION - Static variable in class org.mule.context.notification.ServerNotificationManager
 
NULL_VALIDATOR - Static variable in class org.mule.module.http.internal.request.SuccessStatusCodeValidator
An status code validator that allows any status code.
NullBulkQueryLogger - Class in org.mule.module.db.internal.domain.logger
Null implementation of BulkQueryLogger
NullBulkQueryLogger() - Constructor for class org.mule.module.db.internal.domain.logger.NullBulkQueryLogger
 
NullClusterConfiguration - Class in org.mule.config
Empty cluster configuration to be used when the instance does not belong to a cluster
NullClusterConfiguration() - Constructor for class org.mule.config.NullClusterConfiguration
 
NullComponent - Class in org.mule.component.simple
NullComponent is a service that is used as a placeholder.
NullComponent() - Constructor for class org.mule.component.simple.NullComponent
 
NullConnector - Class in org.mule.endpoint.dynamic
A placeholder for a connector that has not been created yet.
NullConnector(MuleContext) - Constructor for class org.mule.endpoint.dynamic.NullConnector
 
NullDeploymentListener - Class in org.mule.module.launcher.application
Defines a DeploymentListener that does nothing
NullDeploymentListener() - Constructor for class org.mule.module.launcher.application.NullDeploymentListener
 
nullEmptyArray(byte[]) - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
 
nullifyExceptionPayloadIfRequired(MuleEvent) - Method in class org.mule.exception.CatchMessagingExceptionStrategy
 
nullifyExceptionPayloadIfRequired(MuleEvent) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
NullLifecycleAdapter - Class in org.mule.component
NullLifecycleAdapter is a lifecycle adaptor implementation that performs no Mule lifecycle propagation to Mule service component implementations.
NullLifecycleAdapter(Object, JavaComponent, FlowConstruct, EntryPointResolverSet, MuleContext) - Constructor for class org.mule.component.NullLifecycleAdapter
 
NullLifecycleInterceptor - Class in org.mule.lifecycle
Implementation of the null object design pattern for the LifecycleInterceptor interface
NullLifecycleInterceptor() - Constructor for class org.mule.lifecycle.NullLifecycleInterceptor
 
NullMessageProcessor - Class in org.mule.processor
 
NullMessageProcessor() - Constructor for class org.mule.processor.NullMessageProcessor
 
NullMetadataProvider - Class in org.mule.module.db.internal.metadata
Null implementation of QueryMetadataProvider
NullMetadataProvider() - Constructor for class org.mule.module.db.internal.metadata.NullMetadataProvider
 
NullPayload - Class in org.mule.transport
NullPayload represents a null event payload
NullPreparedBulkQueryLogger - Class in org.mule.module.db.internal.domain.logger
Null implementation of PreparedBulkQueryLogger
NullPreparedBulkQueryLogger() - Constructor for class org.mule.module.db.internal.domain.logger.NullPreparedBulkQueryLogger
 
NullResultSetHandler - Class in org.mule.module.db.internal.result.resultset
Returns an unprocessed ResultSet.
NullResultSetHandler() - Constructor for class org.mule.module.db.internal.result.resultset.NullResultSetHandler
 
NullSessionHandler - Class in org.mule.session
A session handler that ignores any session information
NullSessionHandler() - Constructor for class org.mule.session.NullSessionHandler
 
NullSingleQueryLogger - Class in org.mule.module.db.internal.domain.logger
Null implementation of SingleQueryLogger
NullSingleQueryLogger() - Constructor for class org.mule.module.db.internal.domain.logger.NullSingleQueryLogger
 
NullVariableResolverFactory - Class in org.mule.el.mvel
 
NullVariableResolverFactory() - Constructor for class org.mule.el.mvel.NullVariableResolverFactory
 
nullWatermark() - Static method in class org.mule.config.i18n.CoreMessages
 
NUMBER - Static variable in class org.mule.util.counters.CounterFactory.Type
A basic counter representing a double value
Number - Class in org.mule.util.counters.impl
 
Number(String) - Constructor for class org.mule.util.counters.impl.Number
 
NUMBER_OF_CONCURRENT_TRANSACTED_RECEIVERS_ATTRIBUTE - Static variable in class org.mule.transport.jms.config.JmsNamespaceHandler
 
NUMBER_OF_CONSUMERS_ATTRIBUTE - Static variable in class org.mule.transport.jms.config.JmsNamespaceHandler
 
NUMBER_OF_CONSUMERS_PROPERTY - Static variable in class org.mule.transport.jms.config.JmsNamespaceHandler
 
numberOfConcurrentTransactedReceivers - Variable in class org.mule.transport.AbstractConnector
 
NumberToString - Class in org.mule.transformer.simple
NumberToString converts a Number to a String.
NumberToString() - Constructor for class org.mule.transformer.simple.NumberToString
 
NumberToString(NumberFormat) - Constructor for class org.mule.transformer.simple.NumberToString
 
NumberUtils - Class in org.mule.util
NumberUtils contains useful methods for manipulating numbers.
NumberUtils() - Constructor for class org.mule.util.NumberUtils
 
NUMERIC_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
NVARCHAR_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 

O

OAuth1Adapter - Interface in org.mule.security.oauth
 
OAuth1Connector - Interface in org.mule.security.oauth
 
OAuth1FetchAccessTokenMessageProcessor - Class in org.mule.security.oauth.processor
 
OAuth1FetchAccessTokenMessageProcessor(OAuth1Adapter) - Constructor for class org.mule.security.oauth.processor.OAuth1FetchAccessTokenMessageProcessor
 
OAuth1Manager - Interface in org.mule.security.oauth
 
OAuth2Adapter - Interface in org.mule.security.oauth
 
OAuth2Connector - Interface in org.mule.security.oauth
 
OAuth2FetchAccessTokenMessageProcessor - Class in org.mule.security.oauth.processor
 
OAuth2FetchAccessTokenMessageProcessor(OAuth2Manager<OAuth2Adapter>, String) - Constructor for class org.mule.security.oauth.processor.OAuth2FetchAccessTokenMessageProcessor
 
OAuth2Manager<C extends OAuth2Adapter> - Interface in org.mule.security.oauth
Wrapper around org.mule.api.annotations.oauth.OAuth2 annotated class that will infuse it with access token management capabilities.
OAuth2NamespaceHandler - Class in org.mule.module.oauth2.internal.config
 
OAuth2NamespaceHandler() - Constructor for class org.mule.module.oauth2.internal.config.OAuth2NamespaceHandler
 
OAUTH_AUTHORIZATION_BEGIN - Static variable in class org.mule.security.oauth.notification.OAuthAuthorizeNotification
 
OAUTH_AUTHORIZATION_END - Static variable in class org.mule.security.oauth.notification.OAuthAuthorizeNotification
 
OAUTH_STATE_ID_FLOW_VAR_NAME - Static variable in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
OAuthAdapter - Interface in org.mule.security.oauth
 
OAuthAuthenticationHeader - Class in org.mule.module.oauth2.internal.authorizationcode
 
OAuthAuthenticationHeader() - Constructor for class org.mule.module.oauth2.internal.authorizationcode.OAuthAuthenticationHeader
 
OAuthAuthorizeNotification - Class in org.mule.security.oauth.notification
 
OAuthAuthorizeNotification(MuleEvent, int) - Constructor for class org.mule.security.oauth.notification.OAuthAuthorizeNotification
 
OAuthConstants - Interface in org.mule.module.oauth2.internal
 
OAuthContextExpressionLanguageFunction - Class in org.mule.module.oauth2.internal.mel
Function oauthState for accessing OAuth authentication state
OAuthContextExpressionLanguageFunction() - Constructor for class org.mule.module.oauth2.internal.mel.OAuthContextExpressionLanguageFunction
 
OAuthExpressionLanguageExtension - Class in org.mule.module.oauth2.internal.mel
MEL extension for adding OAuth related functions.
OAuthExpressionLanguageExtension() - Constructor for class org.mule.module.oauth2.internal.mel.OAuthExpressionLanguageExtension
 
OAuthProcessTemplate<P> - Class in org.mule.security.oauth.process
 
OAuthProcessTemplate(Capabilities) - Constructor for class org.mule.security.oauth.process.OAuthProcessTemplate
 
OAuthProperties - Interface in org.mule.security.oauth
OAuthProperties is a set of constants pertaining to OAuth properties.
OAuthResponseParser - Interface in org.mule.security.oauth.util
 
object - Variable in class org.mule.lifecycle.AbstractLifecycleManager
 
object - Variable in class org.mule.processor.InvokerMessageProcessor
 
OBJECT - Static variable in class org.mule.transformer.types.DataTypeFactory
 
OBJECT - Static variable in class org.mule.transport.rmi.config.RmiNamespaceHandler
 
OBJECT_CLUSTER_CONFIGURATION - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_CONNECTOR_MESSAGE_PROCESSOR_LOCATOR - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_CONVERTER_RESOLVER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_DATA_TYPE - Static variable in interface org.mule.api.transformer.DataType
 
OBJECT_DEFAULT_GLOBAL_EXCEPTION_STRATEGY - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_DEFAULT_MESSAGE_DISPATCHER_THREADING_PROFILE - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_DEFAULT_MESSAGE_PROCESSING_MANAGER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_DEFAULT_MESSAGE_RECEIVER_THREADING_PROFILE - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_DEFAULT_MESSAGE_REQUESTER_THREADING_PROFILE - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_DEFAULT_RETRY_POLICY_TEMPLATE - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_DEFAULT_SERVICE_THREADING_PROFILE - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_DEFAULT_THREADING_PROFILE - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_EXPRESSION_LANGUAGE - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_EXTENSION_MANAGER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_FACTORY_SETTER - Static variable in class org.mule.config.spring.parsers.specific.ObjectFactoryWrapper
 
OBJECT_FOR_ENRICHMENT - Static variable in class org.mule.expression.DefaultExpressionManager
 
OBJECT_HTTP_CLIENT_FACTORY - Static variable in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
OBJECT_KEY - Static variable in class org.mule.config.bootstrap.AbstractRegistryBootstrap
 
OBJECT_LIFECYCLE_MANAGER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_LOCK_FACTORY - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_LOCK_PROVIDER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_MULE_APPLICATION_PROPERTIES - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_MULE_CONFIGURATION - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_MULE_CONTEXT - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_MULE_CONTEXT_PROCESSOR - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_MULE_ENDPOINT_FACTORY - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_MULE_NAMESPACE_MANAGER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_MULE_OUTBOUND_ENDPOINT_EXECUTOR_FACTORY - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_MULE_SIMPLE_REGISTRY_BOOTSTRAP - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_MULE_STREAM_CLOSER_SERVICE - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_NOTIFICATION_MANAGER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_OBJECT_NAME_PROCESSOR - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_POLLING_CONTROLLER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_PROCESSING_TIME_WATCHER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_PROPERTY_PLACEHOLDER_PROCESSOR - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_QUEUE_MANAGER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_SECURITY_MANAGER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_SERIALIZER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_STORE_DEFAULT_IN_MEMORY_NAME - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_STORE_DEFAULT_PERSISTENT_NAME - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_STORE_DIR - Static variable in class org.mule.util.store.PartitionedPersistentObjectStore
 
OBJECT_STORE_FILE_NAME - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_STORE_MANAGER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_STORE_SIMPLE_MEMORY_NAME - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_SYSTEM_MODEL - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_TRANSACTION_MANAGER - Static variable in class org.mule.api.config.MuleProperties
 
OBJECT_WORK_MANAGER - Static variable in class org.mule.api.config.MuleProperties
 
objectAlreadyExists(String) - Static method in class org.mule.config.i18n.CoreMessages
 
ObjectAlreadyExistsException - Exception in org.mule.api.store
 
ObjectAlreadyExistsException() - Constructor for exception org.mule.api.store.ObjectAlreadyExistsException
 
ObjectAlreadyExistsException(Message, Throwable) - Constructor for exception org.mule.api.store.ObjectAlreadyExistsException
 
ObjectAlreadyExistsException(Message) - Constructor for exception org.mule.api.store.ObjectAlreadyExistsException
 
ObjectAlreadyExistsException(Throwable) - Constructor for exception org.mule.api.store.ObjectAlreadyExistsException
 
objectAlreadyInitialised(String) - Static method in class org.mule.config.i18n.CoreMessages
 
objectAlreadyRegistered(String, Object, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
ObjectArrayToString - Class in org.mule.transformer.simple
ObjectArrayToString transformer is the opposite of StringToObjectArray - it simply converts Object[] to a String in which each element is separated by a configurable delimiter (default is a space).
ObjectArrayToString() - Constructor for class org.mule.transformer.simple.ObjectArrayToString
 
ObjectBuilder<T> - Interface in org.mule.module.extension.internal.runtime
A builder capable of creating instances of a given Class, populating its attributes based on a list of ValueResolvers.
ObjectBuilderValueResolver<T> - Class in org.mule.module.extension.internal.runtime.resolver
ObjectBuilderValueResolver(ObjectBuilder<T>) - Constructor for class org.mule.module.extension.internal.runtime.resolver.ObjectBuilderValueResolver
 
objectClass - Variable in class org.mule.object.AbstractObjectFactory
 
objectClassName - Variable in class org.mule.object.AbstractObjectFactory
 
ObjectDoesNotExistException - Exception in org.mule.api.store
 
ObjectDoesNotExistException() - Constructor for exception org.mule.api.store.ObjectDoesNotExistException
 
ObjectDoesNotExistException(Message, Throwable) - Constructor for exception org.mule.api.store.ObjectDoesNotExistException
 
ObjectDoesNotExistException(Message) - Constructor for exception org.mule.api.store.ObjectDoesNotExistException
 
ObjectDoesNotExistException(Throwable) - Constructor for exception org.mule.api.store.ObjectDoesNotExistException
 
objectDoesNotImplementInterface(Object, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
ObjectFactory - Interface in org.mule.api.object
ObjectFactory is a generic Factory interface.
objectFactory - Variable in class org.mule.component.AbstractJavaComponent
 
objectFactory - Variable in class org.mule.util.pool.CommonsPoolObjectPool
The ObjectFactory used to create new pool instances
ObjectFactoryDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
ObjectFactoryDefinitionParser(Class, String) - Constructor for class org.mule.config.spring.parsers.specific.ObjectFactoryDefinitionParser
 
ObjectFactoryDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.ObjectFactoryDefinitionParser
 
ObjectFactoryWrapper - Class in org.mule.config.spring.parsers.specific
Use this BeanDefinitionParser when you need a "wrapper" element for an ObjectFactory.
ObjectFactoryWrapper(String) - Constructor for class org.mule.config.spring.parsers.specific.ObjectFactoryWrapper
 
objectFailedToInitialise(String) - Static method in class org.mule.config.i18n.CoreMessages
 
ObjectFieldDebugInfo - Class in org.mule.api.debug
Provides debug information for an object's field that contains a value composed of many simple values.
ObjectFilter - Interface in org.mule.api.routing.filter
Interface for filtering any kind of object.
objectHasMoreThanOnePostConstructAnnotation(Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
objectHasMoreThanOnePreDestroyAnnotation(Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
objectIsNull(String) - Static method in class org.mule.config.i18n.CoreMessages
 
objectMustImplementAnInterface(String) - Static method in class org.mule.transport.soap.axis.i18n.AxisMessages
 
objectName - Variable in class org.mule.module.management.mbean.FlowConstructService
 
objectNameHelper - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
ObjectNameHelper - Class in org.mule.util
Generates consistent objects names for Mule components
ObjectNameHelper(MuleContext) - Constructor for class org.mule.util.ObjectNameHelper
 
objectNotAvailble(String) - Static method in class org.mule.module.xml.i18n.XmlMessages
 
objectNotFound(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
objectNotFound(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
objectNotOfCorrectType(Class<?>, Class<?>[]) - Static method in class org.mule.config.i18n.CoreMessages
 
objectNotOfCorrectType(Class<?>, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
objectNotRegistered(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
objectNotSetInService(Object, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
ObjectPool - Interface in org.mule.util.pool
ObjectPool is a simple pooling interface for objects
ObjectProcessor - Interface in org.mule.api.registry
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)
objects - Variable in class org.mule.config.builders.SimpleConfigurationBuilder
 
ObjectSerializer - Interface in org.mule.api.serialization
Defines a component capable to serialize/deserialize objects into/from an array of bytes.
ObjectStore<T extends Serializable> - Interface in org.mule.api.store
 
objectStore - Variable in class org.mule.util.queue.objectstore.QueueConfiguration
Deprecated.
 
ObjectStoreException - Exception in org.mule.api.store
This exception class is thrown in cases when an exception occurs while operating on an ObjectStore.
ObjectStoreException() - Constructor for exception org.mule.api.store.ObjectStoreException
 
ObjectStoreException(Message, Throwable) - Constructor for exception org.mule.api.store.ObjectStoreException
 
ObjectStoreException(Message) - Constructor for exception org.mule.api.store.ObjectStoreException
 
ObjectStoreException(Throwable) - Constructor for exception org.mule.api.store.ObjectStoreException
 
ObjectStoreFromRegistryFactoryBean - Class in org.mule.config.spring.factories
Lookup an ObjectStore from the registry.
ObjectStoreFromRegistryFactoryBean(String) - Constructor for class org.mule.config.spring.factories.ObjectStoreFromRegistryFactoryBean
 
ObjectStoreManager - Interface in org.mule.api.store
 
ObjectStoreNotAvaliableException - Exception in org.mule.api.store
This exception is thrown when the underlying to an ObjectStore's system fails.
ObjectStoreNotAvaliableException() - Constructor for exception org.mule.api.store.ObjectStoreNotAvaliableException
 
ObjectStoreNotAvaliableException(Message, Throwable) - Constructor for exception org.mule.api.store.ObjectStoreNotAvaliableException
 
ObjectStoreNotAvaliableException(Message) - Constructor for exception org.mule.api.store.ObjectStoreNotAvaliableException
 
ObjectStoreNotAvaliableException(Throwable) - Constructor for exception org.mule.api.store.ObjectStoreNotAvaliableException
 
objectStoreNotFound(String) - Static method in class org.mule.config.i18n.CoreMessages
 
ObjectStorePartition<T extends Serializable> - Class in org.mule.util.store
 
ObjectStorePartition(String, PartitionableObjectStore<T>) - Constructor for class org.mule.util.store.ObjectStorePartition
 
ObjectStoreToMapAdapter<ValueType extends Serializable> - Class in org.mule.util.store
Adapts the object store interface to a map interface so the client doesn't have to deal with all the ObjectStoreExceptions thrown by ObjectStore.
ObjectStoreToMapAdapter(ListableObjectStore<ValueType>) - Constructor for class org.mule.util.store.ObjectStoreToMapAdapter
 
ObjectToByteArray - Class in org.mule.transformer.simple
ObjectToByteArray converts serilaizable object to a byte array but treats java.lang.String differently by converting to bytes using the String.getBytrs() method.
ObjectToByteArray() - Constructor for class org.mule.transformer.simple.ObjectToByteArray
 
ObjectToFeed - Class in org.mule.module.atom.transformers
ObjectToInputStream converts serilaizable object to a input stream but treats java.lang.String differently by converting to bytes using the String.getBytes() method.
ObjectToFeed() - Constructor for class org.mule.module.atom.transformers.ObjectToFeed
 
ObjectToHttpClientMethodRequest - Class in org.mule.transport.http.transformers
ObjectToHttpClientMethodRequest transforms a MuleMessage into a HttpClient HttpMethod that represents an HttpRequest.
ObjectToHttpClientMethodRequest() - Constructor for class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
ObjectToInputStream - Class in org.mule.transformer.simple
ObjectToInputStream converts Serializable objects to an InputStream but treats java.lang.String, byte[] and org.mule.api.transport.OutputHandler differently by using their byte[] content rather thqn Serializing them.
ObjectToInputStream() - Constructor for class org.mule.transformer.simple.ObjectToInputStream
 
ObjectToJMSMessage - Class in org.mule.transport.jms.transformers
ObjectToJMSMessage will convert any object to a javax.jms.Message or sub-type into an object.
ObjectToJMSMessage() - Constructor for class org.mule.transport.jms.transformers.ObjectToJMSMessage
 
ObjectToJson - Class in org.mule.module.json.transformers
Converts a java object to a JSON encoded object that can be consumed by other languages such as Javascript or Ruby.
ObjectToJson() - Constructor for class org.mule.module.json.transformers.ObjectToJson
 
ObjectToMimeMessage - Class in org.mule.transport.email.transformers
Transforms a Message to a MuleMessage, with support for attachments
ObjectToMimeMessage() - Constructor for class org.mule.transport.email.transformers.ObjectToMimeMessage
 
ObjectToOutputHandler - Class in org.mule.transformer.simple
ObjectToOutputHandler converts a byte array into a String.
ObjectToOutputHandler() - Constructor for class org.mule.transformer.simple.ObjectToOutputHandler
 
ObjectToRemoteInvocationResultTransformer - Class in org.mule.module.spring.remoting
Converts an Object to a Spring RemoteInvocationResult and then into a byte[].
ObjectToRemoteInvocationResultTransformer() - Constructor for class org.mule.module.spring.remoting.ObjectToRemoteInvocationResultTransformer
 
ObjectToRemoteInvocationTransformer - Class in org.mule.module.spring.remoting
Transforms a byte[] into an ObjectInputStream and then into a Spring RemoteInvocation instance.
ObjectToRemoteInvocationTransformer() - Constructor for class org.mule.module.spring.remoting.ObjectToRemoteInvocationTransformer
 
ObjectToRssFeed - Class in org.mule.module.rss.transformers
Converts an RSS data representation into a SyndFeed object
ObjectToRssFeed() - Constructor for class org.mule.module.rss.transformers.ObjectToRssFeed
 
ObjectToString - Class in org.mule.transformer.simple
ObjectToString transformer is useful for debugging.
ObjectToString() - Constructor for class org.mule.transformer.simple.ObjectToString
 
ObjectToXml - Class in org.mule.module.xml.transformer
ObjectToXml converts any object to XML using Xstream.
ObjectToXml() - Constructor for class org.mule.module.xml.transformer.ObjectToXml
 
ObjectToXmppPacket - Class in org.mule.transport.xmpp.transformers
Creates an Xmpp message packet from a MuleMessage
ObjectToXmppPacket() - Constructor for class org.mule.transport.xmpp.transformers.ObjectToXmppPacket
 
objectType - Variable in class org.mule.processor.InvokerMessageProcessor
 
ObjectUtils - Class in org.mule.util
 
ObjectUtils() - Constructor for class org.mule.util.ObjectUtils
 
ObservableList<E> - Class in org.mule.module.launcher.util
Adapted version of a groovy.util.ObservableList.
ObservableList() - Constructor for class org.mule.module.launcher.util.ObservableList
 
ObservableList(List<E>) - Constructor for class org.mule.module.launcher.util.ObservableList
 
ObservableList.ObservableListIterator - Class in org.mule.module.launcher.util
 
ObservableList.ObservableListIterator(ListIterator<E>, int) - Constructor for class org.mule.module.launcher.util.ObservableList.ObservableListIterator
 
of(Class<? extends Collection>, List<ValueResolver<T>>) - Static method in class org.mule.module.extension.internal.runtime.resolver.CollectionValueResolver
 
offer(Serializable, int, long) - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
 
offer(Serializable, int, long) - Method in class org.mule.util.queue.DefaultQueueStore
 
offer(QueueStore, Serializable, long) - Method in class org.mule.util.queue.LocalTxQueueTransactionContext
 
offer(Serializable, int, long) - Method in class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
Deprecated.
 
offer(Serializable, int, long) - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
offer(Serializable, int, long) - Method in interface org.mule.util.queue.objectstore.QueueInfoDelegate
Deprecated.
Offer to append a new member to the end of the queue
offer(QueueInfo, Serializable, long) - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
offer(QueueStore, Serializable, long) - Method in class org.mule.util.queue.PersistentQueueTransactionContext
 
offer(QueueStore, Serializable, long) - Method in class org.mule.util.queue.PersistentXaTransactionContext
 
offer(Serializable, long) - Method in interface org.mule.util.queue.Queue
 
offer(Serializable, int, long) - Method in interface org.mule.util.queue.QueueStore
 
offer(Serializable, int, long) - Method in interface org.mule.util.queue.QueueStoreDelegate
Offer to append a new member to the end of the queue
offer(QueueStore, Serializable, long) - Method in interface org.mule.util.queue.QueueTransactionContext
 
offer(QueueStore, Serializable, long) - Method in class org.mule.util.queue.QueueTypeTransactionContextAdapter
 
offer(Serializable, long) - Method in class org.mule.util.queue.TransactionAwareQueueStore
 
offer(QueueStore, Serializable, long) - Method in class org.mule.util.queue.TransientQueueTransactionContext
 
offer(QueueStore, Serializable, long) - Method in class org.mule.util.queue.TransientXaTransactionAdapter
 
offer(QueueStore, Serializable, long) - Method in class org.mule.util.queue.XaQueueTypeTransactionContextAdapter
 
Ognl - Annotation Type in org.mule.api.annotations.expression
TODO
OgnlAnnotationParser - Class in org.mule.module.ognl.config
TODO
OgnlAnnotationParser() - Constructor for class org.mule.module.ognl.config.OgnlAnnotationParser
 
OgnlExpressionEvaluator - Class in org.mule.module.ognl.expression
An expression evaluator that uses OGNL as the expression language
OgnlExpressionEvaluator() - Constructor for class org.mule.module.ognl.expression.OgnlExpressionEvaluator
 
OGNLFilter - Class in org.mule.module.ognl.filters
 
OGNLFilter() - Constructor for class org.mule.module.ognl.filters.OGNLFilter
 
OGNLNamespaceHandler - Class in org.mule.module.ognl.config
Registers Bean Definition Parsers for the "ognl" namespace.
OGNLNamespaceHandler() - Constructor for class org.mule.module.ognl.config.OGNLNamespaceHandler
 
OLD_DOMAIN_LIBRARY_FOLDER - Static variable in class org.mule.module.launcher.MuleSharedDomainClassLoader
 
OlderFirstComparator - Class in org.mule.transport.file.comparator
OlderComparatorComparator is a Comparator of File which is capable of comparing files for equality based on their modification dates.
OlderFirstComparator() - Constructor for class org.mule.transport.file.comparator.OlderFirstComparator
 
OldHttpMessageReceiver - Class in org.mule.transport.http
HttpMessageReceiver is a simple http server that can be used to listen for HTTP requests on a particular port.
OldHttpMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.http.OldHttpMessageReceiver
 
OldHttpMessageReceiver.HttpWorker - Class in org.mule.transport.http
 
OldHttpMessageReceiver.HttpWorker(Socket) - Constructor for class org.mule.transport.http.OldHttpMessageReceiver.HttpWorker
 
OldHttpsMessageReceiver - Class in org.mule.transport.http
 
OldHttpsMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.http.OldHttpsMessageReceiver
 
OLDVALUE - Static variable in class org.mule.module.launcher.util.ElementEvent
 
ON_COMPLETE_REDIRECT_TO_PARAM_NAME - Static variable in class org.mule.module.oauth2.internal.StateEncoder
 
ON_COMPLETE_REDIRECT_TO_PARAM_NAME_ASSIGN - Static variable in class org.mule.module.oauth2.internal.StateEncoder
 
onAdded(FilterChain) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
 
onAfterStartup() - Method in interface org.mule.module.launcher.StartupListener
Invoked after all apps have passed the deployment phase.
onAfterStartup() - Method in class org.mule.module.launcher.StartupSummaryDeploymentListener
 
onApplicationEvent(ApplicationEvent) - Method in class org.mule.module.spring.events.AsynchronousEventListener
Deprecated.
 
onBoolean() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
onBoolean() - Method in class org.mule.module.extension.internal.introspection.SimpleTypeDataQualifierVisitor
 
onCall(MuleEventContext) - Method in interface org.mule.api.lifecycle.Callable
Passes the event to the listener
onCall(MuleEventContext) - Method in class org.mule.component.simple.EchoComponent
 
onCall(MuleEventContext) - Method in class org.mule.component.simple.LogComponent
 
onCall(MuleEventContext) - Method in class org.mule.component.simple.NullComponent
 
onCall(MuleEventContext) - Method in class org.mule.component.simple.StaticComponent
 
onCall(MuleEventContext) - Method in class org.mule.module.atom.AbderaServiceComponent.AbderaCallable
 
onCall(MuleEventContext) - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
onCall(MuleEventContext) - Method in class org.mule.module.cxf.WSProxyService
Deprecated.
 
onCall(MuleEventContext) - Method in class org.mule.module.scripting.component.GroovyRefreshableBeanBuilder
 
onCall(MuleEventContext) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
This is the callback method used by Mule to give Mule events to this Multicaster
onCall(MuleEventContext) - Method in class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
onCall(MuleEventContext) - Method in class org.mule.tck.functional.FunctionalStreamingTestComponent
 
onCall(MuleEventContext) - Method in class org.mule.tck.functional.FunctionalTestComponent
Passes the event to the listener
onCall(MuleEventContext) - Method in class org.mule.tck.functional.TransactionalFunctionalTestComponent
Passes the event to the listener
onCall(MuleEventContext) - Method in class org.mule.tck.property.SessionPropertiesValidatorComponent
 
onCall(MuleEventContext) - Method in class org.mule.tck.security.TestSecurityComponent
 
onCall(MuleEventContext) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
Passes the context to the listener
onCall(MuleMessage) - Method in class org.mule.transport.vm.VMMessageReceiver
 
onChange(File) - Method in class org.mule.module.launcher.AbstractFileWatcher
 
onClose() - Method in interface org.mule.model.streaming.CallbackOutputStream.Callback
 
onClose(Message) - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
onCompletion(R) - Method in interface org.mule.api.CompletionHandler
Invoked on sucessful completion of asynchronous processing
onConfiguration(MuleContext) - Method in interface org.mule.api.context.notification.MuleContextListener
Notifies the configuration of a MuleContext instance, after this notification, the context is ready to be used.
onConfiguration(MuleContext) - Method in class org.mule.module.launcher.artifact.MuleContextDeploymentListener
 
onCreation(MuleContext) - Method in interface org.mule.api.context.notification.MuleContextListener
Notifies the creation of a MuleContext instance right before the initialization.
onCreation(MuleContext) - Method in class org.mule.module.launcher.artifact.MuleContextDeploymentListener
 
onDataReceivedEvent(Connection, Buffer) - Method in class org.mule.module.http.internal.HttpMessageLogger
 
onDataSentEvent(Connection, Buffer) - Method in class org.mule.module.http.internal.HttpMessageLogger
 
onDateTime() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
onDecimal() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
onDecimal() - Method in class org.mule.module.extension.internal.introspection.SimpleTypeDataQualifierVisitor
 
onDeploymentFailure(String, Throwable) - Method in class org.mule.module.launcher.AbstractDeploymentListener
 
onDeploymentFailure(String, Throwable) - Method in class org.mule.module.launcher.application.NullDeploymentListener
 
onDeploymentFailure(String, Throwable) - Method in class org.mule.module.launcher.ArtifactDeploymentStatusTracker
 
onDeploymentFailure(String, Throwable) - Method in class org.mule.module.launcher.CompositeDeploymentListener
 
onDeploymentFailure(String, Throwable) - Method in interface org.mule.module.launcher.DeploymentListener
Notifies that a deploy for a given application has finished with a failure.
onDeploymentFailure(String, Throwable) - Method in class org.mule.test.infrastructure.process.ApplicationStartedDeploymentListener
 
onDeploymentStart(String) - Method in class org.mule.module.launcher.AbstractDeploymentListener
 
onDeploymentStart(String) - Method in class org.mule.module.launcher.application.NullDeploymentListener
 
onDeploymentStart(String) - Method in class org.mule.module.launcher.ArtifactDeploymentStatusTracker
 
onDeploymentStart(String) - Method in class org.mule.module.launcher.CompositeDeploymentListener
 
onDeploymentStart(String) - Method in interface org.mule.module.launcher.DeploymentListener
Notifies that a deploy for a given application has started.
onDeploymentStart(String) - Method in class org.mule.test.infrastructure.process.ApplicationStartedDeploymentListener
 
onDeploymentSuccess(String) - Method in class org.mule.module.launcher.AbstractDeploymentListener
 
onDeploymentSuccess(String) - Method in class org.mule.module.launcher.application.NullDeploymentListener
 
onDeploymentSuccess(String) - Method in class org.mule.module.launcher.ArtifactDeploymentStatusTracker
 
onDeploymentSuccess(String) - Method in class org.mule.module.launcher.CompositeDeploymentListener
 
onDeploymentSuccess(String) - Method in interface org.mule.module.launcher.DeploymentListener
Notifies that a deploy for a given application has successfully finished.
onDeploymentSuccess(String) - Method in class org.mule.test.infrastructure.process.ApplicationStartedDeploymentListener
 
onDouble() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
onDouble() - Method in class org.mule.module.extension.internal.introspection.SimpleTypeDataQualifierVisitor
 
onEnum() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
onEnum() - Method in class org.mule.module.extension.internal.introspection.SimpleTypeDataQualifierVisitor
 
OneTimeWarning - Class in org.mule.util
Utility class to log a warning message only once during the lifecycle of a component.
OneTimeWarning(Logger, String) - Constructor for class org.mule.util.OneTimeWarning
 
OneWayHttpRequesterAdapter - Class in org.mule.module.http.internal.request.client
Adapts an HTTP operation to be one-way.
OneWayHttpRequesterAdapter(MessageProcessor) - Constructor for class org.mule.module.http.internal.request.client.OneWayHttpRequesterAdapter
 
onException(JMSException) - Method in class org.mule.transport.jms.JmsConnector
 
onException(JMSException) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
onException(Object, Method, Object[], Throwable) - Method in interface org.mule.util.Multicaster.InvokeListener
 
onExecutionBegun(MuleEvent) - Method in interface org.mule.api.debug.DebuggerCallback
Notifies when the execution of the event has begun.
onExecutionEnded(MuleEvent) - Method in interface org.mule.api.debug.DebuggerCallback
Notifies when the execution of the event has ended.
onExecutionPaused(MuleEvent, List<DebuggerFrame>, String) - Method in interface org.mule.api.debug.DebuggerCallback
Notifies when the execution is paused for debugging the current execution state.
onFailure(E) - Method in interface org.mule.api.CompletionHandler
Invoked when a failure occurs during asynchronous processing
onFailure(RetryContext, Throwable) - Method in interface org.mule.api.retry.RetryNotifier
Called each time a retry attempt fails.
onFailure(RetryContext, Throwable) - Method in class org.mule.retry.notifiers.ConnectNotifier
 
onFilterChainChanged(FilterChain) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
 
onFlowComplete(MuleEvent) - Method in interface org.mule.api.context.notification.FlowTraceManager
Handles the completion of the current flow for the given event.
onFlowComplete(MuleEvent) - Method in class org.mule.context.notification.MessageProcessingFlowTraceManager
 
onFlowStart(MuleEvent, String) - Method in interface org.mule.api.context.notification.FlowTraceManager
Handles the start of the passed flowName for the given event.
onFlowStart(MuleEvent, String) - Method in class org.mule.context.notification.MessageProcessingFlowTraceManager
 
onInitialization(MuleContext) - Method in interface org.mule.api.context.notification.MuleContextListener
Notifies the initialization of a MuleContext instance right before the configuration.
onInitialization(MuleContext) - Method in class org.mule.module.launcher.artifact.MuleContextDeploymentListener
 
onInteger() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
onInteger() - Method in class org.mule.module.extension.internal.introspection.SimpleTypeDataQualifierVisitor
 
onJettyConnectorStarted(JettyHttpConnector) - Method in class org.mule.transport.servlet.jetty.JettyWebappServerAgent
A callback for the connector, as it has a 'lazy-start' policy.
onList() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
onLong() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
onLong() - Method in class org.mule.module.extension.internal.introspection.SimpleTypeDataQualifierVisitor
 
ONLY_IF_CACHED - Static variable in class org.mule.module.http.api.HttpHeaders.Values
onlyServiceOrClientClassIsValid() - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
onMap() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
onMatch(XPathEvent) - Method in class org.mule.module.sxc.FilterEventHandler
 
onMessage(MuleMessage, Transaction, boolean, OutputStream) - Method in interface org.mule.api.transport.InternalMessageListener
 
onMessage(Message) - Method in class org.mule.module.cxf.transport.MuleUniversalConduit.InterposedMessageObserver
Called for an incoming message.
onMessage(Message) - Method in class org.mule.transport.jms.JmsMessageDispatcher.LatchReplyToListener
 
onMessage(Message) - Method in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
onMessage(Message) - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.SubReceiver
 
onMessage(Message) - Method in class org.mule.transport.jms.SingleJmsMessageReceiver
 
onMessage(Message) - Method in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
onMessage(MuleMessage) - Method in class org.mule.transport.vm.VMMessageReceiver
 
onMessageProcessorNotificationPreInvoke(MessageProcessorNotification) - Method in class org.mule.context.notification.MessageProcessingFlowTraceManager
Callback method for when a message processor is about to be invoked.
onMuleContextConfigured(String, MuleContext) - Method in class org.mule.module.launcher.AbstractDeploymentListener
 
onMuleContextConfigured(String, MuleContext) - Method in class org.mule.module.launcher.application.NullDeploymentListener
 
onMuleContextConfigured(String, MuleContext) - Method in class org.mule.module.launcher.CompositeDeploymentListener
 
onMuleContextConfigured(String, MuleContext) - Method in interface org.mule.module.launcher.DeploymentListener
Notifies the configuration of the MuleContext for a given app.
onMuleContextConfigured(String, MuleContext) - Method in class org.mule.test.infrastructure.process.ApplicationStartedDeploymentListener
 
onMuleContextCreated(String, MuleContext) - Method in class org.mule.module.launcher.AbstractDeploymentListener
 
onMuleContextCreated(String, MuleContext) - Method in class org.mule.module.launcher.application.NullDeploymentListener
 
onMuleContextCreated(String, MuleContext) - Method in class org.mule.module.launcher.CompositeDeploymentListener
 
onMuleContextCreated(String, MuleContext) - Method in interface org.mule.module.launcher.DeploymentListener
Notifies the creation of the MuleContext for a given app.
onMuleContextCreated(String, MuleContext) - Method in class org.mule.test.infrastructure.process.ApplicationStartedDeploymentListener
 
onMuleContextInitialised(String, MuleContext) - Method in class org.mule.module.launcher.AbstractDeploymentListener
 
onMuleContextInitialised(String, MuleContext) - Method in class org.mule.module.launcher.application.NullDeploymentListener
 
onMuleContextInitialised(String, MuleContext) - Method in class org.mule.module.launcher.CompositeDeploymentListener
 
onMuleContextInitialised(String, MuleContext) - Method in interface org.mule.module.launcher.DeploymentListener
Notifies the initialization of the MuleContext for a given app.
onMuleContextInitialised(String, MuleContext) - Method in class org.mule.test.infrastructure.process.ApplicationStartedDeploymentListener
 
onNotification(T) - Method in interface org.mule.api.context.notification.ServerNotificationListener
 
onNotification(PipelineMessageNotification) - Method in class org.mule.context.notification.FlowNotificationTextDebugger
 
onNotification(MessageProcessorNotification) - Method in class org.mule.context.notification.MessageProcessorTextDebugger
 
onNotification(ServerNotification) - Method in class org.mule.lifecycle.PrimaryNodeLifecycleNotificationListener
 
onNotification(MuleContextNotification) - Method in class org.mule.module.management.agent.AbstractJmxAgent.MuleContextStartedListener
 
onNotification(MuleContextNotification) - Method in class org.mule.module.management.agent.AbstractJmxAgent.MuleContextStoppedListener
 
onNotification(MuleContextNotification) - Method in class org.mule.transport.soap.axis.AxisConnector
 
OnNoTokenPolicy - Enum in org.mule.security.oauth
This enum specifies the behavior to take when an OAuth protected operation is executed before the authorization is performed
OnNoTokenPolicyAware - Interface in org.mule.security.oauth
 
onOperation() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
onPhaseCompleted(LifecyclePhase) - Method in interface org.mule.api.lifecycle.LifecycleInterceptor
Invoked when the given phase finished processing all the eligible target objects, including those for which LifecycleInterceptor.beforePhaseExecution(LifecyclePhase, Object) return false
onPhaseCompleted(LifecyclePhase) - Method in class org.mule.lifecycle.NullLifecycleInterceptor
NoOp implementation
onPhaseCompleted(LifecyclePhase) - Method in class org.mule.lifecycle.PhaseErrorLifecycleInterceptor
If the phase name is trackingPhase then it marks the trackingPhase phase as completed and clears all other tracking state so that memory can be reclaimed.
onPipelineNotificationComplete(PipelineMessageNotification) - Method in class org.mule.context.notification.MessageProcessingFlowTraceManager
Callback method for when a flow or sub-flow called from a flow-ref component has been completed.
onPipelineNotificationStart(PipelineMessageNotification) - Method in class org.mule.context.notification.MessageProcessingFlowTraceManager
Callback method for when a flow or sub-flow is about to be called from a flow-ref.
onPojo() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
onReceive(Object) - Method in class org.mule.tck.functional.FunctionalTestComponent
This method is used by some WebServices tests where you don' want to be introducing the MuleEventContext as a complex type.
onReceive(Object) - Method in interface org.mule.tck.functional.Receiveable
This method is used by some WebServices tests where you don' want to be introducing the MuleEventContext as a complex type.
onRemoved(FilterChain) - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyAddressDelegateFilter
 
onRenameEnd(FtpSession, FtpRequest) - Method in class org.mule.tck.util.ftp.MuleFtplet
 
onSimpleType() - Method in class org.mule.module.extension.internal.introspection.SimpleTypeDataQualifierVisitor
 
onString() - Method in class org.mule.module.extension.internal.introspection.AbstractDataQualifierVisitor
 
onString() - Method in class org.mule.module.extension.internal.introspection.SimpleTypeDataQualifierVisitor
 
onSuccess(RetryContext) - Method in interface org.mule.api.retry.RetryNotifier
Called when a retry attempt finally suceeds.
onSuccess(RetryContext) - Method in class org.mule.retry.notifiers.ConnectNotifier
 
onTransition(String, O) - Method in interface org.mule.api.lifecycle.LifecycleCallback
 
onTransition(String, O) - Method in class org.mule.lifecycle.EmptyLifecycleCallback
 
onTransition(String, T) - Method in class org.mule.lifecycle.RegistryLifecycleCallback
 
onTransition(String, String) - Method in interface org.mule.tck.functional.FunctionalTestComponent.LifecycleCallback
 
onUnacceptedFlowConstruct - Variable in class org.mule.processor.AbstractFilteringMessageProcessor
 
onUndeploymentFailure(String, Throwable) - Method in class org.mule.module.launcher.AbstractDeploymentListener
 
onUndeploymentFailure(String, Throwable) - Method in class org.mule.module.launcher.application.NullDeploymentListener
 
onUndeploymentFailure(String, Throwable) - Method in class org.mule.module.launcher.CompositeDeploymentListener
 
onUndeploymentFailure(String, Throwable) - Method in interface org.mule.module.launcher.DeploymentListener
Notifies that an un-deployment for a given application has finished with a failure.
onUndeploymentFailure(String, Throwable) - Method in class org.mule.test.infrastructure.process.ApplicationStartedDeploymentListener
 
onUndeploymentStart(String) - Method in class org.mule.module.launcher.AbstractDeploymentListener
 
onUndeploymentStart(String) - Method in class org.mule.module.launcher.application.NullDeploymentListener
 
onUndeploymentStart(String) - Method in class org.mule.module.launcher.CompositeDeploymentListener
 
onUndeploymentStart(String) - Method in interface org.mule.module.launcher.DeploymentListener
Notifies that an un-deployment for a given application has started.
onUndeploymentStart(String) - Method in class org.mule.test.infrastructure.process.ApplicationStartedDeploymentListener
 
onUndeploymentSuccess(String) - Method in class org.mule.module.launcher.AbstractDeploymentListener
 
onUndeploymentSuccess(String) - Method in class org.mule.module.launcher.application.NullDeploymentListener
 
onUndeploymentSuccess(String) - Method in class org.mule.module.launcher.CompositeDeploymentListener
 
onUndeploymentSuccess(String) - Method in interface org.mule.module.launcher.DeploymentListener
Notifies that an un-deployment for a given application has successfully finished.
onUndeploymentSuccess(String) - Method in class org.mule.test.infrastructure.process.ApplicationStartedDeploymentListener
 
onUploadEnd(FtpSession, FtpRequest) - Method in class org.mule.tck.util.ftp.MuleFtplet
 
open() - Method in class org.apache.commons.httpclient.HttpConnection
Establishes a connection to the specified host and port (via a proxy if specified).
open() - Method in interface org.mule.api.store.ListableObjectStore
Open the underlying store.
open(String) - Method in interface org.mule.api.store.PartitionableObjectStore
 
open() - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
open() - Method in class org.mule.util.store.AbstractPartitionedObjectStore
 
open() - Method in class org.mule.util.store.ManagedObjectStore
 
open() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
open() - Method in class org.mule.util.store.ObjectStorePartition
 
open(String) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
open() - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
 
open() - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
open(String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
open() - Method in class org.mule.util.store.PersistentObjectStorePartition
 
open() - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
open(String) - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
open() - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
open() - Method in class org.mule.util.store.QueueStoreAdapter
Deprecated.
 
open() - Method in class org.mule.util.store.SimpleMemoryObjectStore
 
OPEN_FILE_OPTIONS - Static variable in class org.mule.util.queue.QueueFileProvider
 
openConnection(URL) - Method in class org.mule.transport.soap.axis.transport.jms.Handler
 
openConnection(URL) - Method in class org.mule.transport.soap.axis.transport.pop3.Handler
 
openConnection(URL) - Method in class org.mule.transport.soap.axis.transport.smtp.Handler
 
openConnection(URL) - Method in class org.mule.transport.soap.axis.transport.vm.Handler
 
openDirectory(String) - Static method in class org.mule.util.FileUtils
 
operation - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
OPERATION - Static variable in class org.mule.module.cxf.CxfConstants
 
OPERATION_MODE_RECOVERING - Static variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
OPERATION_MODE_RECOVERING - Static variable in class org.mule.util.xa.AbstractResourceManager
 
OPERATION_MODE_STARTED - Static variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
OPERATION_MODE_STARTED - Static variable in class org.mule.util.xa.AbstractResourceManager
 
OPERATION_MODE_STARTING - Static variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
OPERATION_MODE_STARTING - Static variable in class org.mule.util.xa.AbstractResourceManager
 
OPERATION_MODE_STOPPED - Static variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
OPERATION_MODE_STOPPED - Static variable in class org.mule.util.xa.AbstractResourceManager
 
OPERATION_MODE_STOPPING - Static variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
OPERATION_MODE_STOPPING - Static variable in class org.mule.util.xa.AbstractResourceManager
 
OperationContextAdapter - Interface in org.mule.module.extension.internal.runtime
Adapter interface which expands the contract of OperationContext which functionality that is internal to this implementation of the extensions API and shouldn't be accessible for the extensions themselves
OperationMessageProcessor - Class in org.mule.module.extension.internal.runtime.processor
A MessageProcessor capable of executing extension operations.
OperationMessageProcessor(Extension, Operation, String, ResolverSet, ExtensionManagerAdapter) - Constructor for class org.mule.module.extension.internal.runtime.processor.OperationMessageProcessor
 
operationMode - Variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
operationMode - Variable in class org.mule.util.xa.AbstractResourceManager
 
OperationOptions - Interface in org.mule.api.client
Base options for every operation executed by MuleClient Implementations of this class must redefine Object.hashCode() and Object.equals(Object) since the may be used as key in a map
OperationOptionsConfig<BuilderType> - Interface in org.mule.api.client
Common configuration options for all operations
Operator - Class in org.mule.util.counters.impl
 
Operator(String, AbstractCounter, AbstractCounter, CounterFactory.Type) - Constructor for class org.mule.util.counters.impl.Operator
 
OPT_DIR - Static variable in class org.mule.module.boot.DefaultMuleClassPathConfig
 
OPT_DIR - Static variable in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
OptimisedNotificationHandler - Class in org.mule.context.notification
Optimized to make a quick decision on a particular class of messages.
OptimisedNotificationHandler(ServerNotificationHandler, Class<? extends ServerNotification>) - Constructor for class org.mule.context.notification.OptimisedNotificationHandler
 
OptimizedRequestContext - Class in org.mule
Deprecated.
If access to MuleEvent or MuleMessage is required, then implement a MessageProcessor or Callable instead
OPTIONAL_ARGUMENT - Static variable in class org.mule.expression.ExpressionConstants
 
OptionalChildDefinitionParser - Class in org.mule.config.spring.parsers.generic
This class should be used when the same element can be configured as a child or an orphan (i.e., top-level).
OptionalChildDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.generic.OptionalChildDefinitionParser
 
OptionalChildDefinitionParser(String, Class) - Constructor for class org.mule.config.spring.parsers.generic.OptionalChildDefinitionParser
 
OptionalChildDefinitionParser(String, Class, Class) - Constructor for class org.mule.config.spring.parsers.generic.OptionalChildDefinitionParser
 
OptionalChildDefinitionParser(String, Class, Class, boolean) - Constructor for class org.mule.config.spring.parsers.generic.OptionalChildDefinitionParser
 
OptionalObjectsController - Interface in org.mule.config.spring
Keeps track of keys that have been marked as optional on a registry-bootstrap file.
or(boolean) - Method in class org.mule.util.concurrent.WaitableBoolean
 
ORACLE_XMLTYPE_CLASS - Static variable in class org.mule.module.db.internal.domain.type.oracle.OracleXmlType
 
OracleConfigResolverFactoryBean - Class in org.mule.module.db.internal.config.domain.database
Creates DbConfigResolver for Oracle databases
OracleConfigResolverFactoryBean() - Constructor for class org.mule.module.db.internal.config.domain.database.OracleConfigResolverFactoryBean
 
OracleDataSourceFactoryBean - Class in org.mule.transport.jdbc.config
 
OracleDataSourceFactoryBean() - Constructor for class org.mule.transport.jdbc.config.OracleDataSourceFactoryBean
 
OracleDbConfigFactory - Class in org.mule.module.db.internal.domain.database
Creates DbConfig instances for Oracle databases
OracleDbConfigFactory() - Constructor for class org.mule.module.db.internal.domain.database.OracleDbConfigFactory
 
OracleDbConnection - Class in org.mule.module.db.internal.domain.connection
Custom DbConnection for Oracle databases
OracleDbConnection(Connection, TransactionalAction, DefaultDbConnectionReleaser, ParamTypeResolverFactory) - Constructor for class org.mule.module.db.internal.domain.connection.OracleDbConnection
OracleTransactionalDbConnectionFactory - Class in org.mule.module.db.internal.domain.connection
Custom TransactionalDbConnectionFactory for Oracle that creates OracleDbConnection instances.
OracleTransactionalDbConnectionFactory(DbTransactionManager, DbTypeManager, ConnectionFactory, DataSource) - Constructor for class org.mule.module.db.internal.domain.connection.OracleTransactionalDbConnectionFactory
OracleXmlType - Class in org.mule.module.db.internal.domain.type.oracle
Defines a structured data type for the OracleXmlType.ORACLE_XMLTYPE_CLASS class
OracleXmlType() - Constructor for class org.mule.module.db.internal.domain.type.oracle.OracleXmlType
 
OrderedProperties - Class in org.mule.util
 
OrderedProperties() - Constructor for class org.mule.util.OrderedProperties
 
OrderedProperties(Properties) - Constructor for class org.mule.util.OrderedProperties
 
OrFilter - Class in org.mule.routing.filters.logic
OrFilter accepts if any of the filters accept the message
OrFilter() - Constructor for class org.mule.routing.filters.logic.OrFilter
 
OrFilter(Filter...) - Constructor for class org.mule.routing.filters.logic.OrFilter
 
OrFilter(List<Filter>) - Constructor for class org.mule.routing.filters.logic.OrFilter
 
org.apache.commons.httpclient - package org.apache.commons.httpclient
 
org.apache.maven.enforcer.rule - package org.apache.maven.enforcer.rule
 
org.apache.maven.plugin.archetype - package org.apache.maven.plugin.archetype
 
org.glassfish.jersey.message.internal - package org.glassfish.jersey.message.internal
 
org.guiceyfruit.mule - package org.guiceyfruit.mule
 
org.guiceyfruit.mule.support - package org.guiceyfruit.mule.support
 
org.hibernate.connection - package org.hibernate.connection
 
org.mule - package org.mule
The Mule implementation of the Universal Message Objects(tm) API specification.
org.mule.agent - package org.mule.agent
Admin components and Agents used to control and Monitor Mule
org.mule.api - package org.mule.api
The Universal Message Object(tm) API provides a way for components to interact without needing to know about the protocol or delivery mechanisms of information passed between them
org.mule.api.agent - package org.mule.api.agent
 
org.mule.api.annotations - package org.mule.api.annotations
 
org.mule.api.annotations.expression - package org.mule.api.annotations.expression
 
org.mule.api.annotations.expressions - package org.mule.api.annotations.expressions
 
org.mule.api.annotations.meta - package org.mule.api.annotations.meta
 
org.mule.api.annotations.param - package org.mule.api.annotations.param
 
org.mule.api.cache - package org.mule.api.cache
 
org.mule.api.callback - package org.mule.api.callback
 
org.mule.api.client - package org.mule.api.client
 
org.mule.api.component - package org.mule.api.component
 
org.mule.api.component.simple - package org.mule.api.component.simple
 
org.mule.api.config - package org.mule.api.config
 
org.mule.api.connector - package org.mule.api.connector
 
org.mule.api.construct - package org.mule.api.construct
 
org.mule.api.context - package org.mule.api.context
Mule Context APIs, including the MuleContext, agent and server event interfaces
org.mule.api.context.notification - package org.mule.api.context.notification
 
org.mule.api.debug - package org.mule.api.debug
 
org.mule.api.devkit - package org.mule.api.devkit
 
org.mule.api.devkit.capability - package org.mule.api.devkit.capability
 
org.mule.api.el - package org.mule.api.el
 
org.mule.api.el.datetime - package org.mule.api.el.datetime
 
org.mule.api.endpoint - package org.mule.api.endpoint
Endpoint interfaces.
org.mule.api.exception - package org.mule.api.exception
 
org.mule.api.execution - package org.mule.api.execution
 
org.mule.api.expression - package org.mule.api.expression
 
org.mule.api.interceptor - package org.mule.api.interceptor
 
org.mule.api.lifecycle - package org.mule.api.lifecycle
Lifecycle interfaces for all Components.
org.mule.api.management.stats - package org.mule.api.management.stats
 
org.mule.api.model - package org.mule.api.model
Contains the interfaces for the Model and supporting objects such as the CompoenntResolver, EntryPointResolver, etc.
org.mule.api.object - package org.mule.api.object
 
org.mule.api.processor - package org.mule.api.processor
 
org.mule.api.processor.util - package org.mule.api.processor.util
 
org.mule.api.registry - package org.mule.api.registry
 
org.mule.api.retry - package org.mule.api.retry
 
org.mule.api.routing - package org.mule.api.routing
Interfaces that define inbound and outbound routing API.
org.mule.api.routing.filter - package org.mule.api.routing.filter
 
org.mule.api.schedule - package org.mule.api.schedule
 
org.mule.api.security - package org.mule.api.security
Security API for authentication and authorisation.
org.mule.api.security.tls - package org.mule.api.security.tls
This package contains classes to support TLS/SSL configuration and socket creation.
org.mule.api.serialization - package org.mule.api.serialization
 
org.mule.api.service - package org.mule.api.service
 
org.mule.api.source - package org.mule.api.source
 
org.mule.api.store - package org.mule.api.store
 
org.mule.api.transaction - package org.mule.api.transaction
 
org.mule.api.transformer - package org.mule.api.transformer
Contains the interfaces for transformers and exceptions for the Transformer API.
org.mule.api.transformer.wire - package org.mule.api.transformer.wire
 
org.mule.api.transport - package org.mule.api.transport
Contains the interfaces that comprise a provider implementation.
org.mule.api.util - package org.mule.api.util
 
org.mule.api.work - package org.mule.api.work
 
org.mule.client - package org.mule.client
 
org.mule.component - package org.mule.component
 
org.mule.component.simple - package org.mule.component.simple
A collection of simple mule components that can be useful to simplify configuration while testing.
org.mule.config - package org.mule.config
Providers Mule Xml configuration support and general configuration classes.
org.mule.config.bootstrap - package org.mule.config.bootstrap
 
org.mule.config.builders - package org.mule.config.builders
 
org.mule.config.builders.i18n - package org.mule.config.builders.i18n
 
org.mule.config.converters - package org.mule.config.converters
 
org.mule.config.dsl - package org.mule.config.dsl
 
org.mule.config.dsl.routers - package org.mule.config.dsl.routers
 
org.mule.config.endpoint - package org.mule.config.endpoint
 
org.mule.config.expression - package org.mule.config.expression
 
org.mule.config.factories - package org.mule.config.factories
 
org.mule.config.i18n - package org.mule.config.i18n
Internationalisation support for Mule messages and exception messages.
org.mule.config.parsers - package org.mule.config.parsers
 
org.mule.config.pool - package org.mule.config.pool
 
org.mule.config.processors - package org.mule.config.processors
 
org.mule.config.spring - package org.mule.config.spring
Support claases for Load Mule from Spring.
org.mule.config.spring.editors - package org.mule.config.spring.editors
 
org.mule.config.spring.factories - package org.mule.config.spring.factories
 
org.mule.config.spring.handlers - package org.mule.config.spring.handlers
 
org.mule.config.spring.jndi - package org.mule.config.spring.jndi
 
org.mule.config.spring.parsers - package org.mule.config.spring.parsers
Classes that help to construct a Mule model via Spring's XML specification.
org.mule.config.spring.parsers.assembly - package org.mule.config.spring.parsers.assembly
 
org.mule.config.spring.parsers.assembly.configuration - package org.mule.config.spring.parsers.assembly.configuration
 
org.mule.config.spring.parsers.collection - package org.mule.config.spring.parsers.collection
Support for building collections, or adding an element to a collection in a parent bean.
org.mule.config.spring.parsers.delegate - package org.mule.config.spring.parsers.delegate
 
org.mule.config.spring.parsers.generic - package org.mule.config.spring.parsers.generic
General support for bean construction.
org.mule.config.spring.parsers.processors - package org.mule.config.spring.parsers.processors
 
org.mule.config.spring.parsers.specific - package org.mule.config.spring.parsers.specific
Targetted support for specific components in the Mule system.
org.mule.config.spring.parsers.specific.endpoint - package org.mule.config.spring.parsers.specific.endpoint
 
org.mule.config.spring.parsers.specific.endpoint.support - package org.mule.config.spring.parsers.specific.endpoint.support
 
org.mule.config.spring.parsers.specific.properties - package org.mule.config.spring.parsers.specific.properties
 
org.mule.config.spring.parsers.specific.tls - package org.mule.config.spring.parsers.specific.tls
 
org.mule.config.spring.processors - package org.mule.config.spring.processors
 
org.mule.config.spring.util - package org.mule.config.spring.util
 
org.mule.config.support - package org.mule.config.support
 
org.mule.config.transformer - package org.mule.config.transformer
 
org.mule.connector - package org.mule.connector
 
org.mule.construct - package org.mule.construct
 
org.mule.construct.builder - package org.mule.construct.builder
 
org.mule.construct.flow - package org.mule.construct.flow
 
org.mule.construct.processor - package org.mule.construct.processor
 
org.mule.context - package org.mule.context
 
org.mule.context.notification - package org.mule.context.notification
Internal server notification types fired via the MuleManager.
org.mule.devkit.processor - package org.mule.devkit.processor
 
org.mule.el - package org.mule.el
 
org.mule.el.context - package org.mule.el.context
 
org.mule.el.datetime - package org.mule.el.datetime
 
org.mule.el.function - package org.mule.el.function
 
org.mule.el.mvel - package org.mule.el.mvel
 
org.mule.el.mvel.datatype - package org.mule.el.mvel.datatype
 
org.mule.endpoint - package org.mule.endpoint
Implemtation of Mule endpoint uris.
org.mule.endpoint.dynamic - package org.mule.endpoint.dynamic
 
org.mule.endpoint.inbound - package org.mule.endpoint.inbound
 
org.mule.endpoint.outbound - package org.mule.endpoint.outbound
 
org.mule.enricher - package org.mule.enricher
 
org.mule.exception - package org.mule.exception
 
org.mule.execution - package org.mule.execution
 
org.mule.expression - package org.mule.expression
 
org.mule.expression.transformers - package org.mule.expression.transformers
 
org.mule.impl.model.resolvers - package org.mule.impl.model.resolvers
 
org.mule.interceptor - package org.mule.interceptor
 
org.mule.jndi - package org.mule.jndi
 
org.mule.keygenerator - package org.mule.keygenerator
 
org.mule.lifecycle - package org.mule.lifecycle
 
org.mule.lifecycle.phases - package org.mule.lifecycle.phases
 
org.mule.lifecycle.processor - package org.mule.lifecycle.processor
 
org.mule.logging - package org.mule.logging
 
org.mule.management.stats - package org.mule.management.stats
Jmx statistics support used to monitor messaging status for various Mule components.
org.mule.management.stats.printers - package org.mule.management.stats.printers
Various statistics printers, for table, plain and CVS formats.
org.mule.message - package org.mule.message
Wire message implementations.
org.mule.message.ds - package org.mule.message.ds
 
org.mule.model - package org.mule.model
 
org.mule.model.resolvers - package org.mule.model.resolvers
 
org.mule.model.seda - package org.mule.model.seda
 
org.mule.model.streaming - package org.mule.model.streaming
 
org.mule.module.atom - package org.mule.module.atom
 
org.mule.module.atom.config - package org.mule.module.atom.config
 
org.mule.module.atom.routing - package org.mule.module.atom.routing
 
org.mule.module.atom.server - package org.mule.module.atom.server
 
org.mule.module.atom.transformers - package org.mule.module.atom.transformers
 
org.mule.module.boot - package org.mule.module.boot
 
org.mule.module.bpm - package org.mule.module.bpm
 
org.mule.module.bpm.config - package org.mule.module.bpm.config
 
org.mule.module.client - package org.mule.module.client
Simple interface for Mule clients to send and receive events from local or remote Mule Servers.
org.mule.module.client.config - package org.mule.module.client.config
 
org.mule.module.client.i18n - package org.mule.module.client.i18n
 
org.mule.module.client.remoting - package org.mule.module.client.remoting
 
org.mule.module.client.remoting.notification - package org.mule.module.client.remoting.notification
 
org.mule.module.cxf - package org.mule.module.cxf
 
org.mule.module.cxf.builder - package org.mule.module.cxf.builder
 
org.mule.module.cxf.component - package org.mule.module.cxf.component
 
org.mule.module.cxf.config - package org.mule.module.cxf.config
 
org.mule.module.cxf.endpoint - package org.mule.module.cxf.endpoint
 
org.mule.module.cxf.feature - package org.mule.module.cxf.feature
 
org.mule.module.cxf.i18n - package org.mule.module.cxf.i18n
 
org.mule.module.cxf.security - package org.mule.module.cxf.security
 
org.mule.module.cxf.support - package org.mule.module.cxf.support
 
org.mule.module.cxf.transport - package org.mule.module.cxf.transport
 
org.mule.module.db.config - package org.mule.module.db.config
 
org.mule.module.db.internal.config.domain.connection - package org.mule.module.db.internal.config.domain.connection
 
org.mule.module.db.internal.config.domain.database - package org.mule.module.db.internal.config.domain.database
 
org.mule.module.db.internal.config.domain.param - package org.mule.module.db.internal.config.domain.param
 
org.mule.module.db.internal.config.domain.query - package org.mule.module.db.internal.config.domain.query
 
org.mule.module.db.internal.config.processor - package org.mule.module.db.internal.config.processor
 
org.mule.module.db.internal.config.resolver.database - package org.mule.module.db.internal.config.resolver.database
 
org.mule.module.db.internal.config.resolver.query - package org.mule.module.db.internal.config.resolver.query
 
org.mule.module.db.internal.domain.autogeneratedkey - package org.mule.module.db.internal.domain.autogeneratedkey
 
org.mule.module.db.internal.domain.connection - package org.mule.module.db.internal.domain.connection
 
org.mule.module.db.internal.domain.database - package org.mule.module.db.internal.domain.database
 
org.mule.module.db.internal.domain.executor - package org.mule.module.db.internal.domain.executor
 
org.mule.module.db.internal.domain.logger - package org.mule.module.db.internal.domain.logger
 
org.mule.module.db.internal.domain.param - package org.mule.module.db.internal.domain.param
 
org.mule.module.db.internal.domain.query - package org.mule.module.db.internal.domain.query
 
org.mule.module.db.internal.domain.statement - package org.mule.module.db.internal.domain.statement
 
org.mule.module.db.internal.domain.transaction - package org.mule.module.db.internal.domain.transaction
 
org.mule.module.db.internal.domain.type - package org.mule.module.db.internal.domain.type
 
org.mule.module.db.internal.domain.type.oracle - package org.mule.module.db.internal.domain.type.oracle
 
org.mule.module.db.internal.domain.xa - package org.mule.module.db.internal.domain.xa
 
org.mule.module.db.internal.el - package org.mule.module.db.internal.el
 
org.mule.module.db.internal.i18n - package org.mule.module.db.internal.i18n
 
org.mule.module.db.internal.metadata - package org.mule.module.db.internal.metadata
 
org.mule.module.db.internal.parser - package org.mule.module.db.internal.parser
 
org.mule.module.db.internal.processor - package org.mule.module.db.internal.processor
 
org.mule.module.db.internal.resolver.database - package org.mule.module.db.internal.resolver.database
 
org.mule.module.db.internal.resolver.param - package org.mule.module.db.internal.resolver.param
 
org.mule.module.db.internal.resolver.query - package org.mule.module.db.internal.resolver.query
 
org.mule.module.db.internal.result.resultset - package org.mule.module.db.internal.result.resultset
 
org.mule.module.db.internal.result.row - package org.mule.module.db.internal.result.row
 
org.mule.module.db.internal.result.statement - package org.mule.module.db.internal.result.statement
 
org.mule.module.db.internal.util - package org.mule.module.db.internal.util
 
org.mule.module.drools - package org.mule.module.drools
 
org.mule.module.extension - package org.mule.module.extension
 
org.mule.module.extension.internal - package org.mule.module.extension.internal
 
org.mule.module.extension.internal.capability.metadata - package org.mule.module.extension.internal.capability.metadata
 
org.mule.module.extension.internal.introspection - package org.mule.module.extension.internal.introspection
 
org.mule.module.extension.internal.manager - package org.mule.module.extension.internal.manager
 
org.mule.module.extension.internal.resources - package org.mule.module.extension.internal.resources
 
org.mule.module.extension.internal.runtime - package org.mule.module.extension.internal.runtime
 
org.mule.module.extension.internal.runtime.processor - package org.mule.module.extension.internal.runtime.processor
 
org.mule.module.extension.internal.runtime.resolver - package org.mule.module.extension.internal.runtime.resolver
 
org.mule.module.extension.internal.util - package org.mule.module.extension.internal.util
 
org.mule.module.guice - package org.mule.module.guice
 
org.mule.module.guice.i18n - package org.mule.module.guice.i18n
 
org.mule.module.http.api - package org.mule.module.http.api
 
org.mule.module.http.api.client - package org.mule.module.http.api.client
 
org.mule.module.http.api.listener - package org.mule.module.http.api.listener
 
org.mule.module.http.api.requester - package org.mule.module.http.api.requester
 
org.mule.module.http.api.requester.authentication - package org.mule.module.http.api.requester.authentication
 
org.mule.module.http.api.requester.proxy - package org.mule.module.http.api.requester.proxy
 
org.mule.module.http.internal - package org.mule.module.http.internal
 
org.mule.module.http.internal.config - package org.mule.module.http.internal.config
 
org.mule.module.http.internal.domain - package org.mule.module.http.internal.domain
 
org.mule.module.http.internal.domain.request - package org.mule.module.http.internal.domain.request
 
org.mule.module.http.internal.domain.response - package org.mule.module.http.internal.domain.response
 
org.mule.module.http.internal.listener - package org.mule.module.http.internal.listener
 
org.mule.module.http.internal.listener.async - package org.mule.module.http.internal.listener.async
 
org.mule.module.http.internal.listener.grizzly - package org.mule.module.http.internal.listener.grizzly
 
org.mule.module.http.internal.listener.matcher - package org.mule.module.http.internal.listener.matcher
 
org.mule.module.http.internal.listener.properties - package org.mule.module.http.internal.listener.properties
 
org.mule.module.http.internal.multipart - package org.mule.module.http.internal.multipart
 
org.mule.module.http.internal.request - package org.mule.module.http.internal.request
 
org.mule.module.http.internal.request.client - package org.mule.module.http.internal.request.client
 
org.mule.module.http.internal.request.grizzly - package org.mule.module.http.internal.request.grizzly
 
org.mule.module.jaas - package org.mule.module.jaas
 
org.mule.module.jaas.config - package org.mule.module.jaas.config
 
org.mule.module.jaas.filters - package org.mule.module.jaas.filters
 
org.mule.module.jaas.loginmodule - package org.mule.module.jaas.loginmodule
 
org.mule.module.jboss.config - package org.mule.module.jboss.config
 
org.mule.module.jboss.transaction - package org.mule.module.jboss.transaction
Provides integration with JBoss TS (Arjuna).
org.mule.module.jbpm - package org.mule.module.jbpm
 
org.mule.module.jersey - package org.mule.module.jersey
 
org.mule.module.jersey.config - package org.mule.module.jersey.config
 
org.mule.module.jersey.exception - package org.mule.module.jersey.exception
 
org.mule.module.json - package org.mule.module.json
JSON encoding support for Mule.
org.mule.module.json.config - package org.mule.module.json.config
Classes used for processing the JSON XML configuration elements
org.mule.module.json.filters - package org.mule.module.json.filters
Filters for recognising JSON payloads in Mule.
org.mule.module.json.i18n - package org.mule.module.json.i18n
 
org.mule.module.json.transformers - package org.mule.module.json.transformers
Transfromers for converting from JavaBeans and collections to JSON and back again.
org.mule.module.json.validation - package org.mule.module.json.validation
 
org.mule.module.launcher - package org.mule.module.launcher
 
org.mule.module.launcher.application - package org.mule.module.launcher.application
 
org.mule.module.launcher.application.builder - package org.mule.module.launcher.application.builder
 
org.mule.module.launcher.artifact - package org.mule.module.launcher.artifact
 
org.mule.module.launcher.coreextension - package org.mule.module.launcher.coreextension
 
org.mule.module.launcher.descriptor - package org.mule.module.launcher.descriptor
 
org.mule.module.launcher.domain - package org.mule.module.launcher.domain
 
org.mule.module.launcher.log4j2 - package org.mule.module.launcher.log4j2
 
org.mule.module.launcher.nativelib - package org.mule.module.launcher.nativelib
 
org.mule.module.launcher.plugin - package org.mule.module.launcher.plugin
 
org.mule.module.launcher.util - package org.mule.module.launcher.util
 
org.mule.module.management - package org.mule.module.management
Mule system management extensions such as Jmx support.
org.mule.module.management.agent - package org.mule.module.management.agent
Management agents including agents for Jdmk, MX4J, and Log4J
org.mule.module.management.config - package org.mule.module.management.config
 
org.mule.module.management.i18n - package org.mule.module.management.i18n
 
org.mule.module.management.mbean - package org.mule.module.management.mbean
Jmx Management beans for mule components, the model and the Mule server.
org.mule.module.management.support - package org.mule.module.management.support
Support classes and interface for Mule management subsystem
org.mule.module.management.util - package org.mule.module.management.util
 
org.mule.module.oauth2.api - package org.mule.module.oauth2.api
 
org.mule.module.oauth2.internal - package org.mule.module.oauth2.internal
 
org.mule.module.oauth2.internal.authorizationcode - package org.mule.module.oauth2.internal.authorizationcode
 
org.mule.module.oauth2.internal.authorizationcode.state - package org.mule.module.oauth2.internal.authorizationcode.state
 
org.mule.module.oauth2.internal.clientcredentials - package org.mule.module.oauth2.internal.clientcredentials
 
org.mule.module.oauth2.internal.config - package org.mule.module.oauth2.internal.config
 
org.mule.module.oauth2.internal.mel - package org.mule.module.oauth2.internal.mel
 
org.mule.module.oauth2.internal.tokenmanager - package org.mule.module.oauth2.internal.tokenmanager
 
org.mule.module.ognl.config - package org.mule.module.ognl.config
 
org.mule.module.ognl.expression - package org.mule.module.ognl.expression
 
org.mule.module.ognl.filters - package org.mule.module.ognl.filters
 
org.mule.module.pgp - package org.mule.module.pgp
 
org.mule.module.pgp.config - package org.mule.module.pgp.config
 
org.mule.module.pgp.exception - package org.mule.module.pgp.exception
 
org.mule.module.pgp.filters - package org.mule.module.pgp.filters
 
org.mule.module.pgp.i18n - package org.mule.module.pgp.i18n
 
org.mule.module.pgp.util - package org.mule.module.pgp.util
 
org.mule.module.reboot - package org.mule.module.reboot
 
org.mule.module.rss.config - package org.mule.module.rss.config
 
org.mule.module.rss.routing - package org.mule.module.rss.routing
 
org.mule.module.rss.transformers - package org.mule.module.rss.transformers
 
org.mule.module.scripting - package org.mule.module.scripting
 
org.mule.module.scripting.builders - package org.mule.module.scripting.builders
 
org.mule.module.scripting.component - package org.mule.module.scripting.component
Base classes for script based components such as BeanShell or Groovy.
org.mule.module.scripting.config - package org.mule.module.scripting.config
 
org.mule.module.scripting.expression - package org.mule.module.scripting.expression
 
org.mule.module.scripting.filter - package org.mule.module.scripting.filter
 
org.mule.module.scripting.transformer - package org.mule.module.scripting.transformer
 
org.mule.module.spring.events - package org.mule.module.spring.events
A Spring EventMulticaster that allows any Spring bean to send and receive mule events through the ApplicationContext and event listeners.
org.mule.module.spring.i18n - package org.mule.module.spring.i18n
 
org.mule.module.spring.remoting - package org.mule.module.spring.remoting
 
org.mule.module.spring.security - package org.mule.module.spring.security
 
org.mule.module.spring.security.config - package org.mule.module.spring.security.config
 
org.mule.module.spring.security.editors - package org.mule.module.spring.security.editors
 
org.mule.module.spring.security.filters.http - package org.mule.module.spring.security.filters.http
 
org.mule.module.spring.security.i18n - package org.mule.module.spring.security.i18n
 
org.mule.module.spring.transaction - package org.mule.module.spring.transaction
 
org.mule.module.sxc - package org.mule.module.sxc
 
org.mule.module.tomcat - package org.mule.module.tomcat
 
org.mule.module.ws.config - package org.mule.module.ws.config
 
org.mule.module.ws.config.spring.factories - package org.mule.module.ws.config.spring.factories
 
org.mule.module.ws.config.spring.parsers.specific - package org.mule.module.ws.config.spring.parsers.specific
 
org.mule.module.ws.construct - package org.mule.module.ws.construct
 
org.mule.module.ws.construct.builder - package org.mule.module.ws.construct.builder
 
org.mule.module.ws.consumer - package org.mule.module.ws.consumer
 
org.mule.module.ws.consumer.wsdl.strategy.factory - package org.mule.module.ws.consumer.wsdl.strategy.factory
 
org.mule.module.ws.security - package org.mule.module.ws.security
 
org.mule.module.xml.config - package org.mule.module.xml.config
 
org.mule.module.xml.el - package org.mule.module.xml.el
 
org.mule.module.xml.expression - package org.mule.module.xml.expression
 
org.mule.module.xml.filters - package org.mule.module.xml.filters
Filters that apply specifically to xml using xml querying mechanisms.
org.mule.module.xml.i18n - package org.mule.module.xml.i18n
 
org.mule.module.xml.stax - package org.mule.module.xml.stax
 
org.mule.module.xml.transformer - package org.mule.module.xml.transformer
Xml and Xslt Transformer implementations.
org.mule.module.xml.transformer.jaxb - package org.mule.module.xml.transformer.jaxb
 
org.mule.module.xml.transformer.wire - package org.mule.module.xml.transformer.wire
 
org.mule.module.xml.util - package org.mule.module.xml.util
 
org.mule.module.xml.xpath - package org.mule.module.xml.xpath
 
org.mule.modules.schedulers.config - package org.mule.modules.schedulers.config
 
org.mule.modules.schedulers.cron - package org.mule.modules.schedulers.cron
 
org.mule.modules.schedulers.i18n - package org.mule.modules.schedulers.i18n
 
org.mule.object - package org.mule.object
 
org.mule.pattern.core.config - package org.mule.pattern.core.config
 
org.mule.processor - package org.mule.processor
 
org.mule.processor.chain - package org.mule.processor.chain
 
org.mule.processor.strategy - package org.mule.processor.strategy
 
org.mule.registry - package org.mule.registry
 
org.mule.retry - package org.mule.retry
 
org.mule.retry.async - package org.mule.retry.async
 
org.mule.retry.notifiers - package org.mule.retry.notifiers
 
org.mule.retry.policies - package org.mule.retry.policies
 
org.mule.routing - package org.mule.routing
Defines the core routing patterns supported by mule.
org.mule.routing.correlation - package org.mule.routing.correlation
 
org.mule.routing.filters - package org.mule.routing.filters
Filters are often used by routers to determine if the event should be accepted by the router.
org.mule.routing.filters.logic - package org.mule.routing.filters.logic
Filters that allow other filters to be combined.
org.mule.routing.outbound - package org.mule.routing.outbound
Outbound router implementation as described in the Enterprise Integration Patterns book.
org.mule.routing.requestreply - package org.mule.routing.requestreply
 
org.mule.security - package org.mule.security
Core security implementation including the mule security manager and encryption types
org.mule.security.filters - package org.mule.security.filters
Core sercurity filter types.
org.mule.security.oauth - package org.mule.security.oauth
 
org.mule.security.oauth.callback - package org.mule.security.oauth.callback
 
org.mule.security.oauth.config - package org.mule.security.oauth.config
 
org.mule.security.oauth.exception - package org.mule.security.oauth.exception
 
org.mule.security.oauth.notification - package org.mule.security.oauth.notification
 
org.mule.security.oauth.process - package org.mule.security.oauth.process
 
org.mule.security.oauth.processor - package org.mule.security.oauth.processor
 
org.mule.security.oauth.util - package org.mule.security.oauth.util
 
org.mule.serialization.internal - package org.mule.serialization.internal
 
org.mule.service - package org.mule.service
 
org.mule.service.processor - package org.mule.service.processor
 
org.mule.session - package org.mule.session
 
org.mule.source - package org.mule.source
 
org.mule.streaming - package org.mule.streaming
 
org.mule.streaming.processor - package org.mule.streaming.processor
 
org.mule.tck - package org.mule.tck
 
org.mule.tck.concurrency - package org.mule.tck.concurrency
 
org.mule.tck.config - package org.mule.tck.config
 
org.mule.tck.exceptions - package org.mule.tck.exceptions
 
org.mule.tck.functional - package org.mule.tck.functional
Helper classes and interfaces used by Mule fnctional tests.
org.mule.tck.jndi - package org.mule.tck.jndi
 
org.mule.tck.junit4 - package org.mule.tck.junit4
 
org.mule.tck.listener - package org.mule.tck.listener
 
org.mule.tck.logging - package org.mule.tck.logging
 
org.mule.tck.property - package org.mule.tck.property
 
org.mule.tck.security - package org.mule.tck.security
 
org.mule.tck.testmodels.fruit - package org.mule.tck.testmodels.fruit
 
org.mule.tck.testmodels.services - package org.mule.tck.testmodels.services
 
org.mule.tck.transformer - package org.mule.tck.transformer
 
org.mule.tck.util - package org.mule.tck.util
 
org.mule.tck.util.endpoint - package org.mule.tck.util.endpoint
 
org.mule.tck.util.ftp - package org.mule.tck.util.ftp
 
org.mule.tck.util.sftp - package org.mule.tck.util.sftp
 
org.mule.test.infrastructure - package org.mule.test.infrastructure
 
org.mule.test.infrastructure.deployment - package org.mule.test.infrastructure.deployment
 
org.mule.test.infrastructure.process - package org.mule.test.infrastructure.process
 
org.mule.test.infrastructure.process.matchers - package org.mule.test.infrastructure.process.matchers
 
org.mule.test.infrastructure.process.rules - package org.mule.test.infrastructure.process.rules
 
org.mule.tools.anttasks - package org.mule.tools.anttasks
 
org.mule.tools.maven.archetype - package org.mule.tools.maven.archetype
 
org.mule.transaction - package org.mule.transaction
Contains the core transaction support classes and exception types.
org.mule.transaction.constraints - package org.mule.transaction.constraints
Contains the transaction contraint filter used to control how and when transactions are committed.
org.mule.transaction.lookup - package org.mule.transaction.lookup
 
org.mule.transformer - package org.mule.transformer
Provides the default transformer base implementations for Mule including compression and encryption support.
org.mule.transformer.codec - package org.mule.transformer.codec
Transformers for Base64, UC and UU encoding/decoding.
org.mule.transformer.compression - package org.mule.transformer.compression
Transformers for compressing and uncompressing message payloads.
org.mule.transformer.encryption - package org.mule.transformer.encryption
Transformers for encrypting and decrypting message payloads.
org.mule.transformer.graph - package org.mule.transformer.graph
 
org.mule.transformer.simple - package org.mule.transformer.simple
Basic transformer implementations.
org.mule.transformer.types - package org.mule.transformer.types
 
org.mule.transformer.wire - package org.mule.transformer.wire
 
org.mule.transport - package org.mule.transport
Contains Abstract classes providing common functionality for all Mule providers.
org.mule.transport.ajax - package org.mule.transport.ajax
 
org.mule.transport.ajax.config - package org.mule.transport.ajax.config
 
org.mule.transport.ajax.container - package org.mule.transport.ajax.container
A AJAX transport allows Mule applications to send a receive events to the web browser.
org.mule.transport.ajax.embedded - package org.mule.transport.ajax.embedded
A AJAX transport allows Mule applications to send a receive events to the web browser.
org.mule.transport.ajax.i18n - package org.mule.transport.ajax.i18n
 
org.mule.transport.ejb - package org.mule.transport.ejb
 
org.mule.transport.ejb.config - package org.mule.transport.ejb.config
 
org.mule.transport.ejb.i18n - package org.mule.transport.ejb.i18n
 
org.mule.transport.email - package org.mule.transport.email
Provides pop3, smtp and imap connectivity for Mule.
org.mule.transport.email.config - package org.mule.transport.email.config
 
org.mule.transport.email.filters - package org.mule.transport.email.filters
 
org.mule.transport.email.i18n - package org.mule.transport.email.i18n
 
org.mule.transport.email.transformers - package org.mule.transport.email.transformers
Contains transformers to convert to and from the java.mail.Message type.
org.mule.transport.file - package org.mule.transport.file
Provides file transport in the form of a directory listeners and file dispatchers.
org.mule.transport.file.comparator - package org.mule.transport.file.comparator
 
org.mule.transport.file.config - package org.mule.transport.file.config
 
org.mule.transport.file.filters - package org.mule.transport.file.filters
Filename filters used to filter on a listening directory.
org.mule.transport.file.i18n - package org.mule.transport.file.i18n
 
org.mule.transport.file.transformers - package org.mule.transport.file.transformers
Transformers for converting to and from the FileMessage type.
org.mule.transport.ftp - package org.mule.transport.ftp
 
org.mule.transport.ftp.config - package org.mule.transport.ftp.config
 
org.mule.transport.http - package org.mule.transport.http
Provides http transport including proxy support.
org.mule.transport.http.builder - package org.mule.transport.http.builder
 
org.mule.transport.http.components - package org.mule.transport.http.components
 
org.mule.transport.http.config - package org.mule.transport.http.config
 
org.mule.transport.http.config.spring.factories - package org.mule.transport.http.config.spring.factories
 
org.mule.transport.http.config.spring.parsers.specific - package org.mule.transport.http.config.spring.parsers.specific
 
org.mule.transport.http.construct - package org.mule.transport.http.construct
 
org.mule.transport.http.construct.builder - package org.mule.transport.http.construct.builder
 
org.mule.transport.http.construct.support - package org.mule.transport.http.construct.support
 
org.mule.transport.http.filters - package org.mule.transport.http.filters
 
org.mule.transport.http.i18n - package org.mule.transport.http.i18n
 
org.mule.transport.http.multipart - package org.mule.transport.http.multipart
 
org.mule.transport.http.ntlm - package org.mule.transport.http.ntlm
 
org.mule.transport.http.servlet - package org.mule.transport.http.servlet
 
org.mule.transport.http.transformers - package org.mule.transport.http.transformers
 
org.mule.transport.jdbc - package org.mule.transport.jdbc
Provides jdbc transport.
org.mule.transport.jdbc.config - package org.mule.transport.jdbc.config
 
org.mule.transport.jdbc.i18n - package org.mule.transport.jdbc.i18n
 
org.mule.transport.jdbc.sqlstrategy - package org.mule.transport.jdbc.sqlstrategy
 
org.mule.transport.jdbc.store - package org.mule.transport.jdbc.store
 
org.mule.transport.jdbc.xa - package org.mule.transport.jdbc.xa
 
org.mule.transport.jms - package org.mule.transport.jms
Provides Jms transport connectivity with support for all Jms features.
org.mule.transport.jms.activemq - package org.mule.transport.jms.activemq
Provides Jms connectivity with ActiveMQ-specific workarounds and improvements.
org.mule.transport.jms.config - package org.mule.transport.jms.config
 
org.mule.transport.jms.filters - package org.mule.transport.jms.filters
 
org.mule.transport.jms.i18n - package org.mule.transport.jms.i18n
 
org.mule.transport.jms.jndi - package org.mule.transport.jms.jndi
 
org.mule.transport.jms.mulemq - package org.mule.transport.jms.mulemq
 
org.mule.transport.jms.reconnect - package org.mule.transport.jms.reconnect
 
org.mule.transport.jms.redelivery - package org.mule.transport.jms.redelivery
 
org.mule.transport.jms.transformers - package org.mule.transport.jms.transformers
Contains transformers to convert to and from different javax.jms.Message types
org.mule.transport.jms.weblogic - package org.mule.transport.jms.weblogic
Provides Jms connectivity with Weblogic-specific workarounds and improvements.
org.mule.transport.jms.websphere - package org.mule.transport.jms.websphere
Provides Jms connectivity with Websphere-specific workarounds and improvements.
org.mule.transport.jms.xa - package org.mule.transport.jms.xa
 
org.mule.transport.jnp - package org.mule.transport.jnp
 
org.mule.transport.jnp.config - package org.mule.transport.jnp.config
 
org.mule.transport.multicast - package org.mule.transport.multicast
IP multicast connectivity for Mule.
org.mule.transport.multicast.config - package org.mule.transport.multicast.config
 
org.mule.transport.nameable - package org.mule.transport.nameable
 
org.mule.transport.polling - package org.mule.transport.polling
 
org.mule.transport.polling.schedule - package org.mule.transport.polling.schedule
 
org.mule.transport.polling.watermark - package org.mule.transport.polling.watermark
 
org.mule.transport.polling.watermark.selector - package org.mule.transport.polling.watermark.selector
 
org.mule.transport.quartz - package org.mule.transport.quartz
 
org.mule.transport.quartz.config - package org.mule.transport.quartz.config
 
org.mule.transport.quartz.i18n - package org.mule.transport.quartz.i18n
 
org.mule.transport.quartz.jobs - package org.mule.transport.quartz.jobs
 
org.mule.transport.rmi - package org.mule.transport.rmi
 
org.mule.transport.rmi.config - package org.mule.transport.rmi.config
 
org.mule.transport.rmi.i18n - package org.mule.transport.rmi.i18n
 
org.mule.transport.service - package org.mule.transport.service
Provides SPI support for building mule connectors and providers using service descriptors.
org.mule.transport.servlet - package org.mule.transport.servlet
 
org.mule.transport.servlet.config - package org.mule.transport.servlet.config
 
org.mule.transport.servlet.events - package org.mule.transport.servlet.events
 
org.mule.transport.servlet.i18n - package org.mule.transport.servlet.i18n
 
org.mule.transport.servlet.jetty - package org.mule.transport.servlet.jetty
 
org.mule.transport.servlet.jetty.config - package org.mule.transport.servlet.jetty.config
 
org.mule.transport.servlet.jetty.util - package org.mule.transport.servlet.jetty.util
 
org.mule.transport.servlet.transformers - package org.mule.transport.servlet.transformers
 
org.mule.transport.sftp - package org.mule.transport.sftp
 
org.mule.transport.sftp.config - package org.mule.transport.sftp.config
 
org.mule.transport.sftp.i18n - package org.mule.transport.sftp.i18n
 
org.mule.transport.sftp.notification - package org.mule.transport.sftp.notification
 
org.mule.transport.sftp.transformers - package org.mule.transport.sftp.transformers
 
org.mule.transport.soap.axis - package org.mule.transport.soap.axis
Provides an Axis soap transport for Mule.
org.mule.transport.soap.axis.component - package org.mule.transport.soap.axis.component
 
org.mule.transport.soap.axis.config - package org.mule.transport.soap.axis.config
 
org.mule.transport.soap.axis.extensions - package org.mule.transport.soap.axis.extensions
Axis specific extensions and component implementation that enables Mule components to act as Axis soap services.
org.mule.transport.soap.axis.extras - package org.mule.transport.soap.axis.extras
 
org.mule.transport.soap.axis.i18n - package org.mule.transport.soap.axis.i18n
 
org.mule.transport.soap.axis.transport - package org.mule.transport.soap.axis.transport
 
org.mule.transport.soap.axis.transport.jms - package org.mule.transport.soap.axis.transport.jms
 
org.mule.transport.soap.axis.transport.pop3 - package org.mule.transport.soap.axis.transport.pop3
 
org.mule.transport.soap.axis.transport.smtp - package org.mule.transport.soap.axis.transport.smtp
 
org.mule.transport.soap.axis.transport.vm - package org.mule.transport.soap.axis.transport.vm
 
org.mule.transport.soap.axis.wsdl - package org.mule.transport.soap.axis.wsdl
 
org.mule.transport.stdio - package org.mule.transport.stdio
 
org.mule.transport.stdio.config - package org.mule.transport.stdio.config
 
org.mule.transport.stdio.i18n - package org.mule.transport.stdio.i18n
 
org.mule.transport.tcp - package org.mule.transport.tcp
Provides tcp connectivity for Mule.
org.mule.transport.tcp.config - package org.mule.transport.tcp.config
Configuration classes for processing Xml config elements within the TCP namespace.
org.mule.transport.tcp.i18n - package org.mule.transport.tcp.i18n
 
org.mule.transport.tcp.protocols - package org.mule.transport.tcp.protocols
 
org.mule.transport.udp - package org.mule.transport.udp
Provides Udp connectivity for Mule.
org.mule.transport.udp.config - package org.mule.transport.udp.config
 
org.mule.transport.udp.i18n - package org.mule.transport.udp.i18n
 
org.mule.transport.vm - package org.mule.transport.vm
A connector implementation allowing events to be passed between Mule sessions via in-memory queues.
org.mule.transport.vm.config - package org.mule.transport.vm.config
 
org.mule.transport.vm.i18n - package org.mule.transport.vm.i18n
 
org.mule.transport.xmpp - package org.mule.transport.xmpp
 
org.mule.transport.xmpp.config - package org.mule.transport.xmpp.config
 
org.mule.transport.xmpp.filters - package org.mule.transport.xmpp.filters
 
org.mule.transport.xmpp.i18n - package org.mule.transport.xmpp.i18n
 
org.mule.transport.xmpp.transformers - package org.mule.transport.xmpp.transformers
 
org.mule.util - package org.mule.util
Common helper classes for reading/writing files setting bean properties and SPI helpers.
org.mule.util.annotation - package org.mule.util.annotation
 
org.mule.util.collection - package org.mule.util.collection
 
org.mule.util.compression - package org.mule.util.compression
Compression support used by Mule transformers.
org.mule.util.concurrent - package org.mule.util.concurrent
 
org.mule.util.counters - package org.mule.util.counters
 
org.mule.util.counters.impl - package org.mule.util.counters.impl
 
org.mule.util.file - package org.mule.util.file
A file resource manager to allow acid operations on file systems.
org.mule.util.generics - package org.mule.util.generics
 
org.mule.util.journal - package org.mule.util.journal
 
org.mule.util.journal.queue - package org.mule.util.journal.queue
 
org.mule.util.lock - package org.mule.util.lock
 
org.mule.util.monitor - package org.mule.util.monitor
Various resource monitor implementations.
org.mule.util.pool - package org.mule.util.pool
 
org.mule.util.proxy - package org.mule.util.proxy
 
org.mule.util.queue - package org.mule.util.queue
A resource manager that allow access to transactional queues with optional persistence.
org.mule.util.queue.objectstore - package org.mule.util.queue.objectstore
A resource manager that allow access to transactional queues with optional persistence.
org.mule.util.queue.objectstore.xa - package org.mule.util.queue.objectstore.xa
An abstract resource manager that supports local and xa transactions.
org.mule.util.scan - package org.mule.util.scan
 
org.mule.util.scan.annotations - package org.mule.util.scan.annotations
 
org.mule.util.store - package org.mule.util.store
 
org.mule.util.timer - package org.mule.util.timer
An Event based timer extending the java.util.Timer* classes.
org.mule.util.xa - package org.mule.util.xa
An abstract resource manager that supports local and xa transactions.
org.mule.util.xmlsecurity - package org.mule.util.xmlsecurity
 
org.mule.utils - package org.mule.utils
 
org.mule.work - package org.mule.work
A javax.resource.spi.WorkManager implementation.
org.springframework.asm - package org.springframework.asm
 
org.springframework.beans.factory.support - package org.springframework.beans.factory.support
 
ORIGIN - Static variable in class org.mule.module.http.api.HttpHeaders.Names
OrphanAddressDefinitionParser - Class in org.mule.config.spring.parsers.specific.endpoint.support
Generate an Endpoint URI from simple address components.
OrphanAddressDefinitionParser(String, boolean) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.support.OrphanAddressDefinitionParser
 
OrphanDefinitionParser - Class in org.mule.config.spring.parsers.generic
Contructs a single, standalone bean from an element - it is not injected into any other object.
OrphanDefinitionParser(boolean) - Constructor for class org.mule.config.spring.parsers.generic.OrphanDefinitionParser
This constructor assumes that the class name will be explicitly specified as an attribute on the element.
OrphanDefinitionParser(Class<?>, boolean) - Constructor for class org.mule.config.spring.parsers.generic.OrphanDefinitionParser
 
OrphanEndpointDefinitionParser - Class in org.mule.config.spring.parsers.specific.endpoint.support
A parser for "orphan" (top-level) endpoints - ie GlobalEndpoints.
OrphanEndpointDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.support.OrphanEndpointDefinitionParser
 
OrphanMapDefinitionParser - Class in org.mule.config.spring.parsers.collection
Creates a single, stand-alone map object and processes standard Spring sub elements
OrphanMapDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.collection.OrphanMapDefinitionParser
Creates a Map parser that will add the map directly to the registry
OrphanMapDefinitionParser(Class, String) - Constructor for class org.mule.config.spring.parsers.collection.OrphanMapDefinitionParser
Creates a Map parser that will add the map directly to the registry
OrphanMapDefinitionParser(Class, String, boolean) - Constructor for class org.mule.config.spring.parsers.collection.OrphanMapDefinitionParser
Creates a Map parser that will add the map directly to the registry
OS_ROOT - Static variable in class org.mule.module.jboss.transaction.JBossArjunaTransactionManagerFactory
 
OSGI_HEADER_TRANSPORT - Static variable in interface org.mule.transport.service.TransportServiceDescriptor
 
OTHER_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
otherwise(MuleDefinitionParser) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
out - Variable in class org.mule.transport.AbstractReceiverWorker
 
OUT_FAULT_INTERCEPTORS - Static variable in class org.mule.module.cxf.CxfConstants
 
OUT_INTERCEPTORS - Static variable in class org.mule.module.cxf.CxfConstants
 
OUTBOUND - Static variable in class org.mule.api.transport.PropertyScope
This is the default scope when writing properties to a message.
OUTBOUND_ADDRESS_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
OUTBOUND_ENDPOINT - Static variable in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
OUTBOUND_ENDPOINT_CHILD - Static variable in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
OUTBOUND_ENDPOINT_REF_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
OUTBOUND_NAME - Static variable in class org.mule.api.transport.PropertyScope
 
outboundAddress(String) - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundAndOutboundEndpointBuilder
 
OutboundAttachmentMapContext - Class in org.mule.el.context
 
OutboundAttachmentMapContext(MuleMessage) - Constructor for class org.mule.el.context.OutboundAttachmentMapContext
 
OutboundAttachments - Annotation Type in org.mule.api.annotations.param
Used on component methods, this parameter annotation passes in a reference to a Map that can be used to populate outbound attachments that will be set with the outgoing message.
OutboundAttachmentsAnnotationParser - Class in org.mule.config.parsers
Responsible for parsing the OutboundAttachments annotation.
OutboundAttachmentsAnnotationParser() - Constructor for class org.mule.config.parsers.OutboundAttachmentsAnnotationParser
 
OutboundAttachmentsExpressionEvaluator - Class in org.mule.expression
Creates a Map facade around a MuleMessage instance to allow access to outbound attachments from within components and transformers without the these objects needing access to the Mule Message
OutboundAttachmentsExpressionEvaluator() - Constructor for class org.mule.expression.OutboundAttachmentsExpressionEvaluator
 
OutboundAttachmentsMap - Class in org.mule.expression
Creates a wrapper around Mule Message with a MAp facade used for allowing developers to add attachments to an outgoing message in a transformer of component without needing to access the Mule API directly
OutboundAttachmentsMap(MuleMessage) - Constructor for class org.mule.expression.OutboundAttachmentsMap
 
OutboundEndpoint - Interface in org.mule.api.endpoint
 
outboundEndpoint(OutboundEndpoint) - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundAndOutboundEndpointBuilder
 
outboundEndpoint(EndpointBuilder) - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundAndOutboundEndpointBuilder
 
OutboundEndpointFactoryBean - Class in org.mule.config.spring.factories
Spring FactoryBean used to create concrete instances of outbound endpoints
OutboundEndpointFactoryBean(EndpointURIEndpointBuilder) - Constructor for class org.mule.config.spring.factories.OutboundEndpointFactoryBean
 
OutboundEndpointFactoryBean() - Constructor for class org.mule.config.spring.factories.OutboundEndpointFactoryBean
 
OutboundEndpointMessageProcessorChainBuilder - Class in org.mule.endpoint
Implementation of DefaultMessageProcessorChainBuilder that injects the OutboundEndpoint instance into message processors that implement EndpointAware
OutboundEndpointMessageProcessorChainBuilder(ImmutableEndpoint, FlowConstruct) - Constructor for class org.mule.endpoint.OutboundEndpointMessageProcessorChainBuilder
 
OutboundEndpointMessageProcessorChainBuilder(ImmutableEndpoint) - Constructor for class org.mule.endpoint.OutboundEndpointMessageProcessorChainBuilder
 
OutboundEndpointMimeTypeCheckingMessageProcessor - Class in org.mule.endpoint.outbound
Verify that the outbound mime type is acceptable by this endpoint.
OutboundEndpointMimeTypeCheckingMessageProcessor(OutboundEndpoint) - Constructor for class org.mule.endpoint.outbound.OutboundEndpointMimeTypeCheckingMessageProcessor
 
OutboundEndpointPropertyMessageProcessor - Class in org.mule.endpoint.outbound
Sets the outbound endpoint uri on as a property of the message using the following key: MuleProperties.MULE_ENDPOINT_PROPERTY.
OutboundEndpointPropertyMessageProcessor(OutboundEndpoint) - Constructor for class org.mule.endpoint.outbound.OutboundEndpointPropertyMessageProcessor
 
OutboundEventTimeoutMessageProcessor - Class in org.mule.endpoint.outbound
 
OutboundEventTimeoutMessageProcessor() - Constructor for class org.mule.endpoint.outbound.OutboundEventTimeoutMessageProcessor
 
OutboundHeaders - Annotation Type in org.mule.api.annotations.param
Used on Components that have an outbound endpoint configured or a response being sent back, and enables users to set outbound/response headers via Map without needing to use the Mule API (other than using the annotation) on the method argument).
OutboundHeadersAnnotationParser - Class in org.mule.config.parsers
Responsible for parsing the OutboundHeaders annotation.
OutboundHeadersAnnotationParser() - Constructor for class org.mule.config.parsers.OutboundHeadersAnnotationParser
 
OutboundHeadersExpressionEvaluator - Class in org.mule.expression
Creates a Map facade around a MuleMessage instance to allow access to outbound headers from within components and transformers without the these objects needing access to the Mule Message
OutboundHeadersExpressionEvaluator() - Constructor for class org.mule.expression.OutboundHeadersExpressionEvaluator
 
OutboundHeadersExpressionEvaluator.SendHeadersMap - Class in org.mule.expression
 
OutboundHeadersExpressionEvaluator.SendHeadersMap(MuleMessage) - Constructor for class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
OutboundLoggingMessageProcessor - Class in org.mule.endpoint.outbound
 
OutboundLoggingMessageProcessor() - Constructor for class org.mule.endpoint.outbound.OutboundLoggingMessageProcessor
 
outboundMap - Variable in class org.mule.MessagePropertiesContext
 
OutboundNotificationMessageProcessor - Class in org.mule.endpoint.outbound
Publishes a EndpointMessageNotification's when a message is sent or dispatched.
OutboundNotificationMessageProcessor(OutboundEndpoint) - Constructor for class org.mule.endpoint.outbound.OutboundNotificationMessageProcessor
 
OutboundPassThroughRouter - Class in org.mule.routing.outbound
Deprecated.
OutboundPassThroughRouter() - Constructor for class org.mule.routing.outbound.OutboundPassThroughRouter
Deprecated.
 
OutboundResponsePropertiesMessageProcessor - Class in org.mule.endpoint.outbound
Propagates properties from request message to response message as defined by OutboundEndpoint.getResponseProperties().
OutboundResponsePropertiesMessageProcessor(OutboundEndpoint) - Constructor for class org.mule.endpoint.outbound.OutboundResponsePropertiesMessageProcessor
 
OutboundRootMessageIdPropertyMessageProcessor - Class in org.mule.endpoint.outbound
Sets the outbound root message id on as a property of the message using the following key: MuleProperties.MULE_ROOT_MESSAGE_ID_PROPERTY.
OutboundRootMessageIdPropertyMessageProcessor() - Constructor for class org.mule.endpoint.outbound.OutboundRootMessageIdPropertyMessageProcessor
 
OutboundRouter - Interface in org.mule.api.routing
OutboundRouter is used to control outbound routing behaviour for an event.
outboundRouter - Variable in class org.mule.component.DefaultInterfaceBinding
 
outboundRouter - Variable in class org.mule.service.AbstractService
Deprecated.
 
OutboundRouterCatchAllStrategy - Interface in org.mule.api.routing
Deprecated.
OutboundRouterCollection - Interface in org.mule.api.routing
Deprecated.
outboundRouterMustUseOutboudEndpoints(OutboundRouter, ImmutableEndpoint) - Static method in class org.mule.config.i18n.CoreMessages
 
OutboundSessionHandlerMessageProcessor - Class in org.mule.endpoint.outbound
Stores session information on the outbound message.
OutboundSessionHandlerMessageProcessor(SessionHandler) - Constructor for class org.mule.endpoint.outbound.OutboundSessionHandlerMessageProcessor
 
outboundTransformer - Variable in class org.mule.transformer.wire.TransformerPairWireFormat
 
OutboundTxRollbackMessageProcessor - Class in org.mule.endpoint.outbound
MessageProcessor implementation that stops outbound flow is the current transaction has been rolled back.
OutboundTxRollbackMessageProcessor() - Constructor for class org.mule.endpoint.outbound.OutboundTxRollbackMessageProcessor
 
outFaultInterceptors - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
outInterceptors - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
OUTPUT_TYPE_NODE - Static variable in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
 
OUTPUT_TYPE_VALUE - Static variable in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
 
OUTPUT_TYPE_XML - Static variable in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
 
outputFormat - Variable in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
OutputHandler - Interface in org.mule.api.transport
The OutputHandler is a strategy class that is used to defer the writing of the message payload until there is a stream available to write it to.
OutputParamDefinitionDefinitionParser - Class in org.mule.module.db.internal.config.domain.param
 
OutputParamDefinitionDefinitionParser() - Constructor for class org.mule.module.db.internal.config.domain.param.OutputParamDefinitionDefinitionParser
 
OutputParamProcessingException - Exception in org.mule.module.db.internal.result.statement
Thrown to indicate an error during the processing of a output parameter
OutputParamProcessingException(Throwable) - Constructor for exception org.mule.module.db.internal.result.statement.OutputParamProcessingException
 
OutputParamResult - Class in org.mule.module.db.internal.result.statement
Represents an output parameter after a Statement execution
OutputParamResult(String, Object) - Constructor for class org.mule.module.db.internal.result.statement.OutputParamResult
 
OutputPayloadInterceptor - Class in org.mule.module.cxf.support
 
OutputPayloadInterceptor() - Constructor for class org.mule.module.cxf.support.OutputPayloadInterceptor
 
OutputQueryParam - Interface in org.mule.module.db.internal.domain.param
Defines a parameter that returns an output value
OutputSoapHeadersInterceptor - Class in org.mule.module.ws.consumer
CXF interceptor that adds inbound properties to the Mule message based on the SOAP headers received in the response.
OutputSoapHeadersInterceptor(MuleContext) - Constructor for class org.mule.module.ws.consumer.OutputSoapHeadersInterceptor
 
outputStream - Variable in class org.mule.transport.stdio.StdioConnector
 
OutRouteBuilder - Class in org.mule.config.dsl
Deprecated.
OutRouteBuilder(OutboundRouterCollection, MuleContext) - Constructor for class org.mule.config.dsl.OutRouteBuilder
Deprecated.
 
overlaps(ServerAddress) - Method in class org.mule.module.http.internal.listener.ServerAddress
 
override - Variable in class org.mule.config.spring.factories.PollingMessageSourceFactoryBean
 
override - Variable in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
The MessageProcessorPollingOverride that affects the routing of the MuleEvent
overrides - Variable in class org.mule.module.launcher.FineGrainedControlClassLoader
 
overwritePayload(MuleEvent, Object) - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
Overwrites the event payload with the specified one

P

packetCollector - Variable in class org.mule.transport.xmpp.AbstractXmppConversation
 
padId(String) - Static method in class org.mule.utils.IdUtils
 
PagingConfiguration - Class in org.mule.streaming
Inmutable pojo to carry pagination parameters
PagingConfiguration(int) - Constructor for class org.mule.streaming.PagingConfiguration
 
PagingDelegate<T> - Class in org.mule.streaming
A PagingDelegate is a Closeable capable of consuming a data feed in pages.
PagingDelegate() - Constructor for class org.mule.streaming.PagingDelegate
 
PagingDelegateProducer<T> - Class in org.mule.streaming
Implementation of Producer that uses an instance of PagingDelegate to get its results
PagingDelegateProducer(PagingDelegate<T>) - Constructor for class org.mule.streaming.PagingDelegateProducer
 
PagingDelegateWrapper<T> - Class in org.mule.streaming
This implementation of PagingDelegate takes care of enforcing some basic behaviour of the delegate contract so that users don't have to.
PagingDelegateWrapper(PagingDelegate<T>) - Constructor for class org.mule.streaming.PagingDelegateWrapper
 
PARALLEL_DEPLOYMENT_PROPERTY - Static variable in class org.mule.module.launcher.MuleDeploymentService
 
ParallelDeploymentDirectoryWatcher - Class in org.mule.module.launcher
Provides parallel deployment of Mule applications.
ParallelDeploymentDirectoryWatcher(ArchiveDeployer<Domain>, ArchiveDeployer<Application>, ObservableList<Domain>, ObservableList<Application>, ReentrantLock) - Constructor for class org.mule.module.launcher.ParallelDeploymentDirectoryWatcher
 
PARAM_DEBUG_FIELD_PREFIX - Static variable in class org.mule.module.db.internal.processor.DbDebugInfoUtils
 
PARAM_NAME_COLUN_INDEX - Static variable in class org.mule.module.db.internal.resolver.param.StoredProcedureParamTypeResolver
 
PARAM_SET_DEBUG_FIELD_PREFIX - Static variable in class org.mule.module.db.internal.processor.DbDebugInfoUtils
 
PARAMETER_MAP_PROPERTY_KEY - Static variable in class org.mule.transport.servlet.ServletConnector
This property name is used to store a Map containing all request parameters to the MuleMessage.
PARAMETER_PROPERTY_PREFIX - Static variable in class org.mule.transport.servlet.ServletConnector
This prefix is used to store parameters from the incoming HttpServletRequest to the MuleMessage.
PARAMETER_SET_BEGIN - Static variable in class org.mule.module.db.internal.domain.logger.DebugPreparedBulkQueryLogger
 
PARAMETER_SET_END - Static variable in class org.mule.module.db.internal.domain.logger.DebugPreparedBulkQueryLogger
 
PARAMETER_TYPES_NONE - Static variable in class org.mule.transport.jms.weblogic.WeblogicJmsTopicResolver
Cached empty class array, used in the no-args reflective method call.
ParameterExtractor - Class in org.mule.module.oauth2.internal
Configuration of a custom parameter to extract from the token response.
ParameterExtractor() - Constructor for class org.mule.module.oauth2.internal.ParameterExtractor
 
ParameterGroup - Class in org.mule.module.extension.internal.introspection
A metadata class that groups a set of parameters together.
ParameterGroup(Class<?>, Field) - Constructor for class org.mule.module.extension.internal.introspection.ParameterGroup
 
ParameterGroupArgumentResolver<T> - Class in org.mule.module.extension.internal.runtime.resolver
Resolves arguments annotated with ParameterGroup in a ReflectiveMethodOperationExecutor.
ParameterGroupArgumentResolver(Class<T>) - Constructor for class org.mule.module.extension.internal.runtime.resolver.ParameterGroupArgumentResolver
Creates an instance that will resolve instances of type
ParameterGroupCapability - Class in org.mule.module.extension.internal.capability.metadata
A metadata capability to specify that a certain group of Parameters are grouped.
ParameterGroupCapability(List<ParameterGroup>) - Constructor for class org.mule.module.extension.internal.capability.metadata.ParameterGroupCapability
 
PARAMETERIZED_QUERY - Static variable in class org.mule.module.db.internal.config.domain.query.QueryDefinitionParser
 
PARAMETERIZED_QUERY - Static variable in class org.mule.module.db.internal.config.domain.query.QueryTemplateBeanDefinitionParser
 
ParameterizedQueryTemplateFactoryBean - Class in org.mule.module.db.internal.config.domain.query
Creates QueryTemplate for parameterized queries
ParameterizedQueryTemplateFactoryBean(String, List<QueryParam>, QueryTemplateParser) - Constructor for class org.mule.module.db.internal.config.domain.query.ParameterizedQueryTemplateFactoryBean
 
ParameterMap - Class in org.mule.module.http.internal
 
ParameterMap(Map) - Constructor for class org.mule.module.http.internal.ParameterMap
 
ParameterMap() - Constructor for class org.mule.module.http.internal.ParameterMap
 
ParameterNameDiscoverer - Interface in org.mule.util.generics
Interface to discover parameter names for methods and constructors.
PARAMETERS_SEPARATOR - Static variable in class org.mule.transport.http.RequestLine
 
ParametrizedQueryResolver - Class in org.mule.module.db.internal.resolver.query
Resolves a parameterized query evaluating parameter value expression using a given event
ParametrizedQueryResolver(Query, ParamValueResolver) - Constructor for class org.mule.module.db.internal.resolver.query.ParametrizedQueryResolver
 
ParamReader - Class in org.mule.util
This is the class file reader for obtaining the parameter names for declared methods in a class.
ParamReader(Class) - Constructor for class org.mule.util.ParamReader
process a class file, given it's class.
ParamReader(byte[]) - Constructor for class org.mule.util.ParamReader
process the given class bytes directly.
params - Variable in class org.mule.module.http.internal.HttpMessageBuilder
 
paramsMap - Variable in class org.mule.module.http.internal.ParameterMap
 
ParamTypeResolver - Interface in org.mule.module.db.internal.resolver.param
Resolves QueryTemplate actual parameter types for a given DbConnection
ParamTypeResolverFactory - Interface in org.mule.module.db.internal.resolver.param
Creates ParamTypeResolver instances
ParamValueResolver - Interface in org.mule.module.db.internal.resolver.param
Resolves the values of a template query for a given event
parentContext - Variable in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
ParentContextDefinitionParser - Class in org.mule.config.spring.parsers.delegate
This encapsulates several definition parsers, selected depending on the parent element in the DOM.
ParentContextDefinitionParser(String, MuleDefinitionParser) - Constructor for class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
ParentContextPropertyPlaceholderProcessor - Class in org.mule.config.spring.processors
 
ParentContextPropertyPlaceholderProcessor() - Constructor for class org.mule.config.spring.processors.ParentContextPropertyPlaceholderProcessor
 
ParentDefinitionParser - Class in org.mule.config.spring.parsers.generic
Processes child property elements in Xml but sets the properties on the parent object.
ParentDefinitionParser() - Constructor for class org.mule.config.spring.parsers.generic.ParentDefinitionParser
 
parse(Annotation, Class<?>) - Method in interface org.mule.api.expression.ExpressionAnnotationParser
 
parse(String, MuleMessage) - Method in interface org.mule.api.expression.ExpressionManager
Deprecated.
parse(String, MuleEvent) - Method in interface org.mule.api.expression.ExpressionManager
 
parse(String, MuleMessage, boolean) - Method in interface org.mule.api.expression.ExpressionManager
Deprecated.
parse(String, MuleEvent, boolean) - Method in interface org.mule.api.expression.ExpressionManager
 
parse(Annotation, Class<?>) - Method in class org.mule.config.expression.ExprAnnotationParser
 
parse(Annotation, Class<?>) - Method in class org.mule.config.expression.FunctionAnnotationParser
 
parse(Annotation, Class<?>) - Method in class org.mule.config.expression.LookupAnnotationParser
 
parse(Annotation, Class) - Method in class org.mule.config.expression.MuleAnnotationParser
 
parse(Annotation, Class<?>) - Method in class org.mule.config.parsers.InboundAttachmentsAnnotationParser
 
parse(Annotation, Class<?>) - Method in class org.mule.config.parsers.InboundHeadersAnnotationParser
 
parse(Annotation, Class<?>) - Method in class org.mule.config.parsers.OutboundAttachmentsAnnotationParser
 
parse(Annotation, Class<?>) - Method in class org.mule.config.parsers.OutboundHeadersAnnotationParser
 
parse(Annotation, Class<?>) - Method in class org.mule.config.parsers.PayloadAnnotationParser
 
parse(Element, ParserContext) - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler.IgnoredDefinitionParser
 
parse(String) - Method in class org.mule.config.spring.jndi.DefaultNameParser
 
parse(Element, ParserContext) - Method in class org.mule.config.spring.parsers.DeprecatedBeanDefinitionParser
 
parse(Element, ParserContext) - Method in class org.mule.config.spring.parsers.IndependentDefinitionParser
 
parse(String, MuleMessage) - Method in class org.mule.expression.DefaultExpressionManager
Evaluates expressions in a given string.
parse(String, MuleEvent) - Method in class org.mule.expression.DefaultExpressionManager
 
parse(String, MuleMessage, boolean) - Method in class org.mule.expression.DefaultExpressionManager
Evaluates expressions in a given string.
parse(String, MuleEvent, boolean) - Method in class org.mule.expression.DefaultExpressionManager
 
parse(String) - Method in class org.mule.expression.ExpressionConfig
 
parse(Element, ParserContext) - Method in class org.mule.module.db.internal.config.processor.AbstractUpdateProcessorBeanDefinitionParser
 
parse(String) - Method in interface org.mule.module.db.internal.parser.QueryTemplateParser
Parses a SQL query
parse(String) - Method in class org.mule.module.db.internal.parser.SimpleQueryTemplateParser
 
parse(Annotation, Class<?>) - Method in class org.mule.module.json.config.JsonPathAnnotationParser
 
parse(File, String) - Method in interface org.mule.module.launcher.descriptor.DescriptorParser
 
parse(File) - Method in class org.mule.module.launcher.descriptor.DomainDescriptorParser
 
parse(File, String) - Method in class org.mule.module.launcher.descriptor.PropertiesDescriptorParser
 
parse() - Method in class org.mule.module.launcher.plugin.PluginDescriptorParser
 
parse(Annotation, Class<?>) - Method in class org.mule.module.ognl.config.OgnlAnnotationParser
 
parse(Document, boolean, Locale) - Method in class org.mule.module.rss.transformers.RssParser
 
parse(Annotation, Class<?>) - Method in class org.mule.module.scripting.config.GroovyAnnotationParser
 
parse(Element, ParserContext) - Method in class org.mule.module.spring.security.config.SecurityManagerDefinitionParser
 
parse(Annotation, Class<?>) - Method in class org.mule.module.xml.config.XPathAnnotationParser
 
parse(InputSource) - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
parse(String) - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
parse() - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
parse(Element) - Method in interface org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser.ParseDelegate
 
parse(MuleMessage, ExpressionManager) - Method in class org.mule.transport.http.CacheControlHeader
Evaluates all the properties in case there are expressions
parse(MuleMessage, ExpressionManager) - Method in class org.mule.transport.http.CookieWrapper
 
parse() - Method in class org.mule.transport.http.multipart.MultiPartInputStream
 
parse(Map<?, ?>, String) - Method in class org.mule.util.TemplateParser
Matches one or more templates against a Map of key value pairs.
parse(TemplateParser.TemplateCallback, String) - Method in class org.mule.util.TemplateParser
Matches one or more templates against a Map of key value pairs.
parse(Map<?, ?>, String, TemplateParser.TemplateCallback) - Method in class org.mule.util.TemplateParser
 
parse(Map<?, ?>, List<?>) - Method in class org.mule.util.TemplateParser
Matches one or more templates against a Map of key value pairs.
parse(Map<?, ?>, Map<?, ?>) - Method in class org.mule.util.TemplateParser
Matches one or more templates against a Map of key value pairs.
parse(TemplateParser.TemplateCallback, Map<?, ?>) - Method in class org.mule.util.TemplateParser
 
parseAutoGeneratedKeys(Element, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
parseBeanDefinitions(Element, BeanDefinitionParserDelegate) - Method in class org.mule.config.spring.MuleBeanDefinitionDocumentReader
Override to reject configuration files with no namespace, e.g.
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.AbstractChildDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.collection.AttributeListEntryDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.collection.AttributeMapDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.collection.ChildListDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.collection.ChildListEntryDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.collection.ChildMapDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.collection.ChildPropertiesDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.collection.GenericChildMapDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.generic.OptionalChildDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.AsyncMessageProcessorsDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.FlowRefDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.InvokerMessageProcessorDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.MessageEnricherDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.RetryPolicyDefinitionParser
The BDP magic inside this method will transform this simple config: into this equivalent config, because of the attribute asynchronous="true":
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.ServiceOverridesDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.ShortcutComponentDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.specific.SimpleComponentDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.cxf.config.WsCustomValidatorDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.http.internal.config.HttpAuthenticationDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.http.internal.config.HttpMessageSingleParamDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.http.internal.config.HttpThreadingProfileDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.module.json.config.ValidateJsonSchemaMessageProcessorDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.tck.config.TestComponentDefinitionParser
 
parseChild(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.transport.http.builder.HttpResponseDefinitionParser
 
parseConfig(Element, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
parseConfigName(Element) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseConfigRef(Element, BeanDefinitionBuilder) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseCookiesAsAClient(Header, String) - Static method in class org.mule.transport.http.CookieHelper
 
parseCookiesAsAClient(String, String) - Static method in class org.mule.transport.http.CookieHelper
 
parseCookiesAsAClient(Header, String, URI) - Static method in class org.mule.transport.http.CookieHelper
 
parseCookiesAsAClient(String, String, URI) - Static method in class org.mule.transport.http.CookieHelper
This method parses the value of "Set-Cookie" HTTP header, returning an array with all the Cookies found.
parseCookiesAsAServer(Header, URI) - Static method in class org.mule.transport.http.CookieHelper
This method parses the value of an HTTP "Cookie" header that comes from a client to a server.
parseCookiesAsAServer(String, URI) - Static method in class org.mule.transport.http.CookieHelper
This method parses the value of an HTTP "Cookie" header that comes from a client to a server.
parseCustomElement(Element, BeanDefinition) - Method in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
parseExchangePatterns(String) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
parseExecutorFactory(Element, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
parseFilterString(String) - Method in class org.mule.config.expression.ExpressionFilterParser
 
parseInboundEndpoint(Annotation, Map) - Method in interface org.mule.api.EndpointAnnotationParser
Creates an inbound endpoint from the annotation.
parseInboundEndpoint(Annotation, Map) - Method in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
parseInboundEndpoint(Annotation, Map) - Method in class org.mule.transport.quartz.config.ScheduleAnnotationParser
 
parseInternal(Element, ParserContext) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
parseInternal(Element, ParserContext) - Method in class org.mule.config.spring.parsers.ClassOrRefDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.mule.config.spring.parsers.generic.MuleOrphanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.mule.config.spring.parsers.generic.NamedDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.mule.config.spring.parsers.generic.NameTransferDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.mule.config.spring.parsers.generic.ParentDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.mule.config.spring.parsers.specific.InheritedModelDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class org.mule.config.spring.parsers.specific.TransactionDefinitionParser
 
parseItem(Element, Element, Locale) - Method in class org.mule.module.rss.transformers.RssParser
 
parseJpdl(Element, Parse, JpdlParser) - Method in class org.mule.module.jbpm.MuleReceiveBinding
 
parseJpdl(Element, Parse, JpdlParser) - Method in class org.mule.module.jbpm.MuleSendBinding
 
parseLine(String) - Static method in class org.mule.transport.http.RequestLine
 
parseList(Element, String, AbstractDevkitBasedDefinitionParser.ParseDelegate) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseListAndSetProperty(Element, BeanDefinitionBuilder, String, String, String, AbstractDevkitBasedDefinitionParser.ParseDelegate) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseListWithDefaultAndSetProperty(Element, BeanDefinitionBuilder, String, String, String, String, AbstractDevkitBasedDefinitionParser.ParseDelegate) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseMap(Element, String, AbstractDevkitBasedDefinitionParser.ParseDelegate) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseMapAndSetProperty(Element, BeanDefinitionBuilder, String, String, String, AbstractDevkitBasedDefinitionParser.ParseDelegate) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseMapElement(Element, String, String, String) - Method in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
Parse a map element.
parseMapWithDefaultAndSetProperty(Element, BeanDefinitionBuilder, String, String, String, String, AbstractDevkitBasedDefinitionParser.ParseDelegate) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseMessageProcessor(Annotation) - Method in interface org.mule.api.MessageProcessorAnnotationParser
Will create a Mule Router according to the annotation.
parseMetadataProvider(Element, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
parseMultipartContent(InputStream, String) - Static method in class org.mule.module.http.internal.HttpParser
 
parseNestedProcessor(Element, ParserContext, Class) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseNestedProcessorAndSetProperty(Element, ParserContext, Class, BeanDefinitionBuilder, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseNestedProcessorAndSetProperty(Element, String, ParserContext, Class, BeanDefinitionBuilder, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseNestedProcessorAsList(Element, ParserContext, Class) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseNestedProcessorAsListAndSetProperty(Element, ParserContext, Class, BeanDefinitionBuilder, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseNestedProcessorAsListAndSetProperty(Element, String, ParserContext, Class, BeanDefinitionBuilder, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseNoExprObjectRef(Element, BeanDefinitionBuilder, String, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseNoExprObjectRefWithDefault(Element, BeanDefinitionBuilder, String, String, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseNumber(String, Class<T>) - Static method in class org.mule.util.NumberUtils
 
parseObjectRef(Element, BeanDefinitionBuilder, String, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseObjectRefWithDefault(Element, BeanDefinitionBuilder, String, String, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseOutboundEndpoint(Annotation, Map) - Method in interface org.mule.api.EndpointAnnotationParser
Creates an outbound endpoint from the annotation.
parseOutboundEndpoint(Annotation, Map) - Method in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
parseOverriddenTemplateParameters(List<Element>, ParserContext) - Static method in class org.mule.module.db.internal.config.domain.query.QueryDefinitionParser
 
parsePlaceholderValues(String) - Method in class org.mule.config.endpoint.AnnotatedEndpointHelper
 
parseProcessingStrategy(String) - Static method in class org.mule.config.spring.util.ProcessingStrategyUtils
 
parseProperty(BeanDefinitionBuilder, Element, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseProperty(BeanDefinitionBuilder, Element, String, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parsePropertyDefinitions(String) - Static method in class org.mule.util.SystemUtils
Returns a Map of all valid property definitions in -Dkey=value format.
parsePropertyRef(BeanDefinitionBuilder, Element, String, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parsePropertyRef(BeanDefinitionBuilder, Element, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseQName(String) - Method in class org.mule.config.spring.editors.QNamePropertyEditor
 
parseQuery(Element, ParserContext) - Method in class org.mule.module.db.internal.config.domain.query.QueryDefinitionParser
 
parser - Variable in class org.mule.config.endpoint.AnnotatedEndpointHelper
 
parserConfiguration - Variable in class org.mule.el.mvel.MVELExpressionExecutor
 
parserConfiguration - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
parserConfiguration - Variable in class org.mule.el.mvel.MVELExpressionLanguageContext
 
parseRetryPolicyTemplate(String, Element, ParserContext, BeanDefinitionBuilder, BeanDefinition) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parserFactory - Variable in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
parserRegistry - Variable in class org.mule.module.launcher.DefaultAppBloodhound
 
parseServerAuthority() - Method in class org.mule.endpoint.MuleEndpointURI
 
parseSet(Element, String, AbstractDevkitBasedDefinitionParser.ParseDelegate) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseSetAndSetProperty(Element, BeanDefinitionBuilder, String, String, String, AbstractDevkitBasedDefinitionParser.ParseDelegate) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseSetWithDefaultAndSetProperty(Element, BeanDefinitionBuilder, String, String, String, String, AbstractDevkitBasedDefinitionParser.ParseDelegate) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseSoapAction(String, QName, MuleEvent) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
parseSourceExpression(Element, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
parseStatement(String, List<String>) - Method in class org.mule.transport.jdbc.JdbcConnector
Parse the given statement filling the parameter list and return the ready to use statement.
parseStatementFactory(Element) - Method in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
parseStatements(String, String) - Method in class org.mule.transport.jdbc.JdbcMessageReceiver
Parses the read and acknowledge SQL statements
parseStyle(MuleEvent, Call) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
parseTargetExpression(Element, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
ParseTemplateTransformer - Class in org.mule.transformer.simple
Loads a template and parses its content to resolve expressions.
ParseTemplateTransformer() - Constructor for class org.mule.transformer.simple.ParseTemplateTransformer
 
parseTextProperty(BeanDefinitionBuilder, Element, String, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
parseTokens(String) - Method in class org.mule.module.json.JsonData
 
parseTransactionalAction(Element, BeanDefinitionBuilder) - Method in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
parseUse(MuleEvent, Call) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
Part - Interface in org.mule.transport.http.multipart
This class represents a part or form item that was received within a multipart/form-data POST request.
PartDataSource - Class in org.mule.transport.http.multipart
TODO
PartDataSource(Part) - Constructor for class org.mule.transport.http.multipart.PartDataSource
 
PartitionableExpirableObjectStore<T extends Serializable> - Interface in org.mule.api.store
 
PartitionableObjectStore<T extends Serializable> - Interface in org.mule.api.store
 
PartitionedInMemoryObjectStore<T extends Serializable> - Class in org.mule.util.store
 
PartitionedInMemoryObjectStore() - Constructor for class org.mule.util.store.PartitionedInMemoryObjectStore
 
PartitionedMessageSequence<Q> - Class in org.mule.routing.outbound
A MessageSequence wrapper that partitions the wrapped sequence in collections of the specified size.
PartitionedMessageSequence(MessageSequence<Q>, int) - Constructor for class org.mule.routing.outbound.PartitionedMessageSequence
 
PartitionedObjectStoreWrapper<T extends Serializable> - Class in org.mule.util.store
 
PartitionedObjectStoreWrapper(String, MuleContext, ListableObjectStore<T>) - Constructor for class org.mule.util.store.PartitionedObjectStoreWrapper
 
PartitionedPersistentObjectStore<T extends Serializable> - Class in org.mule.util.store
 
PartitionedPersistentObjectStore() - Constructor for class org.mule.util.store.PartitionedPersistentObjectStore
 
PartitionedPersistentObjectStore(MuleContext) - Constructor for class org.mule.util.store.PartitionedPersistentObjectStore
 
passivate() - Method in interface org.mule.api.transport.MessageDispatcher
After sending a message, the dispatcher can use this method e.g.
passivate(OutboundEndpoint, MessageDispatcher) - Method in interface org.mule.api.transport.MessageDispatcherFactory
Invoked immediately before the given dispatcher is returned to its pool.
passivate() - Method in interface org.mule.api.transport.MessageRequester
After receiving a message, the dispatcher can use this method e.g.
passivate(InboundEndpoint, MessageRequester) - Method in interface org.mule.api.transport.MessageRequesterFactory
Invoked immediately before the given requester is returned to its pool.
passivate(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.AbstractMessageDispatcherFactory
 
passivate(InboundEndpoint, MessageRequester) - Method in class org.mule.transport.AbstractMessageRequesterFactory
 
passivate() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
passivate(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
passivate(InboundEndpoint, MessageRequester) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
passivateObject(Object) - Method in class org.mule.module.xml.transformer.XsltTransformer.PooledXsltTransformerFactory
 
passivateObject(String, OAuth2Adapter) - Method in class org.mule.security.oauth.BaseOAuthClientFactory
Passivates the object by updating the state of the persisted object with the one of the given one.
passivateObject(Object) - Method in class org.mule.transport.ftp.FtpConnectionFactory
 
passivateObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
passivateObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
passivateObject(Object) - Method in class org.mule.transport.sftp.SftpConnectionFactory
 
passivateObject(Object, Object) - Method in class org.mule.transport.tcp.AbstractTcpSocketFactory
 
passivateObject(Object, Object) - Method in class org.mule.transport.udp.UdpSocketFactory
 
PassThroughComponent - Class in org.mule.component.simple
Deprecated.
PassThroughComponent() - Constructor for class org.mule.component.simple.PassThroughComponent
Deprecated.
 
PASSWORD - Static variable in class org.mule.endpoint.URIBuilder
 
PASSWORD - Static variable in class org.mule.tck.util.sftp.SftpServer
 
password - Variable in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
PASSWORD - Static variable in class org.mule.transport.jms.config.ConnectionFactoryDefinitionParser
 
password - Variable in class org.mule.transport.jms.JmsConnector
 
PASSWORD_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
PASSWORD_ATTRIBUTE_MASK - Static variable in class org.mule.api.util.CredentialsMaskUtil
 
PASSWORD_MASK - Static variable in class org.mule.api.util.CredentialsMaskUtil
 
PASSWORD_PATTERN - Static variable in class org.mule.api.util.CredentialsMaskUtil
 
PASSWORD_PATTERN_NO_QUOTES - Static variable in class org.mule.api.util.CredentialsMaskUtil
 
PasswordBasedEncryptionStrategy - Class in org.mule.security
Provides password-based encryption using JCE.
PasswordBasedEncryptionStrategy() - Constructor for class org.mule.security.PasswordBasedEncryptionStrategy
 
PasswordType - Enum in org.mule.module.ws.security
 
PATCH - Annotation Type in org.mule.module.jersey
 
PatchMethod - Class in org.mule.transport.http
 
PatchMethod() - Constructor for class org.mule.transport.http.PatchMethod
 
PatchMethod(String) - Constructor for class org.mule.transport.http.PatchMethod
 
PATH - Static variable in class org.mule.endpoint.URIBuilder
 
PATH_ATTRIBUTES - Static variable in class org.mule.endpoint.URIBuilder
 
PATH_CLASSES - Static variable in class org.mule.module.launcher.MuleApplicationClassLoader
Classes and resources directory in Mule application.
PATH_LIBRARY - Static variable in class org.mule.module.launcher.MuleApplicationClassLoader
Library directory in Mule application.
PATH_MULE - Static variable in class org.mule.module.launcher.MuleApplicationClassLoader
Directory for standard mule modules and transports
PATH_PER_APP - Static variable in class org.mule.module.launcher.MuleApplicationClassLoader
Sub-directory for per-application mule modules and transports
PathSkipMessageProcessorChainBuilder - Class in org.mule.processor.chain
Constructs a chain of MessageProcessors and wraps the invocation of the chain in a composite MessageProcessor.
PathSkipMessageProcessorChainBuilder() - Constructor for class org.mule.processor.chain.PathSkipMessageProcessorChainBuilder
 
pattern - Variable in class org.mule.routing.filters.WildcardFilter
 
pattern - Variable in class org.mule.transport.xmpp.filters.XmppFromContainsFilter
 
patternInfo - Variable in class org.mule.processor.InvokerMessageProcessor
 
patterns - Variable in class org.mule.routing.filters.WildcardFilter
 
PATTERNS_DEPRECATION_MESSAGE - Static variable in class org.mule.config.spring.handlers.MuleNamespaceHandler
 
Pausable - Interface in org.mule.service
Adds a pause lifecycle method to an object.
pause() - Method in interface org.mule.api.service.Service
Deprecated.
Pauses event processing for a single Mule Service.
pause() - Method in class org.mule.module.management.mbean.ServiceService
Pauses event processing for theComponent.
pause() - Method in interface org.mule.module.management.mbean.ServiceServiceMBean
Deprecated.
Pauses event processing for theComponent.
pause() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
pause() - Method in class org.mule.service.AbstractService
Deprecated.
Pauses event processing for a single Mule Service.
pause() - Method in interface org.mule.service.Pausable
 
pauseIfPausable(Object) - Method in class org.mule.service.AbstractService
Deprecated.
 
PausePhase - Class in org.mule.service
Defines a phase phase that will invoke the Pausable.pause() method on an object.
PausePhase() - Constructor for class org.mule.service.PausePhase
 
Payload - Annotation Type in org.mule.api.annotations.param
Used on components, this annotation marks the method parameter that will be used to pass in the message payload.
PAYLOAD - Static variable in class org.mule.el.mvel.MessageVariableResolverFactory
 
PAYLOAD - Static variable in class org.mule.expression.MessageExpressionEvaluator
 
PAYLOAD - Static variable in class org.mule.module.cxf.CxfConstants
 
PAYLOAD_BODY - Static variable in class org.mule.module.cxf.CxfConstants
 
PAYLOAD_CLASS_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 
PAYLOAD_ENVELOPE - Static variable in class org.mule.module.cxf.CxfConstants
 
PAYLOAD_INFO_KEY - Static variable in exception org.mule.api.MessagingException
 
PAYLOAD_PARAMETER_NAME - Static variable in class org.mule.transport.servlet.AbstractReceiverServlet
 
PAYLOAD_TO_ARGUMENTS - Static variable in class org.mule.module.cxf.CxfConstants
 
PAYLOAD_TO_ARGUMENTS_BY_DEFAULT - Static variable in class org.mule.module.cxf.CxfConstants
 
PAYLOAD_TO_ARGUMENTS_NULL_PAYLOAD_AS_PARAMETER - Static variable in class org.mule.module.cxf.CxfConstants
 
PAYLOAD_TO_ARGUMENTS_NULL_PAYLOAD_AS_VOID - Static variable in class org.mule.module.cxf.CxfConstants
 
PAYLOAD_TYPE_INFO_KEY - Static variable in exception org.mule.api.MessagingException
 
PayloadAnnotationParser - Class in org.mule.config.parsers
Responsible for parsing the Payload annotation.
PayloadAnnotationParser() - Constructor for class org.mule.config.parsers.PayloadAnnotationParser
 
payloadAs(Class<T>) - Method in class org.mule.el.context.MessageContext
 
payloadAs(DataType<?>) - Method in class org.mule.el.context.MessageContext
 
PayloadEnricherDataTypePropagator - Class in org.mule.el.mvel.datatype
Propagates data type when payload is used as enrichment target
PayloadEnricherDataTypePropagator() - Constructor for class org.mule.el.mvel.datatype.PayloadEnricherDataTypePropagator
 
PayloadExpressionDataTypeResolver - Class in org.mule.el.mvel.datatype
Resolves data type for expressions representing message's payload
PayloadExpressionDataTypeResolver() - Constructor for class org.mule.el.mvel.datatype.PayloadExpressionDataTypeResolver
 
payloadParameterName - Variable in class org.mule.transport.servlet.AbstractReceiverServlet
 
payloadToArguments - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
payloadToArrayOfArguments(Object) - Method in enum org.mule.module.cxf.CxfPayloadToArguments
This method is the one that converts the payload in an array of arguments.
PayloadTypeExpressionEvaluator - Class in org.mule.expression
 
PayloadTypeExpressionEvaluator() - Constructor for class org.mule.expression.PayloadTypeExpressionEvaluator
 
PayloadTypeFilter - Class in org.mule.routing.filters
PayloadTypeFilter filters based on the type of the object received.
PayloadTypeFilter() - Constructor for class org.mule.routing.filters.PayloadTypeFilter
 
PayloadTypeFilter(String) - Constructor for class org.mule.routing.filters.PayloadTypeFilter
 
PayloadTypeFilter(Class) - Constructor for class org.mule.routing.filters.PayloadTypeFilter
 
PBE_SECRET_KEY_DECRYPTOR_BUILDER - Static variable in class org.mule.module.pgp.util.BouncyCastleUtil
 
peek() - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
 
peek() - Method in class org.mule.util.queue.DefaultQueueStore
 
peek(QueueStore) - Method in class org.mule.util.queue.LocalTxQueueTransactionContext
 
peek() - Method in class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
Deprecated.
 
peek() - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
peek() - Method in interface org.mule.util.queue.objectstore.QueueInfoDelegate
Deprecated.
return, but do not remove, the first member of the queue
peek(QueueInfo) - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
peek(QueueStore) - Method in class org.mule.util.queue.PersistentQueueTransactionContext
 
peek(QueueStore) - Method in class org.mule.util.queue.PersistentXaTransactionContext
 
peek() - Method in interface org.mule.util.queue.Queue
 
peek() - Method in interface org.mule.util.queue.QueueStore
 
peek() - Method in interface org.mule.util.queue.QueueStoreDelegate
return, but do not remove, the first member of the queue
peek(QueueStore) - Method in interface org.mule.util.queue.QueueTransactionContext
 
peek(QueueStore) - Method in class org.mule.util.queue.QueueTypeTransactionContextAdapter
 
peek() - Method in class org.mule.util.queue.TransactionAwareQueueStore
 
peek(QueueStore) - Method in class org.mule.util.queue.TransientQueueTransactionContext
 
peek(QueueStore) - Method in class org.mule.util.queue.TransientXaTransactionAdapter
 
peek(QueueStore) - Method in class org.mule.util.queue.XaQueueTypeTransactionContextAdapter
 
PEER_CERTIFICATES - Static variable in class org.mule.transport.http.HttpsConnector
 
PEER_CERTIFICATES - Static variable in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
pendingWorks() - Method in class org.mule.transport.ConcurrentWorkTracker
 
pendingWorks() - Method in interface org.mule.transport.WorkTracker
Returns a list of works that are not completed.
PeopleService - Interface in org.mule.tck.testmodels.services
PeopleService is a test service that returns complex types
PerAppCopyNativeLibraryFinder - Class in org.mule.module.launcher.nativelib
* Finds native libraries in an application's lib folder and creates a copy of each found library inside a temporal application folder.
PerAppCopyNativeLibraryFinder(File, File) - Constructor for class org.mule.module.launcher.nativelib.PerAppCopyNativeLibraryFinder
 
PerAppNativeLibraryFinder - Class in org.mule.module.launcher.nativelib
Finds native libraries in an application's lib folder
PerAppNativeLibraryFinder(File) - Constructor for class org.mule.module.launcher.nativelib.PerAppNativeLibraryFinder
 
perform(OpenExecution) - Method in class org.mule.module.jbpm.MuleSendActivity
 
performPoll() - Method in class org.mule.transport.AbstractPollingMessageReceiver
Check whether polling should take place on this instance.
performPostProcessingOnClose(boolean) - Method in class org.mule.transport.sftp.SftpFileArchiveInputStream
 
performPostProcessingOnClose(boolean) - Method in class org.mule.transport.sftp.SftpInputStream
 
PERSISTENT_DELIVERY_PROPERTY - Static variable in class org.mule.transport.jms.JmsConstants
 
PersistentObjectStorePartition<T extends Serializable> - Class in org.mule.util.store
 
PersistentObjectStorePartition.StoreValue<T> - Class in org.mule.util.store
 
PersistentObjectStorePartition.StoreValue(Serializable, T) - Constructor for class org.mule.util.store.PersistentObjectStorePartition.StoreValue
 
PersistentQueueTransactionContext - Class in org.mule.util.queue
LocalQueueTransactionContext implementation for a persistent queue.
PersistentQueueTransactionContext(LocalTxQueueTransactionJournal, QueueProvider) - Constructor for class org.mule.util.queue.PersistentQueueTransactionContext
 
persistentStores - Variable in class org.mule.routing.AbstractAggregator
 
PersistentXaTransactionContext - Class in org.mule.util.queue
Implementation of XaQueueTransactionContext for persistent queues using XA transactions
PersistentXaTransactionContext(XaTxQueueTransactionJournal, QueueProvider, Xid) - Constructor for class org.mule.util.queue.PersistentXaTransactionContext
 
Person - Class in org.mule.tck.testmodels.services
Person part of the PeopleService
Person() - Constructor for class org.mule.tck.testmodels.services.Person
 
Person(String, String) - Constructor for class org.mule.tck.testmodels.services.Person
 
PersonResponse - Class in org.mule.tck.testmodels.services
 
PersonResponse() - Constructor for class org.mule.tck.testmodels.services.PersonResponse
 
PersonResponse(Person) - Constructor for class org.mule.tck.testmodels.services.PersonResponse
 
PGPAuthentication - Class in org.mule.module.pgp
 
PGPAuthentication(String, Message) - Constructor for class org.mule.module.pgp.PGPAuthentication
 
PGPAuthentication(String, Message, MuleEvent) - Constructor for class org.mule.module.pgp.PGPAuthentication
 
PGPCryptInfo - Class in org.mule.module.pgp
 
PGPCryptInfo(PGPPublicKey, boolean) - Constructor for class org.mule.module.pgp.PGPCryptInfo
 
PGPKeyRing - Interface in org.mule.module.pgp
 
PGPKeyRingImpl - Class in org.mule.module.pgp
 
PGPKeyRingImpl() - Constructor for class org.mule.module.pgp.PGPKeyRingImpl
 
PGPMessages - Class in org.mule.module.pgp.i18n
 
PGPMessages() - Constructor for class org.mule.module.pgp.i18n.PGPMessages
 
PgpNamespaceHandler - Class in org.mule.module.pgp.config
 
PgpNamespaceHandler() - Constructor for class org.mule.module.pgp.config.PgpNamespaceHandler
 
PGPOutputMode - Enum in org.mule.module.pgp.config
 
pgpPublicKeyExpired() - Static method in class org.mule.module.pgp.i18n.PGPMessages
 
PGPSecurityContext - Class in org.mule.module.pgp
 
PGPSecurityContext(PGPAuthentication) - Constructor for class org.mule.module.pgp.PGPSecurityContext
 
PGPSecurityContextFactory - Class in org.mule.module.pgp
 
PGPSecurityContextFactory() - Constructor for class org.mule.module.pgp.PGPSecurityContextFactory
 
PGPSecurityFilter - Class in org.mule.module.pgp.filters
 
PGPSecurityFilter() - Constructor for class org.mule.module.pgp.filters.PGPSecurityFilter
 
PGPSecurityProvider - Class in org.mule.module.pgp
 
PGPSecurityProvider() - Constructor for class org.mule.module.pgp.PGPSecurityProvider
 
PHASE_NAME - Static variable in interface org.mule.api.lifecycle.Disposable
 
PHASE_NAME - Static variable in interface org.mule.api.lifecycle.Initialisable
 
PHASE_NAME - Static variable in interface org.mule.api.lifecycle.Startable
 
PHASE_NAME - Static variable in interface org.mule.api.lifecycle.Stoppable
 
PHASE_NAME - Static variable in class org.mule.lifecycle.phases.NotInLifecyclePhase
 
PHASE_NAME - Static variable in interface org.mule.service.Pausable
 
PHASE_NAME - Static variable in interface org.mule.service.Resumable
 
phaseConsumedMessage() - Method in class org.mule.execution.PhaseExecutionEngine.InternalPhaseExecutionEngine
 
phaseConsumedMessage() - Method in interface org.mule.execution.PhaseResultNotifier
This method must be called when the phase consume the message and the chain should not continue processing the message.
PhaseErrorLifecycleInterceptor - Class in org.mule.lifecycle
A LifecycleInterceptor which tracks the completion of the a phase so that if it fails to complete, the another phase is only applied on the target objects on which it could be successfully applied.
PhaseErrorLifecycleInterceptor(String, String, Class) - Constructor for class org.mule.lifecycle.PhaseErrorLifecycleInterceptor
Creates a new instance.
PhaseExecutionEngine - Class in org.mule.execution
This class process a message through a set of MessageProcessPhase using the message content and message processing context provided by MessageProcessTemplate and MessageProcessContext.
PhaseExecutionEngine(List<MessageProcessPhase>, SystemExceptionHandler, EndProcessPhase) - Constructor for class org.mule.execution.PhaseExecutionEngine
 
PhaseExecutionEngine.InternalPhaseExecutionEngine - Class in org.mule.execution
 
PhaseExecutionEngine.InternalPhaseExecutionEngine(MessageProcessTemplate, MessageProcessContext) - Constructor for class org.mule.execution.PhaseExecutionEngine.InternalPhaseExecutionEngine
 
phaseFailure(Exception) - Method in class org.mule.execution.PhaseExecutionEngine.InternalPhaseExecutionEngine
 
phaseFailure(Exception) - Method in interface org.mule.execution.PhaseResultNotifier
This message must be called when a phase execution throw an exception
phaseNames - Variable in class org.mule.lifecycle.AbstractLifecycleManager
 
PhaseResultNotifier - Interface in org.mule.execution
Notifier used by MessageProcessPhase in order to define the result of the phase execution
phases - Variable in class org.mule.lifecycle.RegistryLifecycleManager
 
phaseSuccessfully() - Method in class org.mule.execution.PhaseExecutionEngine.InternalPhaseExecutionEngine
 
phaseSuccessfully() - Method in interface org.mule.execution.PhaseResultNotifier
This method must be called when the phase complete successfully
PID_PATTERN_WINDOWS - Static variable in class org.mule.test.infrastructure.process.WindowsController
 
PID_WINDOWS - Static variable in class org.mule.test.infrastructure.process.WindowsController
 
Pipeline - Interface in org.mule.api.construct
A pipeline has an ordered list of MessageProcessor's that are invoked in order to processor new messages received from it's MessageSource
pipeline - Variable in class org.mule.construct.AbstractPipeline
 
PIPELINE_MESSAGE_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
PipelineMessageNotification - Class in org.mule.context.notification
PipelineMessageNotification is fired at key steps in the processing of Pipeline
PipelineMessageNotification(Pipeline, MuleEvent, int) - Constructor for class org.mule.context.notification.PipelineMessageNotification
 
PipelineMessageNotification(Pipeline, MuleEvent, int, MessagingException) - Constructor for class org.mule.context.notification.PipelineMessageNotification
 
PipelineMessageNotificationListener<T extends PipelineMessageNotification> - Interface in org.mule.api.context.notification
 
Placeholder - Class in org.mule.module.scripting
Workaround for javadoc generation (http://bugs.java.com/bugdatabase/view_bug.do?bug_id=4492654)
Placeholder() - Constructor for class org.mule.module.scripting.Placeholder
 
PlainTextDataSource - Class in org.mule.transport.email.transformers
 
PlainTextDataSource(String, String) - Constructor for class org.mule.transport.email.transformers.PlainTextDataSource
 
PLUGIN_PROPERTIES - Static variable in class org.mule.module.launcher.plugin.PluginDescriptor
 
PluginClassLoaderManager - Interface in org.mule.module.launcher
 
PluginClassLoaderManagerAware - Interface in org.mule.module.launcher
Enables PluginClassLoaderManager injection.
PluginClasspath - Class in org.mule.module.launcher.plugin
Represents a physical classpath of the plugin after it was unpacked/deployed.
PluginClasspath() - Constructor for class org.mule.module.launcher.plugin.PluginClasspath
 
PluginDescriptor - Class in org.mule.module.launcher.plugin
 
PluginDescriptor() - Constructor for class org.mule.module.launcher.plugin.PluginDescriptor
 
PluginDescriptorParser - Class in org.mule.module.launcher.plugin
 
PluginDescriptorParser(ApplicationDescriptor, File) - Constructor for class org.mule.module.launcher.plugin.PluginDescriptorParser
 
PLUGINS_FOLDER - Static variable in class org.mule.module.launcher.MuleFoldersUtil
 
pluralize(String) - Static method in class org.mule.module.extension.internal.util.NameUtils
Return the pluralized version of a word.
PLUS - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter represening the sum of two other counters
plusDays(int) - Method in interface org.mule.api.el.datetime.Date
 
plusDays(int) - Method in class org.mule.el.datetime.DateTime
 
plusHours(int) - Method in interface org.mule.api.el.datetime.Time
 
plusHours(int) - Method in class org.mule.el.datetime.DateTime
 
plusMilliSeconds(int) - Method in interface org.mule.api.el.datetime.Time
 
plusMilliSeconds(int) - Method in class org.mule.el.datetime.DateTime
 
plusMinutes(int) - Method in interface org.mule.api.el.datetime.Time
 
plusMinutes(int) - Method in class org.mule.el.datetime.DateTime
 
plusMonths(int) - Method in interface org.mule.api.el.datetime.Date
 
plusMonths(int) - Method in class org.mule.el.datetime.DateTime
 
plusSeconds(int) - Method in interface org.mule.api.el.datetime.Time
 
plusSeconds(int) - Method in class org.mule.el.datetime.DateTime
 
plusWeeks(int) - Method in interface org.mule.api.el.datetime.Date
 
plusWeeks(int) - Method in class org.mule.el.datetime.DateTime
 
plusYears(int) - Method in interface org.mule.api.el.datetime.Date
 
plusYears(int) - Method in class org.mule.el.datetime.DateTime
 
policyExhausted(Throwable) - Static method in class org.mule.retry.PolicyStatus
 
policyOk() - Static method in class org.mule.retry.PolicyStatus
 
PolicyStatus - Class in org.mule.retry
Indicates the current state of a RetryPolicy ok: The policy is active exhausted: The policy has run through the actions for the policy For example, a RetryPolicy may have a RetryCount - how many times the policy can be invoked.
PolicyStatus() - Constructor for class org.mule.retry.PolicyStatus
 
PolicyStatus(boolean, Throwable) - Constructor for class org.mule.retry.PolicyStatus
 
poll() - Method in class org.mule.transport.AbstractPollingMessageReceiver
 
poll() - Method in class org.mule.transport.ContinuousPollingReceiverWorker
 
poll() - Method in class org.mule.transport.email.RetrieveMessageReceiver
 
poll() - Method in class org.mule.transport.file.FileMessageReceiver
 
poll() - Method in class org.mule.transport.ftp.FtpMessageReceiver
 
poll() - Method in class org.mule.transport.http.PollingHttpMessageReceiver
 
poll() - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
The poll method is overriden from the TransactedPollingMessageReceiver
poll() - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
 
poll() - Method in class org.mule.transport.PollingReceiverWorker
 
poll() - Method in class org.mule.transport.rmi.RmiMessageReceiver
 
poll() - Method in class org.mule.transport.sftp.SftpMessageReceiver
 
poll() - Method in class org.mule.transport.stdio.StdioMessageReceiver
 
poll() - Method in class org.mule.transport.tcp.PollingTcpMessageReceiver
 
poll() - Method in class org.mule.transport.TransactedPollingMessageReceiver
 
poll() - Method in class org.mule.transport.xmpp.XmppPollingMessageReceiver
 
poll(long) - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
 
poll(long) - Method in class org.mule.util.queue.DefaultQueueStore
 
poll(QueueStore, long) - Method in class org.mule.util.queue.LocalTxQueueTransactionContext
 
poll(long) - Method in class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
Deprecated.
 
poll(long) - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
poll(long) - Method in interface org.mule.util.queue.objectstore.QueueInfoDelegate
Deprecated.
Poll the queue for its first member, and, if there is one, remove and return it
poll(QueueInfo, long) - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
poll(QueueStore, long) - Method in class org.mule.util.queue.PersistentQueueTransactionContext
 
poll(QueueStore, long) - Method in class org.mule.util.queue.PersistentXaTransactionContext
 
poll(long) - Method in interface org.mule.util.queue.Queue
 
poll(long) - Method in interface org.mule.util.queue.QueueStore
 
poll(long) - Method in interface org.mule.util.queue.QueueStoreDelegate
Poll the queue for its first member, and, if there is one, remove and return it
poll(QueueStore, long) - Method in interface org.mule.util.queue.QueueTransactionContext
 
poll(QueueStore, long) - Method in class org.mule.util.queue.QueueTypeTransactionContextAdapter
 
poll(long) - Method in class org.mule.util.queue.TransactionAwareQueueStore
 
poll(QueueStore, long) - Method in class org.mule.util.queue.TransientQueueTransactionContext
 
poll(QueueStore, long) - Method in class org.mule.util.queue.TransientXaTransactionAdapter
 
poll(QueueStore, long) - Method in class org.mule.util.queue.XaQueueTypeTransactionContextAdapter
 
POLL_CRON_SCHEDULER_JOB - Static variable in class org.mule.modules.schedulers.cron.CronScheduler
 
POLL_OVERRIDE_PROPERTY_NAME - Static variable in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
The InboundEndpoint property for poll that contains the MessageProcessorPollingOverride
PollEndpointJob - Class in org.mule.transport.quartz.jobs
 
PollEndpointJob(String) - Constructor for class org.mule.transport.quartz.jobs.PollEndpointJob
 
PollInboundEndpointFactoryBean - Class in org.mule.config.spring.factories
Spring FactoryBean used to create concrete instances of inbound endpoints
PollInboundEndpointFactoryBean(EndpointURIEndpointBuilder) - Constructor for class org.mule.config.spring.factories.PollInboundEndpointFactoryBean
 
PollInboundEndpointFactoryBean() - Constructor for class org.mule.config.spring.factories.PollInboundEndpointFactoryBean
 
POLLING_TRANSPORT - Static variable in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
The Polling transport name identifier.
PollingController - Interface in org.mule.transport
This determines whether polling is turned on or off
pollingFrequency - Variable in class org.mule.transport.jdbc.JdbcConnector
 
pollingFrequency - Variable in class org.mule.transport.rmi.RmiConnector
 
PollingHttpMessageReceiver - Class in org.mule.transport.http
Will poll an http URL and use the response as the input for a service request.
PollingHttpMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.http.PollingHttpMessageReceiver
 
PollingHttpsMessageReceiver - Class in org.mule.transport.http
 
PollingHttpsMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.http.PollingHttpsMessageReceiver
 
PollingMessageSourceFactoryBean - Class in org.mule.config.spring.factories
 
PollingMessageSourceFactoryBean() - Constructor for class org.mule.config.spring.factories.PollingMessageSourceFactoryBean
 
pollingReceiverCannotbeUsed() - Static method in class org.mule.transport.tcp.i18n.TcpMessages
 
PollingReceiverWorker - Class in org.mule.transport
 
PollingReceiverWorker(AbstractPollingMessageReceiver) - Constructor for class org.mule.transport.PollingReceiverWorker
 
PollingReceiverWorkerSchedule - Class in org.mule.transport
 
PollingReceiverWorkerSchedule(PollingReceiverWorker) - Constructor for class org.mule.transport.PollingReceiverWorkerSchedule
 
pollingReciverCannotbeUsed() - Static method in class org.mule.transport.http.i18n.HttpMessages
 
PollingTcpConnector - Class in org.mule.transport.tcp
PollingTcpMessageReceiver acts as a polling TCP connector.
PollingTcpConnector(MuleContext) - Constructor for class org.mule.transport.tcp.PollingTcpConnector
 
PollingTcpMessageReceiver - Class in org.mule.transport.tcp
PollingTcpMessageReceiver acts like a TCP client polling for new messages.
PollingTcpMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.tcp.PollingTcpMessageReceiver
 
pollMessagesOutsideTransactions() - Method in class org.mule.transport.TransactedPollingMessageReceiver
 
pollMessagesOutsideTransactions() - Method in class org.mule.transport.vm.VMMessageReceiver
 
pollOnPrimaryInstanceOnly() - Method in class org.mule.transport.AbstractPollingMessageReceiver
If this returns true for a transport, polling for that transport takes place only on the primary instance.
pollOnPrimaryInstanceOnly() - Method in class org.mule.transport.email.RetrieveMessageReceiver
 
pollOnPrimaryInstanceOnly() - Method in class org.mule.transport.file.FileMessageReceiver
 
pollOnPrimaryInstanceOnly() - Method in class org.mule.transport.ftp.FtpMessageReceiver
 
pollOnPrimaryInstanceOnly() - Method in class org.mule.transport.http.PollingHttpMessageReceiver
 
pollOnPrimaryInstanceOnly() - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
 
pollOnPrimaryInstanceOnly() - Method in class org.mule.transport.sftp.SftpMessageReceiver
 
pollOnPrimaryInstanceOnly() - Method in class org.mule.transport.xmpp.XmppPollingMessageReceiver
 
PollScheduler<T extends Runnable> - Class in org.mule.transport.polling.schedule
Abstract definition of a Scheduler for poll.
PollScheduler(String, T) - Constructor for class org.mule.transport.polling.schedule.PollScheduler
 
pollSourceReturnedNull(String) - Static method in class org.mule.config.i18n.CoreMessages
 
pollWith(MuleMessage) - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
 
pool - Variable in class org.mule.util.pool.CommonsPoolObjectPool
The pool
POOL_EXHAUSTED_ACTIONS - Static variable in interface org.mule.api.config.ThreadingProfile
 
POOL_EXHAUSTED_ACTIONS - Static variable in class org.mule.config.PoolingProfile
 
POOL_INITIALISATION_POLICIES - Static variable in class org.mule.config.PoolingProfile
 
PooledJavaComponent - Class in org.mule.component
PooledJavaComponent implements pooling.
PooledJavaComponent() - Constructor for class org.mule.component.PooledJavaComponent
 
PooledJavaComponent(ObjectFactory) - Constructor for class org.mule.component.PooledJavaComponent
 
PooledJavaComponent(ObjectFactory, PoolingProfile) - Constructor for class org.mule.component.PooledJavaComponent
 
PooledJavaComponent(ObjectFactory, PoolingProfile, EntryPointResolverSet, List<InterfaceBinding>) - Constructor for class org.mule.component.PooledJavaComponent
 
PooledJavaComponent.LifeCycleAdapterFactory - Class in org.mule.component
LifeCycleAdaptorFactory wraps the Component' s ObjectFactory.
PooledJavaComponent.LifeCycleAdapterFactory() - Constructor for class org.mule.component.PooledJavaComponent.LifeCycleAdapterFactory
 
poolExhaustedAction - Variable in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
poolingProfile - Variable in class org.mule.component.PooledJavaComponent
 
PoolingProfile - Class in org.mule.config
PoolingProfile is a configuration object used to define the object pooling parameters for the service it is associated with.
PoolingProfile() - Constructor for class org.mule.config.PoolingProfile
 
PoolingProfile(PoolingProfile) - Constructor for class org.mule.config.PoolingProfile
 
PoolingProfile(int, int, long, int, int) - Constructor for class org.mule.config.PoolingProfile
 
poolingProfile - Variable in class org.mule.model.seda.SedaModel
Deprecated.
the pooling configuration used when initialising the service described by this descriptor.
poolingProfile - Variable in class org.mule.util.pool.CommonsPoolObjectPool
The pooling profile used to configure and initialise pool
PoolingProfileBeanDefinitionParser - Class in org.mule.module.db.internal.config.domain.connection
 
PoolingProfileBeanDefinitionParser() - Constructor for class org.mule.module.db.internal.config.domain.connection.PoolingProfileBeanDefinitionParser
 
PoolingProfileDefinitionParser - Class in org.mule.config.spring.parsers.specific
This parser is responsible for processing the configuration elements.
PoolingProfileDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.PoolingProfileDefinitionParser
 
pop() - Method in class org.mule.context.notification.DefaultFlowCallStack
Removes the top-most element from this stack.
POP3 - Static variable in class org.mule.transport.email.Pop3Connector
 
Pop3Connector - Class in org.mule.transport.email
Pop3Connector is used to connect and receive mail from a POP3 mailbox.
Pop3Connector(MuleContext) - Constructor for class org.mule.transport.email.Pop3Connector
 
Pop3NamespaceHandler - Class in org.mule.transport.email.config
Registers a Bean Definition Parser for handling elements.
Pop3NamespaceHandler() - Constructor for class org.mule.transport.email.config.Pop3NamespaceHandler
 
POP3S - Static variable in class org.mule.transport.email.Pop3sConnector
 
Pop3sConnector - Class in org.mule.transport.email
Creates a secure connection to a POP3 mailbox
Pop3sConnector(MuleContext) - Constructor for class org.mule.transport.email.Pop3sConnector
 
Pop3sNamespaceHandler - Class in org.mule.transport.email.config
Registers a Bean Definition Parser for handling elements.
Pop3sNamespaceHandler() - Constructor for class org.mule.transport.email.config.Pop3sNamespaceHandler
 
Pop3sSocketFactory - Class in org.mule.transport.email
A socket factor that reads "indirect" configuration (see TlsConfiguration) for POP3S from System properties.
Pop3sSocketFactory() - Constructor for class org.mule.transport.email.Pop3sSocketFactory
 
populate(Object, Map) - Static method in class org.mule.util.BeanUtils
This will overlay a map of properties on a bean.
populateBindings(Bindings) - Method in class org.mule.module.scripting.builders.ScriptConfigurationBuilder
Deprecated.
 
populateBindings(Bindings, Object) - Method in class org.mule.module.scripting.component.Scriptable
 
populateBindings(Bindings, MuleMessage) - Method in class org.mule.module.scripting.component.Scriptable
Deprecated.
populateBindings(Bindings, MuleEvent) - Method in class org.mule.module.scripting.component.Scriptable
 
populateContext(ServletContextHandler) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
populateDefaultBindings(Bindings) - Method in class org.mule.module.scripting.component.Scriptable
 
populateHeaders(HttpRequest, RequestBuilder) - Method in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
populateM2Repo(String) - Method in class org.mule.test.infrastructure.process.MuleUtils
 
populateMessageBindings(Bindings, MuleMessage) - Method in class org.mule.module.scripting.component.Scriptable
 
populateProcessVariables(MuleEvent, Map, PropertyScope) - Method in class org.mule.module.bpm.Process
 
populatePropertyBindings(Bindings) - Method in class org.mule.module.scripting.component.Scriptable
 
populatePropertyBindings(Bindings, MuleMessage) - Method in class org.mule.module.scripting.component.Scriptable
Deprecated.
populatePropertyBindings(Bindings, MuleEvent) - Method in class org.mule.module.scripting.component.Scriptable
 
populateProps(Map<String, Object>, MuleMessage, PropertyScope) - Static method in class org.mule.transport.soap.axis.extras.AxisCleanAndAddProperties
 
populateTestData(Context) - Method in class org.mule.tck.jndi.TestContextFactory
 
populateWithoutFail(Object, Map, boolean) - Static method in class org.mule.util.BeanUtils
Exception safe version of BeanUtils.populate()
PORT - Static variable in class org.mule.endpoint.URIBuilder
 
port - Variable in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
port - Variable in class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
port - Variable in class org.mule.transport.jdbc.config.OracleDataSourceFactoryBean
 
PORT_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
PORT_PROPERTY - Static variable in class org.mule.transport.udp.UdpConnector
 
portNotFound(String) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
post(String, String) - Method in interface org.mule.security.oauth.util.HttpUtil
It posts the given body to a url and returns the response body as a string
post(String, String) - Method in class org.mule.security.oauth.util.HttpUtilImpl
It posts the given body to a url and returns the response body as a string
postAuth(OAuth2Adapter, String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Calls the org.mule.security.oauth.OAuth2Connector.postAuth() on the adapter.
postAuth() - Method in interface org.mule.security.oauth.OAuth2Connector
 
postAuth(OAuth2Adapter, String) - Method in interface org.mule.security.oauth.OAuth2Manager
Calls the org.mule.security.oauth.OAuth2Connector.postAuth() on the adapter.
postDeregister() - Method in class org.mule.module.management.agent.ClassloaderSwitchingMBeanWrapper
 
postDeregister() - Method in class org.mule.module.management.mbean.FlowConstructService
 
postDeregister() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
postDeregister() - Method in class org.mule.module.management.mbean.ServiceService
 
postDeregister() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
postDeserialisationInit(Object) - Method in class org.mule.module.xml.transformer.XmlToObject
 
PostgresqlDataSourceFactoryBean - Class in org.mule.transport.jdbc.config
 
PostgresqlDataSourceFactoryBean() - Constructor for class org.mule.transport.jdbc.config.PostgresqlDataSourceFactoryBean
 
postInitialize(T) - Method in class org.mule.serialization.internal.AbstractObjectSerializer
 
postInitialize(T) - Method in class org.mule.serialization.internal.JavaObjectSerializer
 
postLatchAwait(String) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
postLatchAwait(String) - Method in class org.mule.service.processor.ServiceAsyncRequestReplyRequestor
Deprecated.
 
postObjectRegistrationActions(Object) - Method in class org.mule.registry.MuleRegistryHelper
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.AbstractChildDefinitionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.AbstractHierarchicalDefinitionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
Hook method that derived classes can implement to inspect/change a bean definition after parsing is complete.
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.collection.ChildListEntryDefinitionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.generic.NamedDefinitionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.generic.OptionalChildDefinitionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.generic.ParentDefinitionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.generic.TextDefinitionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in interface org.mule.config.spring.parsers.PostProcessor
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.processors.AbstractChildElementIterator
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.processors.AddAttribute
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.processors.ConstructorReference
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.processors.ExtendTarget
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.specific.ExpressionComponentDefintionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.specific.GlobalFunctionsDefintionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.specific.GlobalPropertyDefinitionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.specific.MessageFilterDefinitionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.config.spring.parsers.specific.ObjectFactoryWrapper
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.module.management.config.JmxAgentDefinitionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.module.scripting.config.ScriptDefinitionParser
 
postProcess(ParserContext, BeanAssembler, Element) - Method in class org.mule.module.xml.config.XsltTextDefinitionParser
 
postProcess(FTPClient, FTPFile, MuleMessage) - Method in class org.mule.transport.ftp.FtpMessageReceiver
 
postProcess(FTPClient, FTPFile, MuleMessage) - Method in class org.mule.transport.ftp.FtpMessageRequester
 
postProcess() - Method in class org.mule.transport.sftp.SftpFileArchiveInputStream
 
postProcess() - Method in class org.mule.transport.sftp.SftpInputStream
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.ExpressionEvaluatorPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.GlobalNamePostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.MuleContextPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.NotificationListenersPostProcessor
Deprecated.
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.processors.AnnotatedTransformerObjectPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.processors.DecoratingFlowAnnotationsBeanProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.processors.DiscardedOptionalBeanPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.processors.ExpressionEnricherPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.processors.LifecycleStatePostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.processors.MuleObjectNameProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.processors.NotificationListenerPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.processors.PostRegistrationActionsPostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.mule.config.spring.processors.TransformerAnnotatedBeanProcessor
 
postProcessAfterInstantiation(Object, String) - Method in class org.mule.config.spring.processors.DiscardedOptionalBeanPostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.mule.config.spring.processors.ParentContextPropertyPlaceholderProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.ExpressionEvaluatorPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.GlobalNamePostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.MuleContextPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.NotificationListenersPostProcessor
Deprecated.
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.processors.AnnotatedTransformerObjectPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.processors.DecoratingFlowAnnotationsBeanProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.processors.DiscardedOptionalBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.processors.ExpressionEnricherPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.processors.LifecycleStatePostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.processors.MuleObjectNameProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.processors.NotificationListenerPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.processors.PostRegistrationActionsPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.mule.config.spring.processors.TransformerAnnotatedBeanProcessor
 
postProcessBeforeInstantiation(Class<?>, String) - Method in class org.mule.config.spring.processors.DiscardedOptionalBeanPostProcessor
 
postProcessMessage(MuleMessage) - Method in class org.mule.transport.AbstractReceiverWorker
If a result is returned back this method will get called before the message is added to te list of results (these are later passed to AbstractReceiverWorker.handleResults(java.util.List))
PostProcessor - Interface in org.mule.config.spring.parsers
This interface allows post-processing of the bean assmebler to be injected into definition parsers
postProcessPropertyValues(PropertyValues, PropertyDescriptor[], Object, String) - Method in class org.mule.config.spring.processors.DiscardedOptionalBeanPostProcessor
 
postProcessRouting(MuleEvent) - Method in class org.mule.transport.polling.MessageProcessorPollingInterceptor
Post process the event after it was routed to the rest of the flow.
postProcessRouting(MuleEvent) - Method in class org.mule.transport.polling.watermark.selector.SelectorWatermarkPollingInterceptor
 
postProcessRouting(MuleEvent) - Method in class org.mule.transport.polling.watermark.WatermarkPollingInterceptor
Watermark post processing saves the flow variable to the object store
postRedeploy(Artifact) - Method in interface org.mule.module.launcher.ArtifactDeploymentTemplate
Callback to be invoked just after redeploying an artifact.
postRedeploy(Artifact) - Method in class org.mule.module.launcher.DomainDeploymentTemplate
Deploys applications that were undeployed when DomainDeploymentTemplate.preRedeploy(Artifact) was called..
postRegister(Boolean) - Method in class org.mule.module.management.agent.ClassloaderSwitchingMBeanWrapper
 
postRegister(Boolean) - Method in class org.mule.module.management.mbean.ApplicationService
 
postRegister(Boolean) - Method in class org.mule.module.management.mbean.FlowConstructService
 
postRegister(Boolean) - Method in class org.mule.module.management.mbean.FlowConstructStats
 
postRegister(Boolean) - Method in class org.mule.module.management.mbean.ServiceService
 
postRegister(Boolean) - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
PostRegistrationActionsPostProcessor - Class in org.mule.config.spring.processors
A BeanPostProcessor which invokes MuleRegistryHelper.postObjectRegistrationActions(Object) after spring finishes initialization over each object, only as long as the PostRegistrationActionsPostProcessor.applicationContext is already running
PostRegistrationActionsPostProcessor(ConfigurableApplicationContext, MuleRegistryHelper) - Constructor for class org.mule.config.spring.processors.PostRegistrationActionsPostProcessor
 
PRAGMA - Static variable in class org.mule.module.http.api.HttpHeaders.Names
PRE_INIT_PROCESSORS_BYPASS_FLAG - Static variable in interface org.mule.api.registry.MuleRegistry
Determines whether pre-init processors should get executed on an object added to the registry.
PreAuthenticatedAuthenticationProvider - Class in org.mule.module.spring.security
Provides a pre authenticated authentication
PreAuthenticatedAuthenticationProvider() - Constructor for class org.mule.module.spring.security.PreAuthenticatedAuthenticationProvider
 
Preconditions - Class in org.mule.util
Utility class to validate Preconditions
Preconditions() - Constructor for class org.mule.util.Preconditions
 
preDeregister() - Method in class org.mule.module.management.agent.ClassloaderSwitchingMBeanWrapper
 
preDeregister() - Method in class org.mule.module.management.mbean.FlowConstructService
 
preDeregister() - Method in class org.mule.module.management.mbean.FlowConstructStats
 
preDeregister() - Method in class org.mule.module.management.mbean.ServiceService
 
preDeregister() - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
Predicate<T> - Interface in org.mule.util
Predicate class to match objects in a query.
Preferred - Annotation Type in org.mule.config
Provides a means to give preference to an SPI implementation over others.
PREFERRED_AUTHENTICATION_METHODS - Static variable in class org.mule.transport.sftp.SftpClient
 
PREFERRED_ENCODING - Static variable in class org.mule.util.Base64
Preferred encoding.
PreferredComparator - Class in org.mule.config
 
PreferredComparator() - Constructor for class org.mule.config.PreferredComparator
 
PreferredObjectSelector<T> - Class in org.mule.config
Selects a preferred object from a collection of instances of the same type based on the weight of the Preferred annotation.
PreferredObjectSelector() - Constructor for class org.mule.config.PreferredObjectSelector
 
PREFETCH_DEFAULT - Static variable in class org.mule.transport.jms.JmsConnector
 
PREFIX - Static variable in class org.mule.config.spring.parsers.generic.AutoIdUtils
 
PrefixValueMap - Class in org.mule.config.spring.parsers.assembly.configuration
 
PrefixValueMap(String) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.PrefixValueMap
 
PreInitProcessor - Interface in org.mule.api.registry
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)
preInstantiateSingletons() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
prepare(Message) - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
Prepare the message for writing.
prepare(Message) - Method in class org.mule.module.cxf.transport.MuleUniversalDestination.ResponseConduit
 
prepare(Xid) - Method in class org.mule.transport.jms.xa.XAResourceWrapper
 
prepare(Xid) - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
prepare(Xid) - Method in class org.mule.util.queue.TransactionalQueueSession
 
prepare(Xid) - Method in class org.mule.util.xa.DefaultXASession
 
prepareBeanFactory(ConfigurableListableBeanFactory) - Method in class org.mule.config.spring.MuleArtifactContext
 
prepareCall(String) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
prepareCall(String, int, int) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
prepareCall(String, int, int, int) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
prepareCall(String) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
prepareCall(String, int, int) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
prepareCall(String, int, int, int) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
prepareCall(String) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
prepareCall(String, int, int) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
prepareCall(String, int, int, int) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
PreparedBulkQueryLogger - Interface in org.mule.module.db.internal.domain.logger
Logs a prepared bulk query
PreparedBulkUpdateMessageProcessor - Class in org.mule.module.db.internal.processor
Executes an update query in bulk mode on a database *

An update query can be parametrized update, insert or delete query or a stored procedure taking input parameters only and returning an update count.

PreparedBulkUpdateMessageProcessor(DbConfigResolver, QueryResolver, BulkQueryExecutorFactory, TransactionalAction, List<QueryType>, ParamValueResolver) - Constructor for class org.mule.module.db.internal.processor.PreparedBulkUpdateMessageProcessor
 
PreparedBulkUpdateMetadataProvider - Class in org.mule.module.db.internal.metadata
Provides metadata for prepared bulk update queries
PreparedBulkUpdateMetadataProvider(DbConfigResolver, Query, AutoGeneratedKeyStrategy) - Constructor for class org.mule.module.db.internal.metadata.PreparedBulkUpdateMetadataProvider
 
PreparedBulkUpdateProcessorBeanDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
PreparedBulkUpdateProcessorBeanDefinitionParser(List<QueryType>) - Constructor for class org.mule.module.db.internal.config.processor.PreparedBulkUpdateProcessorBeanDefinitionParser
 
prepareFile(FTPClient, FTPFile) - Method in class org.mule.transport.ftp.FtpMessageRequester
 
prepareQuery(Statement, Query) - Method in class org.mule.module.db.internal.domain.executor.AbstractSingleQueryExecutor
 
prepareRouting(MuleEvent, MuleEvent) - Method in class org.mule.transport.polling.MessageProcessorPollingInterceptor
Called after the polling message processor processes the event, but before an event is routed to the rest of the flow.
prepareRouting(MuleEvent, MuleEvent) - Method in class org.mule.transport.polling.watermark.selector.SelectorWatermarkPollingInterceptor
Watermark route preparation carries the value from the source event to the flow event
prepareRouting(MuleEvent, MuleEvent) - Method in class org.mule.transport.polling.watermark.WatermarkPollingInterceptor
Watermark route preparation carries the value from the source event to the flow event
prepareSourceEvent(MuleEvent) - Method in class org.mule.transport.polling.MessageProcessorPollingInterceptor
Called before sending the event to the message processor that will do poll for events.
prepareSourceEvent(MuleEvent) - Method in class org.mule.transport.polling.watermark.WatermarkPollingInterceptor
Watermark source preprocessing puts the watermark value into a flow variable
prepareStatement(DbConnection, QueryTemplate) - Method in interface org.mule.module.db.internal.domain.autogeneratedkey.AutoGeneratedKeyStrategy
Prepares a statement in order to return auto generated keys
prepareStatement(DbConnection, QueryTemplate) - Method in class org.mule.module.db.internal.domain.autogeneratedkey.ColumnIndexAutoGeneratedKeyStrategy
 
prepareStatement(DbConnection, QueryTemplate) - Method in class org.mule.module.db.internal.domain.autogeneratedkey.ColumnNameAutoGeneratedKeyStrategy
 
prepareStatement(DbConnection, QueryTemplate) - Method in class org.mule.module.db.internal.domain.autogeneratedkey.DefaultAutoGeneratedKeyStrategy
 
prepareStatement(DbConnection, QueryTemplate) - Method in class org.mule.module.db.internal.domain.autogeneratedkey.NoAutoGeneratedKeyStrategy
 
prepareStatement(String) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
prepareStatement(String, int, int) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
prepareStatement(String, int, int, int) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
prepareStatement(String, int) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
prepareStatement(String, int[]) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
prepareStatement(String, String[]) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
prepareStatement(String) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
prepareStatement(String, int) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
prepareStatement(String, int, int) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
prepareStatement(String, int, int, int) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
prepareStatement(String, int[]) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
prepareStatement(String, String[]) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
prepareStatement(Connection, String) - Method in class org.mule.transport.jdbc.ExtendedQueryRunner
 
prepareStatement(String) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
prepareStatement(String, int) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
prepareStatement(String, int, int) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
prepareStatement(String, int, int, int) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
prepareStatement(String, int[]) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
prepareStatement(String, String[]) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
prepareToBuildEndpoint() - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
prepareTransaction(AbstractTransactionContext) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
prepareTransaction(T) - Method in class org.mule.util.xa.AbstractXAResourceManager
 
prepareWinFilename(String) - Static method in class org.mule.util.FileUtils
 
prependMessage(String) - Method in exception org.mule.api.MuleException
 
preProcess(Element) - Method in class org.mule.config.spring.parsers.AbstractHierarchicalDefinitionParser
 
preProcess(Element) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
Hook method that derived classes can implement to modify internal state before processing.
preProcess(Element) - Method in class org.mule.config.spring.parsers.collection.OrphanMapDefinitionParser
 
preProcess(Element) - Method in class org.mule.config.spring.parsers.generic.ChildDefinitionParser
 
preProcess(Element) - Method in class org.mule.config.spring.parsers.generic.OrphanDefinitionParser
 
preProcess(Element) - Method in class org.mule.config.spring.parsers.generic.WrappingChildDefinitionParser
 
preProcess(PropertyConfiguration, Element) - Method in interface org.mule.config.spring.parsers.PreProcessor
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.config.spring.parsers.processors.AddAttribute
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.config.spring.parsers.processors.AttributeConcatenation
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.config.spring.parsers.processors.BlockAttribute
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.config.spring.parsers.processors.CheckExclusiveAttribute
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.config.spring.parsers.processors.CheckExclusiveAttributeAndText
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.config.spring.parsers.processors.CheckExclusiveAttributes
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.config.spring.parsers.processors.CheckExclusiveAttributesAndChildren
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.config.spring.parsers.processors.CheckRequiredAttributes
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.config.spring.parsers.processors.CheckRequiredAttributesWhenNoChildren
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.config.spring.parsers.processors.ProvideDefaultName
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.config.spring.parsers.processors.ProvideDefaultNameFromElement
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.config.spring.parsers.processors.RequireAttribute
 
preProcess(Element) - Method in class org.mule.config.spring.parsers.specific.endpoint.EndpointRefParser
 
preProcess(Element) - Method in class org.mule.config.spring.parsers.specific.FilterRefDefinitionParser
 
preProcess(Element) - Method in class org.mule.config.spring.parsers.specific.properties.SimplePropertyDefinitionParser
 
preProcess(Element) - Method in class org.mule.config.spring.parsers.specific.RetryPolicyDefinitionParser
 
preProcess(Element) - Method in class org.mule.config.spring.parsers.specific.SimpleComponentDefinitionParser
 
preProcess(MessageProcessor) - Method in class org.mule.processor.BlockingProcessorExecutor
 
preProcess(MessageProcessor) - Method in class org.mule.processor.NonBlockingProcessorExecutor
 
preProcess(PropertyConfiguration, Element) - Method in class org.mule.transport.jdbc.config.CheckDatabaseOrUrl
 
preprocessEndpointData(AnnotatedEndpointData) - Method in class org.mule.config.endpoint.AnnotatedEndpointHelper
This method can be overridden to process endpoints before they get built.
preProcessMessage(Object) - Method in class org.mule.transport.AbstractReceiverWorker
Before a message is passed into Mule this callback is called and can be used by the worker to inspect the message before it gets sent to Mule
preProcessMessage(Message, Session) - Method in class org.mule.transport.jms.JmsConnector
This method may be overridden in order to apply pre-processing to the message as soon as it arrives.
preProcessMessage(Object) - Method in class org.mule.transport.jms.JmsMessageReceiver.JmsWorker
Deprecated.
 
preProcessMessage(Object) - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.JmsWorker
 
PreProcessor - Interface in org.mule.config.spring.parsers
This interface allows pre-processing of the element.
preprocessUri(String) - Method in class org.mule.endpoint.MuleEndpointURI
 
preRedeploy(Artifact) - Method in interface org.mule.module.launcher.ArtifactDeploymentTemplate
Callback to be invoked just before redeploying an artifact.
preRedeploy(Artifact) - Method in class org.mule.module.launcher.DomainDeploymentTemplate
Undeploys all applications that use this domain.
preRegister(MBeanServer, ObjectName) - Method in class org.mule.module.management.agent.ClassloaderSwitchingMBeanWrapper
 
preRegister(MBeanServer, ObjectName) - Method in class org.mule.module.management.mbean.FlowConstructService
 
preRegister(MBeanServer, ObjectName) - Method in class org.mule.module.management.mbean.FlowConstructStats
 
preRegister(MBeanServer, ObjectName) - Method in class org.mule.module.management.mbean.ServiceService
 
preRegister(MBeanServer, ObjectName) - Method in class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
preRouteMessage(MuleMessage) - Method in class org.mule.transport.http.OldHttpMessageReceiver.HttpWorker
 
preRouteMuleMessage(MuleMessage) - Method in class org.mule.transport.AbstractReceiverWorker
This callback is called before a message is routed into Mule and can be used by the worker to set connection specific properties to message before it gets routed
preRouteMuleMessage(MuleMessage) - Method in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
preTrackArtifact(T) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
preTransformMessage(MuleMessage) - Method in class org.mule.transport.jms.JmsMessageDispatcher
This method is called before the current message is transformed.
PrettyLoggingFeature - Class in org.mule.module.cxf.feature
Same as the standard CXF LoggingFeature, but with pretty-printed XML for the message payload.
PrettyLoggingFeature() - Constructor for class org.mule.module.cxf.feature.PrettyLoggingFeature
 
PrettyLoggingInInterceptor - Class in org.mule.module.cxf.feature
Takes the log output from the standard CXF LoggingInterceptor, disassembles it, pretty-prints the XML payload, then puts it all back together again.
PrettyLoggingInInterceptor() - Constructor for class org.mule.module.cxf.feature.PrettyLoggingInInterceptor
 
PrettyLoggingInInterceptor(String) - Constructor for class org.mule.module.cxf.feature.PrettyLoggingInInterceptor
 
PrettyLoggingInInterceptor(int) - Constructor for class org.mule.module.cxf.feature.PrettyLoggingInInterceptor
 
PrettyLoggingInInterceptor(PrintWriter) - Constructor for class org.mule.module.cxf.feature.PrettyLoggingInInterceptor
 
PrettyLoggingOutInterceptor - Class in org.mule.module.cxf.feature
Takes the log output from the standard CXF LoggingInterceptor, disassembles it, pretty-prints the XML payload, then puts it all back together again.
PrettyLoggingOutInterceptor() - Constructor for class org.mule.module.cxf.feature.PrettyLoggingOutInterceptor
 
PrettyLoggingOutInterceptor(String) - Constructor for class org.mule.module.cxf.feature.PrettyLoggingOutInterceptor
 
PrettyLoggingOutInterceptor(int) - Constructor for class org.mule.module.cxf.feature.PrettyLoggingOutInterceptor
 
PrettyLoggingOutInterceptor(PrintWriter) - Constructor for class org.mule.module.cxf.feature.PrettyLoggingOutInterceptor
 
previous() - Method in class org.mule.module.launcher.util.ObservableList.ObservableListIterator
 
previousIndex() - Method in class org.mule.module.launcher.util.ObservableList.ObservableListIterator
 
PRIMARY_CLUSTER_NODE_SELECTED - Static variable in class org.mule.context.notification.ClusterNodeNotification
 
PrimaryNodeLifecycleNotificationListener - Class in org.mule.lifecycle
This class will start an Startable mule object that must only be started in the primary node.
PrimaryNodeLifecycleNotificationListener(Startable, MuleContext) - Constructor for class org.mule.lifecycle.PrimaryNodeLifecycleNotificationListener
 
primTransform(InputStream) - Method in class org.mule.transformer.encryption.AbstractEncryptionTransformer
 
primTransform(InputStream) - Method in class org.mule.transformer.encryption.DecryptionTransformer
 
primTransform(InputStream) - Method in class org.mule.transformer.encryption.EncryptionTransformer
 
print(String) - Method in class org.apache.commons.httpclient.HttpConnection
Deprecated.
Use HttpConnection.print(String, String) Writes the specified String (as bytes) to the output stream.
print(String, String) - Method in class org.apache.commons.httpclient.HttpConnection
Writes the specified String (as bytes) to the output stream.
print(Object) - Method in class org.mule.management.stats.printers.AbstractTablePrinter
 
print(Collection) - Method in class org.mule.management.stats.printers.AbstractTablePrinter
 
print(String) - Method in class org.mule.management.stats.printers.AbstractTablePrinter
 
print(Collection) - Method in class org.mule.management.stats.printers.CSVPrinter
 
print(Collection) - Method in class org.mule.management.stats.printers.HtmlTablePrinter
 
print(Collection) - Method in class org.mule.management.stats.printers.SimplePrinter
 
print(Collection) - Method in class org.mule.management.stats.printers.XMLPrinter
 
print(String) - Method in class org.mule.transport.http.ResponseWriter
 
print(int) - Method in class org.mule.transport.http.ResponseWriter
 
print() - Method in class org.mule.util.ExceptionHolder
 
printCSVSummary() - Method in class org.mule.module.management.mbean.StatisticsService
 
printCSVSummary() - Method in interface org.mule.module.management.mbean.StatisticsServiceMBean
 
printHtmlSummary() - Method in class org.mule.module.management.mbean.StatisticsService
 
printHtmlSummary() - Method in interface org.mule.module.management.mbean.StatisticsServiceMBean
 
printLine(String) - Method in class org.apache.commons.httpclient.HttpConnection
Deprecated.
Use HttpConnection.printLine(String, String) Writes the specified String (as bytes), followed by "\r\n".getBytes() to the output stream.
printLine(String, String) - Method in class org.apache.commons.httpclient.HttpConnection
Writes the specified String (as bytes), followed by "\r\n".getBytes() to the output stream.
printLine() - Method in class org.apache.commons.httpclient.HttpConnection
Writes "\r\n".getBytes() to the output stream.
println(Object) - Method in class org.mule.management.stats.printers.AbstractTablePrinter
 
println(String) - Method in class org.mule.management.stats.printers.AbstractTablePrinter
 
println(String, int) - Method in class org.mule.management.stats.printers.XMLPrinter
 
println(int) - Method in class org.mule.transport.http.ResponseWriter
 
println(String) - Method in class org.mule.transport.http.ResponseWriter
 
println() - Method in class org.mule.transport.http.ResponseWriter
 
printProviderStatsXml(String, int) - Method in class org.mule.management.stats.printers.XMLPrinter
 
printXmlSummary() - Method in class org.mule.module.management.mbean.StatisticsService
 
printXmlSummary() - Method in interface org.mule.module.management.mbean.StatisticsServiceMBean
 
PRIORITY_PROPERTY - Static variable in class org.mule.transport.jms.JmsConstants
 
PriorityWeightingConverterFilter - Class in org.mule.transformer.graph
Filters a list of Converter returning a new list containing only the converters with the highest priority weighting.
PriorityWeightingConverterFilter() - Constructor for class org.mule.transformer.graph.PriorityWeightingConverterFilter
 
PRIVATE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
process(MuleEvent, MessageProcessor) - Method in interface org.mule.api.cache.CachingStrategy
Processes a MuleEvent using a caching schema.
process() - Method in interface org.mule.api.callback.SourceCallback
Dispatch the current event to the flow
process(Object) - Method in interface org.mule.api.callback.SourceCallback
Dispatch message to the flow
process(Object, Map<String, Object>) - Method in interface org.mule.api.callback.SourceCallback
Dispatch message to the flow with properties
process(OutboundEndpoint, Object, Map<String, Object>) - Method in interface org.mule.api.client.LocalMuleClient
Sends an event synchronously to a endpointUri via a Mule server and a resulting message is returned.
process(OutboundEndpoint, MuleMessage) - Method in interface org.mule.api.client.LocalMuleClient
Sends an event synchronously to a endpointUri via a Mule server and a resulting message is returned.
process(String, MessageExchangePattern, Object, Map<String, Object>) - Method in interface org.mule.api.client.MuleClient
Processes a message with an outbound endpoint using the specified MessageExchangePattern
process(String, MessageExchangePattern, MuleMessage) - Method in interface org.mule.api.client.MuleClient
Processes a messsage with an outbound endpoint using the specified MessageExchangePattern
process(MuleEvent) - Method in interface org.mule.api.component.InterfaceBinding
This method is responsible for routing the Message via the MuleSession.
process() - Method in interface org.mule.api.execution.ExecutionCallback
 
process(MuleEvent) - Method in interface org.mule.api.interceptor.Interceptor
Invoked when the component should be called.
process(Object, Map<String, Object>) - Method in interface org.mule.api.NestedProcessor
Dispatch message to the processor chain
process(Object) - Method in interface org.mule.api.NestedProcessor
Dispatch message to the processor chain
process() - Method in interface org.mule.api.NestedProcessor
Dispatch original message to the processor chain
process(MuleEvent) - Method in class org.mule.api.processor.LoggerMessageProcessor
 
process(MuleEvent) - Method in interface org.mule.api.processor.MessageProcessor
Invokes the MessageProcessor.
process(Object) - Method in interface org.mule.api.registry.ObjectProcessor
Deprecated.
 
process(MuleEvent) - Method in interface org.mule.api.routing.OutboundRouterCatchAllStrategy
Deprecated.
This method will be invoked when an event is received or being sent where the criteria of the router(s) do not match the current event.
process(Object, Scheduler) - Method in interface org.mule.api.schedule.SchedulerFactoryPostProcessor
Process based on a Scheduler instance after the SchedulerFactory creates it.
process(OutboundEndpoint, Object, Map<String, Object>) - Method in class org.mule.client.DefaultLocalMuleClient
 
process(OutboundEndpoint, MuleMessage) - Method in class org.mule.client.DefaultLocalMuleClient
 
process(String, MessageExchangePattern, Object, Map<String, Object>) - Method in class org.mule.client.DefaultLocalMuleClient
 
process(String, MessageExchangePattern, MuleMessage) - Method in class org.mule.client.DefaultLocalMuleClient
 
process(MuleEvent) - Method in class org.mule.component.AbstractComponent
 
process(MuleEvent) - Method in class org.mule.component.DefaultInterfaceBinding
 
process(Object) - Method in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
process(Object) - Method in class org.mule.config.processors.LookupInjectionProcessor
Deprecated.
 
process(Object) - Method in class org.mule.config.transformer.AnnotatedTransformerObjectProcessor
Deprecated.
 
process(MuleEvent) - Method in class org.mule.construct.DynamicPipelineMessageProcessor
 
process(MuleEvent) - Method in class org.mule.construct.Flow
 
process(MuleEvent) - Method in class org.mule.construct.processor.FlowConstructStatisticsMessageProcessor
 
process(MuleEvent) - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
This final process implementation shields actual processing into abstract method DevkitBasedMessageProcessor.doProcess(org.mule.api.MuleEvent).
process(MuleEvent) - Method in class org.mule.el.ExpressionLanguageComponent
 
process(MuleEvent) - Method in class org.mule.endpoint.DefaultOutboundEndpoint
 
process(MuleEvent) - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
process(MuleEvent) - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
process(MuleEvent) - Method in class org.mule.endpoint.inbound.InboundEndpointMimeTypeCheckingMessageProcessor
 
process(MuleEvent) - Method in class org.mule.endpoint.inbound.InboundEndpointPropertyMessageProcessor
 
process(MuleEvent) - Method in class org.mule.endpoint.inbound.InboundExceptionDetailsMessageProcessor
 
process(MuleEvent) - Method in class org.mule.endpoint.inbound.InboundLoggingMessageProcessor
 
process(MuleEvent) - Method in class org.mule.endpoint.inbound.InboundNotificationMessageProcessor
 
process(MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundEndpointMimeTypeCheckingMessageProcessor
 
process(MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundEndpointPropertyMessageProcessor
 
process(MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundEventTimeoutMessageProcessor
 
process(MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundLoggingMessageProcessor
 
process(MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundNotificationMessageProcessor
 
process(MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundRootMessageIdPropertyMessageProcessor
 
process(MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundSessionHandlerMessageProcessor
 
process(MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundTxRollbackMessageProcessor
 
process(MuleEvent) - Method in class org.mule.enricher.MessageEnricher
 
process(MuleEvent) - Method in class org.mule.exception.RedeliveryExceeded
 
process() - Method in class org.mule.execution.PhaseExecutionEngine.InternalPhaseExecutionEngine
 
process(MessageProcessTemplate, MessageProcessContext) - Method in class org.mule.execution.PhaseExecutionEngine
 
process(MuleEvent) - Method in class org.mule.interceptor.InterceptorStack
 
process(MuleEvent) - Method in class org.mule.interceptor.TimerInterceptor
 
process(MuleEvent) - Method in class org.mule.lifecycle.processor.ProcessIfStartedWaitIfPausedMessageProcessor
 
process(MuleEvent) - Method in class org.mule.lifecycle.processor.ProcessIfStartedWaitIfSyncPausedMessageProcessor
 
Process - Class in org.mule.module.bpm
A business process definition.
Process(BPMS, String, String, FlowConstruct, MuleContext) - Constructor for class org.mule.module.bpm.Process
 
Process(BPMS, String, String, String, FlowConstruct, MuleContext) - Constructor for class org.mule.module.bpm.Process
 
process - Variable in class org.mule.module.bpm.ProcessComponent
 
process(MuleEvent) - Method in class org.mule.module.cxf.config.FlowConfiguringMessageProcessor
 
process(MuleEvent) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
process(MuleEvent) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
process(MuleEvent) - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
process(ResultSet) - Method in class org.mule.module.db.internal.result.row.InsensitiveMapRowHandler
 
process(ResultSet) - Method in interface org.mule.module.db.internal.result.row.RowHandler
Process a row from a resultSet
process(MuleEvent) - Method in class org.mule.module.extension.internal.runtime.processor.OperationMessageProcessor
 
process(MuleEvent) - Method in class org.mule.module.http.internal.request.client.OneWayHttpRequesterAdapter
 
process(MuleEvent) - Method in class org.mule.module.json.validation.ValidateJsonSchemaMessageProcessor
 
process(MuleEvent) - Method in class org.mule.module.oauth2.internal.tokenmanager.InvalidateOauthContextMessageProcessor
 
process(MuleEvent) - Method in class org.mule.module.oauth2.internal.TokenResponseProcessor
 
process(InputStream) - Method in class org.mule.module.pgp.DecryptStreamTransformer
 
process(InputStream) - Method in class org.mule.module.pgp.EncryptStreamTransformer
 
process(InputStream) - Method in interface org.mule.module.pgp.StreamTransformer
 
process(MuleEvent) - Method in class org.mule.module.ws.consumer.WSConsumer
 
process(MuleEvent) - Method in class org.mule.processor.AbstractDynamicMessageProcessor
 
process(MuleEvent) - Method in class org.mule.processor.AbstractFilteringMessageProcessor
 
process(MuleEvent) - Method in class org.mule.processor.AbstractNonBlockingMessageProcessor
 
process(MuleEvent) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
 
process(MuleEvent) - Method in class org.mule.processor.AsyncDelegateMessageProcessor
 
process(MuleEvent) - Method in class org.mule.processor.AsyncInterceptingMessageProcessor
 
process(MuleEvent) - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
process(MuleEvent) - Method in class org.mule.processor.chain.InterceptingChainLifecycleWrapper
 
process() - Method in class org.mule.processor.chain.NestedProcessorChain
 
process(Object) - Method in class org.mule.processor.chain.NestedProcessorChain
 
process(Object, Map<String, Object>) - Method in class org.mule.processor.chain.NestedProcessorChain
 
process(MuleEvent) - Method in class org.mule.processor.chain.SubflowInterceptingChainLifecycleWrapper
 
process(MuleEvent) - Method in class org.mule.processor.EndpointTransactionalInterceptingMessageProcessor
 
process(MuleEvent) - Method in class org.mule.processor.ExceptionHandlingMessageProcessor
 
process(MuleEvent) - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
process(MuleEvent) - Method in class org.mule.processor.InvokerMessageProcessor
 
process(MuleEvent) - Method in class org.mule.processor.NullMessageProcessor
 
process(MuleEvent) - Method in class org.mule.processor.SecurityFilterMessageProcessor
 
process(MuleEvent) - Method in class org.mule.processor.StopFurtherMessageProcessingMessageProcessor
 
process(MuleEvent) - Method in class org.mule.processor.TransactionalInterceptingMessageProcessor
 
process(Object) - Method in class org.mule.registry.ExpressionEnricherProcessor
Deprecated.
 
process(Object) - Method in class org.mule.registry.ExpressionEvaluatorProcessor
Deprecated.
 
process(Object) - Method in class org.mule.registry.JSR250ValidatorProcessor
Deprecated.
 
process(Object) - Method in class org.mule.registry.LifecycleStateInjectorProcessor
Deprecated.
 
process(Object) - Method in class org.mule.registry.MuleContextProcessor
Deprecated.
 
process(Object) - Method in class org.mule.registry.NotificationListenerProcessor
Deprecated.
 
process(MuleEvent) - Method in class org.mule.routing.AbstractAggregator
 
process(MuleEvent) - Method in class org.mule.routing.AbstractCatchAllStrategy
Deprecated.
This method will be invoked when an event is received or being sent where the criteria of the router(s) do not match the current event.
process(MuleEvent) - Method in class org.mule.routing.AbstractMatchingRouter
 
process(MuleEvent) - Method in class org.mule.routing.AbstractSelectiveRouter
 
process(MuleEvent) - Method in class org.mule.routing.correlation.EventCorrelator
 
process(MuleEvent) - Method in class org.mule.routing.DynamicAll
 
process(MuleEvent) - Method in class org.mule.routing.DynamicFirstSuccessful
 
process(MuleEvent) - Method in class org.mule.routing.DynamicRoundRobin
 
process(MuleEvent) - Method in class org.mule.routing.Foreach
 
process(MuleEvent) - Method in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
process(MuleEvent) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
process(MuleEvent) - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
process(MuleEvent) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
process(MuleEvent) - Method in class org.mule.routing.requestreply.AbstractReplyToPropertyRequestReplyReplier
 
process(MuleEvent) - Method in class org.mule.routing.requestreply.SimpleRequestReplyReplier
 
process(MuleEvent) - Method in class org.mule.routing.Resequencer
 
process(MuleEvent) - Method in class org.mule.routing.ScatterGatherRouter
 
process(MuleEvent) - Method in class org.mule.routing.WireTap
 
process(MuleEvent) - Method in class org.mule.security.oauth.callback.CallbackContinuationMessageProcessor
 
process(O) - Method in class org.mule.security.oauth.callback.ProcessCallback
 
process(MuleEvent) - Method in class org.mule.security.oauth.DefaultHttpCallback.FlowRefMessageProcessor
 
process(Object) - Method in class org.mule.security.oauth.processor.AbstractListeningMessageProcessor
process(Object, Map<String, Object>) - Method in class org.mule.security.oauth.processor.AbstractListeningMessageProcessor
process() - Method in class org.mule.security.oauth.processor.AbstractListeningMessageProcessor
process(MuleEvent) - Method in class org.mule.security.oauth.processor.ExtractAuthorizationCodeMessageProcessor
 
process(MuleEvent) - Method in class org.mule.service.AbstractService
Deprecated.
 
process(MuleEvent) - Method in class org.mule.service.processor.ServiceInternalMessageProcessor
Deprecated.
We do all this together here rather than chaining them in order to conserve 2.x exception handling behaviour
process(MuleEvent) - Method in class org.mule.service.processor.ServiceLoggingMessageProcessor
Deprecated.
 
process(MuleEvent) - Method in class org.mule.service.processor.ServiceOutboundMessageProcessor
Deprecated.
 
process(MuleEvent) - Method in class org.mule.service.processor.ServiceOutboundStatisticsMessageProcessor
Deprecated.
 
process(MuleEvent) - Method in class org.mule.service.processor.ServiceSetEventRequestContextMessageProcessor
Deprecated.
 
process(MuleEvent) - Method in class org.mule.service.processor.ServiceStatisticsMessageProcessor
Deprecated.
 
process(MuleEvent) - Method in class org.mule.tck.functional.AssertionMessageProcessor
 
process(Object, MuleEventContext) - Method in class org.mule.tck.functional.FunctionalTestComponent
The service method that implements the test component logic.
process(MuleEvent) - Method in class org.mule.tck.functional.InvocationCountMessageProcessor
 
process(MuleEvent) - Method in class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
process(MuleEvent) - Method in class org.mule.tck.util.FlowTraceUtils.FlowStackAsserter
 
process(MuleEvent) - Method in class org.mule.tck.util.FlowTraceUtils.FlowStackAsyncAsserter
 
process(MuleEvent) - Method in class org.mule.transformer.AbstractTransformer
 
process(MuleEvent) - Method in class org.mule.transformer.CompositeConverter
 
process(MuleEvent) - Method in class org.mule.transformer.simple.CombineCollectionsTransformer
 
process(MuleEvent) - Method in class org.mule.transformer.simple.SetPayloadMessageProcessor
 
process(MuleEvent) - Method in class org.mule.transport.AbstractMessageDispatcher
 
process(MuleEvent) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
process(MuleEvent) - Method in class org.mule.transport.http.components.StaticResourceMessageProcessor
 
process() - Method in class org.mule.transport.TransactedPollingMessageReceiver.MessageProcessorWorker
 
process() - Method in class org.mule.transport.vm.VMMessageReceiver.MessageProcessorWorker
 
PROCESS_ASYNC_COMPLETE - Static variable in class org.mule.context.notification.AsyncMessageNotification
 
PROCESS_ASYNC_SCHEDULED - Static variable in class org.mule.context.notification.AsyncMessageNotification
 
PROCESS_ATTEMPT_COUNT_PROPERTY_NAME - Static variable in class org.mule.routing.UntilSuccessful
 
PROCESS_COMPLETE - Static variable in class org.mule.context.notification.PipelineMessageNotification
 
PROCESS_CREATION_WAIT - Static variable in class org.mule.module.jbpm.Jbpm
Given the multi-threaded nature of Mule, sometimes a response message will arrive to advance the process before the creation of the process has fully terminated (e.g., during in-memory unit tests).
PROCESS_END - Static variable in class org.mule.context.notification.ExceptionStrategyNotification
 
PROCESS_END - Static variable in class org.mule.context.notification.PipelineMessageNotification
 
PROCESS_ENDED - Static variable in class org.mule.module.jbpm.Jbpm
 
PROCESS_START - Static variable in class org.mule.context.notification.ExceptionStrategyNotification
 
PROCESS_START - Static variable in class org.mule.context.notification.PipelineMessageNotification
 
PROCESS_VARIABLE_DATA - Static variable in class org.mule.module.bpm.Process
 
PROCESS_VARIABLE_INCOMING - Static variable in class org.mule.module.bpm.Process
 
PROCESS_VARIABLE_INCOMING_SOURCE - Static variable in class org.mule.module.bpm.Process
 
ProcessAdapter<O> - Interface in org.mule.api.devkit
 
processAxisFault(AxisFault) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
processBlocking(MuleEvent) - Method in class org.mule.interceptor.AbstractEnvelopeInterceptor
 
processBlocking(MuleEvent) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
processBlocking(MuleEvent) - Method in class org.mule.processor.AbstractNonBlockingMessageProcessor
 
processBlocking(MuleEvent) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
 
ProcessBuilderConfigurer - Interface in org.mule.test.infrastructure.process
 
ProcessCallback<T,O> - Class in org.mule.security.oauth.callback
Callback with logic to execute within a controlled environment provided by ProcessTemplate
ProcessCallback() - Constructor for class org.mule.security.oauth.callback.ProcessCallback
 
ProcessCallbackProcessInterceptor<T,O> - Class in org.mule.security.oauth.process
 
ProcessCallbackProcessInterceptor() - Constructor for class org.mule.security.oauth.process.ProcessCallbackProcessInterceptor
 
processCatch(MuleEvent, MessagingException) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
 
processChallenge(String) - Method in class org.mule.transport.http.ntlm.NTLMScheme
Processes the NTLM challenge.
processChildElement(ParserContext, BeanAssembler, Element, Element) - Method in class org.mule.config.spring.parsers.processors.AbstractChildElementIterator
 
processClientRequest(MessageContext, boolean) - Method in class org.mule.transport.soap.axis.extensions.MuleSoapHeadersHandler
Method processClientRequest
processClientResponse(MessageContext) - Method in class org.mule.transport.soap.axis.extensions.MuleSoapHeadersHandler
Method processClientResponse
ProcessComponent - Class in org.mule.module.bpm
A service backed by the execution of a business process such as jBPM.
ProcessComponent() - Constructor for class org.mule.module.bpm.ProcessComponent
 
processCookies(MuleEvent) - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
processDefaultRoute(MuleEvent) - Method in class org.mule.routing.AbstractMatchingRouter
 
processed - Variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
processedEvent - Variable in exception org.mule.api.MessagingException
 
processedGroups - Variable in class org.mule.routing.correlation.EventCorrelator
 
processedLock - Variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
processEndpoint(AnnotatedEndpointData) - Method in class org.mule.config.endpoint.AnnotatedEndpointHelper
 
processEngine - Variable in class org.mule.module.jbpm.Jbpm
The initialized jBPM ProcessEngine.
processEvent(MuleEvent) - Method in interface org.mule.api.callback.SourceCallback
Dispatch the current event to the flow
processEvent(MuleEvent) - Method in class org.mule.routing.AbstractUntilSuccessfulProcessingStrategy
Process the event through the configured route in the until-successful configuration.
processEvent(MuleEvent) - Method in class org.mule.security.oauth.processor.AbstractListeningMessageProcessor
processExceptionReplyTo(MessagingException, Object) - Method in class org.mule.api.transport.ExceptionHandlingReplyToHandlerDecorator
 
processExceptionReplyTo(MessagingException, Object) - Method in interface org.mule.api.transport.ReplyToHandler
Processes replyTo in the case an exception occurred.
processExceptionReplyTo(MessagingException, Object) - Method in class org.mule.transport.DefaultReplyToHandler
 
processFile(File) - Method in class org.mule.transport.file.FileMessageReceiver
 
processFileUrl(URL, String, Class<T>, int) - Method in class org.mule.util.scan.ClasspathScanner
Deprecated.
 
processFinally(MuleEvent, MessagingException) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
Used to perform post processing after both request and response phases have been completed.
processHeaderName(String) - Method in class org.mule.transport.http.builder.HttpResponseDefinitionParser
 
processHttpRequest(HttpServletRequest, HttpServletResponse, MessageReceiver) - Method in class org.mule.transport.servlet.jetty.JettyReceiverServlet
 
processHttpRequest(HttpServletRequest, HttpServletResponse, MessageReceiver) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
processIdField - Variable in class org.mule.module.bpm.Process
This field will be used to correlate messages with processes.
ProcessIfStartedMessageProcessor - Class in org.mule.lifecycle.processor
 
ProcessIfStartedMessageProcessor(Startable, LifecycleState) - Constructor for class org.mule.lifecycle.processor.ProcessIfStartedMessageProcessor
 
ProcessIfStartedWaitIfPausedMessageProcessor - Class in org.mule.lifecycle.processor
 
ProcessIfStartedWaitIfPausedMessageProcessor(Startable, LifecycleState) - Constructor for class org.mule.lifecycle.processor.ProcessIfStartedWaitIfPausedMessageProcessor
 
ProcessIfStartedWaitIfSyncPausedMessageProcessor - Class in org.mule.lifecycle.processor
 
ProcessIfStartedWaitIfSyncPausedMessageProcessor(Startable, LifecycleState) - Constructor for class org.mule.lifecycle.processor.ProcessIfStartedWaitIfSyncPausedMessageProcessor
 
processInbound(Class, Service) - Method in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
processInboundRouters(Class, Service) - Method in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
processIncomingHeaders(Map<String, Object>) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
PROCESSING_CLASS - Static variable in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
PROCESSING_FIELD - Static variable in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
PROCESSING_METHOD - Static variable in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
PROCESSING_PARAM - Static variable in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
ProcessingDescriptor - Interface in org.mule.api.processor
Provides information about a processing unit represented by this instance
ProcessingMuleEventWork - Class in org.mule.work
Implementation of AbstractMuleEventWork that executes a MessageProcessor using this work's event.
ProcessingMuleEventWork(MessageProcessor, MuleEvent) - Constructor for class org.mule.work.ProcessingMuleEventWork
 
ProcessingStrategy - Interface in org.mule.api.processor
Determines how a list of message processors should processed.
processingStrategy - Variable in class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
processingStrategy - Variable in class org.mule.construct.AbstractPipeline
 
processingStrategy - Variable in class org.mule.processor.AsyncDelegateMessageProcessor
 
ProcessingStrategy.StageNameSource - Interface in org.mule.api.processor
Deprecated.
ProcessingStrategyEditor - Class in org.mule.config.spring.editors
A PropertyEditor for parsing instances of ProcessingStrategy
ProcessingStrategyEditor() - Constructor for class org.mule.config.spring.editors.ProcessingStrategyEditor
 
ProcessingStrategyUtils - Class in org.mule.config.spring.util
 
ProcessingStrategyUtils() - Constructor for class org.mule.config.spring.util.ProcessingStrategyUtils
 
ProcessingTime - Class in org.mule.management.stats
Accumulates the processing time for all branches of a flow
ProcessingTimeInterceptor - Class in org.mule.interceptor
Calculate and record the processing time for a message processing chain
ProcessingTimeInterceptor() - Constructor for class org.mule.interceptor.ProcessingTimeInterceptor
 
ProcessingTimeInterceptor(MessageProcessor, FlowConstruct) - Constructor for class org.mule.interceptor.ProcessingTimeInterceptor
 
ProcessingTimeWatcher - Interface in org.mule.management.stats
Watches ProcessingTime instances to detect when they are weakly reachable.
processInputParam(PreparedStatement, int, Object, DbType) - Method in class org.mule.module.db.internal.domain.executor.AbstractExecutor
 
ProcessInterceptor<T,O> - Interface in org.mule.api.devkit
 
processIntermediaryResult(MuleMessage, MuleMessage) - Method in class org.mule.routing.outbound.ChainingRouter
Deprecated.
Process intermediary result of invocation.
processJarUrl(URL, String, Class<T>, int) - Method in class org.mule.util.scan.ClasspathScanner
Deprecated.
 
processListRequest(AxisStringWriter) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
processMatch(String) - Method in interface org.mule.util.WildcardAttributeEvaluator.MatchCallback
 
processMessage(MessageProcessTemplate, MessageProcessContext) - Method in interface org.mule.execution.MessageProcessingManager
Process a message through a set of execution phases.
processMessage(MessageProcessTemplate, MessageProcessContext) - Method in class org.mule.execution.MuleMessageProcessingManager
 
processMessage(MessageProcessTemplate, MessageProcessContext) - Method in class org.mule.transport.AbstractMessageReceiver
 
processMessage(Object) - Method in class org.mule.transport.jdbc.JdbcMessageReceiver
 
processMessage(Message, MuleEvent) - Method in class org.mule.transport.jms.JmsMessageDispatcher
This method is called once the JMS message is created.
processMessage(Message, MuleEvent) - Method in class org.mule.transport.jms.JmsReplyToHandler
 
processMessage(Object) - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
processMessage(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.jetty.JettyHttpMessageReceiver
 
processMessage(Object) - Method in class org.mule.transport.TransactedPollingMessageReceiver
 
processMessage(Object) - Method in class org.mule.transport.vm.VMMessageReceiver
 
processMessage(Message) - Method in class org.mule.transport.xmpp.XmppPollingMessageReceiver
 
processMessageAsync(HttpServletRequest, HttpServletResponse, Continuation) - Method in class org.mule.transport.servlet.jetty.JettyHttpMessageReceiver
 
processMessages() - Method in class org.mule.transport.AbstractReceiverWorker
The actual logic used to receive messages from the underlying transport.
processMessages(Message, MessageReceiver) - Method in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
processMetadataAnnotations(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
processMetadataAnnotations(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.generic.ParentDefinitionParser
 
processMethodRequest(MessageContext, MuleEventContext, AxisStringWriter, EndpointURI) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
processNext(MuleEvent) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
processNext(MuleEvent) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
This method is public so it can be invoked from the MuleUniversalConduit.
processNext(MuleEvent, Exchange, OutboundEndpoint) - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
processNext(MuleEvent) - Method in class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
processNext(MuleEvent) - Method in class org.mule.routing.IdempotentMessageFilter
 
processNext(MuleEvent) - Method in class org.mule.service.ForwardingConsumer
Deprecated.
 
processNextAsync(MuleEvent) - Method in class org.mule.processor.AsyncInterceptingMessageProcessor
 
processNextAsync(MuleEvent) - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
processNextTimed(MuleEvent) - Method in class org.mule.processor.AsyncInterceptingMessageProcessor
 
processNonBlocking(MuleEvent) - Method in class org.mule.interceptor.AbstractEnvelopeInterceptor
 
processNonBlocking(MuleEvent, CompletionHandler) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
processNonBlocking(MuleEvent, CompletionHandler) - Method in class org.mule.processor.AbstractNonBlockingMessageProcessor
 
processNonBlocking(MuleEvent) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
 
processNow() - Method in class org.mule.routing.EventProcessingThread
 
processOauthContextFunctionACall(Object[]) - Method in class org.mule.module.oauth2.internal.tokenmanager.TokenManagerConfig
Provides support for the oauthContext MEL function for this configuration
ProcessorExecutor - Interface in org.mule.api.processor
Iterates over a list of MessageProcessors executing them one by one using the result of the first processor to invoke the second and so on.
ProcessorExecutorFactory - Class in org.mule.processor.chain
Creates an appropriate instance of BlockingProcessorExecutor based on the current MuleEvent and FlowConstruct.
ProcessorExecutorFactory() - Constructor for class org.mule.processor.chain.ProcessorExecutorFactory
 
processorMayReturnNull(MessageProcessor) - Method in class org.mule.processor.chain.DefaultMessageProcessorChain
 
processors - Variable in class org.mule.config.spring.factories.MessageProcessorChainFactoryBean
 
processors - Variable in class org.mule.processor.AsyncDelegateMessageProcessor
 
processors - Variable in class org.mule.processor.BlockingProcessorExecutor
 
processors - Variable in class org.mule.processor.chain.AbstractMessageProcessorChain
 
processors - Variable in class org.mule.processor.chain.AbstractMessageProcessorChainBuilder
 
processors - Variable in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
ProcessorsTrace - Interface in org.mule.api.context.notification
Keeps context information about the message processors that were executed as part of the processing of an event.
processorToString() - Method in class org.mule.context.notification.MessageProcessorNotification
 
processOutbound(Class, Service) - Method in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
processOutboundRouter(Class) - Method in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
processOutputParam() - Method in class org.mule.module.db.internal.result.statement.StatementResultIterator
 
processOverrides(Set<String>) - Method in class org.mule.module.launcher.FineGrainedControlClassLoader
 
processPacket(Packet) - Method in class org.mule.transport.xmpp.XmppMessageReceiver
 
processParts(MessageSequence<?>, MuleEvent) - Method in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
processProperty(Attr, BeanAssembler) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
processProperty(Attr, BeanAssembler) - Method in class org.mule.config.spring.parsers.specific.ReferenceExceptionStrategyDefinitionParser
 
processQueryParams(String, String) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
processRelativePath(String, String) - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
processRelativePath(String, String) - Method in class org.mule.transport.http.HttpMessageReceiver
 
processRelativePath(String, String) - Method in class org.mule.transport.http.OldHttpMessageReceiver
 
processRemoteAddresses(MuleMessage) - Method in class org.mule.transport.http.HttpMessageProcessTemplate
For a given MuleMessage will set the MULE_REMOTE_CLIENT_ADDRESS property taking into consideration if the header X-Forwarded-For is present in the request or not.
processReply(Class, Service) - Method in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
processReplyRouters(Class, Service) - Method in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
processReplyTo(MuleEvent, MuleMessage, Object) - Method in class org.mule.api.transport.ExceptionHandlingReplyToHandlerDecorator
 
processReplyTo(MuleEvent, MuleMessage, Object) - Method in interface org.mule.api.transport.ReplyToHandler
 
processReplyTo(MuleEvent, Exception) - Method in class org.mule.exception.RollbackMessagingExceptionStrategy
 
processReplyTo(MuleEvent, Exception) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
processReplyTo(MuleEvent, MuleEvent, ReplyToHandler, Object) - Method in class org.mule.routing.requestreply.AbstractReplyToPropertyRequestReplyReplier
 
processReplyTo(MuleEvent, MuleEvent, ReplyToHandler, Object) - Method in class org.mule.service.processor.ServiceInternalMessageProcessor
Deprecated.
 
processReplyTo(MuleEvent, MuleMessage, Object) - Method in class org.mule.transport.ajax.AjaxReplyToHandler
 
processReplyTo(MuleEvent, MuleMessage, Object) - Method in class org.mule.transport.DefaultReplyToHandler
 
processReplyTo(MuleEvent, MuleMessage, Object) - Method in class org.mule.transport.jms.JmsReplyToHandler
 
processRequest(MuleEvent) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
Processes the request phase before the next message processor is invoked.
processRequest(MuleEvent) - Method in class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
processRequest(HttpRequest) - Method in class org.mule.transport.http.OldHttpMessageReceiver.HttpWorker
 
processResponse(MuleEvent, MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundResponsePropertiesMessageProcessor
 
processResponse(MuleEvent, MuleEvent) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
Processes the response phase after the next message processor and it's response phase have been invoked
processResponse(MuleEvent) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
Deprecated.
processResponse(MuleEvent, MuleEvent) - Method in class org.mule.processor.ResponseMessageProcessorAdapter
 
processResponse(MuleEvent) - Method in class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
processResponseThroughAckResponseExpression(MuleEvent) - Method in class org.mule.routing.AbstractUntilSuccessfulProcessingStrategy
 
processResultSet(DbConnection, ResultSet) - Method in class org.mule.module.db.internal.result.resultset.IteratorResultSetHandler
 
processResultSet(DbConnection, ResultSet) - Method in class org.mule.module.db.internal.result.resultset.ListResultSetHandler
 
processResultSet(DbConnection, ResultSet) - Method in class org.mule.module.db.internal.result.resultset.NullResultSetHandler
 
processResultSet(DbConnection, ResultSet) - Method in interface org.mule.module.db.internal.result.resultset.ResultSetHandler
 
processServerRequest(MessageContext) - Method in class org.mule.transport.soap.axis.extensions.MuleSoapHeadersHandler
Method processServerRequest
processServerResponse(MessageContext, boolean) - Method in class org.mule.transport.soap.axis.extensions.MuleSoapHeadersHandler
Method processServerResponse
processStatement(DbConnection, Statement, QueryTemplate, AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.result.statement.AbstractMapStatementResultHandler
 
processStatement(DbConnection, Statement, QueryTemplate, AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.result.statement.EagerStatementResultHandler
 
processStatement(DbConnection, Statement, QueryTemplate, AutoGeneratedKeyStrategy) - Method in interface org.mule.module.db.internal.result.statement.StatementResultHandler
Processes the results from a statement execution
processStreamingAttribute(String) - Method in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
processStreamingAttribute(String) - Method in class org.mule.module.db.internal.config.processor.AbstractResultSetHandlerProcessorDefinitionParser
 
processTemplate(Template, String, VelocityContext) - Method in class com.javaforge.bobber.plugin.archetype.BobberArchetype
 
ProcessTemplate<T,O> - Interface in org.mule.api.devkit
 
processValues(Collection<String>, WildcardAttributeEvaluator.MatchCallback) - Method in class org.mule.util.WildcardAttributeEvaluator
 
processVariables(Iterator, VelocityContext, boolean) - Method in class com.javaforge.bobber.plugin.archetype.BobberArchetype
 
processWithExtraProperties(Map<String, Object>) - Method in interface org.mule.api.NestedProcessor
Dispatch original message to the processor chain
processWithExtraProperties(Map<String, Object>) - Method in class org.mule.processor.chain.NestedProcessorChain
 
processWsdlRequest(MessageContext, AxisStringWriter) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
produce() - Method in class org.mule.streaming.CompositeProducer
Returns the next available item
produce() - Method in class org.mule.streaming.ListableObjectStoreProducer
 
produce() - Method in class org.mule.streaming.PagingDelegateProducer
Asks the delegate for the next page
produce() - Method in interface org.mule.streaming.Producer
Returns the next available item
produce() - Method in class org.mule.streaming.QueueProducer
Returns the next available item
producer - Variable in class org.mule.streaming.AbstractConsumer
 
Producer<T> - Interface in org.mule.streaming
A producer implementation that follows the idea of the Producer-Consumer design pattern.
productInformation() - Static method in class org.mule.config.i18n.CoreMessages
Returns a message that is a product informatin.
PROFILER_OBJECT_NAME - Static variable in class org.mule.module.management.agent.YourKitProfilerAgent
MBean name to register under.
ProjectArchetypeMojo - Class in org.mule.tools.maven.archetype
Builds archetype containers.
ProjectArchetypeMojo() - Constructor for class org.mule.tools.maven.archetype.ProjectArchetypeMojo
 
PromptStdioConnector - Class in org.mule.transport.stdio
PromptStdioConnector connects to the System streams in and out by default and add some basic fuctionality for writing out prompt messages.
PromptStdioConnector(MuleContext) - Constructor for class org.mule.transport.stdio.PromptStdioConnector
 
propagate(MuleMessage, TypedValue, CompiledExpression) - Method in class org.mule.el.mvel.datatype.AbstractEnricherDataTypePropagator
 
propagate(MuleMessage, TypedValue, CompiledExpression) - Method in interface org.mule.el.mvel.datatype.EnricherDataTypePropagator
Propagates DataType on message enrichment
propagate(TypedValue, MuleMessage, Serializable) - Method in class org.mule.el.mvel.datatype.MvelEnricherDataTypePropagator
 
propagate() - Method in class org.mule.util.counters.impl.AbstractCounter
 
propagateJMSProperties(Message, Map<String, Object>) - Method in class org.mule.transport.jms.JmsMuleMessageFactory
 
propagateMagicProperties(MuleMessage, MuleMessage) - Static method in class org.mule.routing.AbstractRoutingStrategy
Propagates a number of internal system properties to handle correlation, session, etc.
propagateMagicProperties(MuleMessage, MuleMessage) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
Propagates a number of internal system properties to handle correlation, session, etc.
propagateRootId(MuleMessage) - Method in interface org.mule.api.MuleMessage
copy the message root id from parent to child
propagateRootId(MuleMessage) - Method in class org.mule.DefaultMuleMessage
 
propagateRootMessageIdProperty(MuleMessage) - Method in class org.mule.transport.AbstractMessageReceiver
 
propagateRootMessageIdProperty(MuleMessage) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
PROPERTIES - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.AddressedEndpointDefinitionParser
 
properties - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
properties - Variable in class org.mule.message.ExceptionMessage
 
properties - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
properties - Variable in class org.mule.object.AbstractObjectFactory
 
PROPERTIES - Static variable in class org.mule.transport.rmi.config.RmiNamespaceHandler
 
PROPERTIES - Static variable in class org.mule.transport.soap.axis.config.AxisNamespaceHandler
 
PROPERTIES_FILE_PATTERN - Static variable in class org.mule.api.security.tls.TlsConfiguration
 
PropertiesConverter - Class in org.mule.config.converters
Converts a comma-separated list of key/value pairs, e.g., "apple=green, banana=yellow" into a Properties map.
PropertiesConverter() - Constructor for class org.mule.config.converters.PropertiesConverter
 
PropertiesDescriptorParser - Class in org.mule.module.launcher.descriptor
 
PropertiesDescriptorParser() - Constructor for class org.mule.module.launcher.descriptor.PropertiesDescriptorParser
 
PropertiesMuleConfigurationFactory - Class in org.mule.config
 
PropertiesMuleConfigurationFactory(String) - Constructor for class org.mule.config.PropertiesMuleConfigurationFactory
 
propertiesNotSet(String) - Static method in class org.mule.config.i18n.CoreMessages
 
propertiesOrNotSet(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
propertiesToString(Map, boolean) - Static method in class org.mule.util.PropertiesUtils
Deprecated.
PropertiesUtils - Class in org.mule.util
PropertiesHelper is a utility class for manipulating and filtering property Maps.
PropertiesUtils() - Constructor for class org.mule.util.PropertiesUtils
Do not instanciate.
PROPERTY_ACTION - Static variable in class org.mule.module.bpm.Process
 
PROPERTY_ARCHIVE_DIR - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_ARCHIVE_TEMP_RECEIVING_DIR - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_ARCHIVE_TEMP_SENDING_DIR - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_BINARY_TRANSFER - Static variable in class org.mule.transport.ftp.FtpConnector
 
PROPERTY_CONFIG_BUILDER - Static variable in class org.mule.module.launcher.descriptor.PropertiesDescriptorParser
 
PROPERTY_CONFIG_RESOURCES - Static variable in class org.mule.module.launcher.descriptor.PropertiesDescriptorParser
 
PROPERTY_CONNECTOR_NAME - Static variable in interface org.mule.api.endpoint.EndpointURI
 
PROPERTY_CRON_EXPRESSION - Static variable in class org.mule.transport.quartz.QuartzConnector
 
PROPERTY_CRON_TIME_ZONE - Static variable in class org.mule.transport.quartz.QuartzConnector
 
PROPERTY_DEFAULT_TIMEOUT - Static variable in class org.mule.module.jboss.transaction.JBossArjunaTransactionManagerFactory
 
PROPERTY_DIRECTORY - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_DIRECTORY - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_DOMAIN - Static variable in class org.mule.module.launcher.descriptor.PropertiesDescriptorParser
 
PROPERTY_DUPLICATE_HANDLING - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_DUPLICATE_HANDLING_APPEND - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_DUPLICATE_HANDLING_ASS_SEQ_NO - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_DUPLICATE_HANDLING_OVERWRITE - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_DUPLICATE_HANDLING_THROW_EXCEPTION - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_ELEMENT_NAME - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
PROPERTY_ENCODING - Static variable in class org.mule.module.launcher.descriptor.PropertiesDescriptorParser
 
PROPERTY_ENDPOINT - Static variable in class org.mule.module.bpm.Process
 
PROPERTY_ENDPOINT_NAME - Static variable in interface org.mule.api.endpoint.EndpointURI
 
PROPERTY_ENDPOINT_URI - Static variable in interface org.mule.api.endpoint.EndpointURI
 
PROPERTY_ENVIRONMENT_OBJECTSTORE_DIR - Static variable in class org.mule.module.jboss.transaction.JBossArjunaTransactionManagerFactory
 
PROPERTY_FAVORITE_COLOR - Static variable in class org.mule.tck.security.TestSingleUserSecurityProvider
 
PROPERTY_FILE_AGE - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_FILE_AGE - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_FILE_EXTENSION - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_FILE_SIZE - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_FILE_TIMESTAMP - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_FILENAME - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_FILENAME - Static variable in class org.mule.transport.ftp.FtpConnector
 
PROPERTY_FILENAME - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_IDENTITY_FILE - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_INCLUDE_SUBFOLDERS - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_JOB_CONFIG - Static variable in class org.mule.transport.quartz.QuartzConnector
 
PROPERTY_JOB_DATA - Static variable in class org.mule.transport.quartz.QuartzConnector
 
PROPERTY_JOB_DYNAMIC - Static variable in class org.mule.transport.quartz.QuartzConnector
 
PROPERTY_JOB_OBJECT - Static variable in class org.mule.transport.quartz.QuartzConnector
 
PROPERTY_JOB_REF - Static variable in class org.mule.transport.quartz.QuartzConnector
 
PROPERTY_KEEP_FILE_ON_ERROR - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_KNOWN_HOSTS_FILE - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_LOADER_OVERRIDE - Static variable in class org.mule.module.launcher.descriptor.PropertiesDescriptorParser
 
PROPERTY_LOADER_OVERRIDE - Static variable in class org.mule.module.launcher.plugin.PluginDescriptorParser
 
PROPERTY_LOG_CONFIG_FILE - Static variable in class org.mule.module.launcher.descriptor.PropertiesDescriptorParser
 
PROPERTY_MAX_CONNECTION_POOL_SIZE - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_MOVE_TO_DIRECTORY - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_MOVE_TO_PATTERN - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_NAME - Static variable in interface org.mule.api.AnnotatedObject
 
PROPERTY_NODE_IDENTIFIER - Static variable in class org.mule.module.jboss.transaction.JBossArjunaTransactionManagerFactory
 
PROPERTY_NUMBER_LOGINS - Static variable in class org.mule.tck.security.TestSingleUserSecurityProvider
 
PROPERTY_OBJECTSTORE_DIR - Static variable in class org.mule.module.jboss.transaction.JBossArjunaTransactionManagerFactory
 
PROPERTY_ORIGINAL_DIRECTORY - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_ORIGINAL_FILENAME - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_ORIGINAL_FILENAME - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_OUTPUT_PATTERN - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_OUTPUT_PATTERN - Static variable in class org.mule.transport.ftp.FtpConnector
 
PROPERTY_OUTPUT_PATTERN - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_PASS_PHRASE - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_PASSIVE_MODE - Static variable in class org.mule.transport.ftp.FtpConnector
 
PROPERTY_PAYLOAD - Static variable in class org.mule.transport.quartz.QuartzConnector
 
PROPERTY_POLLING_FREQUENCY - Static variable in class org.mule.transport.AbstractConnector
 
PROPERTY_POLLING_FREQUENCY - Static variable in class org.mule.transport.jdbc.JdbcConnector
 
PROPERTY_POLLING_FREQUENCY - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_PREFIX - Static variable in class org.mule.api.config.MuleProperties
The prefix for any Mule-specific properties set on an event
PROPERTY_PROCESS_ID - Static variable in class org.mule.module.bpm.Process
 
PROPERTY_PROCESS_STARTED - Static variable in class org.mule.module.bpm.Process
 
PROPERTY_PROCESS_SYNCHRONOUSLY - Static variable in class org.mule.endpoint.AbstractEndpoint
 
PROPERTY_PROCESS_TYPE - Static variable in class org.mule.module.bpm.Process
 
PROPERTY_READ_FROM_DIRECTORY - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_REDEPLOYMENT_ENABLED - Static variable in class org.mule.module.launcher.descriptor.PropertiesDescriptorParser
 
PROPERTY_REPEAT_COUNT - Static variable in class org.mule.transport.quartz.QuartzConnector
 
PROPERTY_REPEAT_INTERVAL - Static variable in class org.mule.transport.quartz.QuartzConnector
 
PROPERTY_RESPONSE_PROPERTIES - Static variable in class org.mule.endpoint.AbstractEndpointBuilder
 
PROPERTY_RESPONSE_TIMEOUT - Static variable in class org.mule.endpoint.AbstractEndpointBuilder
 
PROPERTY_RESPONSE_TRANSFORMERS - Static variable in interface org.mule.api.endpoint.EndpointURI
 
PROPERTY_RMI_SECURITY_POLICY - Static variable in class org.mule.transport.rmi.RmiConnector
 
PROPERTY_RMI_SERVER_CODEBASE - Static variable in class org.mule.transport.rmi.RmiConnector
 
PROPERTY_SCAN_PACKAGES - Static variable in class org.mule.module.launcher.descriptor.PropertiesDescriptorParser
 
PROPERTY_SELECT_EXPRESSION - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_SERVER_CLASS_NAME - Static variable in class org.mule.transport.rmi.RmiConnector
 
PROPERTY_SERVICE_CLASS_NAME - Static variable in class org.mule.transport.rmi.RmiCallbackMessageReceiver
The property name for the service object implementing the callback interface RmiAble This should be set on the inbound endpoint
PROPERTY_SERVICE_METHOD_PARAM_TYPES - Static variable in class org.mule.transport.rmi.RmiConnector
The property name that explicitly defines which argument types should be passed to a remote object method invocation.
PROPERTY_SERVICE_METHOD_PARAMS_LIST - Static variable in class org.mule.transport.rmi.RmiConnector
The property name for a list of objects used to call a Remote object via an RMI or EJB MessageReceiver
PROPERTY_SIZE_CHECK_WAIT_TIME - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_SOURCE_DIRECTORY - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_SOURCE_FILENAME - Static variable in class org.mule.transport.file.FileConnector
 
PROPERTY_START_DELAY - Static variable in class org.mule.transport.quartz.QuartzConnector
 
PROPERTY_TEMP_DIR - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_TRANSFORMERS - Static variable in interface org.mule.api.endpoint.EndpointURI
 
PROPERTY_TRANSITION - Static variable in class org.mule.module.bpm.Process
 
PROPERTY_TX_REAPER_TIMEOUT - Static variable in class org.mule.module.jboss.transaction.JBossArjunaTransactionManagerFactory
 
PROPERTY_USE_TEMP_FILE_TIMESTAMP_SUFFIX - Static variable in class org.mule.transport.sftp.SftpConnector
 
PROPERTY_USER_DIR - Static variable in class org.mule.module.jboss.transaction.JBossArjunaTransactionManagerFactory
 
PROPERTY_WRITE_TO_DIRECTORY - Static variable in class org.mule.transport.file.FileConnector
 
PropertyChecker - Class in org.mule.util
Class to check that system properties are enabled or not, the latter being the default.
PropertyChecker(String) - Constructor for class org.mule.util.PropertyChecker
Similar to PropertyChecker.PropertyChecker(String, String) only the default value is false.
PropertyChecker(String, String) - Constructor for class org.mule.util.PropertyChecker
Creates a PropertyChecker with a custom default value.
PropertyConfiguration - Interface in org.mule.config.spring.parsers.assembly.configuration
This collects together various constraints/rewrites that can be applied to attributes.
PropertyConverter - Interface in org.mule.api.expression
TODO
propertyDoesNotExistOnObject(String, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
PropertyEditorTextToValueTransformer - Class in org.mule.transformer.simple
PropertyEditorTextToValueTransformer adapts a PropertyEditor instance allowing it to be used to transform from a String to another type in Mule
PropertyEditorTextToValueTransformer(PropertyEditor, Class<?>) - Constructor for class org.mule.transformer.simple.PropertyEditorTextToValueTransformer
 
PropertyEditorValueToTextTransformer - Class in org.mule.transformer.simple
PropertyEditorValueToTextTransformer adapts a PropertyEditor instance allowing it to be used to transform from a specific type to a String.
PropertyEditorValueToTextTransformer(PropertyEditor, Class<?>) - Constructor for class org.mule.transformer.simple.PropertyEditorValueToTextTransformer
 
PropertyEnricherDataTypePropagator - Class in org.mule.el.mvel.datatype
Propagates data type for inlined flow and session vars used for enrichment target
PropertyEnricherDataTypePropagator() - Constructor for class org.mule.el.mvel.datatype.PropertyEnricherDataTypePropagator
 
PropertyExpressionDataTypeResolver - Class in org.mule.el.mvel.datatype
Resolves data type for expressions representing a reference to a invocation or session variable.
PropertyExpressionDataTypeResolver() - Constructor for class org.mule.el.mvel.datatype.PropertyExpressionDataTypeResolver
 
PropertyFactory - Interface in org.mule.api.config
PropertyFactory is used to create objects from the property file.
propertyHasInvalidValue(String, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
propertyIsNotSetOnEvent(String) - Static method in class org.mule.config.i18n.CoreMessages
 
propertyIsNotSupportedType(String, Class<?>, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
propertyIsNotSupportedType(String, Class<?>[], Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
propertyNames() - Method in class org.mule.util.OrderedProperties
 
propertyNotSerializableWasDropped(String) - Static method in class org.mule.config.i18n.CoreMessages
 
PropertyPlaceholderProcessor - Class in org.mule.config.spring.processors
TODO
PropertyPlaceholderProcessor() - Constructor for class org.mule.config.spring.processors.PropertyPlaceholderProcessor
 
PropertyScope - Class in org.mule.api.transport
A PropertyScope is used to associate a message property with a lifetime.
PropertyScope.ScopeComparator - Class in org.mule.api.transport
Used for comparing PropertyScope instances in a map.
PropertyScope.ScopeComparator() - Constructor for class org.mule.api.transport.PropertyScope.ScopeComparator
 
propertyTemplateMalformed(String) - Static method in class org.mule.config.builders.i18n.BuildersMessages
 
PROTOCOL - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.AddressedEndpointDefinitionParser
 
PROTOCOL - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.ChildAddressDefinitionParser
 
PROTOCOL - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.OrphanAddressDefinitionParser
 
PROTOCOL - Static variable in class org.mule.endpoint.URIBuilder
 
PROTOCOL - Static variable in class org.mule.transport.ajax.container.AjaxServletConnector
 
PROTOCOL - Static variable in class org.mule.transport.ajax.embedded.AjaxConnector
 
PROTOCOL - Static variable in class org.mule.transport.tcp.config.ByteOrMessageProtocolDefinitionParser
 
protocol - Variable in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
ProtocolHandlerDefinitionParser - Class in org.mule.config.spring.parsers.specific.tls
Deprecated.
This was necessary pre Java SE 5.0. It will be ignored and removed in Mule 4
ProtocolHandlerDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.tls.ProtocolHandlerDefinitionParser
Deprecated.
 
ProtocolStream - Class in org.mule.transport.tcp.protocols
 
ProtocolStream(TcpProtocol, boolean, OutputStream) - Constructor for class org.mule.transport.tcp.protocols.ProtocolStream
 
PrototypeObjectFactory - Class in org.mule.object
Creates a new instance of the object on each call.
PrototypeObjectFactory() - Constructor for class org.mule.object.PrototypeObjectFactory
For Spring only
PrototypeObjectFactory(String) - Constructor for class org.mule.object.PrototypeObjectFactory
 
PrototypeObjectFactory(String, Map) - Constructor for class org.mule.object.PrototypeObjectFactory
 
PrototypeObjectFactory(Class<?>) - Constructor for class org.mule.object.PrototypeObjectFactory
 
PrototypeObjectFactory(Class<?>, Map) - Constructor for class org.mule.object.PrototypeObjectFactory
 
provide() - Method in class org.glassfish.jersey.message.internal.DocumentBuilderFactoryInjectionProvider
 
provide() - Method in class org.glassfish.jersey.message.internal.SaxParserFactoryInjectionProvider
 
provide() - Method in class org.glassfish.jersey.message.internal.XmlInputFactoryInjectionProvider
 
ProvideDefaultName - Class in org.mule.config.spring.parsers.processors
 
ProvideDefaultName(String) - Constructor for class org.mule.config.spring.parsers.processors.ProvideDefaultName
 
ProvideDefaultNameFromElement - Class in org.mule.config.spring.parsers.processors
 
ProvideDefaultNameFromElement() - Constructor for class org.mule.config.spring.parsers.processors.ProvideDefaultNameFromElement
 
ProvidedObjectStoreWrapper<T extends Serializable> - Class in org.mule.util.store
Will wrap a provided object store or a newly created one with the provided factory, with the provided having precedence if present.
ProvidedObjectStoreWrapper(ObjectStore<T>, Factory) - Constructor for class org.mule.util.store.ProvidedObjectStoreWrapper
Wraps the providedObjectStore if given, or uses the objectStoreFactory to create one.
ProvidedPartitionableObjectStoreWrapper<T extends Serializable> - Class in org.mule.util.store
Will wrap a provided object store or a newly created one with the provided factory, with the provided having precedence if present.
ProvidedPartitionableObjectStoreWrapper(PartitionableObjectStore<T>, Factory) - Constructor for class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
Wraps the providedObjectStore if given, or uses the objectStoreFactory to create one.
provideEndLatch() - Method in class org.mule.work.WorkerContext
Provides a latch, which can be used to wait the end of a work execution.
ProviderAwarePagingDelegate<T,P> - Class in org.mule.streaming
Similar to PagingDelegate but aware of the actual component that provides the data being paged
ProviderAwarePagingDelegate() - Constructor for class org.mule.streaming.ProviderAwarePagingDelegate
 
provideStartLatch() - Method in class org.mule.work.WorkerContext
Provides a latch, which can be used to wait the start of a work execution.
ProvidesTotalHint - Interface in org.mule.streaming
Object provides a hint on total amount of elements it has/can process
PROXY_AUTHENTICATE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
PROXY_AUTHORIZATION - Static variable in class org.mule.module.http.api.HttpHeaders.Names
PROXY_REVALIDATE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
ProxyClientFactoryBean - Class in org.mule.module.cxf.config
 
ProxyClientFactoryBean() - Constructor for class org.mule.module.cxf.config.ProxyClientFactoryBean
 
ProxyClientMessageProcessorBuilder - Class in org.mule.module.cxf.builder
Creates an outbound proxy based on a specially configure CXF Client.
ProxyClientMessageProcessorBuilder() - Constructor for class org.mule.module.cxf.builder.ProxyClientMessageProcessorBuilder
 
ProxyConfig - Interface in org.mule.module.http.api.requester.proxy
HTTP proxy configuration for making http requests
ProxyConfigBuilder - Class in org.mule.module.http.api.requester.proxy
Builder for http proxy configuration.
ProxyConfigBuilder() - Constructor for class org.mule.module.http.api.requester.proxy.ProxyConfigBuilder
 
ProxyFaultOutInterceptor - Class in org.mule.module.cxf.support
Fault out interceptor for Proxy configuration considering that FaultInfo might not have an associated class and that it uses StaxDatabinding.
ProxyFaultOutInterceptor() - Constructor for class org.mule.module.cxf.support.ProxyFaultOutInterceptor
 
ProxyGZIPFeature - Class in org.mule.module.cxf.feature
This class is used to control GZIP compression of messages when proxying a web service call.
ProxyGZIPFeature() - Constructor for class org.mule.module.cxf.feature.ProxyGZIPFeature
 
ProxyGZIPInInterceptor - Class in org.mule.module.cxf.support
This interceptor is responsible for decompressing a message received with Content-Encoding that includes gzip or x-zip.
ProxyGZIPInInterceptor() - Constructor for class org.mule.module.cxf.support.ProxyGZIPInInterceptor
 
ProxyGZIPOutInterceptor - Class in org.mule.module.cxf.support
This interceptor is responsible from compressing a message when the Content-Encoding is set to gzip or x-gzip.
ProxyGZIPOutInterceptor() - Constructor for class org.mule.module.cxf.support.ProxyGZIPOutInterceptor
 
proxyPoolTimedOut() - Static method in class org.mule.config.i18n.CoreMessages
 
ProxyRPCInInterceptor - Class in org.mule.module.cxf.support
Sets the correct operation when the binding style is RPC.
ProxyRPCInInterceptor() - Constructor for class org.mule.module.cxf.support.ProxyRPCInInterceptor
 
ProxySchemaValidationInInterceptor - Class in org.mule.module.cxf.support
 
ProxySchemaValidationInInterceptor(Bus, Endpoint, ServiceInfo) - Constructor for class org.mule.module.cxf.support.ProxySchemaValidationInInterceptor
 
ProxyService - Interface in org.mule.module.cxf.support
 
ProxyServiceConfiguration - Class in org.mule.module.cxf.support
 
ProxyServiceConfiguration() - Constructor for class org.mule.module.cxf.support.ProxyServiceConfiguration
 
ProxyServiceFactoryBean - Class in org.mule.module.cxf.config
 
ProxyServiceFactoryBean() - Constructor for class org.mule.module.cxf.config.ProxyServiceFactoryBean
 
ProxyServiceFactoryBean - Class in org.mule.module.cxf.support
 
ProxyServiceFactoryBean() - Constructor for class org.mule.module.cxf.support.ProxyServiceFactoryBean
 
ProxyServiceMessageProcessorBuilder - Class in org.mule.module.cxf.builder
Creates an inbound proxy based on a specially configure CXF Server.
ProxyServiceMessageProcessorBuilder() - Constructor for class org.mule.module.cxf.builder.ProxyServiceMessageProcessorBuilder
 
ProxyWSDLQueryHandler - Class in org.mule.module.cxf.support
 
ProxyWSDLQueryHandler(Bus, String) - Constructor for class org.mule.module.cxf.support.ProxyWSDLQueryHandler
 
pseudoParser - Variable in class org.mule.module.xml.stax.StaxSource
 
PUBLIC - Static variable in class org.mule.module.http.api.HttpHeaders.Values
push(FlowStackElement) - Method in class org.mule.context.notification.DefaultFlowCallStack
Adds an element to the top of this stack
put(Object, Object) - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
put(String, DataHandler) - Method in class org.mule.el.context.InboundAttachmentMapContext
 
put(String, Object) - Method in class org.mule.el.context.MessagePropertyMapContext
 
put(String, DataHandler) - Method in class org.mule.el.context.OutboundAttachmentMapContext
 
put(String, DataHandler) - Method in class org.mule.expression.InboundAttachmentsMap
 
put(String, DataHandler) - Method in class org.mule.expression.OutboundAttachmentsMap
 
put(String, Object, String) - Method in class org.mule.expression.OutboundAttachmentsMap
 
put(String, Object) - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
put(K, V) - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
put(ServerAddress, T) - Method in class org.mule.module.http.internal.listener.ServerAddressMap
 
put(String, String) - Method in class org.mule.module.http.internal.ParameterMap
 
put(String, Object) - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
put(K, Object) - Method in class org.mule.transport.http.multipart.MultiMap
Put and entry into the map.
put(String, T) - Method in class org.mule.util.CaseInsensitiveMapWrapper
 
put(K, V) - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
put(Object, Object) - Method in class org.mule.util.MapCombiner
 
put(Object, Object) - Method in class org.mule.util.OrderedProperties
 
put(Serializable) - Method in interface org.mule.util.queue.Queue
Puts a new object in this queue and wait if necessary.
put(Serializable) - Method in class org.mule.util.queue.TransactionAwareQueueStore
 
put(Serializable, ValueType) - Method in class org.mule.util.store.ObjectStoreToMapAdapter
 
putAll(Map) - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
putAll(Map<? extends K, ? extends V>) - Method in class org.mule.el.context.AbstractMapContext
 
putAll(Map<? extends String, ? extends DataHandler>) - Method in class org.mule.expression.InboundAttachmentsMap
 
putAll(Map<? extends String, ? extends DataHandler>) - Method in class org.mule.expression.OutboundAttachmentsMap
 
putAll(Map<? extends String, ?>) - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
putAll(Map<? extends String, ? extends String>) - Method in class org.mule.module.http.internal.ParameterMap
 
putAll(Map<? extends String, ? extends Object>) - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
putAll(Map<String, Object>) - Method in class org.mule.registry.TransientRegistry.RegistryMap
Deprecated.
 
putAll(Map) - Method in class org.mule.transport.http.multipart.MultiMap
Put all contents of map.
putAll(Map<? extends String, ? extends T>) - Method in class org.mule.util.CaseInsensitiveMapWrapper
 
putAll(Map<? extends K, ? extends V>) - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
putAll(Map) - Method in class org.mule.util.MapCombiner
 
putAll(Map<? extends Serializable, ? extends ValueType>) - Method in class org.mule.util.store.ObjectStoreToMapAdapter
 
putAndLogWarningIfDuplicate(String, Object) - Method in class org.mule.registry.TransientRegistry.RegistryMap
Deprecated.
 
putAndMergeCookie(Object, String, String) - Static method in class org.mule.transport.http.CookieHelper
This method merges a new Cookie (or override the previous one if it exists) to the preExistentCookies.
putAndMergeCookie(Object, Cookie[]) - Static method in class org.mule.transport.http.CookieHelper
Merges all the Cookies in newCookiesArray with the preExistentCookies, adding the new ones and overwriting the existing ones (existing means same cookie name).
putAndMergeCookie(Object, Map<String, String>) - Static method in class org.mule.transport.http.CookieHelper
Merges all the Cookies in newCookiesMap with the preExistentCookies, adding the new ones and overwriting the existing ones (existing means same cookie name).
putFile(String, String) - Method in class org.mule.tck.util.ftp.FtpClient
Upload a file to the ftp server
putFile(String, String, String) - Method in class org.mule.tck.util.ftp.FtpClient
Upload a file to the ftp server
putIfAbsent(K, Object) - Method in class org.mule.transport.http.multipart.MultiMap
 
putInto(MuleEvent) - Method in class org.mule.transport.polling.watermark.Watermark
Retrieves the watermark value from the underlying peristent store and enriches the event.If there is no value stored, a default expression will be used to create a new one.
putNow(Serializable) - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
 
putNow(Serializable) - Method in class org.mule.util.queue.DefaultQueueStore
 
putNow(Serializable) - Method in class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
Deprecated.
 
putNow(Serializable) - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
putNow(Serializable) - Method in interface org.mule.util.queue.objectstore.QueueInfoDelegate
Deprecated.
append a new member to the end of the queue
putNow(Serializable) - Method in interface org.mule.util.queue.QueueStore
 
putNow(Serializable) - Method in interface org.mule.util.queue.QueueStoreDelegate
append a new member to the end of the queue
putValues(K, List) - Method in class org.mule.transport.http.multipart.MultiMap
Put multi valued entry.
putValues(K, String[]) - Method in class org.mule.transport.http.multipart.MultiMap
Put multi valued entry.

Q

QNAME_MULE_PROVIDER - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
QNAME_MULE_TYPE_MAPPINGS - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
QNamePropertyEditor - Class in org.mule.config.spring.editors
This handles qname{....} syntax as used in stockquote-soap-config.xml
QNamePropertyEditor() - Constructor for class org.mule.config.spring.editors.QNamePropertyEditor
 
QNamePropertyEditor(boolean) - Constructor for class org.mule.config.spring.editors.QNamePropertyEditor
 
QUARTZ - Static variable in class org.mule.transport.quartz.QuartzConnector
 
QUARTZ_ATTRIBUTES - Static variable in class org.mule.transport.quartz.config.QuartzNamespaceHandler
 
QUARTZ_CONNECTOR_PROPERTY - Static variable in class org.mule.transport.quartz.QuartzMessageReceiver
 
QUARTZ_INSTANCE_NAME_PROPERTY - Static variable in class org.mule.modules.schedulers.cron.CronScheduler
 
QUARTZ_INSTANCE_NAME_PROPERTY - Static variable in class org.mule.transport.quartz.QuartzConnector
 
QUARTZ_RECEIVER_PROPERTY - Static variable in class org.mule.transport.quartz.QuartzMessageReceiver
 
QUARTZ_SCHEDULER_PREFIX - Static variable in class org.mule.transport.quartz.QuartzConnector
 
QuartzConnector - Class in org.mule.transport.quartz
Creates a connection to a Quartz scheduler.
QuartzConnector(MuleContext) - Constructor for class org.mule.transport.quartz.QuartzConnector
 
QuartzMessageDispatcher - Class in org.mule.transport.quartz
Can schedule a Job with the Quartz scheduler.
QuartzMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.quartz.QuartzMessageDispatcher
 
QuartzMessageDispatcherFactory - Class in org.mule.transport.quartz
Creates a QuartzMessageDispatcher instance.
QuartzMessageDispatcherFactory() - Constructor for class org.mule.transport.quartz.QuartzMessageDispatcherFactory
 
QuartzMessageReceiver - Class in org.mule.transport.quartz
Listens for Quartz sheduled events using the Receiver Job and fires events to the service associated with this receiver.
QuartzMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.quartz.QuartzMessageReceiver
 
QuartzMessages - Class in org.mule.transport.quartz.i18n
 
QuartzMessages() - Constructor for class org.mule.transport.quartz.i18n.QuartzMessages
 
QuartzNamespaceHandler - Class in org.mule.transport.quartz.config
Registers Bean Definition Parsers for the "quartz" namespace
QuartzNamespaceHandler() - Constructor for class org.mule.transport.quartz.config.QuartzNamespaceHandler
 
queries - Variable in class org.mule.transport.jdbc.JdbcConnector
 
QUERIES_DEBUG_FIELD - Static variable in class org.mule.module.db.internal.processor.DbDebugInfoUtils
 
Query - Class in org.mule.module.db.internal.domain.query
Represents an instantiation of a QueryTemplate with parameter values
Query(QueryTemplate, List<QueryParamValue>) - Constructor for class org.mule.module.db.internal.domain.query.Query
Creates a query from a template and a set of parameter values
Query(QueryTemplate) - Constructor for class org.mule.module.db.internal.domain.query.Query
Creates a query from a template
query - Variable in class org.mule.module.db.internal.metadata.AbstractQueryMetadataProvider
 
QUERY_DEBUG_FIELD - Static variable in class org.mule.module.db.internal.processor.DbDebugInfoUtils
 
QUERY_DEFINITION_ELEMENTS - Static variable in class org.mule.module.db.internal.config.domain.query.QueryTemplateBeanDefinitionParser
 
QUERY_KEY - Static variable in class org.mule.transport.jdbc.config.JdbcNamespaceHandler
 
QUERY_METADATA_PROVIDER_PROPERTY - Static variable in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
QUERY_TAG_NAMES - Static variable in class org.mule.module.db.internal.config.domain.query.QueryDefinitionParser
 
QUERY_TIMEOUT_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
queryBean - Variable in class org.mule.module.db.internal.config.processor.AbstractSingleQueryProcessorDefinitionParser
 
QueryDefinitionParser - Class in org.mule.module.db.internal.config.domain.query
Parses Element representing queries
QueryDefinitionParser() - Constructor for class org.mule.module.db.internal.config.domain.query.QueryDefinitionParser
 
queryDefinitionParser - Variable in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
QueryExecutor - Interface in org.mule.module.db.internal.domain.executor
Executes queries against a database
QueryExecutorFactory - Interface in org.mule.module.db.internal.domain.executor
Creates query executor instances
QueryFileFactoryBean - Class in org.mule.module.db.internal.config.domain.query
Creates a query text from a file
QueryFileFactoryBean(String, FileReader) - Constructor for class org.mule.module.db.internal.config.domain.query.QueryFileFactoryBean
 
QueryLogger - Interface in org.mule.module.db.internal.domain.logger
Logs a query
queryLoggerFactory - Variable in class org.mule.module.db.internal.domain.executor.AbstractExecutor
 
QueryLoggerFactory - Interface in org.mule.module.db.internal.domain.logger
Creates QueryLogger instances
QueryMetadataProvider - Interface in org.mule.module.db.internal.metadata
Provides metadata for a given type of query
QueryParam - Interface in org.mule.module.db.internal.domain.param
Defines common SQL parameter information.
QueryParamTypeResolver - Class in org.mule.module.db.internal.resolver.param
Resolves parameter types for standard queries
QueryParamTypeResolver(DbTypeManager) - Constructor for class org.mule.module.db.internal.resolver.param.QueryParamTypeResolver
 
QueryParamValue - Class in org.mule.module.db.internal.domain.query
Contains the value for a query parameter
QueryParamValue(String, Object) - Constructor for class org.mule.module.db.internal.domain.query.QueryParamValue
 
QueryResolutionException - Exception in org.mule.module.db.internal.resolver.query
Thrown to indicate an error during query resolution
QueryResolutionException(String) - Constructor for exception org.mule.module.db.internal.resolver.query.QueryResolutionException
 
QueryResolutionException(String, Throwable) - Constructor for exception org.mule.module.db.internal.resolver.query.QueryResolutionException
 
queryResolver - Variable in class org.mule.module.db.internal.processor.AbstractBulkUpdateMessageProcessor
 
QueryResolver - Interface in org.mule.module.db.internal.resolver.query
Resolves a Query for a given MuleEvent
queryResolverBean - Variable in class org.mule.module.db.internal.config.processor.AbstractSingleQueryProcessorDefinitionParser
 
QueryResolverFactoryBean - Class in org.mule.module.db.internal.config.resolver.query
 
QueryResolverFactoryBean(Query, ParamValueResolver, DbConfigResolver) - Constructor for class org.mule.module.db.internal.config.resolver.query.QueryResolverFactoryBean
 
queryRunner - Variable in class org.mule.transport.jdbc.JdbcConnector
 
QueryStatementFactory - Class in org.mule.module.db.internal.domain.statement
Creates Statement based on the type and parameters of a given query: _CallableStatement for stored p rocedure queries _PreparedStatement for queries with input parameters _Standard Statement otherwise
QueryStatementFactory() - Constructor for class org.mule.module.db.internal.domain.statement.QueryStatementFactory
 
queryString(HttpServletRequest) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
QueryTemplate - Class in org.mule.module.db.internal.domain.query
Defines a SQL query that could be executed against a database connection.
QueryTemplate(String, QueryType, List<QueryParam>) - Constructor for class org.mule.module.db.internal.domain.query.QueryTemplate
Creates a static SQL query template.
QueryTemplate(String, QueryType, List<QueryParam>, boolean) - Constructor for class org.mule.module.db.internal.domain.query.QueryTemplate
Creates a SQL query template.
QueryTemplate(QueryTemplate) - Constructor for class org.mule.module.db.internal.domain.query.QueryTemplate
Creates a SQL template from another query template
QueryTemplateBeanDefinitionParser - Class in org.mule.module.db.internal.config.domain.query
 
QueryTemplateBeanDefinitionParser() - Constructor for class org.mule.module.db.internal.config.domain.query.QueryTemplateBeanDefinitionParser
 
QueryTemplateFactoryBean - Class in org.mule.module.db.internal.config.domain.query
 
QueryTemplateFactoryBean(QueryTemplate, List<QueryParamValue>) - Constructor for class org.mule.module.db.internal.config.domain.query.QueryTemplateFactoryBean
 
QueryTemplateParser - Interface in org.mule.module.db.internal.parser
Parses a SQL queries
QueryTemplateParsingException - Exception in org.mule.module.db.internal.parser
Thrown to indicate an error parsing a SQL query
QueryTemplateParsingException(String) - Constructor for exception org.mule.module.db.internal.parser.QueryTemplateParsingException
 
QueryType - Enum in org.mule.module.db.internal.domain.query
Defines types of SQL queries
queue - Variable in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
QUEUE - Static variable in class org.mule.transport.jms.config.JmsNamespaceHandler
 
Queue - Interface in org.mule.util.queue
Interface for mule queues used for SEDA and VM.
QUEUE_NAME_PREFIX - Static variable in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
QUEUE_STORE_DEFAULT_IN_MEMORY_NAME - Static variable in class org.mule.api.config.MuleProperties
 
QUEUE_STORE_DEFAULT_PERSISTENT_NAME - Static variable in class org.mule.api.config.MuleProperties
 
QUEUE_WINDOW_SIZE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
queueConfiguration - Variable in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
QueueConfiguration - Class in org.mule.util.queue.objectstore
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
QueueConfiguration(MuleContext, int, QueueStore<Serializable>) - Constructor for class org.mule.util.queue.objectstore.QueueConfiguration
Deprecated.
 
QueueConfiguration(int, QueueStore<Serializable>) - Constructor for class org.mule.util.queue.objectstore.QueueConfiguration
Deprecated.
 
QueueConfiguration - Interface in org.mule.util.queue
Queue configuration attributes
QueueControlDataFile - Class in org.mule.util.queue
Control information for queues.
QueueControlDataFile(QueueFileProvider, File, File) - Constructor for class org.mule.util.queue.QueueControlDataFile
Creates a QueueControlDataFile for storing / retrieving information
QUEUED_ASYNC_PROCESSING_STRATEGY - Static variable in class org.mule.config.spring.util.ProcessingStrategyUtils
 
QUEUED_THREAD_PER_PROCESSOR_PROCESSING_STRATEGY - Static variable in class org.mule.config.spring.util.ProcessingStrategyUtils
 
QueuedAsynchronousProcessingStrategy - Class in org.mule.processor.strategy
This strategy uses a QueueManager to decouple receipt and processing of messages.
QueuedAsynchronousProcessingStrategy() - Constructor for class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
QueuedThreadPerProcessorProcessingStrategy - Class in org.mule.processor.strategy
This strategy uses the QueueManager to decouple the processing of each message processor.
QueuedThreadPerProcessorProcessingStrategy() - Constructor for class org.mule.processor.strategy.QueuedThreadPerProcessorProcessingStrategy
 
QueueFileProvider - Class in org.mule.util.queue
Provides access to a RandomAccessFile for queue data.
QueueFileProvider(File, String) - Constructor for class org.mule.util.queue.QueueFileProvider
 
QueueInfo - Class in org.mule.util.queue.objectstore
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
QueueInfo(String, MuleContext, QueueConfiguration) - Constructor for class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
QueueInfo(QueueInfo) - Constructor for class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
QueueInfo.QueueInfoDelegateFactory - Interface in org.mule.util.queue.objectstore
Deprecated.
A factory for creating object store-specific queue info delegates
QueueInfoDelegate - Interface in org.mule.util.queue.objectstore
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
queueIsFull(String, int) - Static method in class org.mule.transport.vm.i18n.VMMessages
 
QueueKey - Class in org.mule.util.queue.objectstore
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
QueueKey(String, Serializable) - Constructor for class org.mule.util.queue.objectstore.QueueKey
Deprecated.
 
QueueManager - Interface in org.mule.util.queue
A Queue manager is responsible for managing one or more Queue resources and providing common support for transactions and persistence.
queueName - Variable in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
queueName - Variable in class org.mule.util.queue.objectstore.QueueKey
Deprecated.
 
QueuePersistenceObjectStore<T extends Serializable> - Class in org.mule.util.store
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
QueuePersistenceObjectStore() - Constructor for class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
Default constructor for Spring.
QueuePersistenceObjectStore(MuleContext) - Constructor for class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
QueueProducer<T> - Class in org.mule.streaming
Implementation of Producer to stream the contents of a Queue A polling timeout value might be specified, otherwise the default value of 5000 milliseconds will be assumed
QueueProducer(Queue) - Constructor for class org.mule.streaming.QueueProducer
Creates an instance with 5000 milliseconds as the default polling value
QueueProducer(Queue, long) - Constructor for class org.mule.streaming.QueueProducer
 
QueueProfile - Class in org.mule.config
QueueProfile determines how an internal queue for a service will behave
QueueProfile(QueueStore<Serializable>) - Constructor for class org.mule.config.QueueProfile
 
QueueProfile(QueueProfile) - Constructor for class org.mule.config.QueueProfile
 
QueueProfile(int, QueueStore<Serializable>) - Constructor for class org.mule.config.QueueProfile
 
queueProfile - Variable in class org.mule.model.seda.SedaModel
Deprecated.
The queuing profile for events received for this service
queueProfile - Variable in class org.mule.model.seda.SedaService
Deprecated.
The queue profile to use for this service.
queueProfile - Variable in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
QueueProfileFactoryBean - Class in org.mule.config.spring.factories
 
QueueProfileFactoryBean() - Constructor for class org.mule.config.spring.factories.QueueProfileFactoryBean
 
QueueProvider - Interface in org.mule.util.queue
Provides access to a certain queue.
QueueSession - Interface in org.mule.util.queue
Session for executing operation over queues.
QueueStatistics - Interface in org.mule.management.stats
Exposes methods required to increment/decrement queue statistics
queueStatistics - Variable in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
queueStatistics - Variable in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
QueueStatisticsAware - Interface in org.mule.management.stats
 
QueueStore<T extends Serializable> - Interface in org.mule.api.store
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
queueStore - Variable in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
QueueStore - Interface in org.mule.util.queue
Internal queue interface that hold queue configuration that will execute operations directly to the queue storage.
QueueStoreAdapter<T extends Serializable> - Class in org.mule.util.store
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
QueueStoreAdapter(ListableObjectStore<T>) - Constructor for class org.mule.util.store.QueueStoreAdapter
Deprecated.
 
QueueStoreCacheListener - Interface in org.mule.util.queue
Listener for queue operations affecting the queue store cache.
QueueStoreDefinitionParser - Class in org.mule.config.spring.parsers.specific
This allows a queue store to be defined globally, or embedded within a queue profile.
QueueStoreDefinitionParser(Class<?>) - Constructor for class org.mule.config.spring.parsers.specific.QueueStoreDefinitionParser
 
QueueStoreDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.QueueStoreDefinitionParser
For custom processors
QueueStoreDelegate - Interface in org.mule.util.queue
A DefaultQueueStore delegates the actual work of processing its queue to one of these.
queueTimeout - Variable in class org.mule.model.seda.SedaService
Deprecated.
The time out used for taking from the Seda Queue.
queueTimeout - Variable in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
queueTimeout - Variable in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
QueueTransactionContext - Class in org.mule.util.queue.objectstore
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
QueueTransactionContext(TransactionalQueueManager) - Constructor for class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
QueueTransactionContext - Interface in org.mule.util.queue
Contract for a transactional context for queue operations.
QueueTransactionContextFactory<T extends QueueTransactionContext> - Interface in org.mule.util.queue
Factory for a transient and persistent QueueTransactionContext
QueueTypeTransactionContextAdapter<T extends QueueTransactionContext> - Class in org.mule.util.queue
Once a queue operations it's executed this operation creates the correct QueueTransactionContext based on the queue type, persistent or transient.
QueueTypeTransactionContextAdapter(QueueTransactionContextFactory<T>) - Constructor for class org.mule.util.queue.QueueTypeTransactionContextAdapter
 
QueueXaResource - Class in org.mule.util.queue
 
QueueXaResource(AbstractXAResourceManager, XaTransactionRecoverer, QueueProvider) - Constructor for class org.mule.util.queue.QueueXaResource
 
QueueXaResourceManager - Class in org.mule.util.queue
 
QueueXaResourceManager() - Constructor for class org.mule.util.queue.QueueXaResourceManager
 
QuietExceptionStrategy - Class in org.mule.tck.functional
Restrict exceptions to debug log messages
QuietExceptionStrategy() - Constructor for class org.mule.tck.functional.QuietExceptionStrategy
 
QUOTED_PRINTABLE - Static variable in class org.mule.module.http.api.HttpHeaders.Values

R

RamlApiConfiguration - Class in org.mule.module.http.internal.request
 
RamlApiConfiguration() - Constructor for class org.mule.module.http.internal.request.RamlApiConfiguration
 
RANDOMISE_R_NAMES - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
RANGE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
RangeStatusCodeValidator - Class in org.mule.module.http.internal.request
 
RangeStatusCodeValidator() - Constructor for class org.mule.module.http.internal.request.RangeStatusCodeValidator
 
RATE_PER_HOUR - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter representing rate per hour of a counter
RATE_PER_MINUTE - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter representing rate per minute of a counter
RATE_PER_SECOND - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter representing rate per second of a counter
RatePerUnit - Class in org.mule.util.counters.impl
 
RatePerUnit(String, String, CounterFactory.Type, AbstractCounter) - Constructor for class org.mule.util.counters.impl.RatePerUnit
 
read(Reader, boolean) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
 
read(Reader) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
 
read(InputStream, boolean) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method read.
read(InputStream) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Method read.
READ - Static variable in interface org.mule.api.ThreadSafeAccess
 
read(InputStream) - Method in interface org.mule.api.transformer.wire.WireFormat
 
read() - Method in class org.mule.config.ReaderInputStream
 
read() - Method in class org.mule.model.streaming.DelegatingInputStream
 
read(byte[]) - Method in class org.mule.model.streaming.DelegatingInputStream
 
read(byte[], int, int) - Method in class org.mule.model.streaming.DelegatingInputStream
 
read() - Method in class org.mule.module.http.internal.listener.grizzly.BlockingTransferInputStream
 
read(InputStream, byte[]) - Method in class org.mule.tck.functional.FunctionalStreamingTestComponent
 
read(InputStream) - Method in class org.mule.transformer.wire.TransformerPairWireFormat
 
read() - Method in class org.mule.transport.sftp.SftpFileArchiveInputStream
 
read(byte[], int, int) - Method in class org.mule.transport.sftp.SftpFileArchiveInputStream
 
read(byte[]) - Method in class org.mule.transport.sftp.SftpFileArchiveInputStream
 
read() - Method in class org.mule.transport.sftp.SftpInputStream
 
read(byte[], int, int) - Method in class org.mule.transport.sftp.SftpInputStream
 
read(byte[]) - Method in class org.mule.transport.sftp.SftpInputStream
 
read(InputStream) - Method in class org.mule.transport.tcp.protocols.CustomClassLoadingLengthProtocol
 
read(InputStream) - Method in class org.mule.transport.tcp.protocols.DirectProtocol
 
read(InputStream, int) - Method in class org.mule.transport.tcp.protocols.DirectProtocol
 
read(InputStream) - Method in class org.mule.transport.tcp.protocols.LengthProtocol
 
read(InputStream) - Method in class org.mule.transport.tcp.protocols.MuleMessageDirectProtocol
 
read(InputStream) - Method in class org.mule.transport.tcp.protocols.MuleMessageEOFProtocol
 
read(InputStream) - Method in class org.mule.transport.tcp.protocols.MuleMessageLengthProtocol
 
read(InputStream) - Method in class org.mule.transport.tcp.protocols.MuleMessageSafeProtocol
 
read(InputStream) - Method in class org.mule.transport.tcp.protocols.SafeProtocol
 
read(InputStream) - Method in class org.mule.transport.tcp.protocols.StreamingProtocol
 
read(InputStream) - Method in class org.mule.transport.tcp.protocols.XmlMessageProtocol
 
read(InputStream) - Method in interface org.mule.transport.tcp.TcpProtocol
Reads the input stream and returns a whole message.
read() - Method in class org.mule.util.Base64.InputStream
Reads enough of the input stream to convert to/from Base64 and returns the next byte.
read(byte[], int, int) - Method in class org.mule.util.Base64.InputStream
Calls Base64.InputStream.read() repeatedly until the end of stream is reached or len bytes are read.
read(char[], int, int) - Method in class org.mule.util.ChainedReader
 
read() - Method in class org.mule.util.ChainedReader
 
read(char[]) - Method in class org.mule.util.ChainedReader
 
read(byte[], int, int) - Method in class org.mule.util.compression.GZIPCompressorInputStream
 
readAttributes() - Method in class org.mule.util.ClassReader
read an attributes array.
readCode() - Method in class org.mule.util.ClassReader
read a code attribute
readCode() - Method in class org.mule.util.ParamReader
 
readCpool() - Method in class org.mule.util.ClassReader
 
readElements(Iterator) - Method in class org.mule.module.cxf.MuleSoapHeaders
 
ReaderInputStream - Class in org.mule.config
 
ReaderInputStream(Reader) - Constructor for class org.mule.config.ReaderInputStream
 
readExternal(ObjectInput) - Method in class org.mule.module.drools.WorkingMemorySLF4JLogger
 
readFromProperties(TlsConfiguration, Properties) - Method in class org.mule.api.security.tls.TlsPropertiesMapper
 
readInt() - Method in class org.mule.util.ClassReader
 
readJarFileEntries(File) - Static method in class org.mule.util.JarUtils
 
readLine() - Method in class org.apache.commons.httpclient.HttpConnection
Deprecated.
use #readLine(String)
readLine(String) - Method in class org.apache.commons.httpclient.HttpConnection
Reads up to "\n" from the (unchunked) input stream.
readLocalVariableTable() - Method in class org.mule.util.ParamReader
this is invoked when a LocalVariableTable attribute is encountered.
readOnly - Variable in class org.mule.util.queue.objectstore.xa.AbstractTransactionContext
Deprecated.
 
readOnly - Variable in class org.mule.util.xa.AbstractTransactionContext
 
readParams - Variable in class org.mule.transport.jdbc.JdbcMessageReceiver
 
readRequest() - Method in class org.mule.transport.http.HttpServerConnection
 
readResponse() - Method in class org.mule.transport.http.HttpServerConnection
 
readShort() - Method in class org.mule.util.ClassReader
 
readStmt - Variable in class org.mule.transport.jdbc.JdbcMessageReceiver
 
REAL_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
rebind(Name, Object) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
rebind(String, Object) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
rebind(Name, Object) - Method in class org.mule.jndi.SimpleContext
 
rebind(String, Object) - Method in class org.mule.jndi.SimpleContext
 
rebind(Name, Object) - Method in class org.mule.tck.jndi.InMemoryContext
 
rebind(String, Object) - Method in class org.mule.tck.jndi.InMemoryContext
 
receive(String) - Method in interface org.mule.tck.testmodels.services.ITestComponent
 
receive(String) - Method in class org.mule.tck.testmodels.services.TestComponent
 
receive(String) - Method in class org.mule.tck.testmodels.services.TestReceiver
 
receive(long) - Method in class org.mule.transport.xmpp.AbstractXmppConversation
 
receive() - Method in class org.mule.transport.xmpp.AbstractXmppConversation
 
receive(long) - Method in interface org.mule.transport.xmpp.XmppConversation
Wait for a response on this conversation until timeout occurs.
receive() - Method in interface org.mule.transport.xmpp.XmppConversation
Wait for a response on this conversation until a message arrives.
receive() - Method in class org.mule.transport.xmpp.XmppMultiUserChatConversation
 
receive(long) - Method in class org.mule.transport.xmpp.XmppMultiUserChatConversation
 
RECEIVE_MESSAGE_IN_TRANSCTION - Static variable in class org.mule.transport.jdbc.JdbcMessageReceiver
 
RECEIVE_MESSAGES_IN_XA_TRANSCTION - Static variable in class org.mule.transport.jdbc.JdbcMessageReceiver
 
RECEIVE_NO_WAIT - Static variable in interface org.mule.api.transport.MessageDispatcher
 
RECEIVE_NO_WAIT - Static variable in interface org.mule.api.transport.MessageDispatching
 
RECEIVE_WAIT_INDEFINITELY - Static variable in interface org.mule.api.transport.MessageDispatcher
 
RECEIVE_WAIT_INDEFINITELY - Static variable in interface org.mule.api.transport.MessageDispatching
 
Receiveable - Interface in org.mule.tck.functional
Interface only to be used by the FunctionalTestComponent.
receiveAction(RemoteDispatcherNotification, MuleEventContext) - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
receiveAsyncReply(MuleEvent) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
receiveBufferSize - Variable in class org.mule.transport.udp.UdpConnector
 
receiveBytes(byte[]) - Method in class org.mule.tck.testmodels.services.TestComponent
 
receivedEventASync - Variable in class org.mule.management.stats.AbstractFlowConstructStatistics
 
receivedEventSync - Variable in class org.mule.management.stats.AbstractFlowConstructStatistics
 
ReceiveException - Exception in org.mule.api.transport
ReceiveException is specifically thrown by the Provider receive method if something fails in the underlying transport
ReceiveException(Message, ImmutableEndpoint, long) - Constructor for exception org.mule.api.transport.ReceiveException
 
ReceiveException(Message, ImmutableEndpoint, long, Throwable) - Constructor for exception org.mule.api.transport.ReceiveException
 
ReceiveException(ImmutableEndpoint, long, Throwable) - Constructor for exception org.mule.api.transport.ReceiveException
 
receiveFromSocket(Socket, int, ImmutableEndpoint) - Static method in class org.mule.transport.tcp.TcpMessageDispatcher
 
receiveMessagesInTransaction - Variable in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
determines whether messages will be received in a transaction template
receiveMessagesInXaTransaction - Variable in class org.mule.transport.jdbc.JdbcMessageReceiver
 
receiver - Variable in class org.mule.transport.AbstractReceiverWorker
 
receiver - Variable in class org.mule.transport.PollingReceiverWorker
 
receiver - Variable in class org.mule.transport.PollingReceiverWorkerSchedule
 
receiver(MuleContext, String) - Static method in class org.mule.util.concurrent.ThreadNameHelper
 
receiveRemote(String, int) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
receiverKey - Variable in class org.mule.transport.AbstractMessageReceiver
Stores the key to this receiver, as used by the Connector to store the receiver.
receiverNotInJobDataMap() - Static method in class org.mule.transport.quartz.i18n.QuartzMessages
 
receiverPropertyNotSet() - Static method in class org.mule.transport.http.i18n.HttpMessages
 
receivers - Variable in class org.mule.transport.AbstractConnector
The collection of listeners on this connector.
receiversCount - Variable in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver
 
receiveTransformer - Variable in class org.mule.transport.http.HttpClientMessageRequester
 
recipient - Variable in class org.mule.transport.xmpp.AbstractXmppConversation
 
RECIPIENT - Static variable in class org.mule.transport.xmpp.config.XmppNamespaceHandler
 
RECIPIENT_DELIMITER - Static variable in class org.mule.routing.outbound.StaticRecipientList
Deprecated.
 
RECIPIENTS_PROPERTY - Static variable in class org.mule.routing.outbound.StaticRecipientList
Deprecated.
 
reconnectStrategyFailed(Class<?>, String) - Static method in class org.mule.config.i18n.CoreMessages
 
ReconnectWorkManager - Class in org.mule.transport.jms.reconnect
Fake work manager for executing jms endpoint level reconnection thread.
ReconnectWorkManager(MuleContext) - Constructor for class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
ReconnectWorkManager.WorkDelegate - Class in org.mule.transport.jms.reconnect
Deprecated.
ReconnectWorkManager.WorkDelegate() - Constructor for class org.mule.transport.jms.reconnect.ReconnectWorkManager.WorkDelegate
Deprecated.
 
recover() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
recover() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
recover() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
recover(int) - Method in class org.mule.transport.jms.xa.XAResourceWrapper
 
recover() - Method in class org.mule.util.journal.queue.LocalTxQueueTransactionRecoverer
Recover all the pending transactions.
recover() - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
recover() - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
recover(int) - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
recover(int) - Method in class org.mule.util.queue.QueueXaResource
 
recover(int) - Method in class org.mule.util.queue.TransactionalQueueSession
 
recover() - Method in class org.mule.util.xa.AbstractResourceManager
 
recover(int) - Method in class org.mule.util.xa.XaTransactionRecoverer
 
RecoverableException - Exception in org.mule.api.lifecycle
RecoverableException can be thrown during initialisation to indicate that the error occurred is not fatal and a reactive action can be performed to try and remedy the error.
RecoverableException(Message, Initialisable) - Constructor for exception org.mule.api.lifecycle.RecoverableException
 
RecoverableException(Message, Initialisable, Throwable) - Constructor for exception org.mule.api.lifecycle.RecoverableException
 
RecoverableQueueStore - Interface in org.mule.util.queue
Extension of QueueStore required to be able to recover a queue store base on a transaction journal.
recreate() - Method in class org.mule.util.queue.QueueFileProvider
recreates the file from scratch doing a delete then create.
recursiveDelete(String) - Method in class org.mule.tck.util.ftp.FtpClient
Delete all files and subdirectories.
recursivelyDeleteDirectory(String) - Method in class org.mule.transport.sftp.SftpClient
 
REDELIVERY_FAIL_ON_FIRST - Static variable in class org.mule.processor.AbstractRedeliveryPolicy
 
REDELIVERY_FAIL_ON_FIRST - Static variable in class org.mule.transport.jms.JmsConnector
Indicates that Mule should throw an exception on any redelivery attempt.
REDELIVERY_IGNORE - Static variable in class org.mule.transport.jms.JmsConnector
 
RedeliveryExceeded - Class in org.mule.exception
 
RedeliveryExceeded() - Constructor for class org.mule.exception.RedeliveryExceeded
 
redeliveryHandler - Variable in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
RedeliveryHandler - Interface in org.mule.transport.jms.redelivery
RedeliveryHandler is used to control how redelivered messages are processed by a connector.
redeliveryHandler - Variable in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
RedeliveryHandlerFactory - Interface in org.mule.transport.jms.redelivery
Implementors of this interface are responsible to create RedeliveryHandler instances upon request.
redeliveryPolicy - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
redeploy(T) - Method in interface org.mule.module.launcher.ArchiveDeployer
 
redeploy(T, Optional<Properties>) - Method in interface org.mule.module.launcher.ArchiveDeployer
 
redeploy(T) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
redeploy(T, Optional<Properties>) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
redeploy(String, Properties) - Method in interface org.mule.module.launcher.DeploymentService
Undeploys and redeploys an application with the properties provided.
redeploy(String) - Method in interface org.mule.module.launcher.DeploymentService
Undeploys and redeploys an application
redeploy(Domain) - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
redeploy(Domain, Optional<Properties>) - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
redeploy(String) - Method in class org.mule.module.launcher.MuleDeploymentService
 
redeploy(String, Properties) - Method in class org.mule.module.launcher.MuleDeploymentService
 
redeployDomain(String) - Method in interface org.mule.module.launcher.DeploymentService
Undeploys and redeploys a domain
redeployDomain(String, Properties) - Method in interface org.mule.module.launcher.DeploymentService
Undeploys and redeploys a domain
redeployDomain(String) - Method in class org.mule.module.launcher.MuleDeploymentService
 
redeployDomain(String, Properties) - Method in class org.mule.module.launcher.MuleDeploymentService
 
redeploymentEnabled - Variable in class org.mule.module.launcher.descriptor.ArtifactDescriptor
 
REDIRECT_STATUS_CODE - Static variable in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
REDIRECT_STATUS_CODE_RANGE_START - Static variable in class org.mule.transport.http.HttpClientMessageDispatcher
 
REDIRECT_URI_PARAMETER - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
REF_ATTRIBUTE_NAME - Static variable in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
REF_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
REF_SUFFIX - Static variable in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
reference - Variable in class org.mule.config.spring.parsers.processors.ConstructorReference
 
ReferenceExceptionStrategyDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
ReferenceExceptionStrategyDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.ReferenceExceptionStrategyDefinitionParser
 
REFERER - Static variable in class org.mule.module.http.api.HttpHeaders.Names
refineMethod(MuleEvent, Call, Object) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
ReflectionEntryPointResolver - Class in org.mule.model.resolvers
ReflectEntryPointResolver is used to determine the entry point on a service after an event has been received for it.
ReflectionEntryPointResolver() - Constructor for class org.mule.model.resolvers.ReflectionEntryPointResolver
 
ReflectionMuleCoreExtensionDependencyDiscoverer - Class in org.mule.module.launcher.coreextension
Discovers dependencies between MuleCoreExtension instances looking for methods annotated with MuleCoreExtensionDependency
ReflectionMuleCoreExtensionDependencyDiscoverer() - Constructor for class org.mule.module.launcher.coreextension.ReflectionMuleCoreExtensionDependencyDiscoverer
 
ReflectionMuleCoreExtensionDependencyResolver - Class in org.mule.module.launcher.coreextension
Resolves dependencies using reflection to inject the required MuleCoreExtension in the dependant instance.
ReflectionMuleCoreExtensionDependencyResolver() - Constructor for class org.mule.module.launcher.coreextension.ReflectionMuleCoreExtensionDependencyResolver
 
ReflectionMuleCoreExtensionDependencyResolver(MuleCoreExtensionDependencyDiscoverer) - Constructor for class org.mule.module.launcher.coreextension.ReflectionMuleCoreExtensionDependencyResolver
 
ReflectiveMethodOperationExecutor - Class in org.mule.module.extension.internal.runtime
Implementation of OperationExecutor which relies on a ReflectiveMethodOperationExecutor.executorDelegate and a reference to one of its Methods.
ReflectiveOperationExecutorFactory<T> - Class in org.mule.module.extension.internal.runtime
An implementation of OperationExecutorFactory which produces instances of ReflectiveMethodOperationExecutor.
ReflectiveOperationExecutorFactory(Class<T>, Method) - Constructor for class org.mule.module.extension.internal.runtime.ReflectiveOperationExecutorFactory
 
refresh() - Method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider.JaasConfig
 
REFRESH_TOKEN_EXPRESSION - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
REFRESH_TOKEN_PARAMETER - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
refreshAccessToken() - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
refreshAccessToken() - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsTokenRequestHandler
 
refreshAccessToken(OAuth2Adapter, String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
if refresh token is available, then it makes an http call to refresh the access token.
refreshAccessToken(String) - Method in interface org.mule.security.oauth.OAuth2Adapter
 
refreshAccessToken(OAuth2Adapter, String) - Method in interface org.mule.security.oauth.OAuth2Manager
if refresh token is available, then it makes an http call to refresh the access token.
refreshAccessTokenOn() - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
refreshToken(MuleEvent, String) - Method in class org.mule.module.oauth2.internal.authorizationcode.AbstractAuthorizationCodeTokenRequestHandler
Updates the access token by calling the token url with refresh token grant type
refreshToken(MuleEvent, String) - Method in interface org.mule.module.oauth2.internal.authorizationcode.AuthorizationCodeGrantType
Does a refresh token for a particular oauth context id.
refreshToken(MuleEvent, String) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
refreshToken(OAuth2Adapter, String) - Method in class org.mule.security.oauth.DefaultRefreshTokenManager
Refreshes the token of the given id for the given adapter.
refreshToken(OAuth2Adapter, String) - Method in interface org.mule.security.oauth.RefreshTokenManager
Refreshes the token of the given id for the given adapter.
RefreshTokenManager - Interface in org.mule.security.oauth
 
RefreshTokenProcessInterceptor<T> - Class in org.mule.security.oauth.process
 
RefreshTokenProcessInterceptor(ProcessInterceptor<T, OAuth2Adapter>, MuleContext) - Constructor for class org.mule.security.oauth.process.RefreshTokenProcessInterceptor
 
REFS_SUFFIX - Static variable in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
REFS_TOKENS - Static variable in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
RegexExpressionEvaluator - Class in org.mule.expression
 
RegexExpressionEvaluator() - Constructor for class org.mule.expression.RegexExpressionEvaluator
 
RegexExpressionLanguageFuntion - Class in org.mule.el.function
 
RegexExpressionLanguageFuntion() - Constructor for class org.mule.el.function.RegexExpressionLanguageFuntion
 
RegExFilter - Class in org.mule.routing.filters
RegExFilter is used to match a String argument against a regular expression.
RegExFilter() - Constructor for class org.mule.routing.filters.RegExFilter
 
RegExFilter(String) - Constructor for class org.mule.routing.filters.RegExFilter
 
RegExFilter(String, int) - Constructor for class org.mule.routing.filters.RegExFilter
 
RegExFilter(String, String) - Constructor for class org.mule.routing.filters.RegExFilter
 
RegExFilter(String, String, int) - Constructor for class org.mule.routing.filters.RegExFilter
 
RegExFilterDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
RegExFilterDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.RegExFilterDefinitionParser
 
RegExFilterDefinitionParser.FlagsMapping - Class in org.mule.config.spring.parsers.specific
Map a comma-separated string to an Integer object that can be used to set the flags on a RegExFilter.
RegExFilterDefinitionParser.FlagsMapping() - Constructor for class org.mule.config.spring.parsers.specific.RegExFilterDefinitionParser.FlagsMapping
 
register() - Method in class org.mule.lifecycle.PrimaryNodeLifecycleNotificationListener
 
register(String, Class, DataContentHandler) - Method in class org.mule.transport.email.DefaultDataContentHandlerFactory
Register a DataContentHandler for a particular MIME type.
register(DataContentHandler) - Method in class org.mule.transport.email.DefaultDataContentHandlerFactory
Registers a DataContentHandler for use with certain mime types.
registerAction(String, int) - Static method in class org.mule.api.context.notification.ServerNotification
 
registerAgent(Agent) - Method in interface org.mule.api.registry.MuleRegistry
 
registerAgent(Agent, MuleRegistry) - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
registerAgent(Agent) - Method in class org.mule.registry.MuleRegistryHelper
registerApplicationServices() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
registerBean(Element, BeanDefinition) - Method in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
registerBeanDefinition(String, BeanDefinition) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
registerBeanDefinitionHolder(BeanDefinitionHolder) - Method in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
registerComponent(Object, String, EndpointURI) - Method in class org.mule.module.client.MuleClient
Deprecated.
Use the RegistryContext to get the registry and register the service there
registerComponent(Object, String, MuleEndpointURI, MuleEndpointURI) - Method in class org.mule.module.client.MuleClient
Deprecated.
Use the RegistryContext to get the registry and register the service there
registerConfigurationInstance(Extension, String, C) - Method in class org.mule.module.extension.internal.manager.DefaultExtensionManager
registerConfigurationInstanceProvider(Extension, String, ConfigurationInstanceProvider<C>) - Method in class org.mule.module.extension.internal.manager.DefaultExtensionManager
registerConfigurationService() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
registerConnector(Connector) - Method in interface org.mule.api.registry.MuleRegistry
 
registerConnector(Connector) - Method in class org.mule.registry.MuleRegistryHelper
registerConnectorDefinitionParser(Class, String) - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
registerConnectorDefinitionParser(Class) - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
registerConnectorDefinitionParser(MuleDefinitionParser) - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
registerConnectorServices() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
registerCustomEditors(PropertyEditorRegistry) - Method in class org.mule.config.spring.editors.MulePropertyEditorRegistrar
 
registerDataSourceDefinitionParsers() - Method in class org.mule.transport.jdbc.config.JdbcNamespaceHandler
 
registerDb2DataSourceDefinitionParser() - Method in class org.mule.transport.jdbc.config.JdbcNamespaceHandler
 
registerDelegateFactory(Class<? extends ObjectStore>, QueueInfo.QueueInfoDelegateFactory) - Static method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
registerDeprecatedBeanDefinitionParser(String, BeanDefinitionParser, String) - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
registerDeprecatedBeanDefinitionParser(String, BeanDefinitionParser) - Method in class org.mule.transport.http.config.HttpNamespaceHandler
 
registerDeprecatedConnectorDefinitionParser(Class, String) - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
registerDeprecatedConnectorDefinitionParser(Class) - Method in class org.mule.transport.http.config.HttpNamespaceHandler
 
registerDeprecatedMuleBeanDefinitionParser(String, MuleDefinitionParser, String) - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
registerDeprecatedMuleBeanDefinitionParser(String, MuleDefinitionParser) - Method in class org.mule.transport.http.config.HttpNamespaceHandler
 
registerDerbyDataSourceDefinitionParser() - Method in class org.mule.transport.jdbc.config.JdbcNamespaceHandler
 
registerEndpoint(ImmutableEndpoint) - Method in interface org.mule.api.registry.MuleRegistry
 
registerEndpoint(ImmutableEndpoint) - Method in class org.mule.endpoint.DefaultEndpointFactory
 
registerEndpoint(ImmutableEndpoint) - Method in class org.mule.registry.MuleRegistryHelper
registerEndpointBuilder(String, EndpointBuilder) - Method in interface org.mule.api.registry.MuleRegistry
 
registerEndpointBuilder(String, EndpointBuilder) - Method in class org.mule.registry.MuleRegistryHelper
registerEndpointServices() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
registerEnricher(ExpressionEnricher) - Method in interface org.mule.api.expression.ExpressionManager
 
registerEnricher(ExpressionEnricher) - Method in class org.mule.expression.DefaultExpressionManager
 
registerEvaluator(ExpressionEvaluator) - Method in interface org.mule.api.expression.ExpressionManager
 
registerEvaluator(ExpressionEvaluator) - Method in class org.mule.expression.DefaultExpressionManager
 
registerExceptionReader(ExceptionReader) - Static method in class org.mule.config.ExceptionHelper
Registers an exception reader with Mule
registerExtension(Extension) - Method in class org.mule.module.extension.internal.manager.DefaultExtensionManager
registerFlowConstruct(FlowConstruct) - Method in interface org.mule.api.registry.MuleRegistry
 
registerFlowConstruct(FlowConstruct) - Method in class org.mule.registry.MuleRegistryHelper
registerFlowConstructServices() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
registerHandler(String, URLStreamHandler) - Static method in class org.mule.util.MuleUrlStreamHandlerFactory
 
registerHostAndPortTypeDefinitionParser(Class<? extends AbstractDataSourceFactoryBean>, String) - Method in class org.mule.transport.jdbc.config.JdbcNamespaceHandler
 
registerIgnoredElement(String) - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
registerInjectorProcessor(BeanDefinitionRegistry) - Method in class org.mule.config.spring.MuleArtifactContext
 
registerJmsEndpointDefinitionParser(String, MuleDefinitionParser) - Method in class org.mule.transport.jms.config.JmsNamespaceHandler
 
registerJmsTransportEndpoints() - Method in class org.mule.transport.jms.config.JmsNamespaceHandler
Need to use the most complex constructors as have mutually exclusive address aattributes
registerLifecycleCallback(String, LifecycleCallback<O>) - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
registerListener(ServerNotificationListener) - Method in interface org.mule.api.MuleContext
Registers an intenal server event listener.
registerListener(ServerNotificationListener, String) - Method in interface org.mule.api.MuleContext
Registers an intenal server event listener.
registerListener(InboundEndpoint, MessageProcessor, FlowConstruct) - Method in interface org.mule.api.transport.Connector
Registers a MessageProcessor listener which will listen to new message received from a specific transport channel and then processed by the endpoint.
registerListener(ServerNotificationListener) - Method in class org.mule.DefaultMuleContext
 
registerListener(ServerNotificationListener, String) - Method in class org.mule.DefaultMuleContext
 
registerListener(InboundEndpoint, MessageProcessor, FlowConstruct) - Method in class org.mule.transport.AbstractConnector
 
registerListener(InboundEndpoint, MessageProcessor, FlowConstruct) - Method in class org.mule.transport.http.HttpConnector
 
registerListener(InboundEndpoint, MessageProcessor, FlowConstruct) - Method in class org.mule.transport.stdio.StdioConnector
 
registerLogConfigChangeListener(PropertyChangeListener) - Method in interface org.mule.logging.LogConfigChangeSubject
Register a listener to be called when log config is changed.
registerMaskedPropertyName(String) - Static method in class org.mule.util.PropertiesUtils
Register a property name for masking.
registerMetaTransportEndpoints(String) - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
registerModel(Model) - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
registerModel(Model) - Method in class org.mule.registry.MuleRegistryHelper
Deprecated.
registerModelServices() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
registerMuleBeanDefinitionParser(String, MuleDefinitionParser) - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
registerMuleService() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
registerMulticasterComponent() - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
 
registerMysqlDataSourceDefinitionParser() - Method in class org.mule.transport.jdbc.config.JdbcNamespaceHandler
 
registerNamespaces(Map<String, String>) - Method in class org.mule.module.xml.xpath.JaxpXPathEvaluator
Registers the given namespaces so that they can be recognized during evaluation
registerNamespaces(NamespaceManager) - Method in class org.mule.module.xml.xpath.JaxpXPathEvaluator
Registers the namespaces in namespaceManager
registerNamespaces(Map<String, String>) - Method in interface org.mule.module.xml.xpath.XPathEvaluator
Registers the given namespaces so that they can be recognized during evaluation
registerNamespaces(NamespaceManager) - Method in interface org.mule.module.xml.xpath.XPathEvaluator
Registers the namespaces in namespaceManager
registerObject(String, Object) - Method in interface org.mule.api.registry.Registry
Registers an object in the registry with a key.
registerObject(String, Object, Object) - Method in interface org.mule.api.registry.Registry
Deprecated.
registerObject(String, Object) - Method in class org.mule.config.spring.SpringRegistry
 
registerObject(String, Object, Object) - Method in class org.mule.config.spring.SpringRegistry
 
registerObject(String, Object) - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
registerObject(String, Object, Object) - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
registerObject(String, Object) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
Registers an object in the registry with a key.
registerObject(String, Object, Object) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
registerObject(String, Object, Object) - Method in class org.mule.registry.MuleRegistryHelper
Registers an object in the registry with a key.
registerObject(String, Object) - Method in class org.mule.registry.MuleRegistryHelper
Registers an object in the registry with a key.
registerObject(String, Object) - Method in class org.mule.registry.TransientRegistry
Deprecated.
Allows for arbitary registration of transient objects
registerObject(String, Object, Object) - Method in class org.mule.registry.TransientRegistry
Deprecated.
Allows for arbitrary registration of transient objects
registerObjectProcessor(ObjectProcessor) - Method in class org.mule.config.endpoint.RegistryBackedAnnotationsParserFactory
 
registerObjects(Map<String, Object>) - Method in interface org.mule.api.registry.Registry
Registers a Map of objects into the registry
registerObjects(Map<String, Object>) - Method in class org.mule.config.spring.SpringRegistry
 
registerObjects(Map) - Method in class org.mule.module.guice.GuiceRegistry
Deprecated.
 
registerObjects(Map) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
Registers a Map of objects into the registry
registerObjects(Map) - Method in class org.mule.registry.MuleRegistryHelper
Registers a Map of objects into the registry
registerObjects(Map<String, Object>) - Method in class org.mule.registry.TransientRegistry
Deprecated.
 
registerOptionalKey(String) - Method in class org.mule.config.spring.CompositeOptionalObjectsController
 
registerOptionalKey(String) - Method in class org.mule.config.spring.DefaultOptionalObjectsController
 
registerOptionalKey(String) - Method in interface org.mule.config.spring.OptionalObjectsController
Registers the given key as optional
registerOutParameter(CallableStatement, int) - Method in class org.mule.module.db.internal.domain.type.AbstractDbType
 
registerOutParameter(CallableStatement, int) - Method in class org.mule.module.db.internal.domain.type.AbstractStructuredDbType
 
registerOutParameter(CallableStatement, int) - Method in interface org.mule.module.db.internal.domain.type.DbType
Registers an output parameter
registerOutParameter(CallableStatement, int) - Method in class org.mule.module.db.internal.domain.type.DynamicDbType
 
registerOutParameter(CallableStatement, int) - Method in class org.mule.module.db.internal.domain.type.StructuredDbType
 
registerPhase(String, LifecyclePhase) - Method in class org.mule.lifecycle.RegistryLifecycleManager
 
registerPhase(String, LifecyclePhase, LifecycleCallback) - Method in class org.mule.lifecycle.RegistryLifecycleManager
 
registerPhases() - Method in class org.mule.config.spring.SpringRegistryLifecycleManager
 
registerPhases() - Method in class org.mule.lifecycle.RegistryBrokerLifecycleManager
Deprecated.
 
registerPhases() - Method in class org.mule.lifecycle.RegistryLifecycleManager
 
registerPojo(String, Class<?>) - Method in class org.mule.config.spring.handlers.AbstractPojoNamespaceHandler
 
registerPostgresqlDataSourceDefinitionParser() - Method in class org.mule.transport.jdbc.config.JdbcNamespaceHandler
 
registerPostProcessor(BeanDefinitionRegistry, RootBeanDefinition, String) - Method in class org.mule.config.spring.MuleArtifactContext
 
registerPostProcessor(PostProcessor) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
registerPostProcessor(PostProcessor) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
registerPostProcessor(PostProcessor) - Method in class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
registerPostProcessor(PostProcessor) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
registerPostProcessor(PostProcessor) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
registerPostProcessor(PostProcessor) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParserConfiguration
These are appended to existing processors
registerPreProcessor(PreProcessor) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
registerPreProcessor(PreProcessor) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
registerPreProcessor(PreProcessor) - Method in class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
registerPreProcessor(PreProcessor) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
registerPreProcessor(PreProcessor) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
registerPreProcessor(PreProcessor) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParserConfiguration
These are prepended to existing processors
registerProtocols() - Method in class org.mule.transport.soap.axis.AxisConnector
 
registerProtocols() - Method in class org.mule.transport.soap.axis.wsdl.AxisWsdlConnector
 
registerQuartzEndpointDefinitionParser(String, MuleDefinitionParser) - Method in class org.mule.transport.quartz.config.QuartzNamespaceHandler
 
registerQuartzTransportEndpoints() - Method in class org.mule.transport.quartz.config.QuartzNamespaceHandler
Need to use the most complex constructors as have mutually exclusive address aattributes
registerReceiverWithMuleService(MessageReceiver, EndpointURI) - Method in class org.mule.transport.soap.axis.AxisConnector
 
registerResolvableDependency(Class<?>, Object) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
registerScheduler(Scheduler) - Method in interface org.mule.api.registry.MuleRegistry
 
registerScheduler(Scheduler) - Method in class org.mule.registry.MuleRegistryHelper
 
registerService(Service) - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
registerService(Service) - Method in class org.mule.registry.MuleRegistryHelper
registerServices() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
registerServices() - Method in class org.mule.module.management.agent.JmxApplicationAgent
 
registerServices() - Method in class org.mule.module.management.agent.JmxDomainAgent
 
registerServiceServices() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
registerShutdownHook() - Method in class org.mule.module.launcher.MuleContainer
 
registerShutdownHook() - Method in class org.mule.MuleServer
 
registerSingleton(String, Object) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
registerSourceType(Class<?>) - Method in class org.mule.transformer.AbstractTransformer
Deprecated.
use registerSourceType(DataType)
registerSourceType(DataType<?>) - Method in class org.mule.transformer.AbstractTransformer
Register a supported data type with this transformer.
registerStandardTransportEndpoints(String, String[]) - Method in class org.mule.config.spring.handlers.AbstractMuleNamespaceHandler
 
registerStatisticsService() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
registerSupportedMetaProtocol(String) - Method in class org.mule.transport.AbstractConnector
Used by Meta endpoint descriptors to register support for endpoint of the meta endpoint type.
registerSupportedPhase(String) - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
registerSupportedPhase(String) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
registerSupportedProtocol(String) - Method in class org.mule.transport.AbstractConnector
Registers other protocols 'understood' by this connector.
registerSupportedProtocolWithoutPrefix(String) - Method in class org.mule.transport.AbstractConnector
Registers other protocols 'understood' by this connector.
registerTransactionFactory(Class, TransactionFactory) - Method in class org.mule.api.SingleResourceTransactionFactoryManager
 
registerTransformer(Transformer) - Method in interface org.mule.api.registry.MuleRegistry
 
registerTransformer(Transformer) - Method in class org.mule.registry.MuleRegistryHelper
registerTransformerResolver(TransformerResolver) - Method in class org.mule.registry.MuleRegistryHelper
 
registerTransformers() - Method in class org.mule.config.bootstrap.AbstractRegistryBootstrap
 
registerTransformers() - Method in class org.mule.config.bootstrap.SimpleRegistryBootstrap
Deprecated.
 
registerTransformers() - Method in class org.mule.config.spring.SpringRegistryBootstrap
 
registerTransitions() - Method in class org.mule.construct.FlowConstructLifecycleManager
 
registerTransitions() - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
registerTransitions() - Method in class org.mule.lifecycle.MuleContextLifecycleManager
 
registerTransitions() - Method in class org.mule.lifecycle.RegistryLifecycleManager
 
registerTransitions() - Method in class org.mule.lifecycle.SimpleLifecycleManager
 
registerTransitions() - Method in class org.mule.processor.SedaStageLifecycleManager
 
registerTransitions() - Method in class org.mule.service.ServiceLifecycleManager
Deprecated.
 
registerTransportTypes() - Method in class org.mule.transport.soap.axis.AxisConnector
 
registerType(DbType) - Method in class org.mule.module.db.internal.domain.type.MetadataDbTypeManager
 
registerWrapperService() - Method in class org.mule.module.management.agent.AbstractJmxAgent
Register a Java Service Wrapper agent.
RegistrationException - Exception in org.mule.api.registry
 
RegistrationException(Message) - Constructor for exception org.mule.api.registry.RegistrationException
 
RegistrationException(Throwable) - Constructor for exception org.mule.api.registry.RegistrationException
 
RegistrationException(Message, Throwable) - Constructor for exception org.mule.api.registry.RegistrationException
 
Registry - Interface in org.mule.api.registry
 
registry - Variable in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
REGISTRY_DISPOSED - Static variable in class org.mule.context.notification.RegistryNotification
 
REGISTRY_DISPOSING - Static variable in class org.mule.context.notification.RegistryNotification
 
REGISTRY_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
REGISTRY_ID - Static variable in class org.mule.config.spring.SpringRegistry
 
REGISTRY_ID - Static variable in class org.mule.registry.TransientRegistry
Deprecated.
 
REGISTRY_INITIALISED - Static variable in class org.mule.context.notification.RegistryNotification
 
REGISTRY_INITIALISING - Static variable in class org.mule.context.notification.RegistryNotification
 
RegistryBackedAnnotationsParserFactory - Class in org.mule.config.endpoint
Loads the default expression, router and endpoint parsers provided by Mule.
RegistryBackedAnnotationsParserFactory() - Constructor for class org.mule.config.endpoint.RegistryBackedAnnotationsParserFactory
 
RegistryBootstrapDiscoverer - Interface in org.mule.config.bootstrap
Allows to discover properties to be used during the bootstrap process.
RegistryBroker - Interface in org.mule.api.registry
Deprecated.
as of 3.7.0. This will be removed in Mule 4.0
RegistryBrokerLifecycleManager - Class in org.mule.lifecycle
Deprecated.
as of 3.7.0 since RegistryBroker also is
RegistryBrokerLifecycleManager(String, Registry, MuleContext) - Constructor for class org.mule.lifecycle.RegistryBrokerLifecycleManager
Deprecated.
 
RegistryDelegatingInjector - Class in org.mule.registry
An implementation of Injector which uses a RegistryProvider to look for Registry instances which also implement Injector.
RegistryDelegatingInjector(RegistryProvider) - Constructor for class org.mule.registry.RegistryDelegatingInjector
 
RegistryExpressionEvaluator - Class in org.mule.expression
Looks up information about objects in the Registry
RegistryExpressionEvaluator() - Constructor for class org.mule.expression.RegistryExpressionEvaluator
 
registryId - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
RegistryLifecycleCallback<T> - Class in org.mule.lifecycle
An implementation of LifecycleCallback for applying Registry lifecycles
RegistryLifecycleCallback(RegistryLifecycleManager) - Constructor for class org.mule.lifecycle.RegistryLifecycleCallback
 
RegistryLifecycleHelpers - Interface in org.mule.api.lifecycle
This interface defines additional Registry Lifecycle methods to enable extenral objects to have there lifecycle managed by the registry.
registryLifecycleManager - Variable in class org.mule.lifecycle.RegistryLifecycleCallback
 
RegistryLifecycleManager - Class in org.mule.lifecycle
 
RegistryLifecycleManager(String, Registry, MuleContext) - Constructor for class org.mule.lifecycle.RegistryLifecycleManager
 
RegistryLifecycleManager(String, Registry, Map<String, LifecyclePhase>) - Constructor for class org.mule.lifecycle.RegistryLifecycleManager
 
RegistryLookupBindings - Class in org.mule.module.scripting.component
This class will attempt to lookup up objects inside the registry in case they don't exist in the delegate binding.
RegistryLookupBindings(Registry, Bindings) - Constructor for class org.mule.module.scripting.component.RegistryLookupBindings
 
RegistryLookupValueResolver<T> - Class in org.mule.module.extension.internal.runtime.resolver
Implementation of ValueResolver which accesses the mule registry and returns the value associated with RegistryLookupValueResolver.key.
RegistryLookupValueResolver(String) - Constructor for class org.mule.module.extension.internal.runtime.resolver.RegistryLookupValueResolver
Construct a new instance and set the RegistryLookupValueResolver.key that will be used to access the registry
RegistryMap - Class in org.mule.registry
Provides a HashMap view of values stored in the registry
RegistryMap(Registry) - Constructor for class org.mule.registry.RegistryMap
 
RegistryMap(int, Registry) - Constructor for class org.mule.registry.RegistryMap
 
RegistryMap(int, float, Registry) - Constructor for class org.mule.registry.RegistryMap
 
RegistryMap(Map, Registry) - Constructor for class org.mule.registry.RegistryMap
 
RegistryNotification - Class in org.mule.context.notification
RegistryNotification is fired when an event such as a Registry being started occurs.
RegistryNotification(Registry, String) - Constructor for class org.mule.context.notification.RegistryNotification
 
RegistryNotification(Registry, int) - Constructor for class org.mule.context.notification.RegistryNotification
 
RegistryNotificationListener<T extends RegistryNotification> - Interface in org.mule.api.context.notification
RegistryNotificationListener is an observer interface that objects can implement and then register themselves with the MuleContext to be notified when a Registry event occurs.
RegistryProvider - Interface in org.mule.api.registry
A component capable of providing all the registered Registry instances
RegistryServiceMBean - Interface in org.mule.module.management.mbean
RegistryServiceMBean JMX Service interface for the Registry
regMap - Variable in class org.mule.config.endpoint.AnnotatedEndpointHelper
 
regProps - Variable in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.mule.util.concurrent.WaitPolicy
 
relativize(URI) - Method in class org.mule.endpoint.MuleEndpointURI
 
release() - Method in interface org.mule.api.MuleMessage
Perform any clean up operations on the message resource.
release() - Method in class org.mule.component.AbstractComponent
 
release() - Method in class org.mule.context.notification.ServerNotificationManager
 
release() - Method in class org.mule.DefaultMuleMessage
Perform any clean up operations on the message resource.
release() - Method in class org.mule.module.db.internal.domain.connection.AbstractDbConnection
 
release() - Method in interface org.mule.module.db.internal.domain.connection.DbConnection
Indicates that the connection is not used anymore
release(DbConnection) - Method in interface org.mule.module.db.internal.domain.connection.DbConnectionReleaser
Releases a given connection
release(DbConnection) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnectionReleaser
 
release() - Method in class org.mule.module.launcher.artifact.DefaultResourceReleaser
 
release() - Method in interface org.mule.module.launcher.artifact.ResourceReleaser
Attempts to release, during an Artifact undeployment, resources that were not explicitly released and could cause a memory leak.
release() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
release() - Method in class org.mule.retry.async.RetryWorker
 
release() - Method in class org.mule.transport.AbstractReceiverWorker
This method is called once this worker is no longer required.
release() - Method in class org.mule.transport.http.OldHttpMessageReceiver.HttpWorker
 
release() - Method in class org.mule.transport.jms.JmsMessageDispatcher.LatchReplyToListener
 
release() - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager.WorkDelegate
Deprecated.
 
release() - Method in class org.mule.transport.PollingReceiverWorker
 
release() - Method in class org.mule.transport.tcp.TcpMessageReceiver
 
release() - Method in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
release() - Method in class org.mule.transport.TransactedPollingMessageReceiver.MessageProcessorWorker
 
release() - Method in class org.mule.transport.udp.UdpMessageReceiver
 
release() - Method in class org.mule.transport.udp.UdpMessageReceiver.UdpWorker
 
release() - Method in class org.mule.transport.vm.VMMessageReceiver.MessageProcessorWorker
 
release() - Method in class org.mule.util.concurrent.Latch
 
release() - Method in class org.mule.work.AbstractMuleEventWork
 
release() - Method in class org.mule.work.WorkerContext
 
releaseAccessToken(String, OAuth2Adapter) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Return an access token to the pool
releaseAccessToken(String, C) - Method in interface org.mule.security.oauth.OAuth2Manager
Return an access token to the pool
releaseClient(ImmutableEndpoint, SftpClient) - Method in class org.mule.transport.sftp.SftpConnector
 
releaseConnection() - Method in class org.apache.commons.httpclient.HttpConnection
Releases the connection.
releaseConnection(DbConnection) - Method in interface org.mule.module.db.internal.domain.connection.DbConnectionFactory
Indicates that the connection is not used anymore
releaseConnection(DbConnection) - Method in class org.mule.module.db.internal.domain.connection.TransactionalDbConnectionFactory
 
releaseFtp(ImmutableEndpoint, FTPClient) - Method in class org.mule.transport.ftp.FtpConnector
 
releaseResources(DbConnection) - Method in class org.mule.module.db.internal.result.statement.StatementStreamingResultSetCloser
 
releaseSavepoint(Savepoint) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
releaseSavepoint(Savepoint) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
releaseSavepoint(Savepoint) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
ReleasingInputStream - Class in org.mule.transport.http
 
ReleasingInputStream(InputStream, HttpMethod) - Constructor for class org.mule.transport.http.ReleasingInputStream
 
reloadControl - Static variable in class org.mule.config.i18n.MessageFactory
Do not use the default reload control to avoid loading the resource bundle upon each request.
ReloadControl - Class in org.mule.config.i18n
 
ReloadControl() - Constructor for class org.mule.config.i18n.ReloadControl
 
remaining(int, int, int) - Method in class org.mule.transport.tcp.protocols.DirectProtocol
 
REMOTE_DISPATCHER_EVENT_ACTION_START_RANGE - Static variable in class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
Deprecated.
This is a low range since it was allocated before being refactred into the client module from core
RemoteDispatcher - Class in org.mule.module.client
Deprecated.
RemoteDispatcher(String, Credentials, MuleContext) - Constructor for class org.mule.module.client.RemoteDispatcher
Deprecated.
 
RemoteDispatcher(String, MuleContext) - Constructor for class org.mule.module.client.RemoteDispatcher
Deprecated.
 
RemoteDispatcherAgent - Class in org.mule.module.client.remoting
Deprecated.
RemoteDispatcherAgent() - Constructor for class org.mule.module.client.remoting.RemoteDispatcherAgent
Deprecated.
 
RemoteDispatcherAgentDefinitionParser - Class in org.mule.module.client.config
Deprecated.
RemoteDispatcherAgentDefinitionParser() - Constructor for class org.mule.module.client.config.RemoteDispatcherAgentDefinitionParser
Deprecated.
 
RemoteDispatcherComponent - Class in org.mule.module.client.remoting
Deprecated.
RemoteDispatcherComponent(InboundEndpoint, WireFormat, String, int) - Constructor for class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
RemoteDispatcherException - Exception in org.mule.module.client.remoting
Deprecated.
RemoteDispatcherException(Message) - Constructor for exception org.mule.module.client.remoting.RemoteDispatcherException
Deprecated.
 
RemoteDispatcherException(Message, Throwable) - Constructor for exception org.mule.module.client.remoting.RemoteDispatcherException
Deprecated.
 
RemoteDispatcherNotification - Class in org.mule.module.client.remoting.notification
Deprecated.
RemoteDispatcherNotification(MuleMessage, int) - Constructor for class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
Deprecated.
 
RemoteDispatcherNotification(MuleMessage, int, String) - Constructor for class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
Deprecated.
 
RemoteDispatcherNotificationListener<T extends RemoteDispatcherNotification> - Interface in org.mule.module.client.remoting.notification
Deprecated.
remoteObject - Variable in class org.mule.transport.rmi.RmiCallbackMessageReceiver
 
remoteObject - Variable in class org.mule.transport.rmi.RmiMessageDispatcher
 
remoteObject - Variable in class org.mule.transport.rmi.RmiMessageReceiver
 
remove(Serializable) - Method in interface org.mule.api.store.ObjectStore
Remove the object with key.
remove(Serializable, String) - Method in interface org.mule.api.store.PartitionableObjectStore
 
remove(Object) - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
remove(Object) - Method in class org.mule.el.context.InboundAttachmentMapContext
 
remove(Object) - Method in class org.mule.el.context.MessagePropertyMapContext
 
remove(Object) - Method in class org.mule.el.context.OutboundAttachmentMapContext
 
remove(Object) - Method in class org.mule.expression.InboundAttachmentsMap
 
remove(Object) - Method in class org.mule.expression.OutboundAttachmentsMap
 
remove(Object) - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
remove(FlowConstructStatistics) - Method in class org.mule.management.stats.AllStatistics
 
remove() - Method in class org.mule.module.db.internal.result.resultset.ResultSetIterator
 
remove(Object) - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
remove() - Method in class org.mule.module.db.internal.result.statement.StatementResultIterator
 
remove(Object) - Method in class org.mule.module.http.internal.ParameterMap
 
remove(int) - Method in class org.mule.module.launcher.util.ObservableList
 
remove(Object) - Method in class org.mule.module.launcher.util.ObservableList
 
remove(Object) - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
remove(String) - Method in class org.mule.registry.TransientRegistry.RegistryMap
Deprecated.
 
remove() - Method in class org.mule.routing.AbstractMessageSequence
 
remove() - Method in interface org.mule.routing.MessageSequence
Unsupported operation.
remove() - Method in class org.mule.routing.outbound.PartitionedMessageSequence
 
remove() - Method in class org.mule.streaming.ConsumerIterator
Not allowed on this implementations
remove(Serializable) - Method in class org.mule.tck.util.FakeObjectStore
 
remove(Object, Object) - Static method in class org.mule.transport.http.multipart.LazyList
 
remove(Object, int) - Static method in class org.mule.transport.http.multipart.LazyList
 
remove(Object) - Method in class org.mule.transport.http.multipart.MultiMap
 
remove(Object, Object) - Method in class org.mule.transport.http.multipart.MultiMap
 
remove(Serializable) - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
Remove the object with key.
remove(String) - Method in class org.mule.transport.soap.axis.extensions.AxisMuleSession
 
remove(Object) - Method in class org.mule.util.CaseInsensitiveMapWrapper
 
remove(Object) - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
remove(Object) - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
remove(Object) - Method in class org.mule.util.MapCombiner
 
remove(Object) - Method in class org.mule.util.OrderedProperties
 
remove(Serializable) - Method in class org.mule.util.queue.DefaultQueueStore
 
remove(Serializable) - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
remove(Serializable) - Method in interface org.mule.util.queue.RecoverableQueueStore
Removes the value from the queue.
remove(Serializable) - Method in interface org.mule.util.queue.TransactionalQueueStoreDelegate
Remove the specified value from the queue.
remove(Serializable) - Method in class org.mule.util.store.AbstractObjectStore
 
remove(Serializable) - Method in class org.mule.util.store.AbstractPartitionedObjectStore
 
remove(Serializable) - Method in class org.mule.util.store.InMemoryObjectStore
 
remove(Serializable) - Method in class org.mule.util.store.ManagedObjectStore
 
remove(Serializable) - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
remove(Serializable) - Method in class org.mule.util.store.ObjectStorePartition
 
remove(Object) - Method in class org.mule.util.store.ObjectStoreToMapAdapter
 
remove(Serializable, String) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
remove(Serializable) - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
 
remove(Serializable, String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
remove(Serializable) - Method in class org.mule.util.store.PersistentObjectStorePartition
 
remove(Serializable) - Method in class org.mule.util.store.ProvidedObjectStoreWrapper
 
remove(Serializable, String) - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
remove(Serializable) - Method in class org.mule.util.store.QueueStoreAdapter
Deprecated.
 
removeAlias(String) - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
removeAlias(Class<? extends Converter>) - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
removeAll(Collection<?>) - Method in class org.mule.module.launcher.util.ObservableList
 
removeAll(Collection) - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
removeAllListeners(Collection<ServerNotificationListener>) - Method in class org.mule.context.notification.ServerNotificationManager
Deprecated.
removeAllListeners() - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
Removes all the listeners from the multicaster
removeAllListeners() - Method in class org.mule.util.timer.EventTimerTask
 
removeApplicationListener(ApplicationListener) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
Removes a listener from the multicaster
removeApplicationListenerBean(String) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
 
removeArgument(ExpressionArgument) - Method in class org.mule.expression.transformers.AbstractExpressionTransformer
 
removeAttachment(String) - Method in interface org.mule.api.MuleMessage
removeAttachment(String) - Method in class org.mule.DefaultMuleMessage
Deprecated.
RemoveAttachmentTransformer - Class in org.mule.transformer.simple
 
RemoveAttachmentTransformer() - Constructor for class org.mule.transformer.simple.RemoveAttachmentTransformer
 
removeAttribute(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
removeBeanDefinition(String) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
removeBreakpoint(Breakpoint) - Method in interface org.mule.api.debug.BreakpointManager
Removes a breakpoint from the current set of breakpoints.
removeClassProperty(String, Properties) - Method in class org.mule.api.registry.AbstractServiceDescriptor
 
removeConverter(Converter) - Method in class org.mule.transformer.graph.TransformationGraph
 
REMOVED - Static variable in class org.mule.module.launcher.util.ElementEvent
 
removeDeploymentListener(DeploymentListener) - Method in class org.mule.module.launcher.CompositeDeploymentListener
 
removeDeploymentListener(DeploymentListener) - Method in interface org.mule.module.launcher.DeploymentListenerManager
 
removeDeploymentListener(DeploymentListener) - Method in class org.mule.module.launcher.MuleDeploymentService
 
removeDeploymentListener(DeploymentListener) - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
removedMessage(MuleMessage) - Method in interface org.mule.api.MuleMessageCollection
 
removedMessage(MuleMessage) - Method in class org.mule.DefaultMessageCollection
 
removeDomainDeploymentListener(DeploymentListener) - Method in interface org.mule.module.launcher.DomainDeploymentListenerManager
 
removeDomainDeploymentListener(DeploymentListener) - Method in class org.mule.module.launcher.MuleDeploymentService
 
removeEncryptionStrategy(String) - Method in interface org.mule.api.security.SecurityManager
 
removeEncryptionStrategy(String) - Method in class org.mule.security.MuleSecurityManager
 
removeEntryPointResolver(EntryPointResolver) - Method in interface org.mule.api.model.EntryPointResolverSet
Removes a resolver from the list
removeEntryPointResolver(EntryPointResolver) - Method in class org.mule.model.resolvers.DefaultEntryPointResolverSet
 
removeEvent(MuleEvent) - Method in class org.mule.routing.EventGroup
Remove the given event from the group.
removeEvent() - Method in class org.mule.routing.requestreply.MultipleRequestReplierEvent
 
removeEventGroup(EventGroup) - Method in class org.mule.routing.correlation.EventCorrelator
 
removeExpirable(Expirable) - Method in class org.mule.util.monitor.ExpiryMonitor
 
removeExpressionMarker(String) - Static method in class org.mule.expression.DefaultExpressionManager
 
removeFile(File) - Method in class org.mule.util.monitor.FileMonitor
Remove specified file for listening.
removeFirst() - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
removes the first element in the queue
removeFirst() - Method in class org.mule.util.queue.DefaultQueueStoreDelegate
 
removeFirst() - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
removeFlowVariable(String) - Method in interface org.mule.api.MuleEvent
 
removeFlowVariable(String) - Method in class org.mule.DefaultMuleEvent
 
removeFlowVariable(String) - Method in class org.mule.VoidMuleEvent
 
RemoveFlowVariableTransformer - Class in org.mule.transformer.simple
 
RemoveFlowVariableTransformer() - Constructor for class org.mule.transformer.simple.RemoveFlowVariableTransformer
 
removeFromArray(Object[], Object) - Static method in class org.mule.transport.http.multipart.LazyList
 
removeFromEnvironment(String) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
removeFromEnvironment(String) - Method in class org.mule.jndi.SimpleContext
 
removeFromEnvironment(String) - Method in class org.mule.tck.jndi.InMemoryContext
 
removeHeader(String) - Method in class org.mule.module.http.internal.domain.request.HttpRequestBuilder
 
removeHeader(String) - Method in class org.mule.module.http.internal.listener.HttpResponseHeaderBuilder
 
removeHeaders(String) - Method in class org.mule.transport.http.HttpRequest
 
removeHeaders(String) - Method in class org.mule.transport.http.HttpResponse
 
removeIgnored(String) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
removeIgnored(String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
removeIgnored(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
removeIgnored(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
removeIgnored(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
removeIgnored(String) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
removeIgnored(String) - Method in class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
removeIgnored(String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
removeIgnored(String) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
removeIgnored(String) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParserConfiguration
 
removeIgnoredMethod(String) - Method in class org.mule.model.resolvers.ReflectionEntryPointResolver
 
removeInterceptor(List<Interceptor<? extends Message>>, String) - Static method in class org.mule.module.cxf.support.CxfUtils
 
removeInterface(Class<?>[], Class<?>) - Static method in class org.mule.transport.soap.axis.AxisServiceProxy
 
removeLifecycleCallback(FunctionalTestComponent.LifecycleCallback) - Static method in class org.mule.tck.functional.FunctionalTestComponent
 
removeListener(MuleContextListener) - Method in interface org.mule.api.context.MuleContextFactory
Removes a listener from the factory.
removeListener(MuleContextListener) - Method in class org.mule.context.DefaultMuleContextFactory
 
removeListener(ServerNotificationListener<?>) - Method in class org.mule.context.notification.ServerNotificationManager
This removes *all* registrations that reference this listener
removeListener(FileListener) - Method in class org.mule.util.monitor.FileMonitor
Remove listener from this file monitor.
removeListener(TimeEventListener) - Method in class org.mule.util.timer.EventTimerTask
 
removeMessageProcessor(MessageProcessor) - Method in class org.mule.exception.AbstractExceptionListener
 
removeMethod(String) - Method in class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
 
removeMethod(String) - Method in class org.mule.model.resolvers.ExplicitMethodEntryPointResolver
 
removeNamedParameter(NamedParameter) - Method in class org.mule.transport.soap.axis.SoapMethod
 
removeNamespacePrefix(String) - Static method in class org.mule.util.PropertiesUtils
 
removeNamespaces(Map) - Static method in class org.mule.util.PropertiesUtils
 
removeNonSerializableProperties(MuleSession, MuleContext) - Method in class org.mule.session.SerializeOnlySessionHandler
 
removeNotificationListeners() - Method in class org.mule.context.notification.MessageProcessingFlowTraceManager
 
removeOrderedLifecycleObject(LifecycleObject) - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
removeOrderedLifecycleObject(LifecycleObject) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
removeOutboundAttachment(String) - Method in interface org.mule.api.MuleMessage
Remove an attachment form this message with the specified name
removeOutboundAttachment(String) - Method in class org.mule.DefaultMuleMessage
 
removeOverride() - Method in class org.mule.util.PropertyChecker
 
removePacketListener(PacketListener) - Method in class org.mule.transport.xmpp.AbstractXmppConversation
 
removePacketListener(PacketListener) - Method in interface org.mule.transport.xmpp.XmppConversation
Removes listener from this conversation's XMPP connection.
removePadding(String) - Static method in class org.mule.utils.IdUtils
 
removeProperty(String) - Method in interface org.mule.api.MuleMessage
removeProperty(String, PropertyScope) - Method in interface org.mule.api.MuleMessage
Removes a property on this message from the specified scope only.
removeProperty(String) - Method in interface org.mule.api.MuleSession
Will retrieve a session scope property and remove it from the session
removeProperty(Object) - Method in interface org.mule.api.MuleSession
Deprecated.
removeProperty(String, Properties) - Method in class org.mule.api.registry.AbstractServiceDescriptor
 
removeProperty(String) - Method in class org.mule.DefaultMuleMessage
Removes a property on this message.
removeProperty(String, PropertyScope) - Method in class org.mule.DefaultMuleMessage
Removes a property on this message from the specified scope only.
removeProperty(String) - Method in class org.mule.MessagePropertiesContext
Removes a property from all scopes except for SESSION and INBOUND (which is read-only).
removeProperty(String, PropertyScope) - Method in class org.mule.MessagePropertiesContext
Removes a property from the specified property scope.
removeProperty(Object) - Method in class org.mule.session.DefaultMuleSession
Will retrieve a session level property and remove it from the session
removeProperty(String) - Method in class org.mule.session.DefaultMuleSession
 
removePropertyChangeListener(PropertyChangeListener) - Method in class org.mule.module.launcher.util.ObservableList
 
removePropertyChangeListener(String, PropertyChangeListener) - Method in class org.mule.module.launcher.util.ObservableList
 
RemovePropertyTransformer - Class in org.mule.transformer.simple
 
RemovePropertyTransformer() - Constructor for class org.mule.transformer.simple.RemovePropertyTransformer
 
removeProvider(String) - Method in interface org.mule.api.security.SecurityManager
 
removeProvider(String) - Method in class org.mule.security.MuleSecurityManager
 
removeReceiver(R) - Method in interface org.mule.transport.servlet.jetty.ConnectorHolder
 
removeReceiver(JettyHttpMessageReceiver) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector.MuleReceiverConnectorHolder
 
removeRegistry(Registry) - Method in interface org.mule.api.MuleContext
Deprecated.
as of 3.7.0. This will be removed in Mule 4.0
removeRegistry(Registry) - Method in interface org.mule.api.registry.RegistryBroker
Deprecated.
 
removeRegistry(Registry) - Method in class org.mule.DefaultMuleContext
Deprecated.
removeRegistry(Registry) - Method in class org.mule.registry.DefaultRegistryBroker
Deprecated.
 
removeRequestHandlerMatcherPair(HttpListenerRegistry.RequestHandlerMatcherPair) - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.PathMap
 
removeRoute(MessageProcessor) - Method in interface org.mule.api.processor.MessageRouter
Removes a message processor from the list of routes
removeRoute(MatchableMessageProcessor) - Method in interface org.mule.api.routing.MatchingRouter
 
removeRoute(MessageProcessor) - Method in interface org.mule.api.routing.SelectiveRouter
 
removeRoute(MatchableMessageProcessor) - Method in class org.mule.routing.AbstractMatchingRouter
 
removeRoute(MessageProcessor) - Method in class org.mule.routing.AbstractSelectiveRouter
 
removeRoute(MessageProcessor) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
removeRoute(MatchableMessageProcessor) - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
removeRoute(MessageProcessor) - Method in class org.mule.routing.ScatterGatherRouter
Removes a message processor from the list of routes
removeSessionVariable(String) - Method in interface org.mule.api.MuleEvent
Deprecated.
use getSession() to manipulate session state
removeSessionVariable(String) - Method in class org.mule.DefaultMuleEvent
 
removeSessionVariable(String) - Method in class org.mule.VoidMuleEvent
 
RemoveSessionVariableTransformer - Class in org.mule.transformer.simple
 
RemoveSessionVariableTransformer() - Constructor for class org.mule.transformer.simple.RemoveSessionVariableTransformer
 
removeSource(MessageSource) - Method in interface org.mule.api.source.CompositeMessageSource
 
removeSource(MessageSource) - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
removeSource(MessageSource) - Method in class org.mule.source.StartableCompositeMessageSource
 
removeStartupListener(StartupListener) - Method in interface org.mule.module.launcher.DeploymentService
 
removeStartupListener(StartupListener) - Method in class org.mule.module.launcher.MuleDeploymentService
 
removeTemplate(Template) - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Method removeTemplate.
removeType(Collection<?>, Class<?>) - Static method in class org.mule.util.CollectionUtils
 
removeValue(K, Object) - Method in class org.mule.transport.http.multipart.MultiMap
Remove value.
removeVariable(Variable) - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Method removeVariable.
removeVariable(Variable) - Method in class com.javaforge.bobber.archetype.model.Variable
Method removeVariable.
removeWork(Runnable) - Method in class org.mule.transport.ConcurrentWorkTracker
 
removeWork(Runnable) - Method in interface org.mule.transport.WorkTracker
Removes a work from tracking.
removeXmlNamespacePrefix(String) - Static method in class org.mule.util.PropertiesUtils
 
rename(Name, Name) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
rename(String, String) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
rename(Name, Name) - Method in class org.mule.jndi.SimpleContext
 
rename(Attributes.Name, Attributes.Name) - Method in class org.mule.jndi.SimpleContext
 
rename(String, String) - Method in class org.mule.jndi.SimpleContext
 
rename(Name, Name) - Method in class org.mule.tck.jndi.InMemoryContext
 
rename(String, String) - Method in class org.mule.tck.jndi.InMemoryContext
 
rename(String, String) - Method in class org.mule.transport.sftp.SftpClient
 
renameFile(File, File) - Static method in class org.mule.module.boot.MuleBootstrapUtils
 
renameFile(File, File) - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
renameFile(String, String) - Static method in class org.mule.util.FileUtils
 
renameFile(File, File) - Static method in class org.mule.util.FileUtils
 
renameFileHard(File, File) - Static method in class org.mule.module.boot.MuleBootstrapUtils
 
renameFileHard(File, File) - Static method in class org.mule.module.reboot.MuleContainerBootstrapUtils
 
renameFileHard(String, String) - Static method in class org.mule.util.FileUtils
 
renameFileHard(File, File) - Static method in class org.mule.util.FileUtils
 
renameInScope(String, String, PropertyScope, MuleMessage) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
renameProperties(MuleMessage) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
repeat(char, int) - Static method in class org.mule.util.StringUtils
Like StringUtils.repeat(String, int) but with a single character as argument.
repeater - Variable in class org.mule.module.xml.stax.StaxSource
 
replace(K, Object, Object) - Method in class org.mule.transport.http.multipart.MultiMap
 
replace(K, Object) - Method in class org.mule.transport.http.multipart.MultiMap
 
REPLACEMENT_CHAR - Static variable in class org.mule.transport.jms.JmsMessageUtils
 
replaceObjectNameChars(String) - Static method in class org.mule.util.ObjectNameHelper
 
replaceUriParams(String, MuleEvent) - Method in class org.mule.module.http.internal.request.HttpRequesterRequestBuilder
 
REPLY_TO_ADDRESSES_PROPERTY - Static variable in interface org.mule.transport.email.MailProperties
 
replyMessageProcessor - Variable in class org.mule.routing.requestreply.SimpleRequestReplyReplier
 
replyMessageSource - Variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
replyTo - Variable in class org.mule.routing.outbound.AbstractOutboundRouter
 
REPLYTO_PARAM - Static variable in class org.mule.transport.ajax.embedded.AjaxConnector
This is the key that's used to retrieve the reply to destination from a Map that's passed into AjaxMuleMessageFactory.
ReplyToHandler - Interface in org.mule.api.transport
ReplyToHandler is used to handle routing where a replyTo endpointUri is set on the message
replyToHandler - Variable in class org.mule.transport.AbstractMessageReceiver
 
ReplyToPropertyRequestReplyReplier - Class in org.mule.routing.requestreply
 
ReplyToPropertyRequestReplyReplier() - Constructor for class org.mule.routing.requestreply.ReplyToPropertyRequestReplyReplier
 
reportAvailableServices(MuleEventContext, AxisStringWriter) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
reportCantGetAxisService(MuleEventContext, AxisStringWriter) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
reportServiceInfo(AxisStringWriter, SOAPService, String) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
request(InboundEndpoint, long) - Method in interface org.mule.api.client.LocalMuleClient
Will receive an event from an endpointUri determined by the URL.
request(String, long) - Method in interface org.mule.api.client.MuleClient
Will receive an event from an endpointUri determined by the URL.
request(String, long) - Method in interface org.mule.api.transport.Connector
Deprecated.
Use request(ImmutableEndpoint endpoint, long timeout)
request(InboundEndpoint, long) - Method in interface org.mule.api.transport.Connector
Make a specific request to the underlying transport
request(long) - Method in interface org.mule.api.transport.MessageRequesting
Make a specific request to the underlying transport
request(InboundEndpoint, long) - Method in class org.mule.client.DefaultLocalMuleClient
 
request(String, long) - Method in class org.mule.client.DefaultLocalMuleClient
 
request(long) - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
request(long) - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
request(RequestContext) - Method in class org.mule.module.atom.MuleProvider
 
request(String, long) - Method in class org.mule.module.client.MuleClient
Will receive an event from an endpointUri determined by the URL.
request(String, String, long) - Method in class org.mule.module.client.MuleClient
Will receive an event from an endpointUri determined by the URL
request(String, List<?>, long) - Method in class org.mule.module.client.MuleClient
Will receive an event from an endpointUri determined by the URL
request(long) - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
request(String, long) - Method in class org.mule.transport.AbstractConnector
Make a specific request to the underlying transport
request(InboundEndpoint, long) - Method in class org.mule.transport.AbstractConnector
 
request(long) - Method in class org.mule.transport.AbstractMessageRequester
Make a specific request to the underlying transport
request(String, Object[]) - Method in class org.mule.transport.soap.axis.AxisMessageRequester
 
request(String, SOAPEnvelope) - Method in class org.mule.transport.soap.axis.AxisMessageRequester
 
REQUEST_HEADER_NAMES - Static variable in class org.mule.transport.http.HttpConstants
 
REQUEST_NO_WAIT - Static variable in interface org.mule.api.transport.MessageRequesting
 
REQUEST_TIMEOUT_PROPERTY - Static variable in class org.mule.transport.servlet.AbstractReceiverServlet
 
REQUEST_WAIT_INDEFINITELY - Static variable in interface org.mule.api.transport.MessageRequesting
 
RequestAuthenticationException - Exception in org.mule.module.oauth2.api
Exception throw when it's not possible to create the authentication request for a given request.
RequestAuthenticationException(Message) - Constructor for exception org.mule.module.oauth2.api.RequestAuthenticationException
 
RequestBodyGenerator - Class in org.mule.module.ws.consumer
Creates the request body for an operation of a web service when no parameters are required.
RequestBodyGenerator(Definition) - Constructor for class org.mule.module.ws.consumer.RequestBodyGenerator
 
RequestBodyGenerator(Definition, MuleWSDLLocator) - Constructor for class org.mule.module.ws.consumer.RequestBodyGenerator
 
requestConfig(HttpRequesterConfig) - Method in class org.mule.module.http.api.client.HttpRequestOptionsBuilder
 
requestConfig(HttpRequesterConfig) - Method in interface org.mule.module.http.api.requester.HttpRequestOperationConfig
 
requestConfig(HttpRequesterConfig) - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
RequestContext - Class in org.mule
Deprecated.
If access to MuleEvent or MuleMessage is required, then implement a MessageProcessor or Callable instead
RequestContext() - Constructor for class org.mule.RequestContext
Deprecated.
Do not instanciate.
requester(MuleContext, String) - Static method in class org.mule.util.concurrent.ThreadNameHelper
 
requesterFactory - Variable in class org.mule.transport.AbstractConnector
Factory used to create requesters for this connector
requesters - Variable in class org.mule.transport.AbstractConnector
A pool of requesters for this connector, keyed by endpoint
requestEvent(InboundEndpoint, long) - Method in interface org.mule.api.MuleEventContext
Deprecated. 
requestEvent(String, long) - Method in interface org.mule.api.MuleEventContext
Requests a synchronous receive of an event on the service.
requestEvent(EndpointURI, long) - Method in interface org.mule.api.MuleEventContext
Deprecated.
requestEvent(InboundEndpoint, long) - Method in class org.mule.DefaultMuleEventContext
Requests a synchronous receive of an event on the service
requestEvent(String, long) - Method in class org.mule.DefaultMuleEventContext
Requests a synchronous receive of an event on the service
requestEvent(EndpointURI, long) - Method in class org.mule.DefaultMuleEventContext
Requests a synchronous receive of an event on the service
requestFailedWithStatus(String) - Static method in class org.mule.transport.http.i18n.HttpMessages
 
RequestHandler - Interface in org.mule.module.http.internal.listener.async
Handler for an incoming http request that allows to send the http response asynchronously.
RequestHandlerManager - Interface in org.mule.module.http.internal.listener
 
RequestHandlerProvider - Interface in org.mule.module.http.internal.listener
Provider of RequestHandler for a certain incoming http request.
RequestLine - Class in org.mule.transport.http
Defines a HTTP request-line, consisting of method name, URI and protocol.
RequestLine(String, String, HttpVersion) - Constructor for class org.mule.transport.http.RequestLine
 
RequestLine(String, String, String) - Constructor for class org.mule.transport.http.RequestLine
 
requestLineIsMalformed(String) - Static method in class org.mule.transport.http.i18n.HttpMessages
 
RequestMatcher - Interface in org.mule.module.http.internal.listener.matcher
A request matcher represents a condition that is fulfilled or not by an http request
requestMessageProcessor - Variable in class org.mule.routing.requestreply.SimpleAsyncRequestReplyRequester
 
RequestReplyReplierMessageProcessor - Interface in org.mule.api.processor
Processes a MuleEvent's by invoking the next MessageProcessor and then rather than returning the result to this processors MessageSource sending it via a seperate reply MessageProcessor,
RequestReplyRequesterMessageProcessor - Interface in org.mule.api.processor
Processes a MuleEvent by invoking the next MessageProcessor but receiving the reply, which is turn is returned from this MessageProcessor from a seperate MessageSource rather than using the return value of the next MessageProcessor invocation.
RequestResponseFlowProcessingPhaseTemplate - Interface in org.mule.execution
Extension of FlowProcessingPhaseTemplate for those MessageSource that requires sending a response of the message processed.
requestStreamingMode(HttpStreamingType) - Method in class org.mule.module.http.api.client.HttpRequestOptionsBuilder
Configures the streaming mode for sending the HTTP request.
requestStreamingMode(HttpStreamingType) - Method in interface org.mule.module.http.api.requester.HttpRequestOperationConfig
Configures if the HTTP request should do streaming (transfer-encoding chunk).
requestStreamingMode(HttpStreamingType) - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
requestWireFormat() - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
require(int, String, String) - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
RequireAttribute - Class in org.mule.config.spring.parsers.processors
Throws an exception if any of the required attributes (after translation) are missing.
RequireAttribute(String) - Constructor for class org.mule.config.spring.parsers.processors.RequireAttribute
 
RequireAttribute(String[]) - Constructor for class org.mule.config.spring.parsers.processors.RequireAttribute
 
RequireAttribute.RequireAttributeException - Exception in org.mule.config.spring.parsers.processors
 
RequireAttribute.RequireAttributeException(String) - Constructor for exception org.mule.config.spring.parsers.processors.RequireAttribute.RequireAttributeException
 
REQUIRED_ADDRESS_ATTRIBUTES - Static variable in class org.mule.transport.xmpp.config.XmppNamespaceHandler
 
RequiredValueException - Exception in org.mule.api.expression
Is thrown explicitly when an expression is executed that returns a null value when a value is required.
RequiredValueException(Message) - Constructor for exception org.mule.api.expression.RequiredValueException
 
RequiredValueException(Message, Throwable) - Constructor for exception org.mule.api.expression.RequiredValueException
 
requiresMultipleOpenedResults() - Method in class org.mule.module.db.internal.result.resultset.IteratorResultSetHandler
 
requiresMultipleOpenedResults() - Method in class org.mule.module.db.internal.result.resultset.ListResultSetHandler
 
requiresMultipleOpenedResults() - Method in class org.mule.module.db.internal.result.resultset.NullResultSetHandler
 
requiresMultipleOpenedResults() - Method in interface org.mule.module.db.internal.result.resultset.ResultSetHandler
Indicates whether or not the resultSet handler requires that the connection supports multiple opened results in order to process the resultSet.
ResequenceCorrelatorCallback - Class in org.mule.routing.correlation
A Correlator that correlates messages based on Mule correlation settings.
ResequenceCorrelatorCallback(Comparator<MuleEvent>, MuleContext, String) - Constructor for class org.mule.routing.correlation.ResequenceCorrelatorCallback
 
ResequenceMessagesCorrelatorCallback - Class in org.mule.routing.correlation
A Correlator that correlates messages based on Mule correlation settings Note that the ResequenceMessagesCorrelatorCallback.aggregateEvents(org.mule.routing.EventGroup) method only resequences the events and returns an MuleEvent[] wrapped in a MuleMessage impl.
ResequenceMessagesCorrelatorCallback(Comparator, MuleContext, String) - Constructor for class org.mule.routing.correlation.ResequenceMessagesCorrelatorCallback
 
Resequencer - Class in org.mule.routing
Resequencer is used to resequence events according to their dispatch sequence in the correlation group.
Resequencer() - Constructor for class org.mule.routing.Resequencer
 
reset() - Method in interface org.mule.api.lifecycle.LifecycleManager
Reset the lifecycle manager state back to 'not in lifecycle' phase
reset() - Method in interface org.mule.api.processor.DynamicPipelineBuilder
Removes and disposes all injected message processors.
reset() - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
reset() - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
reset() - Method in class org.mule.model.streaming.DelegatingInputStream
 
reset() - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
reset() - Method in class org.mule.retry.policies.SimpleRetryPolicy.RetryCounter
 
reset(OAuth1Adapter) - Method in class org.mule.security.oauth.BaseOAuth1Manager
Sets the adapter to a blank, unatuhorized state
reset() - Method in interface org.mule.security.oauth.OAuth1Adapter
Sets the adapter to a blank unauthorized state
reset(OAuth1Adapter) - Method in interface org.mule.security.oauth.OAuth1Manager
Sets the adapter to a blank, unatuhorized state
reset() - Method in class org.mule.tck.functional.AssertionMessageProcessor
 
reset() - Static method in class org.mule.tck.functional.FlowAssert
 
reset() - Method in class org.mule.tck.listener.ConnectionListener
 
reset() - Method in class org.mule.transport.http.HttpServerConnection
Clean up cached values.
reset() - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
reset() - Method in class org.mule.transport.polling.watermark.selector.WatermarkSelector
Returns this selector to a blank state so that it can be reused
reset() - Method in class org.mule.transport.polling.watermark.selector.WatermarkSelectorWrapper
 
resetAccessControl() - Method in interface org.mule.api.ThreadSafeAccess
This method should ONLY be used in the construction of composite ThreadSafeAccess instances.
resetAccessControl() - Method in class org.mule.DefaultMuleEvent
 
resetAccessControl() - Method in class org.mule.DefaultMuleMessage
This method should ONLY be used in the construction of composite ThreadSafeAccess instances.
resetAccessControl(Object) - Static method in class org.mule.RequestContext
Deprecated.
 
resetAndUpdate() - Method in interface org.mule.api.processor.DynamicPipelineBuilder
resetAttribute(Element, String, String) - Method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
resetBeanDefinition(String) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Reset all bean definition caches for the given bean, including the caches of beans that are derived from it.
resetBuffer() - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
resetDeploymentListener() - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
resetExpirable(Expirable) - Method in class org.mule.util.monitor.ExpiryMonitor
 
resetNameAndId(Element) - Method in class org.mule.config.spring.parsers.delegate.AbstractSerialDelegatingDefinitionParser
 
ResetStaxInterceptor - Class in org.mule.module.cxf.support
Replaces the XMLStreamReader with a ReversibleXMLStreamReader which caches the xml events so we can replay them later.
ResetStaxInterceptor() - Constructor for class org.mule.module.cxf.support.ResetStaxInterceptor
 
Resin3TransactionManagerLookupFactory - Class in org.mule.transaction.lookup
 
Resin3TransactionManagerLookupFactory() - Constructor for class org.mule.transaction.lookup.Resin3TransactionManagerLookupFactory
 
resolve(DataType<?>, DataType<?>) - Method in interface org.mule.api.registry.TransformerResolver
Responsible for finding a transformer with the given criteria.
resolve(Class<T>, DataType, DataType, MuleContext) - Method in class org.mule.config.transformer.AbstractAnnotatedTransformerArgumentResolver
 
resolve(Class<T>, DataType, DataType, MuleContext) - Method in interface org.mule.config.transformer.TransformerArgumentResolver
 
resolve(DataType<?>, List<DataType<?>>) - Method in interface org.mule.DataTypeConversionResolver
 
resolve(DataType<?>, List<DataType<?>>) - Method in class org.mule.DynamicDataTypeConversionResolver
 
resolve(MuleMessage, CompiledExpression) - Method in class org.mule.el.mvel.datatype.AbstractExpressionDataTypeResolver
 
resolve(MuleMessage, CompiledExpression) - Method in interface org.mule.el.mvel.datatype.ExpressionDataTypeResolver
Resolves the data type form a given expression
resolve(Object, MuleMessage, Serializable) - Method in class org.mule.el.mvel.datatype.MvelDataTypeResolver
Resolves expression data type
resolve(URI) - Method in class org.mule.endpoint.MuleEndpointURI
 
resolve(String) - Method in class org.mule.endpoint.MuleEndpointURI
 
resolve(MuleEvent) - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
Resolves dataSource configuration using a given event
resolve(MuleEvent) - Method in class org.mule.module.db.internal.resolver.database.ConfiguredDbConfigResolver
 
resolve(MuleEvent) - Method in interface org.mule.module.db.internal.resolver.database.DbConfigResolver
Resolves which database configuration to use for a given event
resolve(MuleEvent) - Method in class org.mule.module.db.internal.resolver.database.DefaultDbConfigResolver
 
resolve(MuleEvent) - Method in class org.mule.module.db.internal.resolver.database.DynamicDbConfigResolver
 
resolve(MuleEvent) - Method in class org.mule.module.db.internal.resolver.database.StaticDbConfigResolver
 
resolve(MuleEvent) - Method in class org.mule.module.db.internal.resolver.query.AbstractBulkQueryResolver
 
resolve(MuleEvent) - Method in interface org.mule.module.db.internal.resolver.query.BulkQueryResolver
Resolves a bulk query in the context of a given Mule event.
resolve(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.resolver.query.DynamicQueryResolver
 
resolve(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.resolver.query.ParametrizedQueryResolver
 
resolve(DbConnection, MuleEvent) - Method in interface org.mule.module.db.internal.resolver.query.QueryResolver
Resolves a query in the context of a given Mule event.
resolve(DbConnection, MuleEvent) - Method in class org.mule.module.db.internal.resolver.query.StaticQueryResolver
 
resolve(OperationContext) - Method in interface org.mule.module.extension.internal.runtime.resolver.ArgumentResolver
Resolves an argument's value from the given operationContext
resolve(OperationContext) - Method in class org.mule.module.extension.internal.runtime.resolver.ByParameterNameArgumentResolver
Resolves an argument's value from the given operationContext
resolve(MuleEvent) - Method in class org.mule.module.extension.internal.runtime.resolver.CachingValueResolverWrapper
Upon first invocation, the value is resolved using the CachingValueResolverWrapper.delegate and the return value is stored.
resolve(MuleEvent) - Method in class org.mule.module.extension.internal.runtime.resolver.CollectionValueResolver
Passes the given event to each resolvers and outputs a collection of type collectionType with each result
resolve(OperationContext) - Method in class org.mule.module.extension.internal.runtime.resolver.ConfigurationInstanceArgumentResolver
 
resolve(OperationContext) - Method in class org.mule.module.extension.internal.runtime.resolver.EventArgumentResolver
Resolves an argument's value from the given operationContext
resolve(OperationContext) - Method in class org.mule.module.extension.internal.runtime.resolver.MessageArgumentResolver
 
resolve(MuleEvent) - Method in class org.mule.module.extension.internal.runtime.resolver.NestedProcessorValueResolver
Returns a NestedProcessor that wraps the event
resolve(MuleEvent) - Method in class org.mule.module.extension.internal.runtime.resolver.ObjectBuilderValueResolver
Delegates to builder
resolve(OperationContext) - Method in class org.mule.module.extension.internal.runtime.resolver.ParameterGroupArgumentResolver
Resolves an argument's value from the given operationContext
resolve(MuleEvent) - Method in class org.mule.module.extension.internal.runtime.resolver.RegistryLookupValueResolver
Returns the registry value associated with RegistryLookupValueResolver.key
resolve(MuleEvent) - Method in class org.mule.module.extension.internal.runtime.resolver.ResolverSet
Evaluates all the added ValueResolvers and returns the results into a ResolverSetResult
resolve(MuleEvent) - Method in class org.mule.module.extension.internal.runtime.resolver.StaticValueResolver
Resolves a value from the given event
resolve(MuleEvent) - Method in class org.mule.module.extension.internal.runtime.resolver.TypeSafeExpressionValueResolver
 
resolve(MuleEvent) - Method in interface org.mule.module.extension.internal.runtime.resolver.ValueResolver
Resolves a value from the given event
resolve(ParameterMap, MuleEvent) - Method in class org.mule.module.http.internal.HttpMapParam
 
resolve(ParameterMap, MuleEvent) - Method in class org.mule.module.http.internal.HttpParam
 
resolve(ParameterMap, MuleEvent) - Method in class org.mule.module.http.internal.HttpSingleParam
 
resolve(DataType<?>, DataType<?>) - Method in class org.mule.module.json.transformers.JsonTransformerResolver
 
resolve(DataType, DataType) - Method in class org.mule.module.xml.transformer.jaxb.JAXBTransformerResolver
 
resolve(String, String) - Method in class org.mule.module.xml.util.LocalURIResolver
 
resolve(DataType, DataType) - Method in class org.mule.registry.TypeBasedTransformerResolver
 
resolve(DataType<?>, DataType<?>) - Method in class org.mule.transformer.graph.GraphTransformerResolver
 
resolveAnnotationClass(Annotation) - Static method in class org.mule.util.ClassUtils
 
resolveBoolean(Object, boolean, boolean, String) - Method in class org.mule.expression.DefaultExpressionManager
 
resolveBooleanValue(MuleEvent) - Method in class org.mule.util.AttributeEvaluator
 
resolveBulkQueries(MuleEvent, String) - Method in class org.mule.module.db.internal.resolver.query.AbstractBulkQueryResolver
 
resolveBulkQueries(MuleEvent, String) - Method in class org.mule.module.db.internal.resolver.query.DynamicBulkQueryResolver
 
resolveBulkQueries(MuleEvent, String) - Method in class org.mule.module.db.internal.resolver.query.FileBulkQueryResolver
 
resolveCapabilities(DeclarationDescriptor, Class<?>) - Method in interface org.mule.module.extension.internal.introspection.CapabilitiesResolver
Resolves the capabilities present in extensionType and registers them in builder
resolveClass(int) - Method in class org.mule.util.ClassReader
 
ResolvedDbType - Class in org.mule.module.db.internal.domain.type
Defines a data type that was resolved for a database instance
ResolvedDbType(int, String) - Constructor for class org.mule.module.db.internal.domain.type.ResolvedDbType
Creates a new DB type
resolveDefaultConfig() - Method in class org.mule.module.db.internal.resolver.database.AbstractDbConfigResolver
 
resolveDefaultConfig() - Method in class org.mule.module.db.internal.resolver.database.ConfiguredDbConfigResolver
 
resolveDependencies(Collection<MuleCoreExtension>) - Method in interface org.mule.module.launcher.coreextension.MuleCoreExtensionDependencyResolver
Resolves the dependencies between a given collection of {link MuleCoreExtension}
resolveDependencies(Collection<MuleCoreExtension>) - Method in class org.mule.module.launcher.coreextension.ReflectionMuleCoreExtensionDependencyResolver
 
resolveDependency(DependencyDescriptor, String, Set<String>, TypeConverter) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
resolveDeploymentProperties(String, Optional<Properties>) - Static method in class org.mule.module.launcher.DeploymentPropertiesUtils
This method resolves the deploymentProperties for a new deploy/redeploy considering the new deployment properties passed by the user as parameter and the deployment properties persisted in a previous deploy.
resolveDomainClash(String) - Method in class org.mule.module.management.support.AbstractJmxSupport
Resolve JMX domain clash by adding an incremented number suffix to the name.
resolveEventSynchronicity() - Method in class org.mule.DefaultMuleEvent
 
resolveField(int) - Method in class org.mule.util.ClassReader
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.mule.config.spring.parsers.collection.OrphanMapDefinitionParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.mule.config.spring.parsers.specific.ConfigurationDefinitionParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.mule.config.spring.parsers.specific.ExpressionLanguageDefinitionParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.mule.module.db.internal.config.domain.param.AbstractParamDefinitionDefinitionParser
 
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.mule.module.db.internal.config.domain.param.InputParamValueBeanDefinitionParser
 
resolveIntegerValue(MuleEvent) - Method in class org.mule.util.AttributeEvaluator
 
resolveJmsCorrelationId(MuleEvent) - Method in class org.mule.transport.jms.JmsMessageDispatcher
Resolve the value of correlationID that should be used for the JMS Message.
resolveMessageProcessor(MuleEvent) - Method in class org.mule.processor.AbstractDynamicMessageProcessor
Determines which MessageProcessor should be used.
resolveMethod(int) - Method in class org.mule.util.ClassReader
 
resolveMethodToInvoke() - Method in class org.mule.processor.InvokerMessageProcessor
 
resolveNameAndType(int) - Method in class org.mule.util.ClassReader
 
resolveParameterType(MethodParameter, Class) - Static method in class org.mule.util.generics.GenericTypeResolver
Determine the target type for the given generic parameter type.
resolveParams(MuleEvent, List<QueryParamValue>) - Method in class org.mule.module.db.internal.resolver.param.DynamicParamValueResolver
 
resolveParams(MuleEvent, List<QueryParamValue>) - Method in interface org.mule.module.db.internal.resolver.param.ParamValueResolver
Resolves query parameters
resolveParams(MuleEvent, List<QueryParamValue>) - Method in class org.mule.module.db.internal.resolver.param.StaticParamValueResolver
 
resolveParams(MuleEvent, HttpParamType) - Method in class org.mule.module.http.internal.HttpMessageBuilder
 
resolveParseRequest(Boolean) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
resolvePath(MessageProcessor) - Method in class org.mule.util.NotificationUtils.FlowMap
 
resolvePath(MessageProcessor) - Method in interface org.mule.util.NotificationUtils.PathResolver
 
resolvePlaceholder(String) - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
 
resolvePlaceholder(String) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
resolvePlaceholder(String, Properties, int) - Method in class org.mule.config.spring.processors.PropertyPlaceholderProcessor
 
resolveProcessorPath(Object) - Method in exception org.mule.api.LocatedMuleException
 
resolveProcessorRepresentation(String, String, Object) - Static method in class org.mule.api.execution.LocationExecutionContextProvider
Generates a representation of a flow element to be logged in a standard way.
resolveRequestAuthentication(MuleEvent) - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
resolveResource(String, String, String, String, String) - Method in class org.mule.module.xml.util.MuleResourceResolver
 
resolveReturnType(Method, Class) - Static method in class org.mule.util.generics.GenericTypeResolver
Determine the target type for the generic return type of the given method.
ResolverException - Exception in org.mule.api.registry
An exception that is thrown by resolver classes responsible for finding objects in the registry based on particular criteria
ResolverException(Message) - Constructor for exception org.mule.api.registry.ResolverException
 
ResolverException(Message, Throwable) - Constructor for exception org.mule.api.registry.ResolverException
 
resolveRoutes(MuleEvent) - Method in interface org.mule.routing.DynamicRouteResolver
Return a list of MessageProcessor to route the message.
resolveRoutes(MuleEvent) - Method in class org.mule.routing.DynamicRouteResolverAdapter
 
ResolverSet - Class in org.mule.module.extension.internal.runtime.resolver
A ValueResolver which is based on associating a set of Parameters -> ValueResolver pairs.
ResolverSet() - Constructor for class org.mule.module.extension.internal.runtime.resolver.ResolverSet
 
ResolverSetResult - Class in org.mule.module.extension.internal.runtime.resolver
This class represents the outcome of the evaluation of a ResolverSet.
ResolverSetResult.Builder - Class in org.mule.module.extension.internal.runtime.resolver
A builder for creating instances of ResolverSetResult.
resolveSource(MuleEvent) - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
resolveStringValue(MuleEvent) - Method in class org.mule.util.AttributeEvaluator
 
resolveTimeZone(String) - Method in class org.mule.modules.schedulers.cron.CronSchedulerFactory
 
resolveTransaction() - Method in class org.mule.transaction.TransactionCoordination
 
resolveTransformer(DataType, DataType) - Method in class org.mule.registry.MuleRegistryHelper
 
resolveTypeArgument(Class, Class) - Static method in class org.mule.util.generics.GenericTypeResolver
Resolve the single type argument of the given generic interface against the given target class which is assumed to implement the generic interface and possibly declare a concrete type for its type variable.
resolveTypeArguments(Class, Class) - Static method in class org.mule.util.generics.GenericTypeResolver
Resolve the type arguments of the given generic interface against the given target class which is assumed to implement the generic interface and possibly declare concrete types for its type variables.
resolveTypedValue(MuleMessage) - Method in class org.mule.util.AttributeEvaluator
 
resolveUtf8(int) - Method in class org.mule.util.ClassReader
 
resolveValue(MuleMessage) - Method in class org.mule.util.AttributeEvaluator
 
resolveValue(MuleEvent) - Method in class org.mule.util.AttributeEvaluator
 
resolveVariable(QName) - Method in class org.mule.module.xml.xpath.JaxpXPathEvaluator
Resolves the given variable against the flow variables in the MuleEvent held by JaxpXPathEvaluator.evaluationEvent
resolveVariable(MuleEvent) - Method in class org.mule.transport.polling.watermark.Watermark
 
resource - Variable in class org.mule.transaction.AbstractSingleResourceTransaction
 
resource - Variable in class org.mule.transport.AbstractReceiverResourceWorker
 
RESOURCE_INFO_PROPERTY - Static variable in class org.mule.endpoint.ResourceNameEndpointURIBuilder
 
RESOURCE_NOT_FOUND - Static variable in class org.mule.module.http.internal.listener.NoListenerRequestHandler
 
RESOURCE_OWNER_PARAM_NAME - Static variable in class org.mule.module.oauth2.internal.StateEncoder
 
RESOURCE_OWNER_PARAM_NAME_ASSIGN - Static variable in class org.mule.module.oauth2.internal.StateEncoder
 
resourceIdentifier - Variable in class org.mule.api.context.notification.ServerNotification
The resourceIdentifier is used when firing inbound server notifications such as Admin notifications or other action notifications triggered by an external source Used to associate the event with a particular resource.
resourceManager - Variable in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
resourceManager - Variable in class org.mule.util.xa.DefaultXASession
 
resourceManagerDirty() - Static method in class org.mule.config.i18n.CoreMessages
 
ResourceManagerException - Exception in org.mule.util.xa
 
ResourceManagerException() - Constructor for exception org.mule.util.xa.ResourceManagerException
 
ResourceManagerException(Message) - Constructor for exception org.mule.util.xa.ResourceManagerException
 
ResourceManagerException(Throwable) - Constructor for exception org.mule.util.xa.ResourceManagerException
 
ResourceManagerException(Message, Throwable) - Constructor for exception org.mule.util.xa.ResourceManagerException
 
resourceManagerNotReady() - Static method in class org.mule.config.i18n.CoreMessages
 
resourceManagerNotStarted() - Static method in class org.mule.config.i18n.CoreMessages
 
ResourceManagerSystemException - Exception in org.mule.util.xa
 
ResourceManagerSystemException() - Constructor for exception org.mule.util.xa.ResourceManagerSystemException
 
ResourceManagerSystemException(Message) - Constructor for exception org.mule.util.xa.ResourceManagerSystemException
 
ResourceManagerSystemException(Throwable) - Constructor for exception org.mule.util.xa.ResourceManagerSystemException
 
ResourceManagerSystemException(Message, Throwable) - Constructor for exception org.mule.util.xa.ResourceManagerSystemException
 
resourceName - Variable in class org.mule.config.ConfigResource
 
ResourceNameEndpointURIBuilder - Class in org.mule.endpoint
ResourceNameEndpointBuilder extracts a resource name from a uri endpointUri
ResourceNameEndpointURIBuilder() - Constructor for class org.mule.endpoint.ResourceNameEndpointURIBuilder
 
ResourceNotFoundException - Exception in org.mule.transport.http.components
Thrown when a static file is requested but not found
ResourceNotFoundException(Message, MuleEvent, MessageProcessor) - Constructor for exception org.mule.transport.http.components.ResourceNotFoundException
 
ResourceOwnerOAuthContext - Class in org.mule.module.oauth2.internal.authorizationcode.state
OAuth state for a particular resource owner which typically represents an user.
ResourceOwnerOAuthContext(Lock, String) - Constructor for class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
ResourceReleaser - Interface in org.mule.module.launcher.artifact
Implementations of this class should take care about resources that may leak memory after application undeployment.
RESPONSE_HANDLER_KEY - Static variable in class org.mule.transport.servlet.jetty.JettyContinuationsReceiverServlet
 
RESPONSE_HEADER_NAMES - Static variable in class org.mule.transport.http.HttpConstants
 
RESPONSE_OBSERVER - Static variable in class org.mule.module.cxf.transport.MuleUniversalDestination
 
RESPONSE_TRANSFORMER_REFS_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
ResponseAssertionMessageProcessor - Class in org.mule.tck.functional
 
ResponseAssertionMessageProcessor() - Constructor for class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
ResponseCompletionCallback - Interface in org.mule.execution
Callback to be used to notify of the result of an asynchronous response writing task.
ResponseCompletionHandler - Class in org.mule.module.http.internal.listener.grizzly
CompletionHandler, responsible for asynchronous response writing
ResponseCompletionHandler(FilterChainContext, HttpRequestPacket, HttpResponse, ResponseStatusCallback) - Constructor for class org.mule.module.http.internal.listener.grizzly.ResponseCompletionHandler
 
responseCountFailOrNullEvent() - Method in class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
ResponseDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
ResponseDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.ResponseDefinitionParser
 
ResponseDispatchException - Exception in org.mule.execution
Exception thrown when there's a failure writing the response using the transport infrastructure.
ResponseDispatchException(Message, MuleEvent) - Constructor for exception org.mule.execution.ResponseDispatchException
 
ResponseDispatchException(Message, MuleEvent, Throwable) - Constructor for exception org.mule.execution.ResponseDispatchException
 
ResponseDispatchException(MuleEvent, Throwable) - Constructor for exception org.mule.execution.ResponseDispatchException
 
responseEvents - Variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
responseExpression - Variable in class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
responseExpressionFailed() - Method in class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
ResponseMessageProcessorAdapter - Class in org.mule.processor
 
ResponseMessageProcessorAdapter() - Constructor for class org.mule.processor.ResponseMessageProcessorAdapter
 
ResponseMessageProcessorAdapter(MessageProcessor) - Constructor for class org.mule.processor.ResponseMessageProcessorAdapter
 
responseMessageProcessors - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
ResponseMessageProcessorsFactoryBean - Class in org.mule.config.spring.factories
 
ResponseMessageProcessorsFactoryBean() - Constructor for class org.mule.config.spring.factories.ResponseMessageProcessorsFactoryBean
 
ResponseOutputStream - Class in org.mule
ResponseOutputStream is an output stream associated with the currently received event.
ResponseOutputStream(OutputStream) - Constructor for class org.mule.ResponseOutputStream
 
ResponseOutputStream(Socket, OutputStream) - Constructor for class org.mule.ResponseOutputStream
 
responseProcessor - Variable in class org.mule.processor.ResponseMessageProcessorAdapter
 
responsePropertiesList - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
responseReady(HttpResponse, ResponseStatusCallback) - Method in interface org.mule.module.http.internal.listener.async.HttpResponseReadyCallback
method to send response to the client
responseSendFailure(Throwable) - Method in interface org.mule.module.http.internal.listener.async.ResponseStatusCallback
method to process a failure while sending the response to the client
responseSendSuccessfully() - Method in interface org.mule.module.http.internal.listener.async.ResponseStatusCallback
notifies that the response was successfully send.
responseSentSuccessfully() - Method in interface org.mule.execution.ResponseCompletionCallback
Notifies that the response was written successfully
responseSentWithFailure(Exception, MuleEvent) - Method in interface org.mule.execution.ResponseCompletionCallback
Notifies that the response writing failed
ResponseStatus - Class in org.mule.module.http.internal.domain.response
 
ResponseStatus() - Constructor for class org.mule.module.http.internal.domain.response.ResponseStatus
 
ResponseStatus(int, String) - Constructor for class org.mule.module.http.internal.domain.response.ResponseStatus
 
ResponseStatusCallback - Interface in org.mule.module.http.internal.listener.async
 
ResponseStreamingCompletionHandler - Class in org.mule.module.http.internal.listener.grizzly
CompletionHandler, responsible for asynchronous http response transferring when the response body is an input stream.
ResponseStreamingCompletionHandler(FilterChainContext, HttpRequestPacket, HttpResponse, ResponseStatusCallback) - Constructor for class org.mule.module.http.internal.listener.grizzly.ResponseStreamingCompletionHandler
 
responseTimedOutWaitingForId(int, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
responseTimeout(long) - Method in class org.mule.api.client.AbstractBaseOptionsBuilder
 
responseTimeout(long) - Method in interface org.mule.api.client.OperationOptionsConfig
 
responseTimeout - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
responseTimeout(long) - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
ResponseTimeoutException - Exception in org.mule.api.routing
ResponseTimeoutException is thrown when a response is not received in a given timeout in the Response Router.
ResponseTimeoutException(Message, MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.routing.ResponseTimeoutException
 
ResponseTimeoutException(Message, MuleEvent, MessageProcessor, Throwable) - Constructor for exception org.mule.api.routing.ResponseTimeoutException
 
responseTransformers - Variable in class org.mule.construct.AbstractConfigurationPattern
 
responseTransformers - Variable in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
responseTransformers(Transformer...) - Method in class org.mule.construct.builder.BridgeBuilder
 
responseTransformers(Transformer...) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
responseTransformers - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
responseTransformers - Variable in class org.mule.endpoint.AbstractEndpointURIBuilder
 
responseTransformers(Transformer...) - Method in class org.mule.module.ws.construct.builder.WSProxyBuilder
 
responseTransformers(Transformer...) - Method in class org.mule.transport.http.construct.builder.HttpProxyBuilder
 
ResponseValidator - Interface in org.mule.module.http.internal.request
 
ResponseValidatorException - Exception in org.mule.module.http.internal.request
 
ResponseValidatorException(String, MuleEvent) - Constructor for exception org.mule.module.http.internal.request.ResponseValidatorException
 
ResponseWriter - Class in org.mule.transport.http
Provides a hybrid Writer/OutputStream for sending HTTP response data
ResponseWriter(OutputStream) - Constructor for class org.mule.transport.http.ResponseWriter
 
ResponseWriter(OutputStream, String) - Constructor for class org.mule.transport.http.ResponseWriter
 
ResponseWriter(OutputStream, String, String) - Constructor for class org.mule.transport.http.ResponseWriter
 
ResponseWriterCallback - Class in org.mule.tck.functional
A test callback that writes the results of a service invocation to the response output stream of the event This should only be used when testing Asynchronous calls with the FunctionalTestComponent otherwise you will get duplicate messages, since both this class and the FunctionalTestComponent will write a return message back to the callee.
ResponseWriterCallback() - Constructor for class org.mule.tck.functional.ResponseWriterCallback
 
restart() - Static method in class org.mule.module.management.util.ManagementUtils
 
restart(String[]) - Method in class org.mule.test.infrastructure.process.Controller
 
restart(String...) - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
restart(String[]) - Method in class org.mule.test.infrastructure.process.WindowsController
 
restoreAccessToken(OAuth1Adapter) - Method in class org.mule.security.oauth.BaseOAuth1Manager
Restores the access token that belongs to the given adapter and sets its value into it.
restoreAccessToken() - Method in class org.mule.security.oauth.callback.DefaultRestoreAccessTokenCallback
 
restoreAccessToken() - Method in interface org.mule.security.oauth.callback.RestoreAccessTokenCallback
Restore access token and secret
restoreAccessToken(OAuth1Adapter) - Method in interface org.mule.security.oauth.OAuth1Manager
Restores the access token that belongs to the given adapter and sets its value into it.
RestoreAccessTokenCallback - Interface in org.mule.security.oauth.callback
 
restoreAuthorizationEvent(String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Recovers a MuleEvent from the object store.
restoreAuthorizationEvent(String) - Method in interface org.mule.security.oauth.OAuth2Manager
Recovers a MuleEvent from the object store.
restoreIsolatedTransaction() - Method in class org.mule.transaction.TransactionCoordination
 
restoreNamespaces() - Method in class org.mule.module.ws.consumer.NamespaceRestorerXMLStreamReader
 
restoreOriginalEvent(MuleEvent) - Method in class org.mule.security.oauth.processor.OAuth2FetchAccessTokenMessageProcessor
 
RESTRICTED_ENDPOINT_ATTRIBUTES - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.AddressedEndpointDefinitionParser
 
RestrictedSSLServerSocketFactory - Class in org.mule.api.security.tls
SSLServerSocketFactory decorator that restricts the available protocols and cipher suites in the sockets that are created.
RestrictedSSLServerSocketFactory(SSLContext, String[], String[]) - Constructor for class org.mule.api.security.tls.RestrictedSSLServerSocketFactory
 
RestrictedSSLSocketFactory - Class in org.mule.api.security.tls
SSLSocketFactory decorator that restricts the available protocols and cipher suites in the sockets that are created.
RestrictedSSLSocketFactory(SSLContext, String[], String[]) - Constructor for class org.mule.api.security.tls.RestrictedSSLSocketFactory
 
RestServiceException - Exception in org.mule.transport.http.components
 
RestServiceException(Message, MuleEvent, MessageProcessor) - Constructor for exception org.mule.transport.http.components.RestServiceException
 
RestServiceException(Message, MuleEvent, Throwable, MessageProcessor) - Constructor for exception org.mule.transport.http.components.RestServiceException
 
RestServiceWrapper - Class in org.mule.transport.http.components
This service can used to proxy REST style services as local Mule Components.
RestServiceWrapper() - Constructor for class org.mule.transport.http.components.RestServiceWrapper
 
ResultSetHandler - Interface in org.mule.module.db.internal.result.resultset
Processes all the records from a given @ResultSet in a stateless way.
resultSetHandler - Variable in class org.mule.transport.jdbc.JdbcConnector
 
resultSetHandlerBeanName - Variable in class org.mule.module.db.internal.config.processor.AbstractResultSetHandlerProcessorDefinitionParser
 
ResultSetIterator - Class in org.mule.module.db.internal.result.resultset
Iterates a ResultSet to provide rows streaming
ResultSetIterator(DbConnection, ResultSet, RowHandler, StreamingResultSetCloser) - Constructor for class org.mule.module.db.internal.result.resultset.ResultSetIterator
 
ResultSetProcessingException - Exception in org.mule.module.db.internal.result.resultset
Thrown to indicate an error during the processing of a ResultSet
ResultSetProcessingException(String, Throwable) - Constructor for exception org.mule.module.db.internal.result.resultset.ResultSetProcessingException
 
ResultSetResult - Class in org.mule.module.db.internal.result.statement
Represents a ResultSet after a Statement execution
ResultSetResult(String, Object) - Constructor for class org.mule.module.db.internal.result.statement.ResultSetResult
 
resultsHandler - Variable in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
resultsHandler - Variable in class org.mule.routing.outbound.AbstractOutboundRouter
 
Resumable - Interface in org.mule.service
Adds a resume lifecycle method to an object.
resume() - Method in interface org.mule.api.debug.ExecutionManager
Resumes the execution.
resume() - Method in interface org.mule.api.service.Service
Deprecated.
Resumes a single Mule Service that has been paused.
resume() - Method in interface org.mule.api.transaction.Transaction
Resume the XA transaction
resume() - Method in class org.mule.module.management.mbean.ServiceService
Resumes the Service that has been paused.
resume() - Method in interface org.mule.module.management.mbean.ServiceServiceMBean
Deprecated.
Resumes the Service that has been paused.
resume() - Method in class org.mule.processor.DelegateTransaction
 
resume() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
resume() - Method in class org.mule.service.AbstractService
Deprecated.
Resumes a single Mule Service that has been paused.
resume() - Method in interface org.mule.service.Resumable
 
resume() - Method in class org.mule.transaction.AbstractTransaction
 
resume() - Method in class org.mule.transaction.XaTransaction
 
resumeEncoding() - Method in class org.mule.util.Base64.OutputStream
Resumes encoding of the stream.
resumeIfResumable(Object) - Method in class org.mule.service.AbstractService
Deprecated.
 
ResumePhase - Class in org.mule.service
Resume phase happens only alfter a pause phase.
ResumePhase() - Constructor for class org.mule.service.ResumePhase
 
resumeSuspendedTransaction() - Method in class org.mule.transaction.TransactionCoordination
 
resumeXATransaction(Transaction) - Method in class org.mule.execution.SuspendXaTransactionInterceptor
 
resumeXaTransactionIfAvailable() - Method in class org.mule.transaction.TransactionCoordination
 
retainAll(Collection<?>) - Method in class org.mule.module.launcher.util.ObservableList
 
retainAll(Collection) - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
retractFact(Rules, Object) - Method in interface org.mule.module.bpm.RulesEngine
Retract a fact from the knowledge base.
retractFact(Rules, Object) - Method in class org.mule.module.drools.Drools
 
retrieve(Serializable) - Method in interface org.mule.api.store.ObjectStore
Retrieve the given Object.
retrieve(Serializable, String) - Method in interface org.mule.api.store.PartitionableObjectStore
 
retrieve(Serializable) - Method in class org.mule.tck.util.FakeObjectStore
 
retrieve(Serializable) - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
Retrieve the given Object.
retrieve(Serializable) - Method in class org.mule.util.store.AbstractObjectStore
 
retrieve(Serializable) - Method in class org.mule.util.store.AbstractPartitionedObjectStore
 
retrieve(Serializable) - Method in class org.mule.util.store.InMemoryObjectStore
 
retrieve(Serializable) - Method in class org.mule.util.store.ManagedObjectStore
 
retrieve(Serializable) - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
retrieve(Serializable) - Method in class org.mule.util.store.ObjectStorePartition
 
retrieve(Serializable, String) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
retrieve(Serializable) - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
 
retrieve(Serializable, String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
retrieve(Serializable) - Method in class org.mule.util.store.PersistentObjectStorePartition
 
retrieve(Serializable) - Method in class org.mule.util.store.ProvidedObjectStoreWrapper
 
retrieve(Serializable, String) - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
retrieve(Serializable) - Method in class org.mule.util.store.QueueStoreAdapter
Deprecated.
 
retrieveAutoGeneratedKeys() - Method in class org.mule.module.db.internal.result.statement.StatementResultIterator
 
retrieveFile(String) - Method in class org.mule.transport.sftp.SftpClient
 
retrieveFile(String, SftpNotifier) - Method in class org.mule.transport.sftp.SftpReceiverRequesterUtil
 
retrieveList(Object) - Static method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
RetrieveMessageReceiver - Class in org.mule.transport.email
Poll a mailbox for messages, remove the messages and route them as events into Mule.
RetrieveMessageReceiver(Connector, FlowConstruct, InboundEndpoint, long, boolean, String) - Constructor for class org.mule.transport.email.RetrieveMessageReceiver
 
RetrieveMessageRequester - Class in org.mule.transport.email
This dispatcher can only be used to receive message (as opposed to listening for them).
RetrieveMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.email.RetrieveMessageRequester
 
RetrieveMessageRequesterFactory - Class in org.mule.transport.email
A source of mail receiving message dispatchers.
RetrieveMessageRequesterFactory() - Constructor for class org.mule.transport.email.RetrieveMessageRequesterFactory
 
retrieveSession() - Method in class org.mule.module.http.internal.listener.properties.SSLSessionProperties
 
retrieveSessionInfoFromMessage(MuleMessage, MuleSession) - Method in interface org.mule.api.transport.SessionHandler
Deprecated.
Use retrieveSessionInfoFromMessage(MuleMessage message) instead
retrieveSessionInfoFromMessage(MuleMessage) - Method in interface org.mule.api.transport.SessionHandler
 
retrieveSessionInfoFromMessage(MuleMessage) - Method in class org.mule.session.LegacySessionHandler
Deprecated.
 
retrieveSessionInfoFromMessage(MuleMessage, MuleSession) - Method in class org.mule.session.LegacySessionHandler
Deprecated.
Use retrieveSessionInfoFromMessage(MuleMessage message) instead
retrieveSessionInfoFromMessage(MuleMessage) - Method in class org.mule.session.NullSessionHandler
 
retrieveSessionInfoFromMessage(MuleMessage, MuleSession) - Method in class org.mule.session.NullSessionHandler
Deprecated.
Use retrieveSessionInfoFromMessage(MuleMessage message) instead
retrieveSessionInfoFromMessage(MuleMessage) - Method in class org.mule.session.SerializeAndEncodeSessionHandler
 
retrieveSessionInfoFromMessage(MuleMessage) - Method in class org.mule.session.SerializeOnlySessionHandler
 
retrieveSessionInfoFromMessage(MuleMessage, MuleSession) - Method in class org.mule.session.SerializeOnlySessionHandler
Deprecated.
Use retrieveSessionInfoFromMessage(MuleMessage message) instead
retrieveSessionInfoFromMessage(MuleMessage) - Method in class org.mule.session.SimpleSessionHandler
 
retrieveSessionInfoFromMessage(MuleMessage, MuleSession) - Method in class org.mule.session.SimpleSessionHandler
Deprecated.
Use retrieveSessionInfoFromMessage(MuleMessage message) instead
retrieveWsdlResource(String) - Method in class org.mule.module.ws.consumer.HttpRequesterWsdlRetrieverStrategy
 
retrieveWsdlResource(String) - Method in class org.mule.module.ws.consumer.URLRetrieverStrategy
 
retrieveWsdlResource(String) - Method in interface org.mule.module.ws.consumer.WsdlRetrieverStrategy
 
RETRY_AFTER - Static variable in class org.mule.module.http.api.HttpHeaders.Names
RETRY_COMMIT - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
RETRY_COUNT_FOREVER - Static variable in class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
RetryCallback - Interface in org.mule.api.retry
This is the main Retry SPI.
RetryConnectionFactory - Class in org.mule.module.db.internal.domain.connection
Defines a ConnectionFactory that is configured to retry connection creation in case of errors using a RetryPolicyTemplate
RetryConnectionFactory(RetryPolicyTemplate, ConnectionFactory) - Constructor for class org.mule.module.db.internal.domain.connection.RetryConnectionFactory
 
RetryContext - Interface in org.mule.api.retry
The RetryContext is used to store any data which carries over from attempt to attempt such as response messages.
retryCounter - Variable in class org.mule.retry.policies.SimpleRetryPolicy
 
RetryForeverPolicyTemplate - Class in org.mule.retry.policies
This policy is the same as SimpleRetryPolicyTemplate but will retry an infinite amount of times.
RetryForeverPolicyTemplate() - Constructor for class org.mule.retry.policies.RetryForeverPolicyTemplate
 
RetryForeverPolicyTemplate(long) - Constructor for class org.mule.retry.policies.RetryForeverPolicyTemplate
 
retryMethod(HttpMethod, IOException, int) - Method in class org.mule.transport.http.MuleHttpMethodRetryHandler
 
RetryNotifier - Interface in org.mule.api.retry
This interface is a callback that allows actions to be performed after each retry attempt, such as firing notifications, logging, etc.
RetryNotifierDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
RetryNotifierDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.RetryNotifierDefinitionParser
 
RetryNotifierDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.RetryNotifierDefinitionParser
 
RetryPolicy - Interface in org.mule.api.retry
A RetryPolicy takes some action each time an exception occurs and returns a PolicyStatus which indicates whether the policy is exhausted or should continue to retry.
RetryPolicyDefinitionParser - Class in org.mule.config.spring.parsers.specific
Allows retry policies to be children of connector elements or the element.
RetryPolicyDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.RetryPolicyDefinitionParser
 
RetryPolicyDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.RetryPolicyDefinitionParser
 
retryPolicyExhausted(RetryPolicyTemplate) - Static method in class org.mule.config.i18n.CoreMessages
 
RetryPolicyExhaustedException - Exception in org.mule.retry
This exception is thrown when a Retry policy has made all the retry attempts it wants to make and is still failing.
RetryPolicyExhaustedException(Message, Object) - Constructor for exception org.mule.retry.RetryPolicyExhaustedException
 
RetryPolicyExhaustedException(Message, Throwable, Object) - Constructor for exception org.mule.retry.RetryPolicyExhaustedException
 
RetryPolicyExhaustedException(Throwable, Object) - Constructor for exception org.mule.retry.RetryPolicyExhaustedException
 
RetryPolicyTemplate - Interface in org.mule.api.retry
A RetryPolicyTemplate creates a new RetryPolicy instance each time the retry goes into effect, thereby resetting any state the policy may have (counters, etc.) A RetryNotifier may be set in order to take action upon each retry attempt.
retryPolicyTemplate - Variable in class org.mule.endpoint.AbstractEndpoint
 
retryPolicyTemplate - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
RetryProcessInterceptor<T,O> - Class in org.mule.security.oauth.process
 
RetryProcessInterceptor(ProcessInterceptor<T, O>, MuleContext, RetryPolicyTemplate) - Constructor for class org.mule.security.oauth.process.RetryProcessInterceptor
 
retryTemplate - Variable in class org.mule.transport.AbstractTransportMessageHandler
 
RetryWorker - Class in org.mule.retry.async
A Work implementation used when executing a RetryPolicyTemplate in a separate thread.
RetryWorker(RetryPolicyTemplate, RetryCallback, WorkManager) - Constructor for class org.mule.retry.async.RetryWorker
 
RetryWorker(RetryPolicyTemplate, RetryCallback, WorkManager, Latch) - Constructor for class org.mule.retry.async.RetryWorker
 
RETURN_ORIGINAL_MESSAGE_PROPERTY - Static variable in class org.mule.transport.jms.JmsConstants
 
returnArtifact(MuleArtifact) - Method in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
returnComponentLifecycleAdaptor(LifecycleAdapter) - Method in class org.mule.component.AbstractJavaComponent
 
returnComponentLifecycleAdaptor(LifecycleAdapter) - Method in class org.mule.component.DefaultJavaComponent
 
returnComponentLifecycleAdaptor(LifecycleAdapter) - Method in class org.mule.component.PooledJavaComponent
 
returnComponentLifecycleAdaptor(LifecycleAdapter) - Method in class org.mule.component.SimpleCallableJavaComponent
 
returnDispatcher(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.AbstractConnector
 
returnDispatcher(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.http.HttpConnector
 
returnDispatcher(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.jdbc.JdbcConnector
 
returnException(MuleEvent, HttpMethod) - Method in class org.mule.transport.http.HttpClientMessageDispatcher
An exception is thrown if http.status >= 400 and exceptions are not disabled through one of the following mechanisms in order of precedence: - setting to true the flow variable "http.disable.status.code.exception.check" - setting to true the outbound property "http.disable.status.code.exception.check" - setting to false the outbound endpoint attribute "exceptionOnMessageError"
returnMessage(MuleEvent) - Method in class org.mule.client.DefaultLocalMuleClient
 
returnObject(Object, Object) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
returnObject(Object) - Method in class org.mule.util.pool.CommonsPoolObjectPool
 
returnObject(Object) - Method in interface org.mule.util.pool.ObjectPool
 
returnResponse(MuleEvent) - Method in class org.mule.transport.AbstractMessageDispatcher
Deprecated. 
returnResponse(MuleEvent, boolean) - Method in class org.mule.transport.AbstractMessageDispatcher
Used to determine if the dispatcher implementation should wait for a response to an event on a response channel after it sends the event.
returnsAutoGeneratedKeys() - Method in interface org.mule.module.db.internal.domain.autogeneratedkey.AutoGeneratedKeyStrategy
Indicates if there are auto generated keys to return
returnsAutoGeneratedKeys() - Method in class org.mule.module.db.internal.domain.autogeneratedkey.ColumnIndexAutoGeneratedKeyStrategy
 
returnsAutoGeneratedKeys() - Method in class org.mule.module.db.internal.domain.autogeneratedkey.ColumnNameAutoGeneratedKeyStrategy
 
returnsAutoGeneratedKeys() - Method in class org.mule.module.db.internal.domain.autogeneratedkey.DefaultAutoGeneratedKeyStrategy
 
returnsAutoGeneratedKeys() - Method in class org.mule.module.db.internal.domain.autogeneratedkey.NoAutoGeneratedKeyStrategy
 
returnType - Variable in class org.mule.transformer.AbstractTransformer
The return type that will be returned by the AbstractTransformer.transform(java.lang.Object) method is called
ReusablePropertyConfiguration - Class in org.mule.config.spring.parsers.assembly.configuration
Allow initial mutation; first call of reset stores values as reference and allows further temporary mutation; further calls to reset return to reference.
ReusablePropertyConfiguration() - Constructor for class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
ReusablePropertyConfiguration(PropertyConfiguration) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
ReusableQueueSessionWrapper - Class in org.mule.transport.jms
 
ReusableSessionWrapper - Class in org.mule.transport.jms
 
ReusableSessionWrapper(Session) - Constructor for class org.mule.transport.jms.ReusableSessionWrapper
 
ReusableSessionWrapperFactory - Class in org.mule.transport.jms
 
ReusableSessionWrapperFactory() - Constructor for class org.mule.transport.jms.ReusableSessionWrapperFactory
 
ReusableTopicSessionWrapper - Class in org.mule.transport.jms
 
reuseConsumer - Variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
reuseSession - Variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
ReversibleStaxInInterceptor - Class in org.mule.module.cxf.support
Resets the ReversibleXMLStreamReader so the person receiving it can start back at the beginning of the stream.
ReversibleStaxInInterceptor() - Constructor for class org.mule.module.cxf.support.ReversibleStaxInInterceptor
 
ReversibleStaxInterceptor - Class in org.mule.module.cxf.support
Creates a ReversibleXMLStreamReader to be able to track and replay events from the XMLStreamReader.
ReversibleStaxInterceptor(String) - Constructor for class org.mule.module.cxf.support.ReversibleStaxInterceptor
 
ReversibleValidatingInterceptor - Class in org.mule.module.cxf.support
The ReversibleValidatingInterceptor is going to allow to reset the Xml Stream Reader once it is consumed by the CheckClosingTagsInterceptor to validate the schema.
ReversibleValidatingInterceptor() - Constructor for class org.mule.module.cxf.support.ReversibleValidatingInterceptor
 
ReversibleXMLStreamReader - Class in org.mule.module.xml.stax
 
ReversibleXMLStreamReader(XMLStreamReader) - Constructor for class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
REVOCATION_KEYSTORE_ALGORITHM - Static variable in class org.mule.api.security.tls.TlsConfiguration
 
RevocationCheck - Interface in org.mule.api.security.tls
Interface for certificate revocation checkers that prepare a trust manager factory configuration.
rewrite(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ListValueMap
 
rewrite(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.PrefixValueMap
 
rewrite(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration.IndentityMapValueMap
 
rewrite(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration.MapValueMap
 
rewrite(String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.ValueMap
 
rewrite(String) - Method in class org.mule.config.spring.parsers.specific.RegExFilterDefinitionParser.FlagsMapping
 
rewriteOperationAddress(EndpointInfo, Document, String) - Method in class org.mule.module.cxf.support.ProxyWSDLQueryHandler
 
rewriteOperationAddress(EndpointInfo, Document, String) - Method in class org.mule.module.cxf.support.WSDLQueryHandler
 
rewriteSchemaLocation(String, String) - Method in class org.mule.module.cxf.support.ProxyWSDLQueryHandler
 
rewriteSchemaLocation(String, String) - Method in class org.mule.module.cxf.support.WSDLQueryHandler
 
rewriteURI(URI) - Method in class org.mule.endpoint.AbstractEndpointURIBuilder
 
Rfc822ByteArraytoMimeMessage - Class in org.mule.transport.email.transformers
 
Rfc822ByteArraytoMimeMessage() - Constructor for class org.mule.transport.email.transformers.Rfc822ByteArraytoMimeMessage
 
RMI - Static variable in class org.mule.transport.rmi.RmiConnector
 
RmiAble - Interface in org.mule.transport.rmi
A callback proxy for binding a RmiMessage receiver to a Remote object
RmiCallbackMessageReceiver - Class in org.mule.transport.rmi
TODO
RmiCallbackMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.rmi.RmiCallbackMessageReceiver
 
RmiConnector - Class in org.mule.transport.rmi
RmiConnector can bind or send to a given RMI port on a given host.
RmiConnector(MuleContext) - Constructor for class org.mule.transport.rmi.RmiConnector
 
RmiMessageDispatcher - Class in org.mule.transport.rmi
RmiMessageDispatcher will send transformed mule events over RMI-JRMP.
RmiMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.rmi.RmiMessageDispatcher
 
RmiMessageDispatcherFactory - Class in org.mule.transport.rmi
Creates and RmiMessageDispatcher
RmiMessageDispatcherFactory() - Constructor for class org.mule.transport.rmi.RmiMessageDispatcherFactory
 
RmiMessageReceiver - Class in org.mule.transport.rmi
Will repeatedly call a method on a Remote object.
RmiMessageReceiver(Connector, FlowConstruct, InboundEndpoint, long) - Constructor for class org.mule.transport.rmi.RmiMessageReceiver
 
RmiMessages - Class in org.mule.transport.rmi.i18n
 
RmiMessages() - Constructor for class org.mule.transport.rmi.i18n.RmiMessages
 
RmiMuleMessageFactory - Class in org.mule.transport.rmi
 
RmiMuleMessageFactory() - Constructor for class org.mule.transport.rmi.RmiMuleMessageFactory
 
RmiNamespaceHandler - Class in org.mule.transport.rmi.config
Registers a Bean Definition Parser for handling <rmi:connector> elements.
RmiNamespaceHandler() - Constructor for class org.mule.transport.rmi.config.RmiNamespaceHandler
 
RmiRegistryAgent - Class in org.mule.module.management.agent
Binds to an existing RMI registry or creates a new one on a defined URI.
RmiRegistryAgent() - Constructor for class org.mule.module.management.agent.RmiRegistryAgent
 
rollback() - Method in interface org.mule.api.exception.RollbackSourceCallback
 
rollback() - Method in interface org.mule.api.transaction.Transaction
Rollback the transaction
rollback(RollbackSourceCallback) - Method in class org.mule.exception.AbstractExceptionListener
rollback(Exception) - Method in class org.mule.exception.AbstractExceptionListener
 
rollback() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
rollback(Savepoint) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
rollback() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
rollback(Savepoint) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
rollback() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
rollback() - Method in class org.mule.transaction.AbstractTransaction
 
rollback() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
rollback(Savepoint) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
rollback() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
rollback() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
rollback() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
rollback(Xid) - Method in class org.mule.transport.jms.xa.XAResourceWrapper
 
rollback() - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
rollback(Xid) - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
rollback() - Method in interface org.mule.util.queue.QueueSession
Rollbacks a transaction started with QueueSession.begin()
rollback() - Method in class org.mule.util.queue.TransactionalQueueSession
 
rollback(Xid) - Method in class org.mule.util.queue.TransactionalQueueSession
 
rollback(Xid) - Method in class org.mule.util.xa.DefaultXASession
 
rollbackAndClose(Connection) - Static method in class org.mule.transport.jdbc.JdbcUtils
 
rollbackCurrentTransaction() - Method in class org.mule.transaction.TransactionCoordination
 
rollbackDandlingTransaction(Xid) - Method in class org.mule.util.queue.QueueXaResource
 
rollbackDandlingTransaction(Xid) - Method in class org.mule.util.xa.DefaultXASession
Commits a dangling transaction that can be caused by the failure of one of the XAResource involved in the transaction or a crash of the transaction manager.
rollbackDandlingTransaction(Xid) - Method in class org.mule.util.xa.XaTransactionRecoverer
 
rollbackDequeue(MuleEvent) - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
Roll back the previous dequeue(), i.e., put the event at the front of the queue, not at the back which is what enqueue() does.
rollbackFileMove(File, String) - Method in class org.mule.transport.file.FileMessageReceiver
Exception tolerant roll back method
RollbackMessagingExceptionStrategy - Class in org.mule.exception
 
RollbackMessagingExceptionStrategy() - Constructor for class org.mule.exception.RollbackMessagingExceptionStrategy
 
rollbackOnly - Variable in class org.mule.transaction.AbstractSingleResourceTransaction
 
RollbackSourceCallback - Interface in org.mule.api.exception
This is used to provide a rollback method in order to achieve atomic message delivery without relying on JTA transactions, The exact behavior of this method will depend on the transport, e.g.
rollbackTransaction() - Method in class org.mule.exception.AbstractExceptionListener
Deprecated.
use AbstractExceptionListener.rollback(Exception) instead. parameter should be null
rollbackTransaction(AbstractTransactionContext) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
rollbackTransaction(AbstractTransactionContext) - Method in class org.mule.util.xa.AbstractResourceManager
 
rollbackTxButNoResource(Transaction) - Static method in class org.mule.config.i18n.CoreMessages
 
rollbackTxFilter - Variable in class org.mule.exception.AbstractExceptionListener
 
rolledBack - Variable in class org.mule.transaction.AbstractSingleResourceTransaction
 
roomDoesNotExist(XMPPException) - Method in class org.mule.transport.xmpp.XmppMultiUserChatConversation
 
ROOT - Static variable in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
ROOT_ELEMENT - Static variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
ROOT_MESSAGE_PROPERTY - Static variable in class org.mule.routing.Foreach
 
ROOT_PATH - Static variable in class org.mule.transport.http.components.StaticResourceMessageProcessor
 
ROOT_PATH - Static variable in class org.mule.transport.http.HttpConnector
 
RootOrNestedElementBeanDefinitionParser - Class in org.mule.config.spring.parsers.delegate
Bean definition parser that allows mapping an element either as root or nested inside other element.
RootOrNestedElementBeanDefinitionParser(Class<?>, String) - Constructor for class org.mule.config.spring.parsers.delegate.RootOrNestedElementBeanDefinitionParser
 
rootStackTrace() - Static method in class org.mule.config.i18n.CoreMessages
 
RoundRobin - Class in org.mule.routing
RoundRobin divides the messages it receives among its target routes in round-robin fashion.
RoundRobin() - Constructor for class org.mule.routing.RoundRobin
 
RoundRobinRoutingStrategy - Class in org.mule.routing
Routing strategy that divides the messages it receives among its target routes in round-robin fashion.
RoundRobinRoutingStrategy(MuleContext, IdentifiableDynamicRouteResolver) - Constructor for class org.mule.routing.RoundRobinRoutingStrategy
 
route - Variable in exception org.mule.api.routing.RoutingException
 
route(MuleEvent) - Method in class org.mule.config.dsl.routers.ContentBasedRouter
Deprecated.
 
route(MuleEvent, Exception) - Method in class org.mule.exception.RollbackMessagingExceptionStrategy
 
route(MuleEvent, Exception) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
route(MuleEvent) - Method in class org.mule.routing.AbstractUntilSuccessfulProcessingStrategy
 
route(MuleEvent) - Method in class org.mule.routing.FirstSuccessful
Route the given event to one of our targets
route(MuleEvent, List<MessageProcessor>) - Method in class org.mule.routing.FirstSuccessfulRoutingStrategy
 
route(MuleEvent, List<MessageProcessor>) - Method in class org.mule.routing.MulticastingRoutingStrategy
 
route(MuleEvent) - Method in class org.mule.routing.outbound.AbstractMessageSplitter
 
route(MuleEvent) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
route(MuleEvent) - Method in class org.mule.routing.outbound.AbstractRecipientList
 
route(MuleEvent) - Method in class org.mule.routing.outbound.AbstractSequenceRouter
 
route(MuleEvent) - Method in class org.mule.routing.outbound.ChainingRouter
Deprecated.
 
route(MuleEvent) - Method in class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
route(MuleEvent) - Method in class org.mule.routing.outbound.ExceptionBasedRouter
Deprecated.
 
route(MuleEvent) - Method in class org.mule.routing.outbound.FilteringOutboundRouter
 
route(MuleEvent) - Method in class org.mule.routing.outbound.MessageChunkingRouter
Deprecated.
 
route(MuleEvent) - Method in class org.mule.routing.outbound.OutboundPassThroughRouter
Deprecated.
 
route(MuleEvent) - Method in class org.mule.routing.outbound.TransformerRouter
Deprecated.
 
route(MuleEvent) - Method in class org.mule.routing.RoundRobin
Process the event using the next target route in sequence
route(MuleEvent, List<MessageProcessor>) - Method in class org.mule.routing.RoundRobinRoutingStrategy
 
route(MuleEvent, List<MessageProcessor>) - Method in interface org.mule.routing.RoutingStrategy
Routes MuleEvent through a set of MessageProcessor
route(MuleEvent) - Method in class org.mule.routing.UntilSuccessful
 
route(MuleEvent) - Method in interface org.mule.routing.UntilSuccessfulProcessingStrategy
 
route(Client, Object) - Method in class org.mule.transport.ajax.AjaxMessageReceiver.ReceiverService
 
route(Object) - Method in interface org.mule.transport.rmi.RmiAble
Implementing method should route message back to Mule receiver and receive possible reply for program that calls this Receiver
routeEvent(MuleEvent) - Method in interface org.mule.execution.AsyncResponseFlowProcessingPhaseTemplate
Routes the MuleEvent through the processors chain
routeEvent(MuleEvent) - Method in interface org.mule.execution.FlowProcessingPhaseTemplate
Routes the MuleEvent through the processors chain
routeEvent(MuleEvent) - Method in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
routeEvent(MuleEvent) - Method in class org.mule.transport.AbstractMessageReceiver
 
routeEvent(MuleEvent) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
routeException(MuleEvent, Throwable) - Method in class org.mule.exception.AbstractExceptionListener
Routes the current exception to an error endpoint such as a Dead Letter Queue (jms) This method is only invoked if there is a MuleMessage available to dispatch.
routeException(MuleEvent, MessageProcessor, Throwable) - Method in class org.mule.exception.AbstractExceptionListener
routeFile(String) - Method in class org.mule.transport.sftp.SftpMessageReceiver
 
routeMessage(MuleMessage) - Method in interface org.mule.api.transport.MessageReceiver
 
routeMessage(MuleMessage, Transaction) - Method in interface org.mule.api.transport.MessageReceiver
 
routeMessage(MuleMessage, Transaction, OutputStream) - Method in interface org.mule.api.transport.MessageReceiver
 
routeMessage(MuleMessage) - Method in class org.mule.transport.AbstractMessageReceiver
 
routeMessage(MuleMessage, Transaction) - Method in class org.mule.transport.AbstractMessageReceiver
 
routeMessage(MuleMessage, Transaction, OutputStream) - Method in class org.mule.transport.AbstractMessageReceiver
 
routeMessage(MuleMessage, MuleSession, Transaction, OutputStream) - Method in class org.mule.transport.AbstractMessageReceiver
 
routeMessage(MuleMessage, MuleSession, OutputStream) - Method in class org.mule.transport.AbstractMessageReceiver
 
routeMessage(Object) - Method in class org.mule.transport.rmi.RmiCallbackMessageReceiver
 
routeMessage(MessageReceiver, MuleMessage, HttpServletRequest) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
RoutePathNotFoundException - Exception in org.mule.api.routing
RoutePathNotFoundException is thrown if a routing path for an event cannot be found.
RoutePathNotFoundException(MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.routing.RoutePathNotFoundException
 
RoutePathNotFoundException(MuleEvent, MessageProcessor, Throwable) - Constructor for exception org.mule.api.routing.RoutePathNotFoundException
 
RoutePathNotFoundException(Message, MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.routing.RoutePathNotFoundException
 
RoutePathNotFoundException(Message, MuleEvent, MessageProcessor, Throwable) - Constructor for exception org.mule.api.routing.RoutePathNotFoundException
 
Router - Annotation Type in org.mule.api.annotations.meta
Marks a router annotation and provides the type.
ROUTER - Static variable in class org.mule.config.spring.parsers.specific.InboundRouterDefinitionParser
 
ROUTER - Static variable in class org.mule.config.spring.parsers.specific.RouterDefinitionParser
 
RouterDefinitionParser - Class in org.mule.config.spring.parsers.specific
Generic router definition parser for parsing all Router elements.
RouterDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.RouterDefinitionParser
 
RouterDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.RouterDefinitionParser
 
RouteResolverException - Exception in org.mule.routing
Exception thrown when a route for an event can not be found
RouteResolverException(MuleEvent, Throwable) - Constructor for exception org.mule.routing.RouteResolverException
 
RouteResolverException(Message, MuleEvent, Throwable) - Constructor for exception org.mule.routing.RouteResolverException
 
RouteResolverException(Message, MuleEvent) - Constructor for exception org.mule.routing.RouteResolverException
 
RouterResultsHandler - Interface in org.mule.api.routing
An SPI interface where custom logic can be plugged in to control how collections and single messages are returned from routers.
routers - Variable in class org.mule.component.BindingInvocationHandler
 
routers - Variable in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
RouterStatistics - Class in org.mule.management.stats
RouterStatistics TODO
RouterStatistics(int) - Constructor for class org.mule.management.stats.RouterStatistics
The constructor
RouterStatisticsRecorder - Interface in org.mule.api.routing
 
RouterStats - Class in org.mule.module.management.mbean
RouterStats TODO
RouterStats(RouterStatistics) - Constructor for class org.mule.module.management.mbean.RouterStats
 
RouterStatsMBean - Interface in org.mule.module.management.mbean
RouterStatsMBean TODO
RouterType - Enum in org.mule.api.annotations.meta
TODO
routes - Variable in class org.mule.routing.outbound.AbstractOutboundRouter
 
ROUTING_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
routingError() - Static method in class org.mule.transport.email.i18n.EmailMessages
 
RoutingException - Exception in org.mule.api.routing
RoutingException is a base class for all routing exceptions.
RoutingException(MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.routing.RoutingException
 
RoutingException(MuleEvent, MessageProcessor, Throwable) - Constructor for exception org.mule.api.routing.RoutingException
 
RoutingException(Message, MuleEvent, MessageProcessor) - Constructor for exception org.mule.api.routing.RoutingException
 
RoutingException(Message, MuleEvent, MessageProcessor, Throwable) - Constructor for exception org.mule.api.routing.RoutingException
 
RoutingFailedMessagingException - Exception in org.mule.routing
Exception through by routing strategies when routing fails
RoutingFailedMessagingException(Message, MuleEvent) - Constructor for exception org.mule.routing.RoutingFailedMessagingException
 
RoutingFailedMessagingException(Message, MuleEvent, MessageProcessor) - Constructor for exception org.mule.routing.RoutingFailedMessagingException
 
RoutingFailedMessagingException(Message, MuleEvent, Throwable) - Constructor for exception org.mule.routing.RoutingFailedMessagingException
 
RoutingFailedMessagingException(MuleEvent, Throwable) - Constructor for exception org.mule.routing.RoutingFailedMessagingException
 
RoutingFailedMessagingException(Message, MuleEvent, Throwable, MessageProcessor) - Constructor for exception org.mule.routing.RoutingFailedMessagingException
 
RoutingFailedMessagingException(MuleEvent, Throwable, MessageProcessor) - Constructor for exception org.mule.routing.RoutingFailedMessagingException
 
routingFailedOnEndpoint(Service, ImmutableEndpoint) - Static method in class org.mule.config.i18n.CoreMessages
Deprecated.
RoutingNotification - Class in org.mule.context.notification
Is fired by routers.
RoutingNotification(MuleMessage, String, int) - Constructor for class org.mule.context.notification.RoutingNotification
 
RoutingNotificationListener<T extends RoutingNotification> - Interface in org.mule.api.context.notification
RoutingNotificationListener is an observer interface that objects can use to receive notifications about routing events such as async-reply misses.
RoutingStrategy - Interface in org.mule.routing
Defines an strategy to route a MuleEvent through a set of MessageProcessor
RowHandler - Interface in org.mule.module.db.internal.result.row
Processes rows from a resultSet
ROWID_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
RSS - Static variable in interface org.mule.transformer.types.MimeTypes
 
RSS_STRING - Static variable in class org.mule.transformer.types.DataTypeFactory
 
RssNamespaceHandler - Class in org.mule.module.rss.config
 
RssNamespaceHandler() - Constructor for class org.mule.module.rss.config.RssNamespaceHandler
 
RssParser - Class in org.mule.module.rss.transformers
RSS20Parser considers all the elements added in the last standard (and earlier standards).
RssParser() - Constructor for class org.mule.module.rss.transformers.RssParser
 
Rules - Class in org.mule.module.bpm
Business rules.
Rules(RulesEngine, String, Object, String, Collection, boolean, boolean, FlowConstruct, MuleContext) - Constructor for class org.mule.module.bpm.Rules
 
rules - Variable in class org.mule.module.bpm.RulesComponent
The ruleset
RulesComponent - Class in org.mule.module.bpm
A service backed by a Business Rules engine such as Drools.
RulesComponent() - Constructor for class org.mule.module.bpm.RulesComponent
 
rulesEngine - Variable in class org.mule.module.bpm.RulesComponent
The underlying Rules Engine
RulesEngine - Interface in org.mule.module.bpm
A generic interface for any Rules Engine.
run() - Method in class org.mule.context.notification.ServerNotificationManager
 
run() - Method in class org.mule.module.launcher.AbstractFileWatcher
 
run() - Method in class org.mule.module.launcher.DeploymentDirectoryWatcher
 
run() - Method in class org.mule.MuleServer
Overloaded the [main] thread run method.
run() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
While the service isn't stopped this runs a continuous loop checking for new events in the queue.
run() - Method in class org.mule.retry.async.RetryWorker
 
run() - Method in class org.mule.routing.EventProcessingThread
 
run() - Method in class org.mule.tck.concurrency.TestingThread
Executes the doRun() method and stores any exception which occurred to be returned at a later time.
run() - Method in class org.mule.transport.AbstractReceiverWorker
This will run the receiver logic and call AbstractReceiverWorker.release() once AbstractReceiverWorker.doRun() completes.
run() - Method in class org.mule.transport.http.HttpRequestDispatcherWork
 
run() - Method in class org.mule.transport.http.OldHttpMessageReceiver.HttpWorker
 
run() - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager.WorkDelegate
Deprecated.
 
run() - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
run() - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
run() - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
run() - Method in class org.mule.transport.PollingReceiverWorker
 
run() - Method in class org.mule.transport.PollingReceiverWorkerSchedule
 
run() - Method in class org.mule.transport.tcp.TcpMessageReceiver
 
run() - Method in class org.mule.transport.TransactedPollingMessageReceiver.MessageProcessorWorker
 
run() - Method in class org.mule.transport.udp.UdpMessageReceiver
 
run() - Method in class org.mule.transport.udp.UdpMessageReceiver.UdpWorker
Accept requests from a given Udp address
run() - Method in class org.mule.transport.vm.VMMessageReceiver.MessageProcessorWorker
 
run() - Method in class org.mule.util.monitor.ExpiryMonitor
The action to be performed by this timer task.
run() - Method in class org.mule.util.monitor.FileMonitor.FileMonitorNotifier
 
run() - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
run() - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
run() - Method in class org.mule.util.timer.EventTimerTask
The action to be performed by this timer task.
run() - Method in class org.mule.work.AbstractMuleEventWork
 
run() - Method in class org.mule.work.WorkerContext
 
runFlow(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
Runs the given flow with a default event
runFlow(String, T) - Method in class org.mule.tck.junit4.FunctionalTestCase
Executes the given flow with a default message carrying the payload
runFlow(String, MuleEvent) - Method in class org.mule.tck.junit4.FunctionalTestCase
Executes the given flow with the given event
runFlowAndExpect(String, T) - Method in class org.mule.tck.junit4.FunctionalTestCase
Run the flow specified by name and assert equality on the expected output
runFlowAndExpectProperty(String, String, T) - Method in class org.mule.tck.junit4.FunctionalTestCase
Runs the given flow and asserts for property name in the outbound scope to match the expected value
runFlowNonBlocking(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
Runs the given non blocking flow with a default event
runFlowNonBlocking(String, MessageExchangePattern) - Method in class org.mule.tck.junit4.FunctionalTestCase
Runs the given non blocking flow with a default event and a specific message exchange pattern
runFlowNonBlocking(String, MuleEvent) - Method in class org.mule.tck.junit4.FunctionalTestCase
Runs the given non blocking flow with a default event
runFlowNonBlocking(String, Object) - Method in class org.mule.tck.junit4.FunctionalTestCase
Runs the given non blocking flow with a given payload
runFlowWithPayloadAndExpect(String, T, U) - Method in class org.mule.tck.junit4.FunctionalTestCase
Run the flow specified by name using the specified payload and assert equality on the expected output
Running - Class in org.mule.test.infrastructure.process.matchers
 
Running(boolean) - Constructor for class org.mule.test.infrastructure.process.matchers.Running
 
running - Variable in class org.mule.transport.PollingReceiverWorker
 
runPhase(AsyncResponseFlowProcessingPhaseTemplate, MessageProcessContext, PhaseResultNotifier) - Method in class org.mule.execution.AsyncResponseFlowProcessingPhase
 
runPhase(EndPhaseTemplate, MessageProcessContext, PhaseResultNotifier) - Method in class org.mule.execution.EndProcessPhase
 
runPhase(FlowProcessingPhaseTemplate, MessageProcessContext, PhaseResultNotifier) - Method in class org.mule.execution.FlowProcessingPhase
 
runPhase(Template, MessageProcessContext, PhaseResultNotifier) - Method in interface org.mule.execution.MessageProcessPhase
Process the template through the phase.
runPhase(ValidationPhaseTemplate, MessageProcessContext, PhaseResultNotifier) - Method in class org.mule.execution.ValidationPhase
 
runSchedulersOnce(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
 
runScript(Bindings) - Method in class org.mule.module.scripting.component.Scriptable
 
runSync(String, String...) - Method in class org.mule.test.infrastructure.process.Controller
 
RUNTIME_VERBOSE - Static variable in class org.mule.util.SplashScreen
 
RUNTIME_VERBOSE_PROPERTY - Static variable in class org.mule.util.SplashScreen
Determines whether extra information should be display.
runToLocation(String) - Method in interface org.mule.api.debug.ExecutionManager
Should resume the execution until the specified location is reached.

S

S_MAXAGE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
SAFE - Static variable in class org.mule.RequestContext
Deprecated.
 
safeCopyFile(File, File) - Static method in class org.mule.util.FileUtils
Copy in file to out file Don't use java.nio as READ_ONLY memory mapped files cannot be deleted
safeMessageCopy(MuleMessage) - Static method in class org.mule.RequestContext
Deprecated.
 
SafeProtocol - Class in org.mule.transport.tcp.protocols
This precedes every message with a cookie.
SafeProtocol() - Constructor for class org.mule.transport.tcp.protocols.SafeProtocol
 
safeRead(InputStream, byte[]) - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
Manage non-blocking reads and handle errors
safeRead(InputStream, byte[], int) - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
Manage non-blocking reads and handle errors
sanitize(Throwable) - Static method in class org.mule.config.ExceptionHelper
Removes some internal Mule entries from the stacktrace.
sanitizeIfNeeded(Throwable) - Static method in class org.mule.config.ExceptionHelper
 
sanitizePathWithStartSlash(String) - Static method in class org.mule.module.http.internal.HttpParser
 
SaslAuthFixBean - Class in org.mule.transport.xmpp
Instantiate this bean in your spring config to work around a known issue with the SMACK API: http://www.igniterealtime.org/issues/browse/SMACK-264
SaslAuthFixBean() - Constructor for class org.mule.transport.xmpp.SaslAuthFixBean
 
saveAccessToken(String, String) - Method in class org.mule.security.oauth.callback.DefaultSaveAccessTokenCallback
 
saveAccessToken(String, String) - Method in interface org.mule.security.oauth.callback.SaveAccessTokenCallback
Save access token and secret
SaveAccessTokenCallback - Interface in org.mule.security.oauth.callback
 
saveBeanAssembler(BeanAssembler) - Method in interface org.mule.config.spring.parsers.assembly.TwoStageMapBeanAssemblerFactory.BeanAssemblerStore
 
saveBeanAssembler(BeanAssembler) - Method in class org.mule.config.spring.parsers.delegate.MapDefinitionParserMutator
 
SAX_PARSER_FACTORY - Static variable in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
SAX_PARSER_PROPERTY - Static variable in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
SAXON_TRANSFORMER_FACTORY - Static variable in class org.mule.module.xml.util.XMLUtils
 
SaxonXpathEvaluator - Class in org.mule.module.xml.xpath
Implementation of JaxpXPathEvaluator which uses the Saxon implementation.
SaxonXpathEvaluator() - Constructor for class org.mule.module.xml.xpath.SaxonXpathEvaluator
 
SaxParserFactoryInjectionProvider - Class in org.glassfish.jersey.message.internal
Thread-scoped injection provider of SAX parser factories.
SaxParserFactoryInjectionProvider(Configuration) - Constructor for class org.glassfish.jersey.message.internal.SaxParserFactoryInjectionProvider
Create new SAX parser factory provider.
SC_ACCEPTED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_BAD_GATEWAY - Static variable in class org.mule.transport.http.HttpConstants
 
SC_BAD_REQUEST - Static variable in class org.mule.transport.http.HttpConstants
 
SC_CONFLICT - Static variable in class org.mule.transport.http.HttpConstants
 
SC_CONTINUE - Static variable in class org.mule.transport.http.HttpConstants
 
SC_CREATED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_EXPECTATION_FAILED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_FAILED_DEPENDENCY - Static variable in class org.mule.transport.http.HttpConstants
 
SC_FORBIDDEN - Static variable in class org.mule.transport.http.HttpConstants
 
SC_GATEWAY_TIMEOUT - Static variable in class org.mule.transport.http.HttpConstants
 
SC_GONE - Static variable in class org.mule.transport.http.HttpConstants
 
SC_HTTP_VERSION_NOT_SUPPORTED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_INSUFFICIENT_SPACE_ON_RESOURCE - Static variable in class org.mule.transport.http.HttpConstants
 
SC_INSUFFICIENT_STORAGE - Static variable in class org.mule.transport.http.HttpConstants
 
SC_INTERNAL_SERVER_ERROR - Static variable in class org.mule.transport.http.HttpConstants
 
SC_LENGTH_REQUIRED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_LOCKED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_METHOD_FAILURE - Static variable in class org.mule.transport.http.HttpConstants
 
SC_METHOD_NOT_ALLOWED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_MOVED_PERMANENTLY - Static variable in class org.mule.transport.http.HttpConstants
 
SC_MOVED_TEMPORARILY - Static variable in class org.mule.transport.http.HttpConstants
 
SC_MULTI_STATUS - Static variable in class org.mule.transport.http.HttpConstants
 
SC_MULTIPLE_CHOICES - Static variable in class org.mule.transport.http.HttpConstants
 
SC_NO_CONTENT - Static variable in class org.mule.transport.http.HttpConstants
 
SC_NON_AUTHORITATIVE_INFORMATION - Static variable in class org.mule.transport.http.HttpConstants
 
SC_NOT_ACCEPTABLE - Static variable in class org.mule.transport.http.HttpConstants
 
SC_NOT_FOUND - Static variable in class org.mule.transport.http.HttpConstants
 
SC_NOT_IMPLEMENTED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_NOT_MODIFIED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_OK - Static variable in class org.mule.transport.http.HttpConstants
 
SC_PARTIAL_CONTENT - Static variable in class org.mule.transport.http.HttpConstants
 
SC_PAYMENT_REQUIRED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_PRECONDITION_FAILED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_PROCESSING - Static variable in class org.mule.transport.http.HttpConstants
 
SC_PROXY_AUTHENTICATION_REQUIRED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_REQUEST_TIMEOUT - Static variable in class org.mule.transport.http.HttpConstants
 
SC_REQUEST_TOO_LONG - Static variable in class org.mule.transport.http.HttpConstants
 
SC_REQUEST_URI_TOO_LONG - Static variable in class org.mule.transport.http.HttpConstants
 
SC_REQUESTED_RANGE_NOT_SATISFIABLE - Static variable in class org.mule.transport.http.HttpConstants
 
SC_RESET_CONTENT - Static variable in class org.mule.transport.http.HttpConstants
 
SC_SEE_OTHER - Static variable in class org.mule.transport.http.HttpConstants
 
SC_SERVICE_UNAVAILABLE - Static variable in class org.mule.transport.http.HttpConstants
 
SC_SWITCHING_PROTOCOLS - Static variable in class org.mule.transport.http.HttpConstants
 
SC_TEMPORARY_REDIRECT - Static variable in class org.mule.transport.http.HttpConstants
 
SC_UNAUTHORIZED - Static variable in class org.mule.transport.http.HttpConstants
 
SC_UNPROCESSABLE_ENTITY - Static variable in class org.mule.transport.http.HttpConstants
 
SC_UNSUPPORTED_MEDIA_TYPE - Static variable in class org.mule.transport.http.HttpConstants
 
SC_USE_PROXY - Static variable in class org.mule.transport.http.HttpConstants
 
scan(String) - Method in class org.mule.util.scan.InterfaceClassScanner
Deprecated.
 
scanFor(Class<T>) - Method in class org.mule.util.scan.ClasspathScanner
Deprecated.
 
scanFor(Class<T>, int) - Method in class org.mule.util.scan.ClasspathScanner
Deprecated.
 
ScatterGatherRouter - Class in org.mule.routing
The Scatter-Gather router will broadcast copies of the current message to every endpoint registered with the router in parallel.
ScatterGatherRouter() - Constructor for class org.mule.routing.ScatterGatherRouter
 
ScatterGatherRouterFactoryBean - Class in org.mule.config.spring.factories
 
ScatterGatherRouterFactoryBean() - Constructor for class org.mule.config.spring.factories.ScatterGatherRouterFactoryBean
 
Schedule - Annotation Type in org.mule.api.annotations
An annotation that allows you to call the method at the specified interval.
schedule() - Method in interface org.mule.api.schedule.Scheduler
Launches the action asynchronously.
schedule() - Method in class org.mule.modules.schedulers.cron.CronScheduler
 
schedule() - Method in class org.mule.transport.AbstractPollingMessageReceiver
This method registers this receiver for periodic polling ticks with the connectors scheduler.
schedule() - Method in class org.mule.transport.polling.schedule.FixedFrequencyScheduler
Executes the the Scheduler task
schedule() - Method in class org.mule.transport.vm.VMMessageReceiver
 
ScheduleAnnotationParser - Class in org.mule.transport.quartz.config
Creates a Quartz inbound endpoint for a service
ScheduleAnnotationParser() - Constructor for class org.mule.transport.quartz.config.ScheduleAnnotationParser
 
ScheduleConfigBuilder - Class in org.mule.transport.quartz.config
TODO
ScheduleConfigBuilder(String, MuleContext) - Constructor for class org.mule.transport.quartz.config.ScheduleConfigBuilder
 
ScheduledDispatchJob - Class in org.mule.transport.quartz.jobs
Will dispatch the current message to a Mule endpoint at a later time.
ScheduledDispatchJob() - Constructor for class org.mule.transport.quartz.jobs.ScheduledDispatchJob
 
ScheduledDispatchJobConfig - Class in org.mule.transport.quartz.jobs
The configuration for the ScheduledDispatchJob job.
ScheduledDispatchJobConfig() - Constructor for class org.mule.transport.quartz.jobs.ScheduledDispatchJobConfig
 
scheduledFiles - Variable in class org.mule.transport.ftp.FtpMessageReceiver
 
Scheduler - Interface in org.mule.api.schedule
An scheduler is a class that arrange jobs in a define schedule.
scheduler - Variable in class org.mule.util.monitor.ExpiryMonitor
 
scheduler - Variable in class org.mule.util.store.AbstractMonitoredObjectStore
 
scheduler - Variable in class org.mule.util.store.MonitoredObjectStoreWrapper
 
scheduler - Variable in class org.mule.util.store.MuleObjectStoreManager
 
SCHEDULER_FACTORY_PROPERTY_NAME - Static variable in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
The InboundEndpoint property for poll that contains the SchedulerFactory
SchedulerCreationException - Exception in org.mule.api.schedule
This exception is thrown if a Scheduler could not be created.
SchedulerCreationException(String, Throwable) - Constructor for exception org.mule.api.schedule.SchedulerCreationException
 
SchedulerCreationException(String) - Constructor for exception org.mule.api.schedule.SchedulerCreationException
 
SchedulerFactory<T extends Runnable> - Class in org.mule.api.schedule
Factory of schedulers.
SchedulerFactory() - Constructor for class org.mule.api.schedule.SchedulerFactory
 
schedulerFactory - Variable in class org.mule.config.spring.factories.PollingMessageSourceFactoryBean
 
SchedulerFactoryPostProcessor - Interface in org.mule.api.schedule
All the classes that implement this interface and are registered in the mule registry are going to be called after the creation of a Scheduler by the SchedulerFactory
SchedulerMessages - Class in org.mule.modules.schedulers.i18n
 
SchedulerMessages() - Constructor for class org.mule.modules.schedulers.i18n.SchedulerMessages
 
Schedulers - Class in org.mule.api.schedule
Utility class to create Scheduler predicates
Schedulers() - Constructor for class org.mule.api.schedule.Schedulers
 
SchedulersNamespaceHandler - Class in org.mule.modules.schedulers.config
 
SchedulersNamespaceHandler() - Constructor for class org.mule.modules.schedulers.config.SchedulersNamespaceHandler
 
schedules - Variable in class org.mule.transport.AbstractPollingMessageReceiver
 
scheduleTimeoutTask(TimerTask, int) - Method in class org.mule.transport.jms.JmsConnector
Schedules a timeout task used for performing timeout of async responses.
scheduleWork(Work) - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
scheduleWork(Work, long, ExecutionContext, WorkListener) - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
scheduleWork(Work) - Method in class org.mule.transport.TrackingWorkManager
 
scheduleWork(Work, long, ExecutionContext, WorkListener) - Method in class org.mule.transport.TrackingWorkManager
 
scheduleWork(Work) - Method in class org.mule.work.MuleWorkManager
 
scheduleWork(Work, long, ExecutionContext, WorkListener) - Method in class org.mule.work.MuleWorkManager
 
scheduleWork(Work) - Method in class org.mule.work.SerialWorkManager
 
scheduleWork(Work, long, ExecutionContext, WorkListener) - Method in class org.mule.work.SerialWorkManager
 
ScheduleWorkExecutor - Class in org.mule.work
 
ScheduleWorkExecutor() - Constructor for class org.mule.work.ScheduleWorkExecutor
 
schemaLanguage - Variable in class org.mule.util.xmlsecurity.XMLFactoryConfig
 
schemaToString(Schema) - Static method in class org.mule.module.ws.consumer.WSDLUtils
Converts a schema into a String.
SchemaValidationFilter - Class in org.mule.module.xml.filters
Filter for schema validation.
SchemaValidationFilter() - Constructor for class org.mule.module.xml.filters.SchemaValidationFilter
 
schemeCannotChangeForRouter(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
schemeNotCompatibleWithConnector(String, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
SCOPE_PARAMETER - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
scopes() - Method in class org.mule.module.ws.consumer.ScopeSaverXMLStreamReader
 
ScopeSaverXMLStreamReader - Class in org.mule.module.ws.consumer
XMLStreamReader decorator that saves the scope and allows accesing to information about all the parent XMLEvent elements
ScopeSaverXMLStreamReader(XMLStreamReader) - Constructor for class org.mule.module.ws.consumer.ScopeSaverXMLStreamReader
 
SCRIPT_ENGINE_NAME_PROPERTY - Static variable in class org.mule.module.scripting.builders.ScriptConfigurationBuilder
Deprecated.
 
Scriptable - Class in org.mule.module.scripting.component
A JSR 223 Script service.
Scriptable() - Constructor for class org.mule.module.scripting.component.Scriptable
 
Scriptable(MuleContext) - Constructor for class org.mule.module.scripting.component.Scriptable
 
ScriptComponent - Class in org.mule.module.scripting.component
A Script service backed by a JSR-223 compliant script engine such as Groovy, JavaScript, or Rhino.
ScriptComponent() - Constructor for class org.mule.module.scripting.component.ScriptComponent
 
ScriptComponentDefinitionParser - Class in org.mule.module.scripting.config
 
ScriptComponentDefinitionParser() - Constructor for class org.mule.module.scripting.config.ScriptComponentDefinitionParser
 
ScriptConfigurationBuilder - Class in org.mule.module.scripting.builders
Deprecated.
This class is deprecated and will be removed in Mule 4.0
ScriptConfigurationBuilder(String) - Constructor for class org.mule.module.scripting.builders.ScriptConfigurationBuilder
Deprecated.
 
ScriptConfigurationBuilder(String[]) - Constructor for class org.mule.module.scripting.builders.ScriptConfigurationBuilder
Deprecated.
 
ScriptConfigurationBuilder(String, String) - Constructor for class org.mule.module.scripting.builders.ScriptConfigurationBuilder
Deprecated.
 
ScriptConfigurationBuilder(String, String[]) - Constructor for class org.mule.module.scripting.builders.ScriptConfigurationBuilder
Deprecated.
 
ScriptDefinitionParser - Class in org.mule.module.scripting.config
 
ScriptDefinitionParser() - Constructor for class org.mule.module.scripting.config.ScriptDefinitionParser
 
ScriptEvaluator - Interface in org.mule.api.debug
Determine if the ExecutionManager supports or not dynamic scripting evaluation.
ScriptFilter - Class in org.mule.module.scripting.filter
 
ScriptFilter() - Constructor for class org.mule.module.scripting.filter.ScriptFilter
 
ScriptingNamespaceHandler - Class in org.mule.module.scripting.config
 
ScriptingNamespaceHandler() - Constructor for class org.mule.module.scripting.config.ScriptingNamespaceHandler
 
ScriptTransformer - Class in org.mule.module.scripting.transformer
Runs a script to perform transformation on an object.
ScriptTransformer() - Constructor for class org.mule.module.scripting.transformer.ScriptTransformer
 
SEC_WEBSOCKET_ACCEPT - Static variable in class org.mule.module.http.api.HttpHeaders.Names
SEC_WEBSOCKET_KEY - Static variable in class org.mule.module.http.api.HttpHeaders.Names
SEC_WEBSOCKET_KEY1 - Static variable in class org.mule.module.http.api.HttpHeaders.Names
SEC_WEBSOCKET_KEY2 - Static variable in class org.mule.module.http.api.HttpHeaders.Names
SEC_WEBSOCKET_LOCATION - Static variable in class org.mule.module.http.api.HttpHeaders.Names
SEC_WEBSOCKET_ORIGIN - Static variable in class org.mule.module.http.api.HttpHeaders.Names
SEC_WEBSOCKET_PROTOCOL - Static variable in class org.mule.module.http.api.HttpHeaders.Names
SEC_WEBSOCKET_VERSION - Static variable in class org.mule.module.http.api.HttpHeaders.Names
seconds() - Static method in class org.mule.config.i18n.CoreMessages
 
secretKey - Variable in class org.mule.security.AbstractJCEEncryptionStrategy
 
SecretKeyEncryptionStrategy - Class in org.mule.security
Deprecated.
This class is deprecated and will be removed in Mule 4.0. Use PasswordBasedEncryptionStrategy instead, which follows the correct way of transforming a string password into a cryptographic key
SecretKeyEncryptionStrategy() - Constructor for class org.mule.security.SecretKeyEncryptionStrategy
Deprecated.
 
SecretKeyFactory - Interface in org.mule.security
A factory class for providing secret keys to an instance of SecretKeyEncryptionStrategy.
SECURITY_AUTHENTICATION_FAILED - Static variable in class org.mule.context.notification.SecurityNotification
 
SECURITY_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
SECURITY_FILTER - Static variable in class org.mule.config.spring.parsers.specific.SecurityFilterDefinitionParser
 
SecurityContext - Interface in org.mule.api.security
SecurityContext holds security information and is associated with the MuleSession.
SecurityContextFactory - Interface in org.mule.api.security
SecurityContextFactory is responsible for creating a SecurityContext instance.
SecurityException - Exception in org.mule.api.security
SecurityException is a generic security exception
SecurityException(Message, MuleEvent) - Constructor for exception org.mule.api.security.SecurityException
 
SecurityException(Message, MuleEvent, Throwable) - Constructor for exception org.mule.api.security.SecurityException
 
SecurityException(Message, MuleEvent, Throwable, MessageProcessor) - Constructor for exception org.mule.api.security.SecurityException
 
SecurityFilter - Interface in org.mule.api.security
SecurityFilter is a base filter for secure filtering of inbound and outbound event flow.
SecurityFilterDefinitionParser - Class in org.mule.config.spring.parsers.specific
This allows a security filter to be defined globally, or embedded within an endpoint.
SecurityFilterDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.SecurityFilterDefinitionParser
 
SecurityFilterDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.SecurityFilterDefinitionParser
 
SecurityFilterMessageProcessor - Class in org.mule.processor
Filters the flow using the specified SecurityFilter.
SecurityFilterMessageProcessor() - Constructor for class org.mule.processor.SecurityFilterMessageProcessor
Deprecated.
Use SecurityFilterMessageProcessor(SecurityFilter filter) instead
SecurityFilterMessageProcessor(SecurityFilter) - Constructor for class org.mule.processor.SecurityFilterMessageProcessor
 
SecurityManager - Interface in org.mule.api.security
SecurityManager is responsible for managing one or more security providers.
securityManager - Variable in class org.mule.security.AbstractSecurityFilter
 
SecurityManagerDefinitionParser - Class in org.mule.module.spring.security.config
This security manager delegates its parsing into two different definition parsers based on the name of the element.
SecurityManagerDefinitionParser() - Constructor for class org.mule.module.spring.security.config.SecurityManagerDefinitionParser
 
SecurityNotification - Class in org.mule.context.notification
SecurityNotification is fired when a request for authorisation failed.
SecurityNotification(SecurityException, int) - Constructor for class org.mule.context.notification.SecurityNotification
 
SecurityNotificationListener<T extends SecurityNotification> - Interface in org.mule.api.context.notification
MuleContextNotificationListener is an observer interface that objects can implement to receive notifications about secure access requests.
SecurityProvider - Interface in org.mule.api.security
SecurityProvider is a target security provider that actually does the work of authenticating credentials and populating the Authentication object.
SecurityProviderNotFoundException - Exception in org.mule.api.security
SecurityProviderNotFoundException is thrown by the SecurityManager when an authentication request is made but no suitable security provider can be found to process the authentication
SecurityProviderNotFoundException(String) - Constructor for exception org.mule.api.security.SecurityProviderNotFoundException
 
SecurityProviderNotFoundException(String, Throwable) - Constructor for exception org.mule.api.security.SecurityProviderNotFoundException
 
SecurityStrategy - Interface in org.mule.module.ws.security
 
SecurityUtils - Class in org.mule.util
 
SecurityUtils() - Constructor for class org.mule.util.SecurityUtils
 
SedaModel - Class in org.mule.model.seda
Deprecated.
SedaModel() - Constructor for class org.mule.model.seda.SedaModel
Deprecated.
 
SedaService - Class in org.mule.model.seda
Deprecated.
SedaService(MuleContext) - Constructor for class org.mule.model.seda.SedaService
Deprecated.
 
sedaService(MuleContext, String) - Static method in class org.mule.util.concurrent.ThreadNameHelper
 
SedaServiceStatistics - Class in org.mule.management.stats
Deprecated.
SedaServiceStatistics(String, int, int) - Constructor for class org.mule.management.stats.SedaServiceStatistics
Deprecated.
 
sedaStage - Variable in class org.mule.model.seda.SedaService
Deprecated.
 
SedaStageInterceptingMessageProcessor - Class in org.mule.processor
Processes MuleEvent's asynchronously using a MuleWorkManager to schedule asynchronous processing of the next MessageProcessor.
SedaStageInterceptingMessageProcessor(String, String, QueueProfile, int, ThreadingProfile, QueueStatistics, MuleContext) - Constructor for class org.mule.processor.SedaStageInterceptingMessageProcessor
 
SedaStageLifecycleManager - Class in org.mule.processor
The lifecycle manager responsible for managing lifecycle transitions for a Mule service.
SedaStageLifecycleManager(String, SedaStageInterceptingMessageProcessor) - Constructor for class org.mule.processor.SedaStageLifecycleManager
 
select(Iterator<T>) - Method in class org.mule.config.PreferredObjectSelector
Selects a preferred object from instances returned by an Iterator.
select(String, Node) - Static method in class org.mule.module.xml.util.XMLUtils
Select a set of Node objects using the Xpath expression
select(Predicate) - Method in class org.mule.registry.TransientRegistry.RegistryMap
Deprecated.
 
SelectExecutor - Class in org.mule.module.db.internal.domain.executor
Executes queries that return a resultSet
SelectExecutor(StatementFactory, ResultSetHandler) - Constructor for class org.mule.module.db.internal.domain.executor.SelectExecutor
 
SelectExecutorFactory - Class in org.mule.module.db.internal.domain.executor
Creates QueryExecutor instances
SelectExecutorFactory(StatementFactory, ResultSetHandler) - Constructor for class org.mule.module.db.internal.domain.executor.SelectExecutorFactory
 
SelectiveRouter - Interface in org.mule.api.routing
Routes the event to MessageProcessors using a Filter to evaluate the event being processed and determine if a given route should be used.
SelectMessageProcessor - Class in org.mule.module.db.internal.processor
Executes a select query on a database

Accepted queries are select queries or stored procedure queries taking input parameters and returning only a resultSet.

SelectMessageProcessor(DbConfigResolver, QueryResolver, QueryExecutorFactory, TransactionalAction, boolean) - Constructor for class org.mule.module.db.internal.processor.SelectMessageProcessor
 
SelectMetadataProvider - Class in org.mule.module.db.internal.metadata
Provides metadata for select queries
SelectMetadataProvider(DbConfigResolver, Query, boolean) - Constructor for class org.mule.module.db.internal.metadata.SelectMetadataProvider
 
selectOne(String, Node) - Static method in class org.mule.module.xml.util.XMLUtils
Select a single XML node using an Xpath
SelectorWatermark - Class in org.mule.transport.polling.watermark.selector
Implementation of Watermark that relies on a WatermarkSelector to update its values
SelectorWatermark(ObjectStore<Serializable>, String, String, WatermarkSelectorBroker, String) - Constructor for class org.mule.transport.polling.watermark.selector.SelectorWatermark
 
SelectorWatermarkPollingInterceptor - Class in org.mule.transport.polling.watermark.selector
Implementation of WatermarkPollingInterceptor that uses a WatermarkSelector to return the new watermark value.
SelectorWatermarkPollingInterceptor(Watermark, WatermarkSelector, String) - Constructor for class org.mule.transport.polling.watermark.selector.SelectorWatermarkPollingInterceptor
 
SelectProcessorDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
SelectProcessorDefinitionParser() - Constructor for class org.mule.module.db.internal.config.processor.SelectProcessorDefinitionParser
 
selectProcessors(MuleEvent) - Method in class org.mule.routing.AbstractSelectiveRouter
 
selectProcessors(MuleEvent) - Method in class org.mule.routing.ChoiceRouter
 
SelectSqlStatementStrategy - Class in org.mule.transport.jdbc.sqlstrategy
Implements strategy for handling normal select statements + acks.
SelectSqlStatementStrategy() - Constructor for class org.mule.transport.jdbc.sqlstrategy.SelectSqlStatementStrategy
 
selectSQLStrategy - Variable in class org.mule.transport.jdbc.sqlstrategy.DefaultSqlStatementStrategyFactory
 
selectValue(String, Node) - Static method in class org.mule.module.xml.util.XMLUtils
Select a single XML String value using an Xpath
send(String, Object, Map<String, Object>) - Method in interface org.mule.api.client.MuleClient
Deprecated.
use MuleClient.send(String, org.mule.api.MuleMessage) instead Sends an event synchronously to a endpointUri via a Mule server and a resulting message is returned.
send(String, MuleMessage) - Method in interface org.mule.api.client.MuleClient
Sends an event synchronously to a endpointUri via a Mule server and a resulting message is returned.
send(String, MuleMessage, OperationOptions) - Method in interface org.mule.api.client.MuleClient
Sends an event synchronously to a endpointUri via a Mule server and a resulting message is returned.
send(String, Object, Map<String, Object>, long) - Method in interface org.mule.api.client.MuleClient
Deprecated.
use MuleClient.send(String, org.mule.api.MuleMessage, OperationOptions) Sends an event synchronously to a endpointUri via a mule server and a resulting message is returned.
send(String, MuleMessage, long) - Method in interface org.mule.api.client.MuleClient
Deprecated.
use MuleClient.send(String, org.mule.api.MuleMessage, OperationOptions) instead Sends an event synchronously to a endpointUri via a mule server and a resulting message is returned.
send(MuleEvent) - Method in interface org.mule.api.transport.MessageDispatching
Sends an event from the endpoint to the external system
send(String, Object, Map<String, Object>) - Method in class org.mule.client.DefaultLocalMuleClient
 
send(String, MuleMessage) - Method in class org.mule.client.DefaultLocalMuleClient
 
send(String, MuleMessage, OperationOptions) - Method in class org.mule.client.DefaultLocalMuleClient
 
send(String, Object, Map<String, Object>, long) - Method in class org.mule.client.DefaultLocalMuleClient
 
send(String, MuleMessage, long) - Method in class org.mule.client.DefaultLocalMuleClient
 
send(String, Object, Map<String, Object>) - Method in class org.mule.module.client.MuleClient
Sends an event synchronously to a endpointUri via a Mule server and a resulting message is returned.
send(String, MuleMessage) - Method in class org.mule.module.client.MuleClient
Sends an event synchronously to a endpointUri via a Mule server and a resulting message is returned.
send(String, Object, Map<String, Object>, int) - Method in class org.mule.module.client.MuleClient
Sends an event synchronously to a endpointUri via a mule server and a resulting message is returned.
send(String, MuleMessage, int) - Method in class org.mule.module.client.MuleClient
Sends an event synchronously to a endpointUri via a mule server and a resulting message is returned.
send(HttpRequest, int, boolean, HttpRequestAuthentication) - Method in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
send(HttpRequest, int, boolean, HttpRequestAuthentication, CompletionHandler<HttpResponse, Exception>, WorkManager) - Method in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
send(HttpRequest, int, boolean, HttpRequestAuthentication) - Method in interface org.mule.module.http.internal.request.HttpClient
Sends a HttpRequest blocking the current thread until a response is available for the request times out.
send(HttpRequest, int, boolean, HttpRequestAuthentication, CompletionHandler<HttpResponse, Exception>, WorkManager) - Method in interface org.mule.module.http.internal.request.HttpClient
Sends a HttpRequest without blocking the current thread.
send(MessageProducer, Message, boolean, int, long, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms102bSupport
 
send(MessageProducer, Message, Destination, boolean, int, long, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms102bSupport
 
send(MessageProducer, Message, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms11Support
 
send(MessageProducer, Message, Destination, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms11Support
 
send(MessageProducer, Message, boolean, int, long, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms11Support
 
send(MessageProducer, Message, Destination, boolean, int, long, boolean, ImmutableEndpoint) - Method in class org.mule.transport.jms.Jms11Support
 
send(MessageProducer, Message, boolean, ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsSupport
 
send(MessageProducer, Message, boolean, int, long, boolean, ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsSupport
 
send(MessageProducer, Message, Destination, boolean, ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsSupport
 
send(MessageProducer, Message, Destination, boolean, int, long, boolean, ImmutableEndpoint) - Method in interface org.mule.transport.jms.JmsSupport
 
SEND_TCP_NO_DELAY_SYSTEM_PROPERTY - Static variable in class org.mule.transport.tcp.TcpConnector
 
sendAction(RemoteDispatcherNotification, MuleEventContext) - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
sendAndDefer(HttpRequest, int, boolean, HttpRequestAuthentication) - Method in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
Blocking send which uses a PipedOutputStream to populate the HTTP response as it arrives and propagates a PipedInputStream as soon as the response headers are parsed.
sendAndReceiveInputStream(HttpRequest, int, boolean, HttpRequestAuthentication) - Method in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
sendAndReceiveInputStream(HttpRequest, int, boolean, HttpRequestAuthentication) - Method in interface org.mule.module.http.internal.request.HttpClient
Sends a HttpRequest blocking the current thread until a response is available for the request times out.
sendAndWait(HttpRequest, int, boolean, HttpRequestAuthentication) - Method in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
Blocking send which waits to load the whole response to memory before propagating it.
sendAsync(String, Object, Map<String, Object>) - Method in class org.mule.module.client.MuleClient
Sends an event request to a URL, making the result of the event trigger available as a Future result that can be accessed later by client code.
sendAsync(String, MuleMessage) - Method in class org.mule.module.client.MuleClient
Sends an event request to a URL, making the result of the event trigger available as a Future result that can be accessed later by client code.
sendAsync(String, Object, Map<String, Object>, int) - Method in class org.mule.module.client.MuleClient
Sends an event request to a URL, making the result of the event trigger available as a Future result that can be accessed later by client code.
sendAsync(String, MuleMessage, int) - Method in class org.mule.module.client.MuleClient
Sends an event request to a URL, making the result of the event trigger available as a Future result that can be accessed later by client code.
sendAsyncRemote(String, Object, Map) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
sendAsyncRequest(MuleEvent) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
sendAsyncRequest(MuleEvent) - Method in class org.mule.routing.requestreply.SimpleAsyncRequestReplyRequester
 
sendAsyncToRemoteComponent(String, String, Object, Map) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
sends an event to a components on a remote Mule instance, while making the result of the event trigger available as a Future result that can be accessed later by client code.
sendBufferSize - Variable in class org.mule.transport.udp.UdpConnector
 
sendDirect(String, String, Object, Map<String, Object>) - Method in class org.mule.module.client.MuleClient
Deprecated.
sendDirect(String, String, MuleMessage) - Method in class org.mule.module.client.MuleClient
Deprecated.
sendDirectAsync(String, String, Object, Map<String, Object>) - Method in class org.mule.module.client.MuleClient
Deprecated.
sendDirectAsync(String, String, MuleMessage) - Method in class org.mule.module.client.MuleClient
Deprecated.
sendError(int, String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
sendError(int) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
sendEvent(Object) - Method in interface org.mule.api.MuleEventContext
Deprecated. 
sendEvent(MuleMessage) - Method in interface org.mule.api.MuleEventContext
Deprecated. 
sendEvent(MuleMessage, EndpointURI) - Method in interface org.mule.api.MuleEventContext
Deprecated. 
sendEvent(MuleMessage, String) - Method in interface org.mule.api.MuleEventContext
Depending on the session state this methods either Passes an event synchronously to the next available Mule component in the pool or via the endpoint configured for the event
sendEvent(MuleMessage, OutboundEndpoint) - Method in interface org.mule.api.MuleEventContext
Depending on the session state this methods either Passes an event synchronously to the next available Mule component in the pool or via the endpoint configured for the event
sendEvent(MuleEvent) - Method in interface org.mule.api.service.Service
Deprecated. 
sendEvent(Object) - Method in class org.mule.DefaultMuleEventContext
This will send an event via the configured outbound router on the service
sendEvent(MuleMessage, OutboundEndpoint) - Method in class org.mule.DefaultMuleEventContext
Depending on the session state this methods either Passes an event synchronously to the next available Mule component in the pool or via the endpoint configured for the event
sendEvent(MuleMessage) - Method in class org.mule.DefaultMuleEventContext
Depending on the session state this methods either Passes an event synchronously to the next available Mule component in the pool or via the endpoint configured for the event
sendEvent(MuleMessage, EndpointURI) - Method in class org.mule.DefaultMuleEventContext
Depending on the session state this methods either Passes an event synchronously to the next available Mule component in the pool or via the endpointUri configured for the event
sendEvent(MuleMessage, String) - Method in class org.mule.DefaultMuleEventContext
Depending on the session state this methods either Passes an event synchronously to the next available Mule component in the pool or via the endpoint configured for the event
sendEvent(MuleEvent) - Method in class org.mule.service.AbstractService
Deprecated.
sendEventAsync(Object, int) - Method in interface org.mule.api.MuleEventContext
Deprecated.
sendEventAsync(MuleMessage, int) - Method in interface org.mule.api.MuleEventContext
Deprecated.
sendEventAsync(MuleMessage, EndpointURI, int) - Method in interface org.mule.api.MuleEventContext
Deprecated. 
sendEventAsync(MuleMessage, String, int) - Method in interface org.mule.api.MuleEventContext
Deprecated. 
sendEventAsync(Object, int) - Method in class org.mule.DefaultMuleEventContext
sends an event request via the configured outbound router for this service.
sendEventAsync(MuleMessage, int) - Method in class org.mule.DefaultMuleEventContext
sends an event request via the configured outbound router for this service.
sendEventAsync(MuleMessage, EndpointURI, int) - Method in class org.mule.DefaultMuleEventContext
sends an event request via the configured outbound router for this service.
sendEventAsync(MuleMessage, String, int) - Method in class org.mule.DefaultMuleEventContext
sends an event request via the configured outbound router for this service.
sendFailureResponseToClient(MessagingException, ResponseCompletionCallback) - Method in interface org.mule.execution.AsyncResponseFlowProcessingPhaseTemplate
 
sendFailureResponseToClient(MessagingException) - Method in interface org.mule.execution.RequestResponseFlowProcessingPhaseTemplate
 
sendFailureResponseToClient(MessagingException, ResponseCompletionCallback) - Method in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
sendFailureResponseToClient(MessagingException) - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
sendFailureResponseToClient(MessagingException) - Method in class org.mule.transport.servlet.jetty.JettyContinuationsMessageProcessTemplate
 
sendFailureResponseToClient(MessagingException) - Method in class org.mule.transport.servlet.jetty.JettyMessageProcessTemplate
 
sendInputStreamChunk() - Method in class org.mule.module.http.internal.listener.grizzly.ResponseStreamingCompletionHandler
 
sendMailMessage(Message) - Method in class org.mule.transport.email.SmtpMessageDispatcher
 
sendMessage(MuleEvent) - Method in class org.mule.transport.xmpp.XmppMessageDispatcher
 
sendNoReceive(String, Object, Map<String, Object>) - Method in class org.mule.module.client.MuleClient
Sends an event synchronously to a endpointUri via a Mule server without waiting for the result.
sendRedirect(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
sendRemote(String, Object, Map, int) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
sendRemote(String, Object, Map) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
sendRequest(MuleEvent, MuleMessage, MessageProcessor, boolean) - Method in class org.mule.routing.AbstractRoutingStrategy
Send message event to destination.
sendRequest(MuleEvent, MuleMessage, MessageProcessor, boolean) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
sendRequestEvent(MuleEvent, MuleMessage, MessageProcessor, boolean) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
Send message event to destination.
sendResponse() - Method in class org.mule.module.http.internal.listener.grizzly.ResponseCompletionHandler
Send the next part of the response
sendResponseToClient(MuleEvent, ResponseCompletionCallback) - Method in interface org.mule.execution.AsyncResponseFlowProcessingPhaseTemplate
Template method to send a response after processing the message.
sendResponseToClient(MuleEvent) - Method in interface org.mule.execution.RequestResponseFlowProcessingPhaseTemplate
Template method to send a response after processing the message.
sendResponseToClient(MuleEvent, ResponseCompletionCallback) - Method in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
sendResponseToClient(MuleEvent) - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
sendResponseToClient(MuleEvent) - Method in class org.mule.transport.servlet.jetty.JettyContinuationsMessageProcessTemplate
 
sendResponseToClient(MuleEvent) - Method in class org.mule.transport.servlet.jetty.JettyMessageProcessTemplate
 
sendToDestination(MuleEvent) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
sendToRemoteComponent(String, Object, Map) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
sends an event synchronously to a components on a remote Mule instance.
SENT_DATE_PROPERTY - Static variable in interface org.mule.transport.email.MailProperties
 
SEPARATOR - Static variable in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
SEPARATOR - Static variable in class org.mule.util.ObjectNameHelper
 
SequenceRouter - Class in org.mule.routing.outbound
Deprecated.
SequenceRouter() - Constructor for class org.mule.routing.outbound.SequenceRouter
Deprecated.
 
SequentialStageNameSource - Class in org.mule.api.processor
 
SequentialStageNameSource(String) - Constructor for class org.mule.api.processor.SequentialStageNameSource
 
SerializableToByteArray - Class in org.mule.transformer.simple
SerializableToByteArray converts a serializable object or a String to a byte array.
SerializableToByteArray() - Constructor for class org.mule.transformer.simple.SerializableToByteArray
 
SerializationException - Exception in org.mule.api.serialization
Exception to signal an error during serialization/deserialization process
SerializationException(String, Throwable) - Constructor for exception org.mule.api.serialization.SerializationException
 
SerializationException(String) - Constructor for exception org.mule.api.serialization.SerializationException
 
SerializationException(Message, Throwable) - Constructor for exception org.mule.api.serialization.SerializationException
 
SerializationException(Message) - Constructor for exception org.mule.api.serialization.SerializationException
 
SerializationUtils - Class in org.mule.util
 
SerializationUtils() - Constructor for class org.mule.util.SerializationUtils
 
SerializationWireFormat - Class in org.mule.transformer.wire
Wire format using Java serialization
SerializationWireFormat() - Constructor for class org.mule.transformer.wire.SerializationWireFormat
 
serialize(Object) - Method in interface org.mule.api.serialization.ObjectSerializer
Serializes the given object into a an array of bytes
serialize(Object, OutputStream) - Method in interface org.mule.api.serialization.ObjectSerializer
Serializes the given object and writes the result into out
serialize(Object) - Method in class org.mule.serialization.internal.AbstractObjectSerializer
Serializes the given object into a an array of bytes
serialize(Object, OutputStream) - Method in class org.mule.serialization.internal.AbstractObjectSerializer
Serializes the given object and writes the result into out
serialize(Object, OutputStream) - Method in class org.mule.serialization.internal.JavaObjectSerializer
Serializes the given object and writes the result into out
serialize(MuleMessage, Object) - Method in class org.mule.session.AbstractSessionHandler
 
serialize(K, DataOutputStream) - Method in interface org.mule.util.journal.JournalEntrySerializer
 
serialize(File, PersistentObjectStorePartition.StoreValue<T>) - Method in class org.mule.util.store.PersistentObjectStorePartition
 
serialize(T, File) - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
SerializeAndEncodeSessionHandler - Class in org.mule.session
A session handler used to store and retrieve session information on an event.
SerializeAndEncodeSessionHandler() - Constructor for class org.mule.session.SerializeAndEncodeSessionHandler
 
SerializedMuleMessageWireFormat - Class in org.mule.transformer.wire
Wire format using Java serialization to serialize MuleMessage objects accross the wire
SerializedMuleMessageWireFormat() - Constructor for class org.mule.transformer.wire.SerializedMuleMessageWireFormat
 
SerializeOnlySessionHandler - Class in org.mule.session
A session handler used to store and retrieve session information on an event.
SerializeOnlySessionHandler() - Constructor for class org.mule.session.SerializeOnlySessionHandler
 
serializeTxId(DataOutputStream) - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
serializeTxId(DataOutputStream) - Method in class org.mule.util.journal.queue.LocalQueueTxJournalEntry
 
serializeTxId(DataOutputStream) - Method in class org.mule.util.journal.queue.XaQueueTxJournalEntry
 
SerialWorkManager - Class in org.mule.work
A simple implementation of WorkManager which executes tasks on the invoking thread.
SerialWorkManager() - Constructor for class org.mule.work.SerialWorkManager
 
server - Variable in class org.mule.module.cxf.CxfInboundMessageProcessor
 
SERVER - Static variable in class org.mule.module.http.api.HttpHeaders.Names
Server - Interface in org.mule.module.http.internal.listener
Represents a ServerSocket connection
server - Variable in class org.mule.module.management.mbean.FlowConstructService
 
server - Variable in class org.mule.module.management.mbean.FlowConstructStats
 
Server - Class in org.mule.tck.util.ftp
A wrapper for the Apache ftpServer.
Server(int) - Constructor for class org.mule.tck.util.ftp.Server
Initialize the ftp server on a given port
Server(int, Ftplet) - Constructor for class org.mule.tck.util.ftp.Server
 
SERVER - Static variable in class org.mule.transport.tcp.TcpConnector
 
SERVER_ALREADY_EXISTS_FORMAT - Static variable in class org.mule.module.http.internal.listener.HttpListenerConnectionManager
 
SERVER_HANDSHAKE_PROPERTY - Static variable in class org.mule.module.client.remoting.ServerHandshake
Deprecated.
 
SERVER_PROBLEM - Static variable in class org.mule.module.http.internal.listener.DefaultHttpListener
 
SERVER_TIME_ZONE_PROPERTY - Static variable in class org.mule.transport.http.HttpConstants
 
ServerAddress - Class in org.mule.module.http.internal.listener
 
ServerAddress(String, int) - Constructor for class org.mule.module.http.internal.listener.ServerAddress
 
ServerAddressMap<T> - Class in org.mule.module.http.internal.listener
This is a wrapper for a map whose keys are ServerAddresss.
ServerAddressMap() - Constructor for class org.mule.module.http.internal.listener.ServerAddressMap
 
ServerAddressMap(Map<ServerAddress, T>) - Constructor for class org.mule.module.http.internal.listener.ServerAddressMap
 
ServerContext - Class in org.mule.el.context
Exposes information about both the physical server and Java Runtime Environment (JRE) that Mule is running on: env Map of Operating System environment variables fileSeparator Character that separates components of a file path.
ServerContext() - Constructor for class org.mule.el.context.ServerContext
 
ServerHandshake - Class in org.mule.module.client.remoting
Deprecated.
ServerHandshake() - Constructor for class org.mule.module.client.remoting.ServerHandshake
Deprecated.
 
serverId - Variable in class org.mule.api.context.notification.ServerNotification
 
ServerNotification - Class in org.mule.api.context.notification
ServerNotification is an event triggered by something happening in the Server itself such as the server starting or a service being registered.
ServerNotification(Object, int) - Constructor for class org.mule.api.context.notification.ServerNotification
 
ServerNotification(Object, int, String) - Constructor for class org.mule.api.context.notification.ServerNotification
 
ServerNotification(Object, int, String, boolean) - Constructor for class org.mule.api.context.notification.ServerNotification
 
ServerNotificationHandler - Interface in org.mule.api.context.notification
 
ServerNotificationListener<T extends ServerNotification> - Interface in org.mule.api.context.notification
ServerNotificationListener is an observer interface that ojects can implement and register themselves with the Mule Server to receive notifications when the server, model and components stop, start, initialise, etc.
ServerNotificationManager - Class in org.mule.context.notification
A reworking of the event manager that allows efficient behaviour without global on/off switches in the config.
ServerNotificationManager() - Constructor for class org.mule.context.notification.ServerNotificationManager
 
ServerNotificationManagerConfigurator - Class in org.mule.config.spring
 
ServerNotificationManagerConfigurator() - Constructor for class org.mule.config.spring.ServerNotificationManagerConfigurator
 
serverNotificationManagerNotEnabled() - Static method in class org.mule.config.i18n.CoreMessages
 
serverProviderAndServerConfigConfigured() - Static method in class org.mule.transport.soap.axis.i18n.AxisMessages
 
serverShutdownAt(Date) - Static method in class org.mule.config.i18n.CoreMessages
 
ServerShutdownSplashScreen - Class in org.mule.util
 
ServerShutdownSplashScreen() - Constructor for class org.mule.util.ServerShutdownSplashScreen
 
serverStartedAt(long) - Static method in class org.mule.config.i18n.CoreMessages
 
ServerStartupSplashScreen - Class in org.mule.util
 
ServerStartupSplashScreen() - Constructor for class org.mule.util.ServerStartupSplashScreen
 
serverUrlNotDefined() - Static method in class org.mule.transport.ajax.i18n.AjaxMessages
 
serverWasUpForDuration(long) - Static method in class org.mule.config.i18n.CoreMessages
 
service - Variable in class org.mule.api.registry.AbstractServiceDescriptor
 
Service - Interface in org.mule.api.service
Deprecated.
service(HttpServletRequest, HttpServletResponse) - Method in class org.mule.config.builders.MuleXmlBuilderContextServlet
 
service(String) - Method in class org.mule.config.dsl.ModelBuilder
Deprecated.
 
service - Variable in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
The mule instance component for the Multicaster
service - Variable in class org.mule.service.processor.ServiceInternalMessageProcessor
Deprecated.
 
service - Variable in class org.mule.service.processor.ServiceLoggingMessageProcessor
Deprecated.
 
service - Variable in class org.mule.service.processor.ServiceOutboundMessageProcessor
Deprecated.
 
service - Variable in class org.mule.service.processor.ServiceOutboundStatisticsMessageProcessor
Deprecated.
 
service - Variable in class org.mule.service.processor.ServiceStatisticsMessageProcessor
Deprecated.
 
service(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.ajax.container.MuleAjaxServlet
 
service(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.jetty.JettyContinuationsReceiverServlet
 
service(HttpServletRequest, HttpServletResponse) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
service - Variable in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
service - Variable in class org.mule.transport.soap.axis.AxisMessageRequester
 
SERVICE_DISPOSED - Static variable in class org.mule.context.notification.ServiceNotification
Deprecated.
 
SERVICE_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
SERVICE_FINDER - Static variable in class org.mule.api.config.MuleProperties
***************************************************************************** Generic Service descriptor properties *****************************************************************************
SERVICE_ID - Static variable in interface org.mule.util.compression.CompressionStrategy
JDK1.3+ 'Service Provider' specification ( http://java.sun.com/j2se/1.3/docs/guide/jar/jar.html )
SERVICE_INITIALISED - Static variable in class org.mule.context.notification.ServiceNotification
Deprecated.
 
SERVICE_INTERFACES - Static variable in interface org.mule.module.cxf.SoapConstants
 
SERVICE_NAMESPACE - Static variable in class org.mule.transport.soap.axis.AxisMessageReceiver
 
SERVICE_PATH - Static variable in class org.mule.module.launcher.coreextension.ClasspathMuleCoreExtensionDiscoverer
 
SERVICE_PAUSED - Static variable in class org.mule.context.notification.ServiceNotification
Deprecated.
 
SERVICE_PROPERTY_COMPONENT_NAME - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
SERVICE_PROPERTY_SERVCE_PATH - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
SERVICE_RESUMED - Static variable in class org.mule.context.notification.ServiceNotification
Deprecated.
 
SERVICE_ROOT - Static variable in class org.mule.util.SpiUtils
 
SERVICE_STARTED - Static variable in class org.mule.context.notification.ServiceNotification
Deprecated.
 
SERVICE_STOPPED - Static variable in class org.mule.context.notification.ServiceNotification
Deprecated.
 
ServiceAsyncReplyCompositeMessageSource - Class in org.mule.service
Deprecated.
ServiceAsyncReplyCompositeMessageSource() - Constructor for class org.mule.service.ServiceAsyncReplyCompositeMessageSource
Deprecated.
 
ServiceAsyncRequestReplyRequestor - Class in org.mule.service.processor
Deprecated.
ServiceAsyncRequestReplyRequestor() - Constructor for class org.mule.service.processor.ServiceAsyncRequestReplyRequestor
Deprecated.
 
ServiceAware - Interface in org.mule.api.service
Deprecated.
ServiceBuilder - Class in org.mule.config.dsl
Deprecated.
ServiceBuilder(String, MuleContext) - Constructor for class org.mule.config.dsl.ServiceBuilder
Deprecated.
 
ServiceCatchAllStrategy - Class in org.mule.routing
Deprecated. 
ServiceCatchAllStrategy() - Constructor for class org.mule.routing.ServiceCatchAllStrategy
Deprecated.
 
serviceClass - Variable in class org.mule.module.cxf.builder.AbstractClientMessageProcessorBuilder
 
serviceClassInvocationFailed() - Static method in class org.mule.transport.rmi.i18n.RmiMessages
 
serviceClassRequiredWithPassThrough() - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
ServiceCompositeMessageSource - Class in org.mule.service
Deprecated.
ServiceCompositeMessageSource() - Constructor for class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
ServiceDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
ServiceDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.ServiceDefinitionParser
 
ServiceDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.ServiceDefinitionParser
 
ServiceDescriptor - Interface in org.mule.api.registry
Parent interface for any pluggable service in Mule (transport, model, etc.)
serviceDescriptor - Variable in class org.mule.transport.AbstractConnector
Holds the service configuration for this connector
ServiceDescriptorFactory - Class in org.mule.api.registry
Factory used to create a new service descriptor.
ServiceDescriptorFactory() - Constructor for class org.mule.api.registry.ServiceDescriptorFactory
 
serviceDoesNotHaveAnnotation(Class, String) - Static method in class org.mule.config.i18n.AnnotationsMessages
 
ServiceException - Exception in org.mule.api.registry
Any service-related exception: service not found, service lookup error, etc.
ServiceException(Message) - Constructor for exception org.mule.api.registry.ServiceException
 
ServiceException(Message, Throwable) - Constructor for exception org.mule.api.registry.ServiceException
 
ServiceFinder - Interface in org.mule.api.registry
ServiceFinder can be used as a hook into the service lookup process to return the correct Service Descriptor for a given service name.
serviceFinderCantFindService(String) - Static method in class org.mule.config.i18n.CoreMessages
 
serviceHasNoEntrypoint(Class) - Static method in class org.mule.config.i18n.AnnotationsMessages
 
ServiceInternalMessageProcessor - Class in org.mule.service.processor
Deprecated.
ServiceInternalMessageProcessor(Service) - Constructor for class org.mule.service.processor.ServiceInternalMessageProcessor
Deprecated.
 
serviceIsNull(String) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
ServiceLifecycleManager - Class in org.mule.service
Deprecated.
ServiceLifecycleManager(FlowConstruct, MuleContext) - Constructor for class org.mule.service.ServiceLifecycleManager
Deprecated.
 
ServiceLoggingMessageProcessor - Class in org.mule.service.processor
Deprecated.
ServiceLoggingMessageProcessor(Service) - Constructor for class org.mule.service.processor.ServiceLoggingMessageProcessor
Deprecated.
 
ServiceNotification - Class in org.mule.context.notification
Deprecated.
ServiceNotification(Service, int) - Constructor for class org.mule.context.notification.ServiceNotification
Deprecated.
 
ServiceNotificationListener<T extends ServiceNotification> - Interface in org.mule.api.context.notification
Deprecated.
ServiceOutboundMessageProcessor - Class in org.mule.service.processor
Deprecated.
ServiceOutboundMessageProcessor(Service) - Constructor for class org.mule.service.processor.ServiceOutboundMessageProcessor
Deprecated.
 
ServiceOutboundStatisticsMessageProcessor - Class in org.mule.service.processor
Deprecated.
ServiceOutboundStatisticsMessageProcessor(Service) - Constructor for class org.mule.service.processor.ServiceOutboundStatisticsMessageProcessor
Deprecated.
 
serviceOverrides - Variable in class org.mule.transport.AbstractConnector
The map of service overrides that can be used to extend the capabilities of the connector
ServiceOverridesDefinitionParser - Class in org.mule.config.spring.parsers.specific
Sets a Map of service overrides on the parent connector
ServiceOverridesDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.ServiceOverridesDefinitionParser
 
ServiceProcessorExecutor - Class in org.mule.service.processor
BlockingProcessorExecutor specifically for use with instances of Service
ServiceProcessorExecutor(MuleEvent, List<MessageProcessor>, MessageProcessorExecutionTemplate, boolean) - Constructor for class org.mule.service.processor.ServiceProcessorExecutor
 
ServiceRegistry - Interface in org.mule.api.registry
Locates and returns all registered instances of a given provider class.
servicesDeprecated() - Static method in class org.mule.config.i18n.CoreMessages
 
ServiceService - Class in org.mule.module.management.mbean
ServiceService exposes service information about a Mule Managed service.
ServiceService(String, MuleContext) - Constructor for class org.mule.module.management.mbean.ServiceService
 
ServiceServiceMBean - Interface in org.mule.module.management.mbean
Deprecated.
ServiceSetEventRequestContextMessageProcessor - Class in org.mule.service.processor
Deprecated.
ServiceSetEventRequestContextMessageProcessor() - Constructor for class org.mule.service.processor.ServiceSetEventRequestContextMessageProcessor
Deprecated.
 
ServiceStatistics - Class in org.mule.management.stats
Deprecated.
ServiceStatistics(String) - Constructor for class org.mule.management.stats.ServiceStatistics
Deprecated.
 
ServiceStatistics(String, int) - Constructor for class org.mule.management.stats.ServiceStatistics
Deprecated.
 
ServiceStatisticsMessageProcessor - Class in org.mule.service.processor
Deprecated.
ServiceStatisticsMessageProcessor(Service) - Constructor for class org.mule.service.processor.ServiceStatisticsMessageProcessor
Deprecated.
 
ServiceStats - Class in org.mule.module.management.mbean
Deprecated.
ServiceStats(ServiceStatistics) - Constructor for class org.mule.module.management.mbean.ServiceStats
Deprecated.
 
ServiceStatsMBean - Interface in org.mule.module.management.mbean
Deprecated.
ServiceTemporarilyUnavailableListenerRequestHandler - Class in org.mule.module.http.internal.listener
Request handler for request calls when service is unavailable
ServiceType - Enum in org.mule.api.registry
TODO
servlet - Variable in class org.mule.transport.servlet.jetty.AbstractConnectorHolder
 
SERVLET - Static variable in class org.mule.transport.servlet.ServletConnector
 
SERVLET_CONNECTOR_NAME_PROPERTY - Static variable in class org.mule.transport.servlet.AbstractReceiverServlet
SERVLET_CONTEXT_DESTROYED - Static variable in class org.mule.transport.servlet.events.ServletContextNotification
 
SERVLET_CONTEXT_INITIALISED - Static variable in class org.mule.transport.servlet.events.ServletContextNotification
 
SERVLET_CONTEXT_START_RANGE - Static variable in class org.mule.transport.servlet.events.ServletContextNotification
 
ServletAware<S extends Servlet> - Interface in org.mule.transport.servlet.jetty
TODO
ServletConnector - Class in org.mule.transport.servlet
ServletConnector is a channel adapter between Mule and a servlet engine.
ServletConnector(MuleContext) - Constructor for class org.mule.transport.servlet.ServletConnector
 
ServletContextNotification - Class in org.mule.transport.servlet.events
TODO
ServletContextNotification(ServletContext, int) - Constructor for class org.mule.transport.servlet.events.ServletContextNotification
 
ServletContextNotificationListener<T extends ServletContextNotification> - Interface in org.mule.transport.servlet.events
 
ServletMessageReceiver - Class in org.mule.transport.servlet
ServletMessageReceiver is a receiver that is invoked from a Servlet when an event is received.
ServletMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.servlet.ServletMessageReceiver
 
ServletMessages - Class in org.mule.transport.servlet.i18n
 
ServletMessages() - Constructor for class org.mule.transport.servlet.i18n.ServletMessages
 
ServletMuleMessageFactory - Class in org.mule.transport.servlet
 
ServletMuleMessageFactory() - Constructor for class org.mule.transport.servlet.ServletMuleMessageFactory
 
ServletNamespaceHandler - Class in org.mule.transport.servlet.config
Registers a Bean Definition Parser for handling elements.
ServletNamespaceHandler() - Constructor for class org.mule.transport.servlet.config.ServletNamespaceHandler
 
ServletRequestToOutputHandler - Class in org.mule.transport.http.transformers
Adds support for converting a HttpServletRequest into an OutputHandler
ServletRequestToOutputHandler() - Constructor for class org.mule.transport.http.transformers.ServletRequestToOutputHandler
 
ServletResponseWriter - Class in org.mule.transport.servlet
Writes a servlet response based on a mule message or basic attributes of a response.
ServletResponseWriter() - Constructor for class org.mule.transport.servlet.ServletResponseWriter
 
ServletTransformer - Class in org.mule.transport.http.servlet
THIS CLASS IS UNSUPPORTED AND THE IMPLEMENTATION DOES NOT CONFORM TO THE SERVLET SPECIFICATION! With that said, it can be used to make integration with libraries that only support servlets easier.
ServletTransformer() - Constructor for class org.mule.transport.http.servlet.ServletTransformer
 
servletUrl - Variable in class org.mule.transport.servlet.ServletConnector
 
SESSION - Static variable in class org.mule.api.transport.PropertyScope
Defines the scope for any properties set on the session.
session - Variable in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
session - Variable in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
session - Variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver.JmsThreadContext
 
SESSION_ID_PROPERTY_KEY - Static variable in class org.mule.transport.servlet.ServletConnector
This property name is used to store the session id HttpServletRequest to the MuleMessage
SESSION_NAME - Static variable in class org.mule.api.transport.PropertyScope
 
SESSION_VARS - Static variable in class org.mule.el.mvel.MessageVariableResolverFactory
 
SessionDetails - Class in org.mule.transport.email
 
SessionDetails(Session, URLName) - Constructor for class org.mule.transport.email.SessionDetails
 
SessionException - Exception in org.mule.api.model
SessionException is thrown when errors occur in the DefaultMuleSession or Seession Manager
SessionException(Message) - Constructor for exception org.mule.api.model.SessionException
 
SessionException(Message, Throwable) - Constructor for exception org.mule.api.model.SessionException
 
SessionHandler - Interface in org.mule.api.transport
An interface used for reading and writing session information to and from the current message.
sessionHandler - Variable in class org.mule.transport.AbstractConnector
The strategy used for reading and writing session information to and from the transport
SessionInvocationHandler - Class in org.mule.transport.jms.xa
 
SessionInvocationHandler(XASession, Boolean) - Constructor for class org.mule.transport.jms.xa.SessionInvocationHandler
 
SessionInvocationHandler(XAQueueSession, Boolean) - Constructor for class org.mule.transport.jms.xa.SessionInvocationHandler
 
SessionInvocationHandler(XATopicSession, Boolean) - Constructor for class org.mule.transport.jms.xa.SessionInvocationHandler
 
sessionMap - Variable in class org.mule.MessagePropertiesContext
 
SessionPropertiesValidatorComponent - Class in org.mule.tck.property
 
SessionPropertiesValidatorComponent() - Constructor for class org.mule.tck.property.SessionPropertiesValidatorComponent
 
sessionPropertyNotSerializableWarning(String) - Static method in class org.mule.config.i18n.CoreMessages
 
sessionShouldBeTransacted() - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
sessionShouldNotBeTransacted() - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
sessionValueIsMalformed(String) - Static method in class org.mule.config.i18n.CoreMessages
 
SessionVarEnricherDataTypePropagator - Class in org.mule.el.mvel.datatype
Propagates data type for session vars used for enrichment target
SessionVarEnricherDataTypePropagator() - Constructor for class org.mule.el.mvel.datatype.SessionVarEnricherDataTypePropagator
 
SessionVarExpressionDataTypeResolver - Class in org.mule.el.mvel.datatype
Resolves data type for session var when sessionVars['x'] syntax is used
SessionVarExpressionDataTypeResolver() - Constructor for class org.mule.el.mvel.datatype.SessionVarExpressionDataTypeResolver
 
set(Object, ResolverSetResult) - Method in class org.mule.module.extension.internal.util.GroupValueSetter
 
set(Object, ResolverSetResult) - Method in class org.mule.module.extension.internal.util.SingleValueSetter
Invokes SingleValueSetter.field over target, obtaining the value from result
set(Object, ResolverSetResult) - Method in interface org.mule.module.extension.internal.util.ValueSetter
Sets on target values contained in result.
set(E) - Method in class org.mule.module.launcher.util.ObservableList.ObservableListIterator
 
set(int, E) - Method in class org.mule.module.launcher.util.ObservableList
 
set(String, Object) - Method in class org.mule.transport.soap.axis.extensions.AxisMuleSession
 
set(boolean) - Method in class org.mule.util.concurrent.WaitableBoolean
 
set(T) - Method in class org.mule.util.ValueHolder
Updates the held value
SET_COOKIE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
SET_COOKIE2 - Static variable in class org.mule.module.http.api.HttpHeaders.Names
SET_PROPERTIES_METHOD - Static variable in class org.mule.util.BeanUtils
 
SET_REUSE_OBJECT_METHOD_NAME - Static variable in interface org.mule.transaction.XaTransaction.MuleXaObject
 
setAbsoluteResourcePaths(String[]) - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
setAcceptExternalEntities(boolean) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
setAcceptMuleMessage(boolean) - Method in class org.mule.module.xml.transformer.ObjectToXml
 
setAcceptMuleMessage(boolean) - Method in class org.mule.transformer.simple.SerializableToByteArray
 
setAcceptors(int) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
Set the number of "acceptor" threads Jetty should use
setAcceptVoidMethods(boolean) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
setAcceptWithoutUpdateDate(boolean) - Method in class org.mule.module.atom.routing.EntryLastUpdatedFilter
 
setAcceptWithoutUpdateDate(boolean) - Method in class org.mule.module.atom.routing.FeedLastUpdatedFilter
 
setAcceptWithoutUpdateDate(boolean) - Method in class org.mule.module.rss.routing.EntryLastUpdatedFilter
 
setAcceptWithoutUpdateDate(boolean) - Method in class org.mule.module.rss.routing.FeedLastUpdatedFilter
 
setAccessToken(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
setAccessToken(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.TokenResponseConfiguration
 
setAccessToken(String) - Method in interface org.mule.security.oauth.OAuthAdapter
 
setAccessTokenId(String) - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
 
setAccessTokenId(String) - Method in class org.mule.security.oauth.callback.ProcessCallback
 
setAccessTokenObjectStore(ObjectStore<Serializable>) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Sets accessTokenObjectStore
setAccessTokenPool(GenericKeyedObjectPool<String, OAuth2Adapter>) - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
setAccessTokenSecret(String) - Method in interface org.mule.security.oauth.OAuth1Adapter
Sets access token secret
setAccessTokenUrl(String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Sets accessTokenUrl
setAccessTokenUrl(String) - Method in interface org.mule.security.oauth.OAuthAdapter
 
setAccessTokenUrl(String) - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
Sets accessTokenUrl
setAccessTokenUrl(String) - Method in class org.mule.security.oauth.processor.FetchAccessTokenMessageProcessor
Sets accessTokenUrl
setAckExpression(String) - Method in class org.mule.config.spring.factories.ValidatorFactoryBean
 
setAckExpression(String) - Method in class org.mule.routing.UntilSuccessful
 
setAcknowledgementMode(int) - Method in class org.mule.transport.jms.JmsConnector
 
setAcquireIncrement(int) - Method in class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
setAction(byte) - Method in interface org.mule.api.transaction.TransactionConfig
 
setAction(String) - Method in class org.mule.config.spring.factories.TransactionalMessageProcessorsFactoryBean
 
setAction(byte) - Method in class org.mule.transaction.MuleTransactionConfig
 
setActionAsString(String) - Method in class org.mule.transaction.MuleTransactionConfig
 
setAddCreated(boolean) - Method in class org.mule.module.ws.security.WssUsernameTokenSecurityStrategy
 
setAddDefaultEntities(boolean) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Reader
Sets the state of the "add default entities" flag.
setAddNonce(boolean) - Method in class org.mule.module.ws.security.WssUsernameTokenSecurityStrategy
 
setAddProperties(Map<String, Object>) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setAddProperties(Map<String, Object>) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setAddProperties(Map<String, Object>) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
setAddress(String) - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
setAddress(String) - Method in class org.mule.config.spring.factories.SimpleServiceFactoryBean
 
setAddress(String) - Method in class org.mule.endpoint.URIBuilder
 
setAddress(String) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setAddress(String) - Method in class org.mule.module.cxf.component.AbstractWebServiceWrapperComponent
 
setAddress(String) - Method in class org.mule.tck.testmodels.services.Address
 
setAddress(Address) - Method in class org.mule.tck.testmodels.services.Person
 
setAddressFromMessage(boolean) - Method in class org.mule.module.cxf.component.AbstractWebServiceWrapperComponent
 
setAddTypedProperties(Map<String, TypedValue>) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
setAggregationStrategy(AggregationStrategy) - Method in class org.mule.config.spring.factories.ScatterGatherRouterFactoryBean
 
setAggregationStrategy(AggregationStrategy) - Method in class org.mule.routing.ScatterGatherRouter
 
setAlgorithm(String) - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
setAlias(String) - Method in class org.mule.module.ws.security.WssEncryptSecurityStrategy
 
setAliases(Map<String, String>) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
setAliases(Map<String, Class<?>>) - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
setAllListenerSubscriptionPairs(Collection) - Method in class org.mule.config.spring.ServerNotificationManagerConfigurator
 
setAllListenerSubscriptionPairs(Collection<?>) - Method in class org.mule.context.notification.ServerNotificationManager
Deprecated.
Use addAllListenerSubscriptionPairs which better describes the "add" operation that occurs.
setAllowBeanDefinitionOverriding(boolean) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Set whether it should be allowed to override bean definitions by registering a different definition with the same name, automatically replacing the former.
setAllowClassAttribute(boolean) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
setAllowEagerClassLoading(boolean) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Set whether the factory is allowed to eagerly load bean classes even for bean definitions that are marked as "lazy-init".
setAllowedMethods(String) - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
setAllowNullReturn(boolean) - Method in class org.mule.transformer.AbstractTransformer
 
setAllowPartial(boolean) - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Set the allowPartial field.
setAnnotations(Map<QName, Object>) - Method in class org.mule.AbstractAnnotatedObject
 
setAnnotations(Map<QName, Object>) - Method in interface org.mule.api.AnnotatedObject
Sets annotations to the object.
setAnnotations(Map<QName, Object>) - Method in class org.mule.config.spring.factories.AnnotatedObjectFactoryBean
 
setAnnotations(Map<QName, Object>) - Method in class org.mule.config.spring.factories.WatermarkFactoryBean
 
setAnnotations(Map<QName, Object>) - Method in class org.mule.processor.AbstractMessageProcessorOwner
 
setApiConfiguration(RamlApiConfiguration) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setAppDescriptor(ApplicationDescriptor) - Method in class org.mule.module.launcher.plugin.PluginDescriptor
 
setAppendString(String) - Method in class org.mule.tck.functional.FunctionalTestComponent
 
setAppFactory(ApplicationFactory) - Method in class org.mule.module.launcher.MuleDeploymentService
 
setApplicationClassLoaderFactory(ApplicationClassLoaderFactory) - Method in class org.mule.module.launcher.application.builder.DefaultMuleApplicationBuilder
 
setApplicationConfigFile(String) - Method in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
setApplicationContext(ApplicationContext) - Method in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.mule.config.spring.factories.FlowRefFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.mule.config.spring.factories.SimpleServiceFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
setApplicationContext(ApplicationContext) - Method in class org.mule.config.spring.ServerNotificationManagerConfigurator
 
setApplicationContext(ApplicationContext) - Method in class org.mule.config.spring.SpringRegistryBootstrap
 
setApplicationContext(ApplicationContext) - Method in class org.mule.config.spring.util.SpringBeanLookup
 
setApplicationContext(ApplicationContext) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
Set the current Spring application context
setApplicationCredentials(ApplicationCredentials) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsTokenRequestHandler
 
setApplicationFile(File) - Method in class org.mule.tools.anttasks.MuleDeploy
Specify the Mule application file to install
setApplicationFile(File) - Method in class org.mule.tools.anttasks.MulePackage
Specify the Mule application file to install
setApplicationName(String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Sets applicationName
setApplicationProperties(ApplicationDescriptor, File) - Method in class org.mule.module.launcher.DefaultAppBloodhound
 
setApplicationResources(String[]) - Method in class org.mule.tck.junit4.ApplicationContextBuilder
 
setAppName(String) - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
setAppProperties(Map<String, String>) - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
setArchiveDir(String) - Method in class org.mule.transport.sftp.SftpConnector
 
setArchiveTempReceivingDir(String) - Method in class org.mule.transport.sftp.SftpConnector
 
setArchiveTempSendingDir(String) - Method in class org.mule.transport.sftp.SftpConnector
 
setArgumentExpressionsString(String) - Method in class org.mule.processor.InvokerMessageProcessor
 
setArguments(List<ExpressionArgument>) - Method in class org.mule.expression.transformers.AbstractExpressionTransformer
 
setArguments(List<?>) - Method in class org.mule.processor.InvokerMessageProcessor
 
setArgumentTypes(Class<?>[]) - Method in class org.mule.processor.InvokerMessageProcessor
 
setArtifactFactory(ArtifactFactory<T>) - Method in interface org.mule.module.launcher.ArchiveDeployer
 
setArtifactFactory(ArtifactFactory<T>) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
setArtifactFactory(ArtifactFactory<Domain>) - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
setArtifactType(ArtifactType) - Method in class org.mule.DefaultMuleContext
 
setAssertMessageAccess(boolean) - Static method in class org.mule.api.ThreadSafeAccess.AccessControl
 
setAsText(String) - Method in class org.mule.config.spring.editors.ConnectorPropertyEditor
 
setAsText(String) - Method in class org.mule.config.spring.editors.DatePropertyEditor
Parse the Date from the given text, using the specified DateFormat.
setAsText(String) - Method in class org.mule.config.spring.editors.EndpointURIPropertyEditor
 
setAsText(String) - Method in class org.mule.config.spring.editors.MessageExchangePatternPropertyEditor
 
setAsText(String) - Method in class org.mule.config.spring.editors.ProcessingStrategyEditor
 
setAsText(String) - Method in class org.mule.config.spring.editors.QNamePropertyEditor
 
setAsText(String) - Method in class org.mule.config.spring.editors.SimpleServiceTypePropertyEditor
 
setAsText(String) - Method in class org.mule.config.spring.editors.URIBuilderPropertyEditor
 
setAsText(String) - Method in class org.mule.module.spring.security.editors.MethodSecurityMetadataSourceEditor
Create a MapBasedMethodSecurityMetadataSource from configured text The syntax expected is a set of Java properties, eachof the form fully-qualified-method-name=comma-separated-list-of-ConfigAttributes
setAsync(Boolean) - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
Sets async
setAsync(Boolean) - Method in interface org.mule.security.oauth.callback.HttpCallbackAdapter
Sets async
setAsynchronous(boolean) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
Determines whether events will be processed asynchronously
setAsyncReplyMessageSource(ServiceAsyncReplyCompositeMessageSource) - Method in interface org.mule.api.service.Service
Deprecated.
 
setAsyncReplyMessageSource(ServiceAsyncReplyCompositeMessageSource) - Method in class org.mule.service.AbstractService
Deprecated.
 
setAsyncReplyProperties(MuleEvent) - Method in class org.mule.routing.requestreply.SimpleAsyncRequestReplyRequester
 
setAttachmentName(String) - Method in class org.mule.transformer.simple.AddAttachmentTransformer
 
setAttachmentName(String) - Method in class org.mule.transformer.simple.CopyAttachmentsTransformer
 
setAttachmentName(String) - Method in class org.mule.transformer.simple.RemoveAttachmentTransformer
 
setAttribute(RequestContext.Scope, String, Object) - Method in class org.mule.module.atom.server.MuleRequestContext
 
setAttribute(String, Object) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
setAttributeName(String) - Method in class org.mule.config.spring.parsers.collection.AttributeListEntryDefinitionParser
 
setAttributeName(String) - Method in interface org.mule.config.spring.parsers.collection.DynamicAttributeDefinitionParser
 
setAuthenticate(boolean) - Method in class org.mule.security.AbstractAuthenticationFilter
 
setAuthenticated(boolean) - Method in interface org.mule.api.security.Authentication
 
setAuthenticated(boolean) - Method in class org.mule.module.jaas.JaasAuthentication
 
setAuthenticated(boolean) - Method in class org.mule.module.pgp.PGPAuthentication
 
setAuthenticated(boolean) - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
setAuthenticated(boolean) - Method in class org.mule.security.DefaultMuleAuthentication
 
setAuthentication(Authentication) - Method in interface org.mule.api.security.SecurityContext
 
setAuthentication(HttpAuthentication) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
setAuthentication(HttpAuthentication) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setAuthentication(Authentication) - Method in class org.mule.module.pgp.PGPSecurityContext
 
setAuthentication(Authentication) - Method in class org.mule.module.spring.security.SpringSecurityContext
 
setAuthentication(Authentication) - Method in class org.mule.security.DefaultSecurityContext
 
setAuthenticationMethod(String) - Method in class org.mule.module.management.agent.Mx4jAgent
 
setAuthenticationProvider(SpringAuthenticationProvider) - Method in class org.mule.module.spring.security.SpringProviderAdapter
 
setAuthenticator(Authenticator) - Method in class org.mule.transport.email.AbstractMailConnector
 
setAuthorizationRequestHandler(AuthorizationRequestHandler) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
setAuthorizationUrl(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
setAuthorizationUrl(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestUrlBuilder
 
setAuthorizationUrl(String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Sets authorizationUrl
setAuthorizationUrl(String) - Method in interface org.mule.security.oauth.OAuthAdapter
 
setAuthorizationUrl(String) - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
Sets authorizationUrl
setAuthorizationUrl(String) - Method in class org.mule.security.oauth.processor.OAuth1FetchAccessTokenMessageProcessor
Sets authorizationUrl
setAutoAckCount(int) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setAutoCommit(boolean) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
setAutoCommit(boolean) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setAutoCommit(boolean) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setAutoDelete(boolean) - Method in class org.mule.transport.file.FileConnector
 
setAutoDelete(boolean) - Method in class org.mule.transport.sftp.SftpConnector
 
setAutoGeneratedKeyStrategy(AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.config.processor.BulkUpdateMessageProcessorFactoryBean
 
setAutoGeneratedKeyStrategy(AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.processor.AbstractBulkUpdateMessageProcessor
 
setAutoGeneratedKeyStrategy(AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.processor.StoredProcedureMessageProcessor
 
setAutoGeneratedKeyStrategy(AutoGeneratedKeyStrategy) - Method in class org.mule.module.db.internal.processor.UpdateMessageProcessor
 
setAutoResolveVariables(boolean) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
setAutowireCandidateResolver(AutowireCandidateResolver) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Set a custom autowire candidate resolver for this BeanFactory to use when deciding whether a bean definition should be considered as a candidate for autowiring.
setAutoWrapMessageAwareTransform(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
 
setAxis(AxisServer) - Method in class org.mule.transport.soap.axis.AxisConnector
 
setAxis(AxisServer) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
setAxisTransportProtocols(Map<String, Class<?>>) - Method in class org.mule.transport.soap.axis.AxisConnector
 
setBacklog(int) - Method in class org.mule.transport.tcp.TcpConnector
Deprecated.
setBackupEnabled(boolean) - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
setBackupFolder(String) - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
setBase64Encoding(boolean) - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
setBasePath(String) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
setBasePath(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setBasepath(String) - Method in class org.mule.transport.servlet.JarResourceServlet
 
setBasePersistentStoreKey(String) - Method in class org.mule.util.store.MuleObjectStoreManager
 
setBasePersistentUserStoreKey(String) - Method in class org.mule.util.store.MuleObjectStoreManager
 
setBaseTransientStoreKey(String) - Method in class org.mule.util.store.MuleObjectStoreManager
 
setBaseTransientUserStoreKey(String) - Method in class org.mule.util.store.MuleObjectStoreManager
 
setBaseURI(String) - Method in class org.mule.module.ws.consumer.MuleWSDLLocatorConfig.Builder
 
setBaseURI(String) - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
setBatchSize(int) - Method in class org.mule.routing.Foreach
 
setBatchSize(int) - Method in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
Split the elements in groups of the specified size
setBatchSize(int) - Method in class org.mule.transaction.constraints.BatchConstraint
 
setBayeux(AbstractBayeux) - Method in class org.mule.transport.ajax.AjaxMessageDispatcher
 
setBayeux(AbstractBayeux) - Method in class org.mule.transport.ajax.AjaxMessageReceiver
 
setBayeux(AbstractBayeux) - Method in interface org.mule.transport.ajax.BayeuxAware
 
setBayeux(AbstractBayeux) - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
setBayeux(AbstractBayeux) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setBccAddresses(String) - Method in class org.mule.transport.email.SmtpConnector
 
setBean(BeanDefinitionBuilder) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
setBean(String) - Method in class org.mule.config.spring.util.SpringBeanLookup
 
setBeanAssemblerFactory(BeanAssemblerFactory) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
setBeanClass(Class<?>) - Method in class org.mule.expression.transformers.BeanBuilderTransformer
 
setBeanFactory(BeanFactory) - Method in class org.mule.config.spring.SpringRegistryBootstrap
 
setBeanFactory(ObjectFactory) - Method in class org.mule.expression.transformers.BeanBuilderTransformer
 
setBeanFlag(String) - Method in interface org.mule.config.spring.parsers.assembly.BeanAssembler
Set a flag on the bean - this is used to communicate with MuleHierarchicalBeanDefinitionParserDelegate
setBeanFlag(String) - Method in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
setBeanTypes(List<?>) - Method in class org.mule.transport.soap.axis.AxisConnector
 
setBinary(boolean) - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
setBinary(boolean) - Method in class org.mule.transport.ftp.FtpConnector
Setter for FTP transfer type.
setBindingId(String) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setBody(HttpResponse, MuleMessage, MuleEvent) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setBody(MuleMessage) - Method in class org.mule.transport.http.HttpResponse
 
setBody(OutputHandler) - Method in class org.mule.transport.http.HttpResponse
 
setBody(String) - Method in class org.mule.transport.http.HttpResponse
 
setBooleanProperty(String, boolean) - Method in interface org.mule.api.MuleMessage
setBooleanProperty(String, boolean) - Method in class org.mule.DefaultMuleMessage
Deprecated.
setBpms(BPMS) - Method in class org.mule.module.bpm.ProcessComponent
 
setBroadcast(boolean) - Method in class org.mule.transport.udp.UdpConnector
 
setBrokerURL(String) - Method in class org.mule.transport.jms.activemq.ActiveMQJmsConnector
 
setBufferOutput(String) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setBufferSize(int) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
setBufferSize(int) - Method in class org.mule.transport.stdio.StdioMessageReceiver
 
setBufferSize(int) - Method in class org.mule.transport.tcp.TcpConnector
setBuilders(List<HttpMessageBuilderRef>) - Method in class org.mule.module.http.internal.HttpMessageBuilder
 
setBus(Bus) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
setBus(Bus) - Method in class org.mule.module.cxf.transport.MuleUniversalTransport
 
setByteStream(InputStream) - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
setCacheControl(HttpResponse, MuleMessage) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setCacheControl(CacheControlHeader) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setCacheJmsSessions(boolean) - Method in class org.mule.transport.jms.JmsConnector
 
setCacheMessageAsBytes(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
 
setCacheMessageOriginalPayload(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
 
setCacheProducers(boolean) - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
setCacheXsl(boolean) - Method in class org.mule.module.management.agent.Mx4jAgent
 
setCachingStrategy(CachingStrategy) - Method in class org.mule.transport.http.config.spring.factories.HttpProxyFactoryBean
 
setCallbackFactory(HttpCallbackFactory) - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
setCaseSensitive(boolean) - Method in class org.mule.routing.filters.MessagePropertyFilter
 
setCaseSensitive(boolean) - Method in class org.mule.routing.filters.WildcardFilter
 
setCaseSensitive(boolean) - Method in class org.mule.transport.file.filters.FilenameRegexFilter
 
setCatalog(String) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
setCatalog(String) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setCatalog(String) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setCatchAllStrategy(OutboundRouterCatchAllStrategy) - Method in interface org.mule.api.routing.OutboundRouterCollection
Deprecated.
 
setCatchAllStrategy(OutboundRouterCatchAllStrategy) - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
setCatchAllStrategy(MessageProcessor) - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
setCategory(String) - Method in class org.mule.api.processor.LoggerMessageProcessor
 
setCauseRollback(boolean) - Method in exception org.mule.api.MessagingException
Marks exception as rollback cause.
setCcAddresses(String) - Method in class org.mule.transport.email.SmtpConnector
 
setCepMode(boolean) - Method in class org.mule.module.bpm.RulesComponent
 
setCertifiedText(boolean) - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
setChain(MessageProcessor) - Method in class org.mule.processor.chain.NestedProcessorChain
Sets chain
setChainsawHost(String) - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
setChainsawPort(int) - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
setCharacterEncoding(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
setCharacterEncoding(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
setCharacterStream(Reader) - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
setCheckEtag(boolean) - Method in class org.mule.transport.http.HttpPollingConnector
 
setCheckEtag(boolean) - Method in class org.mule.transport.http.HttpsPollingConnector
 
setCheckFrequency(long) - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
setCheckKeyExpirity(boolean) - Method in class org.mule.module.pgp.KeyBasedEncryptionStrategy
 
setCheckResponseTimestamp(boolean) - Method in class org.mule.module.ws.security.WssTimestampSecurityStrategy
 
setClassConstraint(Class<?>) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
setClassLoader(ClassLoader) - Method in class org.mule.transport.tcp.protocols.CustomClassLoadingLengthProtocol
 
setClassName(String) - Method in class org.mule.util.scan.annotations.AnnotationInfo
Deprecated.
 
setClasspath(PluginClasspath) - Method in class org.mule.module.launcher.plugin.PluginDescriptor
 
setClearQueryKey(String) - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
setClientCertificate(Certificate) - Method in class org.mule.module.http.internal.listener.HttpMessagePropertiesResolver
 
setClientClass(String) - Method in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
setClientConfig(String) - Method in class org.mule.transport.soap.axis.AxisConnector
 
setClientConnectionManager(HttpConnectionManager) - Method in class org.mule.transport.http.HttpConnector
 
setClientId(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestUrlBuilder
 
setClientId(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
setClientId(String) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
setClientId(String) - Method in class org.mule.transport.jms.JmsConnector
 
setClientInfo(String, String) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
setClientInfo(Properties) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
setClientInfo(Properties) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setClientInfo(String, String) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setClientInfo(Properties) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setClientInfo(String, String) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setClientKeyStore(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setClientKeyStore(String) - Method in interface org.mule.api.security.TlsIndirectKeyStore
 
setClientKeyStore(String) - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
setClientKeyStore(String) - Method in class org.mule.transport.email.SmtpsConnector
 
setClientKeyStore(String) - Method in class org.mule.transport.http.HttpsConnector
 
setClientKeyStore(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setClientKeyStorePassword(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setClientKeyStorePassword(String) - Method in interface org.mule.api.security.TlsIndirectKeyStore
 
setClientKeyStorePassword(String) - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
setClientKeyStorePassword(String) - Method in class org.mule.transport.email.SmtpsConnector
 
setClientKeyStorePassword(String) - Method in class org.mule.transport.http.HttpsConnector
 
setClientKeyStorePassword(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setClientKeyStoreType(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setClientKeyStoreType(String) - Method in interface org.mule.api.security.TlsIndirectKeyStore
 
setClientKeyStoreType(String) - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
setClientKeyStoreType(String) - Method in class org.mule.transport.email.SmtpsConnector
 
setClientKeyStoreType(String) - Method in class org.mule.transport.http.HttpsConnector
 
setClientKeyStoreType(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setClientMode(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
 
setClientProvider(SimpleProvider) - Method in class org.mule.transport.soap.axis.AxisConnector
 
setClientProxy(BindingProvider) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
setClientSecret(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestUrlBuilder
 
setClientSecret(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
setClientSecret(String) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
setClientSocketProperties(TcpClientSocketProperties) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setClientSocketProperties(TcpClientSocketProperties) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setClientSoTimeout(int) - Method in class org.mule.transport.tcp.TcpConnector
 
setCloseInput(boolean) - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
setClusterId(String) - Method in class org.mule.config.DefaultMuleConfiguration
 
setCollection() - Method in interface org.mule.config.spring.parsers.assembly.configuration.SingleProperty
 
setCollection() - Method in class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyLiteral
 
setCollection() - Method in class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyWrapper
 
setCollectionExpression(String) - Method in class org.mule.routing.Foreach
 
setCommandListener(CommandServer.CommandListener) - Method in class org.mule.test.infrastructure.process.CommandServer
 
setCommitTxFilter(WildcardFilter) - Method in class org.mule.exception.AbstractExceptionListener
 
setCompiledScript(CompiledScript) - Method in class org.mule.module.scripting.component.Scriptable
 
setComponent(Component) - Method in interface org.mule.api.service.Service
Deprecated.
Sets the Component that is a invoked by a Service for each incoming MuleEvent routed on by the inbound routers.
setComponent(Component) - Method in class org.mule.service.AbstractService
Deprecated.
 
setComponentBeanName(String) - Method in class org.mule.config.spring.factories.SimpleServiceFactoryBean
 
setComponentClass(Class<?>) - Method in class org.mule.config.spring.factories.SimpleServiceFactoryBean
 
setComponentName(String) - Method in class org.mule.module.management.mbean.EndpointService
 
setComponentPoolSize(int) - Method in class org.mule.management.stats.SedaServiceStatistics
Deprecated.
 
setComponents(List<JavaComponent>) - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
setComponentStat(ComponentStatistics) - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
setConfig(DefaultHttpListenerConfig) - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
setConfig(DefaultHttpRequesterConfig) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setConfig(TokenManagerConfig) - Method in class org.mule.module.oauth2.internal.tokenmanager.InvalidateOauthContextMessageProcessor
 
setConfig(WSConsumerConfig) - Method in class org.mule.module.ws.consumer.WSConsumer
 
setConfig(QueueConfiguration) - Method in class org.mule.util.queue.DefaultQueueStore
 
setConfig(QueueConfiguration) - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
setConfigBuilderClassName(String) - Static method in class org.mule.MuleServer
Sets the configuration builder to use for this server.
setConfigFile(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
setConfigNamespaces(Map<String, String>) - Method in class org.mule.module.xml.util.NamespaceManager
 
setConfigProperties(Map<String, Object>) - Method in class org.mule.module.cxf.config.WsConfig
 
setConfigResources(String[]) - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
setConfigResourcesFile(File[]) - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
setConfiguration(CxfConfiguration) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setConfiguration(CxfConfiguration) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setConfiguration(Configuration) - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
setConfigurationBuilder(String) - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
setConfigurationLocation(String) - Method in class org.mule.module.cxf.CxfConfiguration
 
setConfigurationResource(String) - Method in class org.mule.module.jbpm.Jbpm
 
setConfigurationResources(String) - Method in class org.mule.MuleServer
Setter for property configurationResources.
setConnected(boolean) - Method in class org.mule.transport.AbstractConnector
 
setConnecting(boolean) - Method in class org.mule.transport.AbstractConnector
 
setConnection(Connection) - Method in class org.mule.transport.jms.JmsConnector
 
setConnectionFactory(ConnectionFactory) - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
setConnectionFactory(ConnectionFactory) - Method in class org.mule.transport.jms.JmsConnector
 
setConnectionFactoryClass(String) - Method in class org.mule.transport.ftp.FtpConnector
Setter for property 'connectionFactoryClass'.
setConnectionFactoryJndiName(String) - Method in class org.mule.transport.jms.JmsConnector
 
setConnectionFactoryProperties(Map) - Method in class org.mule.transport.jms.JmsConnector
 
setConnectionIdleTimeout(int) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setConnectionIdleTimeout(int) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
setConnectionIdleTimeout(int) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setConnectionIdleTimeout(int) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setConnectionProperties(Map<String, String>) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setConnectionTimeout(int) - Method in class org.apache.commons.httpclient.HttpConnection
setconnectionTimeout(int) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setConnectionTimeout(int) - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
setConnectionTimeout(int) - Method in class org.mule.transport.ftp.FtpConnectionFactory
 
setConnectionTimeout(int) - Method in class org.mule.transport.ftp.FtpConnector
 
setConnectionTimeout(int) - Method in class org.mule.transport.tcp.AbstractTcpSocketFactory
 
setConnectionTimeout(Integer) - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
setConnectionTimeout(int) - Method in class org.mule.transport.tcp.TcpConnector
 
setConnectionTimeoutMillis(int) - Method in class org.mule.transport.sftp.SftpClient
 
setConnector(Connector) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setConnector(Connector) - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
setConnector(Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setConnector(Connector) - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
setConnector(Object) - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
Sets connector
setConnector(Object) - Method in interface org.mule.security.oauth.callback.HttpCallbackAdapter
Sets connector
setConnector(JmsConnector) - Method in class org.mule.transport.jms.redelivery.AbstractRedeliveryHandler
The connector associated with this handler is set before handleRedelivery() is called
setConnector(JmsConnector) - Method in interface org.mule.transport.jms.redelivery.RedeliveryHandler
The connector associated with this handler is set before handleRedelivery() is called
setConnectorConfig(HttpRequesterConfig) - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
setConnectorName(String) - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
setConnectorServerProperties(Map<String, Object>) - Method in class org.mule.module.management.agent.AbstractJmxAgent
Setter for property 'connectorServerProperties'.
setConnectorServerProperties(Map<String, Object>) - Method in class org.mule.module.management.agent.JmxAgentConfigurer
Setter for property 'connectorServerProperties'.
setConnectorServerUrl(String) - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
setConnectorServerUrl(String) - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
setConstraint(ConstraintFilter) - Method in interface org.mule.api.transaction.TransactionConfig
 
setConstraint(ConstraintFilter) - Method in class org.mule.transaction.MuleTransactionConfig
 
setConstraints() - Method in class org.mule.config.spring.parsers.specific.TransactionManagerDefinitionParser
 
setConsumer(OAuthConsumer) - Method in interface org.mule.security.oauth.OAuth1Adapter
Sets the OAuthConsumer
setConsumerKey(String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Sets consumerKey
setConsumerKey(String) - Method in interface org.mule.security.oauth.OAuth2Adapter
 
setConsumerSecret(String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Sets consumerSecret
setConsumerSecret(String) - Method in interface org.mule.security.oauth.OAuth2Adapter
 
setContainerMode(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
The setting is only editable before the context has been initialized, change requests ignored afterwards.
setContent(Object, Message, String, MuleMessage) - Method in class org.mule.transport.email.transformers.ObjectToMimeMessage
 
setContent(Object, Message, String, MuleMessage) - Method in class org.mule.transport.email.transformers.StringToEmailMessage
 
setContentHandler(ContentHandler) - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
setContentLenght(String) - Method in class org.mule.module.http.internal.listener.HttpResponseHeaderBuilder
 
setContentLength(int) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
setContentType(String) - Method in class org.mule.transformer.simple.AddAttachmentTransformer
 
setContentType(String) - Method in class org.mule.transport.email.SmtpConnector
 
setContentType(HttpResponse, MuleMessage) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setContentType(String) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setContentType(String) - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
setContentType(String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
setContext(MuleContext) - Method in class org.mule.module.ws.consumer.MuleWSDLLocatorConfig.Builder
 
setContext(Context) - Method in class org.mule.object.JndiObjectFactory
 
setContext(Context) - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
setContextFactory(InitialContextFactory) - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
setContextProperties(Map) - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
setContextProperties(Map) - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
setContextProperties(Map<String, Object>) - Method in class org.mule.module.xml.transformer.XQueryTransformer
Sets the parameters to be used when applying the transformation
setContextProperties(Map<String, Object>) - Method in class org.mule.module.xml.transformer.XsltTransformer
Sets the parameters to be used when applying the transformation
setContextResolvers(List<ContextResolver<?>>) - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
setConversationFactory(XmppConversationFactory) - Method in class org.mule.transport.xmpp.XmppConnector
 
setConverters(Set<Class<? extends Converter>>) - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
setCookies(HttpResponse, MuleMessage) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setCookies(List<CookieWrapper>) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setCookieSpec(String) - Method in class org.mule.transport.http.HttpConnector
 
setCookieSpec(String) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
setCoreExtensions(List<MuleCoreExtension>) - Method in interface org.mule.CoreExtensionsAware
 
setCorrelationExpression(String) - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
setCorrelationGroup(String) - Method in class org.mule.module.cxf.MuleSoapHeaders
 
setCorrelationGroupSize(int) - Method in interface org.mule.api.MuleMessage
Determines how many messages are in the correlation group
setCorrelationGroupSize(int) - Method in class org.mule.DefaultMuleMessage
Determines how many messages are in the correlation group
setCorrelationId(String) - Method in interface org.mule.api.MuleMessage
Sets a correlationId for this message.
setCorrelationId(String) - Method in class org.mule.DefaultMuleMessage
Sets a correlationId for this message.
setCorrelationId(String) - Method in class org.mule.module.cxf.MuleSoapHeaders
 
setCorrelationIdExpression(String) - Method in class org.mule.routing.ExpressionMessageInfoMapping
 
setCorrelationSequence(int) - Method in interface org.mule.api.MuleMessage
Gets the sequence or ordering number for this message in the the correlation group (as defined by the correlationId)
setCorrelationSequence(int) - Method in class org.mule.DefaultMuleMessage
Gets the sequence or ordering number for this message in the the correlation group (as defined by the correlationId)
setCorrelationSequence(String) - Method in class org.mule.module.cxf.MuleSoapHeaders
 
setCount(int) - Method in class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
setCount(int) - Method in class org.mule.tck.functional.AssertionMessageProcessor
 
setCounterVariableName(String) - Method in class org.mule.routing.Foreach
 
setCounterVariableName(String) - Method in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
setCreate(boolean) - Method in class org.mule.transport.jdbc.config.DerbyDataSourceFactoryBean
 
setCreateAccount(boolean) - Method in class org.mule.transport.xmpp.XmppConnector
 
setCreateConnector(int) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setCreateMultipleTransactedReceivers(boolean) - Method in class org.mule.transport.AbstractConnector
 
setCreateRegistry(boolean) - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
setCreateRmiRegistry(boolean) - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
setCreateRmiRegistry(boolean) - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
setCreateServer(boolean) - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
setCreateServer(boolean) - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
setCredentials(MuleEvent, Object) - Method in interface org.mule.api.security.CredentialsAccessor
 
setCredentials(MuleMessage) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
setCredentials(String) - Method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider
Sets the user's credentials.
setCredentials(Map<String, String>) - Method in class org.mule.module.management.agent.AbstractJmxAgent
Setter for property 'credentials'.
setCredentials(Map<String, String>) - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
setCredentials(Map<String, String>) - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
setCredentials(Map<String, String>) - Method in class org.mule.module.management.support.SimplePasswordJmxAuthenticator
 
setCredentials(MuleEvent, Object) - Method in class org.mule.security.MuleHeaderCredentialsAccessor
 
setCredentialsAccessor(CredentialsAccessor) - Method in interface org.mule.api.security.AuthenticationFilter
 
setCredentialsAccessor(CredentialsAccessor) - Method in class org.mule.module.pgp.KeyBasedEncryptionStrategy
 
setCredentialsAccessor(CredentialsAccessor) - Method in class org.mule.security.AbstractAuthenticationFilter
 
setCron(String) - Method in class org.mule.transport.quartz.config.ScheduleConfigBuilder
 
setCurrentPhase(String) - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
setCurrentProcessorPath(String) - Method in class org.mule.context.notification.DefaultFlowCallStack
Adds a message processor path to the list of processors that were invoked as part of the processing of this stack's event.
setCustomAdapterProperties(OAuth2Adapter, OAuthState) - Method in class org.mule.security.oauth.BaseOAuthClientFactory
Implementors can levarage this method to move custom property values from the state to the adapter You can leave this method blank if not needed in your case.
setCustomContentDisposition(String) - Method in class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
setCustomContentType(String) - Method in class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
setCustomDataTypes(List<DbType>) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setCustomDataTypes(List<DbType>) - Method in interface org.mule.module.db.internal.domain.database.ConfigurableDbConfigFactory
Sets the list of custom types available for the created DbConfig
setCustomDataTypes(List<DbType>) - Method in class org.mule.module.db.internal.domain.database.GenericDbConfigFactory
 
setCustomEvaluator(String) - Method in class org.mule.config.spring.factories.MessageProcessorFilterPairFactoryBean
 
setCustomEvaluator(String) - Method in class org.mule.expression.ExpressionConfig
 
setCustomEvaluator(String) - Method in class org.mule.expression.transformers.ExpressionArgument
 
setCustomEvaluator(String) - Method in class org.mule.routing.ExpressionSplitter
 
setCustomEvaluator(String) - Method in class org.mule.routing.filters.ExpressionFilter
 
setCustomEvaluator(String) - Method in class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
setCustomEvaluator(String) - Method in class org.mule.routing.outbound.ExpressionMessageSplitter
Deprecated.
 
setCustomEvaluator(String) - Method in class org.mule.routing.outbound.ExpressionRecipientList
 
setCustomEvaluator(String) - Method in class org.mule.transport.quartz.jobs.CustomJobFromMessageConfig
 
setCustomHeaders(Properties) - Method in class org.mule.transport.email.SmtpConnector
 
setCustomParameters(Map<String, String>) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
setCustomParameters(Map<String, String>) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestUrlBuilder
 
setCustomProperties(OAuth2Adapter) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Populates the adapter with custom properties not accessible from the base interface.
setCustomProperties(MuleEvent, Call) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
setCustomStateProperties(OAuth2Adapter, OAuthState) - Method in class org.mule.security.oauth.BaseOAuthClientFactory
Implementos can leverage this method to move custom property values from the adapter to the state.
setCustomTxManager(TransactionManager) - Method in class org.mule.config.spring.factories.TransactionManagerFactoryBean
 
setCustomValidator(Map<String, Object>) - Method in class org.mule.module.cxf.config.WsSecurity
 
setCxfBus(Bus) - Method in class org.mule.module.cxf.CxfConfiguration
 
setData(Object) - Method in class org.mule.component.simple.StaticComponent
 
setData(Object) - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
setDatabase(String) - Method in class org.mule.module.db.internal.config.domain.database.AbstractVendorConfigResolverFactoryBean
 
setDatabase(String) - Method in class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
setDatabase(String) - Method in class org.mule.transport.jdbc.config.DerbyDataSourceFactoryBean
 
setDatabinding(DataBinding) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setDatabinding(DataBinding) - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
setDataFile(String) - Method in class org.mule.component.simple.StaticComponent
 
setDataSource(DataSource) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setDataSource(DataSource) - Method in class org.mule.transport.jdbc.JdbcConnector
 
setDataType(DataType<?>) - Method in class org.mule.DefaultMuleMessage
 
SetDataType<T> - Class in org.mule.transformer.types
Defines a Set collection type with item type information
SetDataType() - Constructor for class org.mule.transformer.types.SetDataType
 
SetDataType(Class, String) - Constructor for class org.mule.transformer.types.SetDataType
 
SetDataType(Class) - Constructor for class org.mule.transformer.types.SetDataType
 
setDataTypeResolver(MvelDataTypeResolver) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
setDateHeader(HttpResponse, Date) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setDateHeader(String, long) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
setDateHeader(HttpResponse, long) - Method in class org.mule.transport.http.transformers.MuleMessageToHttpResponse
 
setDeadLetterQueue(MessageProcessorFilterPair) - Method in class org.mule.processor.AbstractRedeliveryPolicy
 
setDeadLetterQueue(Object) - Method in class org.mule.routing.UntilSuccessful
 
setDebugEnabled(boolean) - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
setDecoupledEndpoint(String) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setDecoupledEndpoint(String) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
setDefaultAccessTokenId(String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
setDefaultEncoding(String) - Method in class org.mule.config.DefaultMuleConfiguration
 
setDefaultEndpointName(String) - Method in class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
setDefaultExceptionStrategyName(String) - Method in class org.mule.config.DefaultMuleConfiguration
 
setDefaultExceptionStrategyName(String) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setDefaultExpression(String) - Method in class org.mule.config.spring.factories.WatermarkFactoryBean
 
setDefaultFile(String) - Method in class org.mule.transport.http.components.StaticResourceMessageProcessor
 
setDefaultObjectSerializer(ObjectSerializer) - Method in class org.mule.config.DefaultMuleConfiguration
 
setDefaultObjectSerializer(ObjectSerializer) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setDefaultProcessingStrategy(ProcessingStrategy) - Method in class org.mule.config.DefaultMuleConfiguration
 
setDefaultProcessingStrategy(ProcessingStrategy) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setDefaultProcessMessageAction(Flags.Flag) - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
setDefaultQueueConfiguration(QueueConfiguration) - Method in class org.mule.util.queue.AbstractQueueManager
Sets the default QueueConfiguration for any created Queue for which a custom configuration hasn't been specified
setDefaultQueueConfiguration(QueueConfiguration) - Method in class org.mule.util.queue.DelegateQueueManager
 
setDefaultQueueConfiguration(QueueConfiguration) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
Sets the default QueueConfiguration for any created Queue for which a custom configuration hasn't been specified
setDefaultQueueConfiguration(QueueConfiguration) - Method in interface org.mule.util.queue.QueueManager
Sets the default QueueConfiguration for any created Queue for which a custom configuration hasn't been specified
setDefaultQueueTimeout(int) - Method in class org.mule.config.DefaultMuleConfiguration
 
setDefaultResponseTimeout(int) - Method in class org.mule.config.DefaultMuleConfiguration
 
setDefaultResponseTimeout(int) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setDefaultRoute(MessageProcessor) - Method in interface org.mule.api.routing.SelectiveRouter
 
setDefaultRoute(MessageProcessorFilterPair) - Method in class org.mule.config.spring.factories.AbstractSelectiveRouterFactoryBean
 
setDefaultRoute(MessageProcessor) - Method in class org.mule.routing.AbstractMatchingRouter
 
setDefaultRoute(MessageProcessor) - Method in class org.mule.routing.AbstractSelectiveRouter
 
setDefaultSynchronousEndpoints(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
 
setDefaultSynchronousEndpoints(boolean) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setDefaultTransactionTimeout(int) - Method in class org.mule.config.DefaultMuleConfiguration
 
setDefaultTransactionTimeout(int) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setDefaultTransactionTimeout(long) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
Sets the default transaction timeout.
setDefaultTransactionTimeout(long) - Method in class org.mule.util.xa.AbstractResourceManager
Sets the default transaction timeout.
setDefaultUnauthorizedConnector(OAuth2Adapter) - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
setDefvalue(String) - Method in class com.javaforge.bobber.archetype.model.Variable
Set the defvalue field.
setDelegate(OutputStream) - Method in class org.mule.module.jersey.DeferredForwardOutputStream
 
setDelegate(AuthenticationManager) - Method in class org.mule.module.spring.security.SpringProviderAdapter
 
setDelegate(MessageProcessor) - Method in class org.mule.processor.AsyncDelegateMessageProcessor
 
setDelegate(DefaultObjectStoreFactory) - Static method in class org.mule.util.store.DefaultObjectStoreFactoryBean
setDeleteProperties(List<String>) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
setDeleteProperties(String...) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
setDeleteQueryKey(String) - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
setDeleteReadMessages(boolean) - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
setDeleteUnacceptedMessages(boolean) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setDeleteUnacceptedMessages(boolean) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setDelimiter(String) - Method in class org.mule.transformer.simple.ObjectArrayToString
 
setDelimiter(String) - Method in class org.mule.transformer.simple.StringToObjectArray
 
setDependencyComparator(Comparator<Object>) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Set a Comparator for dependency Lists and arrays.
setDependsOnVar(String) - Method in class com.javaforge.bobber.archetype.model.Template
Set if the specified variable is true, the template will be processed, otherwise skipped.
setDeploymentListener(DeploymentListener) - Method in class org.mule.module.launcher.application.DefaultApplicationFactory
 
setDeploymentListener(DeploymentListener) - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
setDeploymentListener(CompositeDeploymentListener) - Method in interface org.mule.module.launcher.ArchiveDeployer
 
setDeploymentListener(CompositeDeploymentListener) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
setDeploymentListener(DeploymentListener) - Method in class org.mule.module.launcher.domain.DefaultDomainFactory
 
setDeploymentListener(DeploymentListener) - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
setDeploymentListener(CompositeDeploymentListener) - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
setDeploymentProperties(Properties) - Method in class org.mule.context.DefaultMuleContextBuilder
 
setDeploymentProperties(Properties) - Method in class org.mule.DefaultMuleContext
Sets the deployment properties so that beans as well as application properties are overridden.
setDeploymentProperties(Properties) - Method in class org.mule.module.launcher.application.builder.DefaultMuleApplicationBuilder
 
setDeploymentProperties(Properties) - Method in class org.mule.module.launcher.application.builder.DefaultMuleDomainBuilder
 
setDeploymentProperties(Properties) - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
setDeploymentProperties(Properties) - Method in interface org.mule.module.launcher.artifact.Artifact
Sets the deployment properties
setDeploymentProperties(Properties) - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
setDeploymentProperties(Optional<Properties>) - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
setDeploymentProperties(Properties) - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
setDeploymentService(DeploymentService) - Method in class org.mule.module.launcher.coreextension.DefaultMuleCoreExtensionManager
 
setDeploymentService(DeploymentService) - Method in interface org.mule.module.launcher.DeploymentServiceAware
 
setDerbyHome() - Static method in class org.mule.tck.util.MuleDerbyTestUtils
 
setDerbyHome(String) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
 
setDereferencing(JsonSchemaDereferencing) - Method in class org.mule.module.json.validation.JsonSchemaValidator.Builder
Sets the dereferencing mode to be used.
setDereferencing(JsonSchemaDereferencing) - Method in class org.mule.module.json.validation.ValidateJsonSchemaMessageProcessor
 
setDescription(String) - Method in class com.javaforge.bobber.archetype.model.Variable
Set the description field.
setDescriptor(ApplicationDescriptor) - Method in class org.mule.module.launcher.application.builder.DefaultMuleApplicationBuilder
 
setDescriptor(DomainDescriptor) - Method in class org.mule.module.launcher.application.builder.DefaultMuleDomainBuilder
 
setDeserializationMixins(Map<Class<?>, Class<?>>) - Method in class org.mule.module.json.transformers.JsonToObject
 
setDestroyMethodIfNeeded(BeanDefinitionBuilder, Class) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
setDetails(PGPPublicKey) - Method in class org.mule.module.pgp.PGPAuthentication
 
setDeterministic(boolean) - Method in class org.mule.routing.outbound.AbstractRoundRobinMessageSplitter
If this option is true (the default) then the first message part is routed to the first endpoint, the second part to the second endpoint, etc, with the nth part going to the (n modulo number of targets) endpoint.
setDifference(Object[], Object[]) - Static method in class org.mule.util.ArrayUtils
 
setDifference(String[], String[]) - Static method in class org.mule.util.ArrayUtils
 
setDirectDeliver(boolean) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setDirective(String) - Method in class org.mule.transport.http.CacheControlHeader
 
setDirectory(String) - Method in class org.mule.transport.servlet.jetty.WebappsConfiguration
 
setDirectory(String) - Method in class org.mule.util.store.TextFileObjectStore
 
setDirty(AbstractTransactionContext, Throwable) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
Flag this resource manager as dirty.
setDirty(AbstractTransactionContext, Throwable) - Method in class org.mule.util.xa.AbstractResourceManager
Flag this resource manager as dirty.
setDisabledInterfaces(Collection) - Method in class org.mule.config.spring.ServerNotificationManagerConfigurator
 
setDisabledInterfaces(Collection<Class<? extends ServerNotificationListener>>) - Method in class org.mule.context.notification.ServerNotificationManager
 
setDisabledTypes(Collection<Class<? extends ServerNotificationListener>>) - Method in class org.mule.context.notification.ServerNotificationManager
Deprecated.
setDisablePropertiesAsHeaders(boolean) - Method in class org.mule.module.http.internal.listener.HttpResponseBuilder
 
setDisableReplyTo(boolean) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setDisableRoundRobin(boolean) - Method in class org.mule.routing.outbound.AbstractRoundRobinMessageSplitter
The default behaviour for splitter routers is to round-robin across targets.
setDisableTemporaryReplyToDestinations(boolean) - Method in class org.mule.transport.jms.JmsConnector
 
setDisableTransportTransformer(boolean) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setDisableTransportTransformer(boolean) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setDiscardEmptyContent(boolean) - Method in class org.mule.transport.http.HttpPollingConnector
 
setDiscardEmptyContent(boolean) - Method in class org.mule.transport.http.HttpsPollingConnector
 
setDiscOnClusterFailure(boolean) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setDispatcherFactory(MessageDispatcherFactory) - Method in interface org.mule.api.transport.Connector
The dispatcher factory is used to create a message dispatcher of the current request
setDispatcherFactory(MessageDispatcherFactory) - Method in class org.mule.transport.AbstractConnector
 
setDispatcherFactory(MessageDispatcherFactory) - Method in class org.mule.transport.tcp.TcpConnector
 
setDispatcherPoolFactory(ConfigurableKeyedObjectPoolFactory) - Method in class org.mule.transport.AbstractConnector
Allows to define a factory to create the dispatchers pool that will be used in the connector
setDispatcherPoolMaxWait(int) - Method in class org.mule.transport.AbstractConnector
Allows a maxWait timeout to be configured on the dispatcher object pool See: GenericKeyedObjectPool.setMaxWait(long)
setDispatcherPoolWhenExhaustedAction(byte) - Method in class org.mule.transport.AbstractConnector
Allows an ExhaustedAction to be configured on the dispatcher object pool See: GenericKeyedObjectPool.setWhenExhaustedAction(byte)
setDispatcherThreadingProfile(ThreadingProfile) - Method in class org.mule.transport.AbstractConnector
Setter for property 'dispatcherThreadingProfile'.
setDoAutoTypes(boolean) - Method in class org.mule.transport.soap.axis.AxisConnector
 
setDocumentBuilderFactory(DocumentBuilderFactory) - Method in class org.mule.module.xml.filters.AbstractJaxpFilter
The document builder factory to use in case XML needs to be parsed.
setDoInboundTransform(boolean) - Method in class org.mule.tck.functional.FunctionalTestComponent
 
setDomain(String) - Method in class org.mule.module.http.internal.domain.request.HttpRequestAuthentication
 
setDomain(String) - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
setDomain(Domain) - Method in class org.mule.module.launcher.application.builder.DefaultMuleApplicationBuilder
 
setDomain(String) - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
setDomain(String) - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
Sets domain
setDomain(String) - Method in interface org.mule.security.oauth.callback.HttpCallbackAdapter
Sets domain
setDomain(String) - Method in class org.mule.transport.http.CookieWrapper
 
setDomainClassLoaderRepository(DomainClassLoaderRepository) - Method in class org.mule.module.launcher.application.builder.DefaultMuleDomainBuilder
 
setDomainConfig(String) - Method in class org.mule.tck.junit4.DomainContextBuilder
 
setDomainContext(MuleContext) - Method in interface org.mule.api.config.DomainMuleContextAwareConfigurationBuilder
 
setDomainContext(MuleContext) - Method in class org.mule.config.builders.AutoConfigurationBuilder
 
setDomainContext(MuleContext) - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
setDomainContext(MuleContext) - Method in class org.mule.tck.junit4.ApplicationContextBuilder
 
setDomainFactory(DomainFactory) - Method in class org.mule.module.launcher.MuleDeploymentService
 
setDomainId(String) - Method in class org.mule.config.DefaultMuleConfiguration
 
setDoThreading(boolean) - Method in interface org.mule.api.config.ThreadingProfile
 
setDoThreading(boolean) - Method in class org.mule.config.ChainedThreadingProfile
 
setDoThreading(boolean) - Method in class org.mule.config.ImmutableThreadingProfile
 
setDoThreading(boolean) - Method in class org.mule.config.MutableThreadingProfile
 
setDoubleProperty(String, double) - Method in interface org.mule.api.MuleMessage
setDoubleProperty(String, double) - Method in class org.mule.DefaultMuleMessage
Deprecated.
setDriverClass(String) - Method in class org.mule.module.xml.transformer.AbstractXStreamTransformer
 
setDriverClassName(String) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setDriverClassName(String) - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
setDTDHandler(DTDHandler) - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
setDuplicateHandling(String) - Method in class org.mule.transport.sftp.SftpConnector
 
setDurable(boolean) - Method in class org.mule.transport.jms.JmsConnector
 
setDynamicNotification(boolean) - Method in class org.mule.transport.AbstractConnector
 
setDynamicRouteResolver(DynamicRouteResolver) - Method in class org.mule.routing.DynamicAll
 
setDynamicRouteResolver(DynamicRouteResolver) - Method in class org.mule.routing.DynamicFirstSuccessful
 
setDynamicRouteResolver(DynamicRouteResolver) - Method in class org.mule.routing.DynamicRoundRobin
 
setEagerConsumer(boolean) - Method in class org.mule.transport.jms.JmsConnector
A value of true will create a consumer on connect, in contrast to lazy instantiation in the poll loop.
setEmbeddedMode(boolean) - Method in class org.mule.transport.jms.JmsConnector
 
setEnableCookies(boolean) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setEnableCookies(boolean) - Method in class org.mule.transport.http.HttpConnector
 
setEnableCookies(boolean) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
setEnableCorrelation(CorrelationMode) - Method in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
setEnableCorrelation(CorrelationMode) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
setEnableCorrelationAsString(String) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
setEnabled(boolean) - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
Enable statistics logs (this is a dynamic parameter)
setEnabled(boolean) - Method in class org.mule.management.stats.AllStatistics
Enable statistics logs (this is a dynamic parameter)
setEnabled(boolean) - Method in class org.mule.management.stats.ComponentStatistics
Tags this stats collector as enabled or disabled.
setEnabled(boolean) - Method in class org.mule.management.stats.FlowConstructStatistics
Enable statistics logs (this is a dynamic parameter)
setEnabled(boolean) - Method in class org.mule.management.stats.RouterStatistics
 
setEnabled(boolean) - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
Enable statistics logs (this is a dynamic parameter)
setEnabled(boolean) - Method in class org.mule.module.management.mbean.StatisticsService
 
setEnableDiscovery(boolean) - Method in class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
 
setEnableList(boolean) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
setEnableMessageHistory(boolean) - Method in class org.mule.tck.functional.FunctionalTestComponent
 
setEnableMuleSoapHeaders(boolean) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setEnableMuleSoapHeaders(boolean) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setEnableMuleSoapHeaders(boolean) - Method in class org.mule.module.cxf.CxfConfiguration
 
setEnableMultiplexedConnections(boolean) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setEnableNotifications(boolean) - Method in interface org.mule.api.MuleEvent
Enables the firing of notifications when processing the message.
setEnableNotifications(boolean) - Method in class org.mule.DefaultMuleEvent
 
setEnableNotifications(boolean) - Method in class org.mule.exception.AbstractExceptionListener
 
setEnableNotifications(boolean) - Method in class org.mule.tck.functional.FunctionalTestComponent
 
setEnableNotifications(boolean) - Method in class org.mule.VoidMuleEvent
 
setEnableSharedDurable(boolean) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setEnableStatistics(boolean) - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
setEnableStatistics(boolean) - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
setEnableStreaming(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
 
setEncodeClientCredentialsInBody(boolean) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsTokenRequestHandler
 
setEncoding(String) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setEncoding(String) - Method in interface org.mule.api.MuleMessage
Sets the encoding for this message
setEncoding(String) - Method in interface org.mule.api.transformer.DataType
The encoding for the object to transform
setEncoding(String) - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
setEncoding(String) - Method in class org.mule.DefaultMuleMessage
Sets the encoding for this message
setEncoding(String) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setEncoding(String) - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
setEncoding(String) - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
setEncoding(String) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setEncoding(String) - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
setEncoding(String) - Method in class org.mule.transformer.AbstractTransformer
 
setEncoding(String) - Method in class org.mule.transformer.simple.SetPayloadMessageProcessor
 
setEncoding(String) - Method in class org.mule.transformer.types.SimpleDataType
 
setEncoding(String) - Method in class org.mule.util.store.TextFileObjectStore
 
setEncryptionAlgorithm(String) - Method in class org.mule.module.pgp.KeyBasedEncryptionStrategy
 
setEncryptionStrategies(Collection<EncryptionStrategy>) - Method in interface org.mule.api.security.SecurityManager
 
setEncryptionStrategies(Collection<EncryptionStrategy>) - Method in class org.mule.security.MuleSecurityManager
 
setEndpoint(OutboundEndpoint) - Method in class org.mule.agent.EndpointNotificationLoggerAgent
 
setEndpoint(ImmutableEndpoint) - Method in interface org.mule.api.component.InterfaceBinding
 
setEndpoint(ImmutableEndpoint) - Method in interface org.mule.api.security.EndpointSecurityFilter
Deprecated.
 
setEndpoint(InboundEndpoint) - Method in interface org.mule.api.transport.MessageReceiver
 
setEndpoint(ImmutableEndpoint) - Method in class org.mule.component.DefaultInterfaceBinding
 
setEndpoint(OutboundEndpoint) - Method in class org.mule.config.spring.factories.BridgeFactoryBean
 
setEndpoint(OutboundEndpoint) - Method in class org.mule.config.spring.factories.ValidatorFactoryBean
 
setEndpoint(InboundEndpoint) - Method in class org.mule.construct.Flow
Deprecated.
use setMessageSource(MessageSource) instead
setEndpoint(URI, Properties) - Method in class org.mule.endpoint.AbstractEndpointURIBuilder
 
setEndpoint(ImmutableEndpoint) - Method in interface org.mule.endpoint.EndpointAware
 
setEndpoint(URI, Properties) - Method in class org.mule.endpoint.ResourceNameEndpointURIBuilder
 
setEndpoint(URI, Properties) - Method in class org.mule.endpoint.SocketEndpointURIBuilder
 
setEndpoint(URI, Properties) - Method in class org.mule.endpoint.UrlEndpointURIBuilder
 
setEndpoint(URI, Properties) - Method in class org.mule.endpoint.UserInfoEndpointURIBuilder
 
setEndpoint(InboundEndpoint) - Method in class org.mule.module.client.remoting.RemoteDispatcherAgent
Deprecated.
 
setEndpoint(String) - Method in class org.mule.module.jbpm.MuleReceiveActivity
 
setEndpoint(String) - Method in class org.mule.module.jbpm.MuleSendActivity
 
setEndpoint(OutboundEndpoint) - Method in class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
setEndpoint(ImmutableEndpoint) - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
setEndpoint(ImmutableEndpoint) - Method in class org.mule.processor.SecurityFilterMessageProcessor
 
setEndpoint(OutboundEndpoint) - Method in class org.mule.routing.ForwardingCatchAllStrategy
Deprecated.
 
setEndpoint(ImmutableEndpoint) - Method in class org.mule.security.AbstractEndpointSecurityFilter
Deprecated.
 
setEndpoint(ImmutableEndpoint) - Method in class org.mule.transformer.AbstractTransformer
 
setEndpoint(ImmutableEndpoint) - Method in class org.mule.transformer.CompositeConverter
 
setEndpoint(ImmutableEndpoint) - Method in class org.mule.transformer.TransformerChain
 
setEndpoint(InboundEndpoint) - Method in class org.mule.transport.AbstractMessageReceiver
 
setEndpoint(ImmutableEndpoint) - Method in class org.mule.transport.AbstractTransportMessageHandler
 
setEndpoint(URI, Properties) - Method in class org.mule.transport.file.FileEndpointURIBuilder
 
setEndpoint(OutboundEndpoint) - Method in class org.mule.transport.http.config.spring.factories.HttpProxyFactoryBean
 
setEndpoint(URI, Properties) - Method in class org.mule.transport.jdbc.JdbcEndpointURIBuilder
 
setEndpoint(URI, Properties) - Method in class org.mule.transport.jms.JmsEndpointURIBuilder
 
setEndpoint(URI, Properties) - Method in class org.mule.transport.soap.axis.WsdlUrlEndpointURIBuilder
 
setEndpoint(URI, Properties) - Method in class org.mule.transport.xmpp.XmppEndpointURIBuilder
 
setEndpointBuilder(EndpointBuilder) - Method in class org.mule.config.spring.factories.SimpleServiceFactoryBean
 
setEndpointRef(String) - Method in class org.mule.transport.quartz.jobs.EndpointPollingJobConfig
 
setEndpointRef(String) - Method in class org.mule.transport.quartz.jobs.ScheduledDispatchJobConfig
 
setEndpointURI(EndpointURI) - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
setEndpointURI(EndpointURI) - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
setEnlisted(boolean) - Method in class org.mule.transport.jms.xa.SessionInvocationHandler
 
setEnricherPropagatesSessionVariableChanges(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
 
setEnricherPropagatesSessionVariableChanges(boolean) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setEnrichExpressionPairs(List<MessageEnricher.EnrichExpressionPair>) - Method in class org.mule.enricher.MessageEnricher
 
setEnrichmentMessageProcessor(MessageProcessor) - Method in class org.mule.enricher.MessageEnricher
 
setEntity(HttpEntity) - Method in class org.mule.module.http.internal.domain.request.HttpRequestBuilder
 
setEntity(HttpEntity) - Method in class org.mule.module.http.internal.domain.response.HttpResponseBuilder
 
setEntityResolver(EntityResolver) - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
setEntries(Map) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
setEntryFilter(Filter) - Method in class org.mule.module.atom.routing.FeedSplitter
 
setEntryFilter(Filter) - Method in class org.mule.module.rss.routing.FeedSplitter
 
setEntryPoint(String) - Method in class org.mule.module.bpm.RulesComponent
 
setEntryPointResolvers(Collection<EntryPointResolver>) - Method in class org.mule.component.AbstractJavaComponent
Allow for incremental addition of resolvers by for example the spring-config module
setEntryPointResolvers(Collection<EntryPointResolver>) - Method in class org.mule.model.AbstractModel
Deprecated.
This allows us to configure entry point resolvers incrementally
setEntryPointResolvers(Set<EntryPointResolver>) - Method in class org.mule.model.resolvers.DefaultEntryPointResolverSet
 
setEntryPointResolverSet(EntryPointResolverSet) - Method in interface org.mule.api.component.JavaComponent
A JavaComponent can have a custom entry-point resolver for its own object.
setEntryPointResolverSet(EntryPointResolverSet) - Method in interface org.mule.api.model.Model
Deprecated.
This will be used to build entry points on the components registered with the model.
setEntryPointResolverSet(EntryPointResolverSet) - Method in class org.mule.component.AbstractJavaComponent
 
setEntryPointResolverSet(EntryPointResolverSet) - Method in class org.mule.model.AbstractModel
Deprecated.
 
setEntryTTL(int) - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
setEntryTTL(int) - Method in class org.mule.util.store.ManagedObjectStore
 
setEnvironment(Map) - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
setErrorExpression(String) - Method in class org.mule.config.spring.factories.ValidatorFactoryBean
 
setErrorHandler(ErrorHandler) - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
setErrorHandler(ErrorHandler) - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
setErrorHandler(ErrorHandler) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
setErrorHandler(ErrorHandler) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
setErrorHandler(ErrorHandler) - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
setErrorMessage(String) - Method in class org.mule.api.model.InvocationResult
An optional error message can be set if the invocation state is not InvocationResult.State.SUCCESSFUL
setErrorNoMatchingMethods(Object, Class<?>[]) - Method in class org.mule.api.model.InvocationResult
 
setErrorNoMatchingMethodsCalled(Object, String) - Method in class org.mule.api.model.InvocationResult
 
setErrorOccurred() - Method in interface org.mule.transport.sftp.ErrorOccurredDecorator
 
setErrorOccurred() - Method in class org.mule.transport.sftp.SftpFileArchiveInputStream
 
setErrorOccurred() - Method in class org.mule.transport.sftp.SftpInputStream
 
setErrorOccurredOnInputStream(InputStream) - Method in class org.mule.transport.sftp.SftpUtil
 
setErrorReasonPhrase(String) - Method in class org.mule.module.http.api.listener.HttpListenerBuilder
 
setErrorResponseBuilder(HttpResponseBuilder) - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
setErrorStatusCode(String) - Method in class org.mule.module.http.api.listener.HttpListenerBuilder
 
setErrorTooManyMatchingMethods(Object, Class<?>[], String) - Method in class org.mule.api.model.InvocationResult
 
setEvaluator(String) - Method in class org.mule.config.spring.factories.MessageProcessorFilterPairFactoryBean
 
setEvaluator(String) - Method in class org.mule.expression.ExpressionConfig
 
setEvaluator(String) - Method in class org.mule.expression.transformers.ExpressionArgument
 
setEvaluator(String) - Method in class org.mule.routing.ExpressionSplitter
 
setEvaluator(String) - Method in class org.mule.routing.filters.ExpressionFilter
 
setEvaluator(String) - Method in class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
setEvaluator(String) - Method in class org.mule.routing.outbound.ExpressionMessageSplitter
Deprecated.
 
setEvaluator(String) - Method in class org.mule.routing.outbound.ExpressionRecipientList
 
setEvaluator(String) - Method in class org.mule.transport.quartz.jobs.CustomJobFromMessageConfig
 
setEvent(MuleEvent) - Method in interface org.mule.api.security.Authentication
 
setEvent(MuleEvent) - Method in class org.mule.module.jaas.JaasAuthentication
 
setEvent(MuleEvent) - Method in class org.mule.module.pgp.PGPAuthentication
 
setEvent(MuleEvent) - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
setEvent(MuleEvent) - Method in class org.mule.processor.chain.NestedProcessorChain
Sets event
setEvent(MuleEvent) - Static method in class org.mule.RequestContext
Deprecated.
Set an event for out-of-scope thread access.
setEvent(MuleEvent) - Method in class org.mule.security.DefaultMuleAuthentication
 
setEventCallback(EventCallback, long) - Method in class org.mule.tck.functional.FunctionalStreamingTestComponent
 
setEventCallback(EventCallback) - Method in class org.mule.tck.functional.FunctionalTestComponent
An event callback is called when a message is received by the service.
setEventComparator(Comparator) - Method in class org.mule.routing.Resequencer
 
setEventGroupsObjectStore(PartitionableObjectStore<MuleEvent>) - Method in class org.mule.routing.AbstractAggregator
 
setEvictionCheckIntervalMillis(int) - Method in class org.mule.config.PoolingProfile
 
setExceptionCode(int) - Method in exception org.mule.api.MuleException
 
setExceptionDetails(MuleMessage, Connector, Throwable) - Method in class org.mule.endpoint.inbound.InboundExceptionDetailsMessageProcessor
This method is used to set any additional and possibly transport specific information on the return message where it has an exception payload.
setExceptionListener(MessagingExceptionHandler) - Method in interface org.mule.api.model.Model
Deprecated.
The exception strategy to use by components managed by the model.
setExceptionListener(SystemExceptionHandler) - Method in interface org.mule.api.MuleContext
 
setExceptionListener(MessagingExceptionHandler) - Method in interface org.mule.api.service.Service
Deprecated.
 
setExceptionListener(MessagingExceptionHandler) - Method in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
setExceptionListener(MessagingExceptionHandler) - Method in class org.mule.config.spring.factories.TransactionalMessageProcessorsFactoryBean
 
setExceptionListener(MessagingExceptionHandler) - Method in class org.mule.construct.AbstractFlowConstruct
 
setExceptionListener(SystemExceptionHandler) - Method in class org.mule.DefaultMuleContext
 
setExceptionListener(ExceptionListener) - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
setExceptionListener(MessagingExceptionHandler) - Method in class org.mule.model.AbstractModel
Deprecated.
 
setExceptionListener(ExceptionListener) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
 
setExceptionListener(MessagingExceptionHandler) - Method in class org.mule.processor.TransactionalInterceptingMessageProcessor
 
setExceptionListener(MessagingExceptionHandler) - Method in class org.mule.service.AbstractService
Deprecated.
 
setExceptionListeners(List<MessagingExceptionHandlerAcceptor>) - Method in class org.mule.exception.ChoiceMessagingExceptionStrategy
 
setExceptionMappers(List<ExceptionMapper<?>>) - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
setExceptionMappings(Properties) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
setExceptionMappings(Properties) - Method in interface org.mule.transport.service.TransportServiceDescriptor
 
setExceptionPayload(ExceptionPayload) - Method in interface org.mule.api.MuleMessage
If an error occurs while processing this message, a ErrorPayload is attached which contains the root exception and Mule error code, plus any other releated info.
setExceptionPayload(ExceptionPayload) - Method in class org.mule.DefaultMuleMessage
If an error occurs while processing this message, a ErrorPayload is attached which contains the root exception and Mule error code, plus any other releated info.
setExceptionPayload(ExceptionPayload) - Static method in class org.mule.RequestContext
Deprecated.
There is no unsafe version of this because it shouldn't be performance critical
setExceptionText(String) - Method in class org.mule.tck.functional.FunctionalTestComponent
 
setExceptionToThrow(Class<? extends Throwable>) - Method in class org.mule.tck.functional.FunctionalTestComponent
 
setExchangePattern(MessageExchangePattern) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setExchangePattern(MessageExchangePattern) - Method in class org.mule.config.spring.factories.BridgeFactoryBean
 
setExchangePattern(MessageExchangePattern) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setExchangePattern(MessageExchangePattern) - Method in class org.mule.transport.http.HttpMuleMessageFactory
 
setExecutingPhase(String) - Method in class org.mule.lifecycle.AbstractLifecycleManager
 
setExecutionClassLoader(ClassLoader) - Method in interface org.mule.api.MuleContext
 
setExecutionClassLoader(ClassLoader) - Method in class org.mule.DefaultMuleContext
 
setExecutionClassLoader(ClassLoader) - Method in class org.mule.module.management.agent.ClassloaderSwitchingMBeanWrapper
 
setExecutor(Executor) - Method in class org.mule.api.FutureMessageResult
Set an ExecutorService to run this invocation.
setExecutor(Executor) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
setExhaustedAction(int) - Method in class org.mule.config.PoolingProfile
 
setExpandEmptyElements(boolean) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setExpandInternalEntities(boolean) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
setExpectedAction(int) - Method in class org.mule.tck.listener.ConnectionListener
 
setExpectedProperties(Map<String, String>) - Method in class org.mule.tck.property.SessionPropertiesValidatorComponent
 
setExpectedType(Class) - Method in class org.mule.routing.filters.PayloadTypeFilter
 
setExpectedType(Class<? extends Packet>) - Method in class org.mule.transport.xmpp.filters.XmppPacketTypeFilter
 
setExpectedValue(String) - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
Sets the expected result value of the XPath expression
setExpectedValue(String) - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
Sets the expected result value of the XPath expression
setExpectedValue(String) - Method in class org.mule.module.xml.filters.XPathFilter
Sets the expected result value of the XPath expression
setExpectTransaction(boolean) - Method in class org.mule.tck.functional.TransactionalFunctionalTestComponent
 
setExpiration(Date) - Method in interface org.mule.security.oauth.OAuth2Adapter
Sets expiration
setExpirationInterval(int) - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
setExpirationInterval(int) - Method in class org.mule.util.store.ManagedObjectStore
 
setExpires(long) - Method in class org.mule.module.ws.security.WssTimestampSecurityStrategy
 
setExpiresIn(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
setExpiresIn(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.TokenResponseConfiguration
 
setExpiryDate(Object) - Method in class org.mule.transport.http.CookieWrapper
 
setExplicitTrustStoreOnly(boolean) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setExplicitTrustStoreOnly(boolean) - Method in interface org.mule.api.security.TlsDirectTrustStore
If the trust store is undefined and the trust store generated via System properties then the key store certificates defined via TODO can be used as a source of trust information.
setExplicitTrustStoreOnly(boolean) - Method in class org.mule.transport.http.HttpsConnector
 
setExplicitTrustStoreOnly(boolean) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setExpression(String) - Method in class org.mule.config.spring.factories.MessageProcessorFilterPairFactoryBean
 
setExpression(String) - Method in class org.mule.el.ExpressionLanguageComponent
 
setExpression(String) - Method in class org.mule.expression.ExpressionConfig
 
setExpression(String) - Method in class org.mule.expression.transformers.ExpressionArgument
 
setExpression(String) - Method in class org.mule.keygenerator.ExpressionMuleEventKeyGenerator
 
setExpression(String) - Method in class org.mule.module.http.internal.HttpMapParam
 
setExpression(String) - Method in class org.mule.module.ognl.filters.OGNLFilter
Sets the expression for this filter.
setExpression(String) - Method in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
 
setExpression(String) - Method in class org.mule.module.xml.transformer.XPathExtractor
 
setExpression(String) - Method in class org.mule.modules.schedulers.cron.CronSchedulerFactory
 
setExpression(String) - Method in class org.mule.routing.ExpressionSplitter
 
setExpression(String) - Method in class org.mule.routing.filters.ExpressionFilter
 
setExpression(String) - Method in class org.mule.routing.outbound.EndpointSelector
Deprecated.
 
setExpression(String) - Method in class org.mule.routing.outbound.ExpressionMessageSplitter
Deprecated.
 
setExpression(String) - Method in class org.mule.routing.outbound.ExpressionRecipientList
 
setExpression(String) - Method in class org.mule.tck.functional.AssertionMessageProcessor
 
setExpression(String) - Method in class org.mule.transport.email.filters.MailSubjectRegExFilter
 
setExpression(String) - Method in class org.mule.transport.jms.filters.JmsPropertyFilter
Sets the match expression
setExpression(String) - Method in class org.mule.transport.jms.filters.JmsSelectorFilter
 
setExpression(String) - Method in class org.mule.transport.quartz.jobs.CustomJobFromMessageConfig
 
setExpressionConfig(ExpressionConfig) - Method in class org.mule.expression.transformers.ExpressionArgument
 
setExpressionEvaluationClassLoader(ClassLoader) - Method in class org.mule.expression.transformers.ExpressionArgument
 
setExpressionFile(String) - Method in class org.mule.el.ExpressionLanguageComponent
 
setExpressionLanguage(ExpressionLanguage) - Method in class org.mule.expression.DefaultExpressionManager
 
setExpressionManager(DefaultExpressionManager) - Method in class org.mule.DefaultMuleContext
 
setExtendedProperties(Map<String, String>) - Method in class org.mule.config.DefaultMuleConfiguration
 
setExtendedProperty(String, String) - Method in class org.mule.config.DefaultMuleConfiguration
 
setExtensionManager(ExtensionManager) - Method in class org.mule.DefaultMuleContext
 
setExtensions(List<Object>) - Method in class org.mule.config.DefaultMuleConfiguration
 
setExtensions(List<Object>) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setExternalRedirectionUrl(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
setFactories(Map) - Method in class org.mule.config.spring.processors.PropertyPlaceholderProcessor
 
setFactory(TransactionFactory) - Method in interface org.mule.api.transaction.TransactionConfig
 
setFactory(AbstractFactory) - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
setFactory(AbstractFactory) - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
setFactory(TransactionFactory) - Method in class org.mule.transaction.MuleTransactionConfig
 
setFactory(KeyedPoolableObjectFactory) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
setFactoryDelegate(UniversalTransactionFactory) - Static method in class org.mule.transport.vm.VMTransactionFactory
Deprecated.
For customizing the behavior of VM transport the whole QueueManager should be override
setFactoryProperties(Properties) - Method in class org.mule.transport.quartz.QuartzConnector
 
setFailed(Throwable) - Method in interface org.mule.api.retry.RetryContext
Typically called by validation logic to mark a problem and an optional root cause.
setFailed(Throwable) - Method in class org.mule.retry.async.FutureRetryContext
 
setFailed(Throwable) - Method in class org.mule.retry.DefaultRetryContext
 
setFailIfNoMatch(boolean) - Method in class org.mule.routing.outbound.AbstractRoundRobinMessageSplitter
If none of the targets match a split message part i.e.
setFailOnMessageScribbling(boolean) - Static method in class org.mule.api.ThreadSafeAccess.AccessControl
 
setFailOnTimeout(boolean) - Method in interface org.mule.api.routing.Aggregator
 
setFailOnTimeout(boolean) - Method in class org.mule.routing.AbstractAggregator
 
setFailOnTimeout(boolean) - Method in class org.mule.routing.correlation.EventCorrelator
 
setFailOnTimeout(boolean) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
setFailOnTimeout(boolean) - Method in class org.mule.service.ServiceAsyncReplyCompositeMessageSource
Deprecated.
 
setFailOnUnresolvedHost(Boolean) - Method in class org.mule.transport.tcp.TcpConnector
 
setFailureExpression(String) - Method in class org.mule.routing.DynamicFirstSuccessful
Specifies an expression that when evaluated as determines if the processing of one a route was a failure or not.
setFailureExpression(String) - Method in class org.mule.routing.FirstSuccessful
Specifies an expression that when evaluated as determines if the processing of one a route was a failure or not.
setFailureExpression(String) - Method in class org.mule.routing.UntilSuccessful
 
setFallbackCharset(String) - Method in class org.mule.transport.http.HttpResponse
 
setFeature(String, boolean) - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
setFeatures(List<AbstractFeature>) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setFeatures(List<AbstractFeature>) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setFeedbackOnEmptyResponse(boolean) - Method in class org.mule.transport.servlet.ServletResponseWriter
 
setFetchSize(int) - Method in interface org.mule.module.db.internal.domain.statement.ConfigurableStatementFactory
Indicates how many rows should fetched from the database any time more rows are requested on any resultSet returned by a statement created by this factory
setFetchSize(int) - Method in class org.mule.module.db.internal.domain.statement.QueryStatementFactory
 
setFetchSize(String) - Method in class org.mule.streaming.processor.AbstractDevkitBasedPageableMessageProcessor
 
setFieldValue(Object, String, Object, boolean) - Static method in class org.mule.util.ClassUtils
 
setFile(String) - Method in class com.javaforge.bobber.archetype.model.Template
Set the file field.
setFile(String) - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
setFileAge(long) - Method in class org.mule.transport.file.FileConnector
 
setFileAge(long) - Method in class org.mule.transport.sftp.SftpConnector
Sets the file age.
setFileName(String) - Method in class org.mule.transport.sftp.SftpInputStream
 
setFilenameParser(FilenameParser) - Method in class org.mule.transport.file.FileConnector
 
setFilenameParser(FilenameParser) - Method in class org.mule.transport.ftp.FtpConnector
 
setFilenameParser(FilenameParser) - Method in class org.mule.transport.sftp.SftpConnector
 
setFilter(String) - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
setFilter(Filter) - Method in class org.mule.config.spring.factories.MessageProcessorFilterPairFactoryBean
 
setFilter(Filter) - Method in class org.mule.module.sxc.SxcFilteringOutboundRouter
 
setFilter(SecurityFilter) - Method in class org.mule.processor.SecurityFilterMessageProcessor
 
setFilter(Filter) - Method in class org.mule.routing.filters.logic.NotFilter
 
setFilter(Filter) - Method in class org.mule.routing.MessageFilter
 
setFilter(Filter) - Method in class org.mule.routing.outbound.FilteringOutboundRouter
 
setFilter(Filter) - Method in class org.mule.routing.outbound.OutboundPassThroughRouter
Deprecated.
 
setFilter(Filter) - Method in class org.mule.routing.WireTap
 
setFilter(Filter) - Method in class org.mule.transport.http.components.RestServiceWrapper
 
setFilter(PacketFilter) - Method in class org.mule.transport.xmpp.filters.XmppNotFilter
 
setFilters(List<Filter>) - Method in class org.mule.routing.filters.logic.AbstractFilterCollection
 
setFilters(String) - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
setFilters(String) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setFirstName(String) - Method in class org.mule.tck.testmodels.services.Person
 
setFlag(BeanDefinition, String) - Static method in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
setFlags(int) - Method in class org.mule.routing.filters.RegExFilter
 
setFlow(Flow) - Method in class org.mule.module.http.api.listener.HttpListenerBuilder
 
setFlowConstruct(FlowConstruct) - Method in interface org.mule.api.construct.FlowConstructAware
 
setFlowConstruct(FlowConstruct) - Method in interface org.mule.api.MuleSession
Deprecated.
setFlowConstruct(FlowConstruct) - Method in class org.mule.component.AbstractComponent
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.component.AbstractJavaComponent
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.construct.processor.FlowConstructStatisticsMessageProcessor
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
Sets flowConstruct
setFlowConstruct(FlowConstruct) - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.exception.RedeliveryExceeded
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.interceptor.AbstractEnvelopeInterceptor
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.module.cxf.config.FlowConfiguringMessageProcessor
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.object.AbstractObjectFactory
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.processor.AbstractMuleObjectOwner
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.processor.AbstractRedeliveryPolicy
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.processor.ResponseMessageProcessorAdapter
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.routing.AbstractAggregator
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.routing.AbstractSelectiveRouter
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.routing.IdempotentMessageFilter
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.routing.MessageFilter
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.routing.MessageProcessorFilterPair
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.session.DefaultMuleSession
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.source.ClusterizableMessageSourceWrapper
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.source.StartableCompositeMessageSource
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.tck.functional.AssertionMessageProcessor
 
setFlowConstruct(FlowConstruct) - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
setFlowEndingWithOneWayEndpointReturnsNull(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
 
setFlowEndingWithOneWayEndpointReturnsNull(boolean) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setFlowVariable(String, Object) - Method in interface org.mule.api.MuleEvent
Sets a session variable value with a default data type
setFlowVariable(String, Object, DataType) - Method in interface org.mule.api.MuleEvent
Sets a flow variable value with a given data type
setFlowVariable(String, Object) - Method in class org.mule.DefaultMuleEvent
 
setFlowVariable(String, Object, DataType) - Method in class org.mule.DefaultMuleEvent
 
setFlowVariable(String, Object) - Method in class org.mule.VoidMuleEvent
 
setFlowVariable(String, Object, DataType) - Method in class org.mule.VoidMuleEvent
 
setFolder(Folder) - Method in class org.mule.transport.email.RetrieveMessageReceiver
 
setFollowRedirects(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setFollowRedirects(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setFooter(MuleContext) - Method in class org.mule.util.SplashScreen
 
setForceJndiDestinations(boolean) - Method in class org.mule.transport.jms.JmsConnector
 
setForceOldHttpTransport(boolean) - Method in class org.mule.security.oauth.DefaultHttpCallback
 
setFreeze(boolean) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
setFrequency(Long) - Method in class org.mule.config.spring.factories.PollingMessageSourceFactoryBean
 
setFrequency(long) - Method in class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
setFrequency(long) - Method in class org.mule.transport.AbstractPollingMessageReceiver
 
setFrequency(long) - Method in class org.mule.transport.polling.schedule.FixedFrequencySchedulerFactory
 
setFromAddress(String) - Method in class org.mule.transport.email.SmtpConnector
 
setFrontend(String) - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
Whether to use the simple frontend or JAX-WS frontend.
setFtpClient(FTPClient) - Method in class org.mule.transport.ftp.FtpMuleMessageFactory
 
setFullStackTraces(boolean) - Method in class org.mule.module.management.mbean.MuleConfigurationService
 
setFullStackTraces(boolean) - Method in interface org.mule.module.management.mbean.MuleConfigurationServiceMBean
 
setGetProperty(String) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
setGlobalFunctionsFile(String) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
setGlobalFunctionsString(String) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
setGlobalName(String) - Method in interface org.mule.api.GlobalNameableObject
 
setGlobalName(String) - Method in class org.mule.exception.AbstractExceptionListener
 
setGlobalName(String) - Method in class org.mule.exception.ChoiceMessagingExceptionStrategy
 
setGlobalStoreCapacity(int) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setGroupName(String) - Method in class org.mule.transport.quartz.config.AbstractJobConfig
 
setGroupName(String) - Method in interface org.mule.transport.quartz.config.JobConfig
 
setHandled(boolean) - Method in exception org.mule.api.MessagingException
Marks an exception as handled so it won't be re-throwed
setHandleException(boolean) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
setHandleException(boolean) - Method in class org.mule.module.json.transformers.ObjectToJson
 
setHeader(Header) - Method in class org.mule.transport.http.HttpRequest
 
setHeader(Header) - Method in class org.mule.transport.http.HttpResponse
 
setHeader(String, String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
setHeader(MuleContext) - Method in class org.mule.util.SplashScreen
Setting the header clears body and footer assuming a new splash-screen is built.
setHeaders(ParameterMap) - Method in class org.mule.module.http.internal.domain.request.HttpRequestBuilder
 
setHeaders(HttpResponse, MuleMessage) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setHeaders(Map<String, String>) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setHeaders(Header[]) - Method in class org.mule.transport.http.HttpResponse
 
setHeaders(MultiMap<String>) - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
setHeaders(HttpMethod, MuleMessage) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
setHoldability(int) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
setHoldability(int) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setHoldability(int) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setHomeDir(String) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
setHonorQosHeaders(boolean) - Method in class org.mule.transport.jms.JmsConnector
Sets the honorQosHeaders property, which determines whether JmsMessageDispatcher should honor incoming message's QoS headers (JMSPriority, JMSDeliveryMode).
setHost(String) - Method in class org.apache.commons.httpclient.HttpConnection
Sets the host to connect to.
setHost(String) - Method in class org.mule.endpoint.URIBuilder
 
setHost(String) - Method in class org.mule.module.db.internal.config.domain.database.AbstractVendorConfigResolverFactoryBean
 
setHost(String) - Method in class org.mule.module.http.api.listener.HttpListenerBuilder
 
setHost(String) - Method in class org.mule.module.http.api.requester.proxy.NtlmProxyConfigBuilder
 
setHost(String) - Method in class org.mule.module.http.api.requester.proxy.ProxyConfigBuilder
 
setHost(String) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
setHost(String) - Method in class org.mule.module.http.internal.listener.HttpListenerConfigBuilder
 
setHost(String) - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
setHost(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setHost(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setHost(String) - Method in class org.mule.module.http.internal.request.DefaultProxyConfig
 
setHost(String) - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
Deprecated.
setHost(String) - Method in class org.mule.module.management.agent.JdmkAgent
 
setHost(String) - Method in class org.mule.module.management.agent.Mx4jAgent
 
setHost(String) - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
setHost(URI) - Method in class org.mule.transport.http.MuleHostConfiguration
 
setHost(HttpHost) - Method in class org.mule.transport.http.MuleHostConfiguration
 
setHost(String, int, String) - Method in class org.mule.transport.http.MuleHostConfiguration
 
setHost(String, String, int, Protocol) - Method in class org.mule.transport.http.MuleHostConfiguration
 
setHost(String, int) - Method in class org.mule.transport.http.MuleHostConfiguration
 
setHost(String) - Method in class org.mule.transport.http.MuleHostConfiguration
 
setHost(String) - Method in class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
setHost(String) - Method in class org.mule.transport.jdbc.config.OracleDataSourceFactoryBean
 
setHost(String) - Method in class org.mule.transport.servlet.jetty.WebappsConfiguration
 
setHost(String) - Method in class org.mule.transport.sftp.config.SftpProxyConfig
 
setHost(String) - Method in class org.mule.transport.xmpp.XmppConnector
 
setHostExpression(String) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setHttpConnectionManager(HttpConnectionManager) - Method in class org.apache.commons.httpclient.HttpConnection
Sets the httpConnectionManager.
setHttpMethod(String) - Method in class org.mule.transport.http.components.RestServiceWrapper
 
setHttpUtil(HttpUtil) - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
setId(String) - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Set the id field.
setId(String) - Method in class org.mule.config.DefaultMuleConfiguration
 
setId(String) - Method in class org.mule.retry.policies.AbstractPolicyTemplate
 
setId(String) - Method in class org.mule.tck.functional.FunctionalTestComponent
 
setIdentifier(String) - Method in class org.mule.transformer.simple.AbstractAddVariablePropertyTransformer
 
setIdentifier(String) - Method in class org.mule.transformer.simple.AbstractRemoveVariablePropertyTransformer
 
setIdentityFile(String) - Method in class org.mule.transport.sftp.SftpConnector
 
setIdExpression(String) - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
setIdExpression(String) - Method in class org.mule.routing.IdempotentMessageFilter
 
setIgnoreAdminNotifications(boolean) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
setIgnoreBadInput(boolean) - Method in class org.mule.transformer.AbstractTransformer
 
setIgnoreBadInput(boolean) - Method in class org.mule.transformer.simple.SetPayloadMessageProcessor
Deprecated.
setIgnoreComponentMessageNotifications(boolean) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
setIgnoreComponentNotifications(boolean) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
setIgnoreConnectionNotifications(boolean) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
setIgnoreCustomNotifications(boolean) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
setIgnored() - Method in interface org.mule.config.spring.parsers.assembly.configuration.SingleProperty
 
setIgnored() - Method in class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyLiteral
 
setIgnored() - Method in class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyWrapper
 
setIgnoredDefault(boolean) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
setIgnoredDefault(boolean) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
setIgnoredDefault(boolean) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
setIgnoredDefault(boolean) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
setIgnoredDefault(boolean) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
setIgnoredDefault(boolean) - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
setIgnoredDefault(boolean) - Method in class org.mule.config.spring.parsers.delegate.AbstractPluggableDelegate
 
setIgnoredDefault(boolean) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
setIgnoredDefault(boolean) - Method in class org.mule.config.spring.parsers.delegate.ParentContextDefinitionParser
 
setIgnoredDefault(boolean) - Method in interface org.mule.config.spring.parsers.MuleDefinitionParserConfiguration
 
setIgnoredMethods(Set<String>) - Method in class org.mule.model.resolvers.ReflectionEntryPointResolver
 
setIgnoredObjectTypes(Class<?>[]) - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
setIgnoredObjectTypes(Class<?>[]) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
setIgnoreEndpointMessageNotifications(boolean) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
setIgnoreManagementNotifications(boolean) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
setIgnoreManagerNotifications(boolean) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
setIgnoreMessageNotifications(boolean) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
setIgnoreMessageProcessorNotifications(boolean) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
setIgnoreModelNotifications(boolean) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
setIgnoreSecurityNotifications(boolean) - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
setImports(Map<String, Class<?>>) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
setInboundAddress(String) - Method in class org.mule.config.spring.factories.BridgeFactoryBean
 
setInboundAddress(String) - Method in class org.mule.config.spring.factories.ValidatorFactoryBean
 
setInboundAddress(String) - Method in class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
setInboundAddress(String) - Method in class org.mule.transport.http.config.spring.factories.HttpProxyFactoryBean
 
setInboundEndpoint(EndpointBuilder) - Method in class org.mule.config.spring.factories.BridgeFactoryBean
 
setInboundEndpoint(EndpointBuilder) - Method in class org.mule.config.spring.factories.ValidatorFactoryBean
 
setInboundEndpoint(EndpointBuilder) - Method in class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
setInboundEndpoint(EndpointBuilder) - Method in class org.mule.transport.http.config.spring.factories.HttpProxyFactoryBean
 
setInboundProperty(String, Object) - Method in class org.mule.DefaultMuleMessage
 
setInboundProperty(String, Object, DataType<?>) - Method in class org.mule.DefaultMuleMessage
 
setInboundRouterStat(RouterStatistics) - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
setInboundTransformer(Transformer) - Method in class org.mule.transformer.wire.TransformerPairWireFormat
 
setIncludeConfigNamespaces(boolean) - Method in class org.mule.module.xml.util.NamespaceManager
 
setInCluster(boolean) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setIndentEnabled(boolean) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setIndentSize(int) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setIndentString(String) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setIndexedVariableResolver(int, VariableResolver) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
setInFaultInterceptors(List<Interceptor<? extends Message>>) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setInFaultInterceptors(List<Interceptor<? extends Message>>) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setInInterceptors(List<Interceptor<? extends Message>>) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setInInterceptors(List<Interceptor<? extends Message>>) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setInitialFactory(String) - Method in class org.mule.object.JndiObjectFactory
 
setInitialFacts(Collection) - Method in class org.mule.module.bpm.RulesComponent
 
setInitialisationPolicy(int) - Method in class org.mule.config.PoolingProfile
 
setInitializeStaticBusInstance(boolean) - Method in class org.mule.module.cxf.CxfConfiguration
 
setInitialRetryCount(int) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setInitialState(String) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setInitialState(String) - Method in interface org.mule.api.service.Service
Deprecated.
Sets the initial state of this service
setInitialState(String) - Method in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
setInitialState(String) - Method in class org.mule.construct.AbstractFlowConstruct
 
setInitialState(String) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setInitialState(String) - Method in class org.mule.service.AbstractService
Deprecated.
 
setInitialStateStopped(boolean) - Method in class org.mule.transport.AbstractConnector
The will cause the connector not to start when AbstractConnector.start() is called.
setInitMethodIfNeeded(BeanDefinitionBuilder, Class) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
setInjector(Injector) - Method in class org.mule.DefaultMuleContext
 
setInputStream(InputStream) - Method in class org.mule.transport.stdio.StdioConnector
 
setInputStream(InputStream) - Method in class org.mule.transport.stdio.StdioMessageReceiver
 
setInsertQueryKey(String) - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
setInstance(String) - Method in class org.mule.transport.jdbc.config.OracleDataSourceFactoryBean
 
setInteractWithExternal(boolean) - Method in interface org.mule.api.transaction.TransactionConfig
 
setInteractWithExternal(boolean) - Method in class org.mule.transaction.MuleTransactionConfig
 
setInterceptors(List<Interceptor>) - Method in class org.mule.component.AbstractComponent
 
setInterceptors(List<Interceptor>) - Method in class org.mule.interceptor.InterceptorStack
 
setInterface(Class<?>) - Method in interface org.mule.api.component.InterfaceBinding
 
setInterface(Class<?>) - Method in class org.mule.component.DefaultInterfaceBinding
 
setInterfaceBindings(List<InterfaceBinding>) - Method in interface org.mule.api.component.JavaComponent
 
setInterfaceBindings(List<InterfaceBinding>) - Method in class org.mule.component.AbstractJavaComponent
 
setInterfaceBindings(List<InterfaceBinding>) - Method in class org.mule.module.scripting.component.ScriptComponent
 
setInterfaceToTypes(Map) - Method in class org.mule.config.spring.ServerNotificationManagerConfigurator
 
setInterfaceToTypes(Map<Class<? extends ServerNotificationListener>, Set<Class<? extends ServerNotification>>>) - Method in class org.mule.context.notification.ServerNotificationManager
 
setInterval(int) - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
setInterval(int) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setInterval(long) - Method in class org.mule.transport.quartz.config.ScheduleConfigBuilder
 
setIntHeader(String, int) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
setIntProperty(String, int) - Method in interface org.mule.api.MuleMessage
setIntProperty(String, int) - Method in class org.mule.DefaultMuleMessage
Deprecated.
setInvocationProperty(String, Object) - Method in interface org.mule.api.MuleMessage
 
setInvocationProperty(String, Object, DataType<?>) - Method in interface org.mule.api.MuleMessage
 
setInvocationProperty(String, Object) - Method in class org.mule.DefaultMuleMessage
 
setInvocationProperty(String, Object, DataType<?>) - Method in class org.mule.DefaultMuleMessage
 
setIsRunning(Boolean) - Method in class org.mule.module.http.internal.listener.HttpListenerRegistry.RequestHandlerMatcherPair
 
setIterationCount(int) - Method in class org.mule.security.PasswordBasedEncryptionStrategy
 
setJaxbContext(JAXBContext) - Method in class org.mule.module.xml.transformer.jaxb.JAXBMarshallerTransformer
 
setJaxbContext(JAXBContext) - Method in class org.mule.module.xml.transformer.jaxb.JAXBUnmarshallerTransformer
 
setJdbcConnector(JdbcConnector) - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
setJmsProperties(MuleMessage, Message) - Method in class org.mule.transport.jms.transformers.AbstractJmsTransformer
 
setJmsPropertySanitizeKeyIfNecessary(Message, String, Object) - Method in class org.mule.transport.jms.transformers.AbstractJmsTransformer
 
setJmsSupport(JmsSupport) - Method in class org.mule.transport.jms.JmsConnector
 
setJmxAdaptorUrl(String) - Method in class org.mule.module.management.agent.JdmkAgent
 
setJmxAdaptorUrl(String) - Method in class org.mule.module.management.agent.Mx4jAgent
 
setJmxAuthenticator(ConfigurableJMXAuthenticator) - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
setJmxAuthenticator(ConfigurableJMXAuthenticator) - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
setJmxSupportFactory(JmxSupportFactory) - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
setJmxSupportFactory(JmxSupportFactory) - Method in class org.mule.module.management.agent.JmxServerNotificationAgent
 
setJndiContext(Context) - Method in class org.mule.transport.AbstractJndiConnector
 
setJndiDestinations(boolean) - Method in class org.mule.transport.jms.JmsConnector
 
setJndiInitialFactory(String) - Method in class org.mule.transport.AbstractJndiConnector
 
setJndiInitialFactory(String) - Method in class org.mule.transport.jms.JmsConnector
Deprecated.
use a JndiNameResolver instead of access this property
setJndiInitialFactory(String) - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
setJndiName(String) - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
setJndiNameResolver(JndiNameResolver) - Method in class org.mule.transport.jms.JmsConnector
 
setJndiProviderProperties(Map) - Method in class org.mule.transport.AbstractJndiConnector
 
setJndiProviderProperties(Map) - Method in class org.mule.transport.jms.JmsConnector
Deprecated.
use a JndiNameResolver instead of access this property
setJndiProviderProperties(Map) - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
setJndiProviderUrl(String) - Method in class org.mule.transport.AbstractJndiConnector
 
setJndiProviderUrl(String) - Method in class org.mule.transport.jms.JmsConnector
Deprecated.
use a JndiNameResolver instead of access this property
setJndiProviderUrl(String) - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
setJndiUrlPkgPrefixes(String) - Method in class org.mule.transport.AbstractJndiConnector
 
setJob(Job) - Method in class org.mule.transport.quartz.jobs.CustomJobConfig
 
setJobGroupName(String) - Method in class org.mule.transport.quartz.config.AbstractJobConfig
 
setJobGroupName(String) - Method in interface org.mule.transport.quartz.config.JobConfig
 
setJsonCommented(boolean) - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
setJsonCommented(boolean) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setKeepAlive(boolean) - Method in class org.mule.transport.http.HttpResponse
 
setKeepAlive(boolean) - Method in class org.mule.transport.http.HttpServerConnection
 
setKeepAlive(Boolean) - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
setKeepAlive(Boolean) - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
setKeepAlive(boolean) - Method in class org.mule.transport.tcp.TcpConnector
 
setKeepAliveTimeout(int) - Method in class org.mule.transport.tcp.TcpConnector
Sets the keep alive timeout (in Milliseconds)
setKeepFileOnError(Boolean) - Method in class org.mule.transport.sftp.SftpConnector
 
setKeepSendSocketOpen(boolean) - Method in class org.mule.transport.http.HttpConnector
Deprecated.
Use keepAlive property in the outbound endpoint.
setKeepSendSocketOpen(boolean) - Method in class org.mule.transport.tcp.TcpConnector
 
setKeepSendSocketOpen(boolean) - Method in class org.mule.transport.udp.UdpConnector
 
setKernelCoreSize(Integer) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setKey(Object) - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
setKey(String) - Method in class org.mule.config.spring.parsers.collection.ChildMapEntryDefinitionParser.KeyValuePair
 
setKey(byte[]) - Method in class org.mule.security.SecretKeyEncryptionStrategy
Deprecated.
 
setKey(String) - Method in class org.mule.security.SecretKeyEncryptionStrategy
Deprecated.
 
setKey(Object) - Method in class org.mule.transformer.simple.MapLookup
 
setKeyAlias(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setKeyAlias(String) - Method in interface org.mule.api.security.TlsDirectKeyStore
 
setKeyAlias(String) - Method in class org.mule.transport.http.HttpsConnector
 
setKeyAlias(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setKeyFactory(SecretKeyFactory) - Method in class org.mule.security.SecretKeyEncryptionStrategy
Deprecated.
 
setKeyManager(PGPKeyRing) - Method in class org.mule.module.pgp.filters.PGPSecurityFilter
 
setKeyManager(PGPKeyRing) - Method in class org.mule.module.pgp.KeyBasedEncryptionStrategy
 
setKeyManager(PGPKeyRing) - Method in class org.mule.module.pgp.PGPSecurityProvider
 
setKeyManagerAlgorithm(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setKeyManagerAlgorithm(String) - Method in interface org.mule.api.security.TlsDirectKeyStore
 
setKeyManagerAlgorithm(String) - Method in class org.mule.transport.http.HttpsConnector
 
setKeyManagerAlgorithm(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setKeyPassword(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setKeyPassword(String) - Method in interface org.mule.api.security.TlsDirectKeyStore
 
setKeyPassword(String) - Method in class org.mule.transport.http.HttpsConnector
 
setKeyPassword(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setKeyStore(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setKeyStore(String) - Method in interface org.mule.api.security.TlsDirectKeyStore
 
setKeyStore(String) - Method in class org.mule.transport.http.HttpsConnector
 
setKeyStore(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setKeyStorePassword(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setKeyStorePassword(String) - Method in interface org.mule.api.security.TlsDirectKeyStore
 
setKeyStorePassword(String) - Method in class org.mule.transport.http.HttpsConnector
 
setKeyStorePassword(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setKeyStoreType(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setKeyStoreType(String) - Method in interface org.mule.api.security.TlsDirectKeyStore
 
setKeyStoreType(String) - Method in class org.mule.transport.http.HttpsConnector
 
setKeyStoreType(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setKnownHostsFile(File) - Method in class org.mule.transport.sftp.SftpClient
 
setKnownHostsFile(String) - Method in class org.mule.transport.sftp.SftpConnector
 
setLastName(String) - Method in class org.mule.tck.testmodels.services.Person
 
setLastResponseInputStream(InputStream) - Method in class org.apache.commons.httpclient.HttpConnection
Set the state to keep track of the last response for the last request.
setLastUpdate(Date) - Method in class org.mule.module.atom.routing.EntryLastUpdatedFilter
 
setLastUpdate(Date) - Method in class org.mule.module.atom.routing.FeedLastUpdatedFilter
 
setLastUpdate(Date) - Method in class org.mule.module.rss.routing.EntryLastUpdatedFilter
 
setLastUpdate(Date) - Method in class org.mule.module.rss.routing.FeedLastUpdatedFilter
 
setLeftFilter(PacketFilter) - Method in class org.mule.transport.xmpp.filters.XmppAndFilter
 
setLenient(boolean) - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
setLevel(String) - Method in class org.mule.api.processor.LoggerMessageProcessor
 
setLevelMappings(Map<String, String>) - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
setLifecycleAdapterFactory(LifecycleAdapterFactory) - Method in interface org.mule.api.component.JavaComponent
Sets the factory used create life-cycle adaptors that are used to wrap component instance.
setLifecycleAdapterFactory(LifecycleAdapterFactory) - Method in interface org.mule.api.model.Model
Deprecated.
Sets the lifecycleAdapterFactory on the model.
setLifecycleAdapterFactory(LifecycleAdapterFactory) - Method in class org.mule.component.AbstractJavaComponent
 
setLifecycleAdapterFactory(LifecycleAdapterFactory) - Method in class org.mule.model.AbstractModel
Deprecated.
 
setLifecycleClass(Class<?>) - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
setLifecycleClass(Class<?>) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
setLifecycleFlags() - Method in class org.mule.component.DefaultComponentLifecycleAdapter
 
setLifecycleInterceptor(LifecycleInterceptor) - Method in interface org.mule.api.lifecycle.HasLifecycleInterceptor
Sets the given interceptor
setLifecycleInterceptor(LifecycleInterceptor) - Method in class org.mule.lifecycle.RegistryLifecycleCallback
 
setLifecycleManager(LifecycleManager) - Method in interface org.mule.api.context.MuleContextBuilder
 
setLifecycleManager(LifecycleManager) - Method in class org.mule.context.DefaultMuleContextBuilder
 
setLifecycleManager(MuleContextLifecycleManager) - Method in class org.mule.DefaultMuleContext
 
setLifecycleManager(SedaStageLifecycleManager) - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
setLifecycleState(LifecycleState) - Method in interface org.mule.api.lifecycle.LifecycleStateAware
 
setLineNumber(int) - Method in class org.mule.config.spring.parsers.DefaultXmlMetadataAnnotations
 
setLineSeparator(String) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setLinger(Integer) - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
setLinger(Integer) - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
setList(List) - Method in class org.mule.util.MapCombiner
 
setListener(MessageProcessor) - Method in interface org.mule.api.source.MessageSource
Set the MessageProcessor listener on a message source which will be invoked when a message is received or generated.
setListener(MessageProcessor) - Method in class org.mule.construct.DynamicPipelineMessageProcessor
 
setListener(ServerNotificationListener) - Method in class org.mule.context.notification.ListenerSubscriptionPair
 
setListener(MessageProcessor) - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
setListener(MessageProcessor) - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
setListener(MessageProcessor) - Method in class org.mule.module.cxf.config.FlowConfiguringMessageProcessor
 
setListener(MessageProcessor) - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
setListener(MessageProcessor) - Method in class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
setListener(MessageProcessor) - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
Sets listener
setListener(MessageProcessor) - Method in class org.mule.security.oauth.processor.AbstractListeningMessageProcessor
Sets the message processor that will "listen" the events generated by this message source
setListener(MessageProcessor) - Method in class org.mule.source.ClusterizableMessageSourceWrapper
 
setListener(MessageProcessor) - Method in class org.mule.source.StartableCompositeMessageSource
 
setListener(MessageProcessor) - Method in class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
setListener(MessageProcessor) - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
setListener(MessageProcessor) - Method in class org.mule.transport.AbstractMessageReceiver
 
setListenerConfig(HttpListenerConfig) - Method in class org.mule.module.http.api.listener.HttpListenerBuilder
 
setListenerPath(ListenerPath) - Method in class org.mule.module.http.internal.listener.HttpMessagePropertiesResolver
 
setListSize(int) - Method in class org.mule.module.management.agent.JmxServerNotificationAgent.NotificationListener
 
setListSize(int) - Method in interface org.mule.module.management.agent.JmxServerNotificationAgent.NotificationListenerMBean
 
setLoaderOverride(Set<String>) - Method in class org.mule.module.launcher.descriptor.ArtifactDescriptor
 
setLoaderOverride(Set<String>) - Method in class org.mule.module.launcher.plugin.PluginDescriptor
 
setLoadJdmkAgent(boolean) - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
setLoadLog4jAgent(boolean) - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
setLoadMx4jAgent(boolean) - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
setLoadProfilerAgent(boolean) - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
setLocalAddress(InetAddress) - Method in class org.apache.commons.httpclient.HttpConnection
Set the local address used when creating the connection.
setLocalAuthorizationUrl(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
setLocalAuthorizationUrlResourceOwnerId(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
setLocale(Locale) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
setLocalMuleClient(DefaultLocalMuleClient) - Method in class org.mule.DefaultMuleContext
 
setLocalPort(Integer) - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
Sets localPort
setLocalPort(Integer) - Method in interface org.mule.security.oauth.callback.HttpCallbackAdapter
Sets localPort
setLocateServer(boolean) - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
setLocateServer(boolean) - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
setLocation(Object) - Method in exception org.mule.api.LocatedMuleException
 
setLocation(String) - Method in class org.mule.module.http.internal.request.RamlApiConfiguration
 
setLocation(String) - Method in class org.mule.transformer.simple.ParseTemplateTransformer
 
setLocked(boolean) - Method in class org.apache.commons.httpclient.HttpConnection
Locks or unlocks the connection.
setLockProvider(LockProvider) - Method in class org.mule.util.lock.MuleLockFactory
 
setLogConfigFile(String) - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
setLogConfigFile(File) - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
setLogException(String) - Method in class org.mule.exception.AbstractExceptionListener
 
setLogFile(String) - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
setLogin(String) - Method in class org.mule.module.management.agent.Mx4jAgent
 
setLoginConfig(String) - Method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider
Sets the login Configuration
setLoginContextName(String) - Method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider
Sets the Login Context name
setLoginModule(String) - Method in class org.mule.module.jaas.JaasSimpleAuthenticationProvider
sets the login module name
setLoginTimeout(int) - Method in class org.mule.module.db.internal.domain.xa.DataSourceWrapper
 
setLoginTimeout(int) - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
setLoginTimeout(int) - Method in class org.mule.transport.jdbc.xa.DataSourceWrapper
 
setLogLevel(int) - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
setLogLevel(int) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setLogMessageDetails(boolean) - Method in class org.mule.tck.functional.FunctionalTestComponent
 
setLogName(String) - Method in class org.mule.agent.Log4jNotificationLoggerAgent
 
setLogWriter(PrintWriter) - Method in class org.mule.module.db.internal.domain.xa.DataSourceWrapper
 
setLogWriter(PrintWriter) - Method in class org.mule.transport.jdbc.xa.DataSourceWrapper
 
setLongProperty(String, long) - Method in interface org.mule.api.MuleMessage
setLongProperty(String, long) - Method in class org.mule.DefaultMuleMessage
Deprecated.
setLookupOnEachCall(boolean) - Method in class org.mule.object.JndiObjectFactory
 
setLoopback(boolean) - Method in class org.mule.transport.multicast.MulticastConnector
 
setMailboxFolder(String) - Method in class org.mule.transport.email.AbstractMailConnector
 
setManager(PlatformTransactionManager) - Method in class org.mule.module.spring.transaction.SpringTransactionFactory
 
setMapper(ObjectMapper) - Method in class org.mule.module.json.transformers.AbstractJsonTransformer
 
setMatchAll(boolean) - Method in interface org.mule.api.routing.OutboundRouterCollection
Deprecated.
 
setMatchAll(boolean) - Method in class org.mule.routing.AbstractMatchingRouter
 
setMatchAll(boolean) - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
setMaxActive(int) - Method in class org.mule.config.PoolingProfile
 
setMaxActive(int) - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
Sets the cap on the number of active instances per key.
setMaxActive(int) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
setMaxActiveTransformers(int) - Method in class org.mule.module.xml.transformer.XQueryTransformer
Sets the the current maximum number of active transformer objects allowed in the pool
setMaxActiveTransformers(int) - Method in class org.mule.module.xml.transformer.XsltTransformer
Sets the the current maximum number of active transformer objects allowed in the pool
setMaxAge(String) - Method in class org.mule.transport.http.CacheControlHeader
 
setMaxAge(String) - Method in class org.mule.transport.http.CookieWrapper
 
setMaxBufferSize(int) - Method in interface org.mule.api.config.ThreadingProfile
 
setMaxBufferSize(int) - Method in class org.mule.config.ChainedThreadingProfile
 
setMaxBufferSize(int) - Method in class org.mule.config.ImmutableThreadingProfile
 
setMaxBufferSize(int) - Method in class org.mule.config.MutableThreadingProfile
 
setMaxBufferSize(Integer) - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
setMaxConnectionPoolSize(int) - Method in class org.mule.transport.sftp.SftpConnector
 
setMaxConnections(int) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setMaxConnections(int) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setMaxConnections(int) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setMaxDepth(int) - Method in class org.mule.util.MapCombiner
 
setMaxDispatchersActive(int) - Method in class org.mule.transport.AbstractConnector
Configures the maximum number of dispatchers that can be concurrently active per endpoint
setMaxDispatchersActive(int) - Method in class org.mule.transport.file.FileConnector
 
setMaxEntries(int) - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
setMaxEntries(int) - Method in class org.mule.util.store.ManagedObjectStore
 
setMaxIdle(int) - Method in class org.mule.config.PoolingProfile
 
setMaxIdle(int) - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
Sets the cap on the number of "idle" instances in the pool.
setMaxIdle(int) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
setMaxIdleTransformers(int) - Method in class org.mule.module.xml.transformer.XQueryTransformer
Sets the the current maximum number of idle transformer objects allowed in the pool
setMaxIdleTransformers(int) - Method in class org.mule.module.xml.transformer.XsltTransformer
Sets the the current maximum number of idle transformer objects allowed in the pool
setMaxInterval(int) - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
setMaxInterval(int) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setMaxKernelPoolSize(Integer) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setMaxMessageLength(int) - Method in class org.mule.transport.tcp.protocols.LengthProtocol
 
setMaxMessageLength(int) - Method in class org.mule.transport.tcp.protocols.SafeProtocol
 
setMaxOutstandingMessages(int) - Method in class org.mule.config.QueueProfile
This specifies the number of messages that can be queued before it starts blocking.
setMaxOutstandingMessages(int) - Method in class org.mule.config.spring.factories.QueueProfileFactoryBean
 
setMaxPoolSize(int) - Method in class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
setMaxQueuePrefetch(int) - Method in class org.mule.transport.jms.JmsConnector
 
setMaxQueueSize(Integer) - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
setMaxQueueTransactionFilesSize(int) - Method in class org.mule.config.DefaultMuleConfiguration
 
setMaxQueueTransactionFilesSize(int) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setMaxRedelivery(int) - Method in class org.mule.transport.jms.JmsConnector
 
setMaxRedeliveryAttempts(Integer) - Method in class org.mule.exception.RollbackMessagingExceptionStrategy
 
setMaxRedeliveryCount(int) - Method in class org.mule.processor.AbstractRedeliveryPolicy
 
setMaxRequestersActive(int) - Method in class org.mule.transport.AbstractConnector
Configures the maximum number of requesters that can be concurrently active per endpoint
setMaxRetries(int) - Method in class org.mule.routing.UntilSuccessful
 
setMaxRows(int) - Method in interface org.mule.module.db.internal.domain.statement.ConfigurableStatementFactory
Sets the maximum numbers of rows that will be returned by any resultSet returned by a statement created by this factory
setMaxRows(int) - Method in class org.mule.module.db.internal.domain.statement.QueryStatementFactory
 
setMaxThreads(Integer) - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
setMaxThreadsActive(int) - Method in interface org.mule.api.config.ThreadingProfile
 
setMaxThreadsActive(int) - Method in class org.mule.config.ChainedThreadingProfile
 
setMaxThreadsActive(int) - Method in class org.mule.config.ImmutableThreadingProfile
 
setMaxThreadsActive(int) - Method in class org.mule.config.MutableThreadingProfile
 
setMaxThreadsIdle(int) - Method in interface org.mule.api.config.ThreadingProfile
 
setMaxThreadsIdle(int) - Method in class org.mule.config.ChainedThreadingProfile
 
setMaxThreadsIdle(int) - Method in class org.mule.config.ImmutableThreadingProfile
 
setMaxThreadsIdle(int) - Method in class org.mule.config.MutableThreadingProfile
 
setMaxTotal(int) - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
Sets the cap on the total number of instances from all pools combined.
setMaxTotal(int) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
setMaxUnackedSize(int) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setMaxWait(long) - Method in class org.mule.config.PoolingProfile
 
setMaxWait(long) - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
Sets the maximum amount of time (in milliseconds) the KeyedObjectPool.borrowObject(K) method should block before throwing an exception when the pool is exhausted and the "when exhausted" action is ConfigurableKeyedObjectPool.WHEN_EXHAUSTED_BLOCK.
setMaxWait(long) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
setMaxWaitMillis(int) - Method in class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
setMaxWorkerPoolSize(Integer) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setMBeanServer(MBeanServer) - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
setMBeanServer(MBeanServer) - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
setMEPUsingMethod(Method) - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
setMessage(MuleMessage) - Method in interface org.mule.api.MuleEvent
 
setMessage(Message) - Method in exception org.mule.api.MuleException
 
setMessage(String) - Method in exception org.mule.api.MuleException
 
setMessage(String) - Method in class org.mule.api.processor.LoggerMessageProcessor
 
setMessage(MuleMessage) - Method in class org.mule.DefaultMuleEvent
 
setMessage(String) - Method in class org.mule.tck.functional.AssertionMessageProcessor
 
setMessage(String) - Method in class org.mule.transformer.simple.StringAppendTransformer
 
setMessage(Message) - Method in class org.mule.transport.jms.JmsClientAcknowledgeTransaction
 
setMessage(MuleMessage) - Method in class org.mule.transport.sftp.notification.SftpNotifier
 
setMessage(MuleMessage) - Method in class org.mule.VoidMuleEvent
 
setMessageContextAttachments(MuleMessage, MessageContext) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
setMessageContextProperties(MuleMessage, MessageContext) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
setMessageDelayTime(long) - Method in class org.mule.transport.stdio.PromptStdioConnector
 
setMessageDigestAlgorithm(String) - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
setMessageDigestAlgorithm(String) - Method in class org.mule.routing.IdempotentSecureHashMessageFilter
 
setMessageExchangePattern(String) - Method in class org.mule.module.jbpm.MuleSendActivity
 
setMessageIdExpression(String) - Method in class org.mule.routing.ExpressionMessageInfoMapping
 
setMessageInfoMapping(MessageInfoMapping) - Method in class org.mule.construct.AbstractFlowConstruct
 
setMessageInfoMapping(MessageInfoMapping) - Method in class org.mule.routing.AbstractAggregator
 
setMessageInfoMapping(MessageInfoMapping) - Method in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
setMessageInfoMapping(MessageInfoMapping) - Method in class org.mule.service.AbstractService
Deprecated.
 
setMessageListener(MessageListener) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
setMessageListener(MessageListener) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
setMessageListener(MessageListener) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
setMessageProcessor(MessageProcessor) - Method in class org.mule.config.spring.factories.BridgeFactoryBean
 
setMessageProcessor(MessageProcessor) - Method in class org.mule.config.spring.factories.PollingMessageSourceFactoryBean
 
setMessageProcessor(MessageProcessor) - Method in class org.mule.config.spring.factories.SimpleServiceFactoryBean
 
setMessageProcessor(MessageProcessor) - Method in class org.mule.config.spring.factories.ValidatorFactoryBean
 
setMessageProcessor(MessageProcessor) - Method in class org.mule.enricher.MessageEnricher
For spring
setMessageProcessor(MessageProcessor) - Method in class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
setMessageProcessor(MessageProcessor) - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
setMessageProcessor(MessageProcessor) - Method in class org.mule.routing.ForwardingCatchAllStrategy
Deprecated.
 
setMessageProcessor(MessageProcessor) - Method in class org.mule.routing.requestreply.SimpleAsyncRequestReplyRequester
 
setMessageProcessor(MessageProcessor) - Method in class org.mule.routing.WireTap
Deprecated.
setMessageProcessor(MessageProcessor) - Method in class org.mule.security.oauth.callback.DefaultRestoreAccessTokenCallback
Sets messageProcessor
setMessageProcessor(MessageProcessor) - Method in class org.mule.security.oauth.callback.DefaultSaveAccessTokenCallback
Sets messageProcessor
setMessageProcessor(MessageProcessor) - Method in class org.mule.service.AbstractService
Deprecated.
setMessageProcessor(MessageProcessor) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setMessageProcessor(MessageProcessor) - Method in class org.mule.transport.http.config.spring.factories.HttpProxyFactoryBean
 
setMessageProcessors(List<MessageProcessor>) - Method in interface org.mule.api.construct.Pipeline
 
setMessageProcessors(List<MessageProcessor>) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setMessageProcessors(List) - Method in class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
setMessageProcessors(List) - Method in class org.mule.config.spring.factories.MessageProcessorChainFactoryBean
 
setMessageProcessors(List<MessageProcessor>) - Method in class org.mule.config.spring.factories.MessageProcessorFilterPairFactoryBean
 
setMessageProcessors(List) - Method in class org.mule.config.spring.factories.ResponseMessageProcessorsFactoryBean
 
setMessageProcessors(List<MessageProcessor>) - Method in class org.mule.config.spring.factories.ScatterGatherRouterFactoryBean
 
setMessageProcessors(List) - Method in class org.mule.config.spring.factories.TransactionalMessageProcessorsFactoryBean
 
setMessageProcessors(List<MessageProcessor>) - Method in class org.mule.construct.AbstractPipeline
 
setMessageProcessors(List<MessageProcessor>) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setMessageProcessors(List<MessageProcessor>) - Method in class org.mule.exception.AbstractExceptionListener
 
setMessageProcessors(List<MessageProcessor>) - Method in class org.mule.exception.RedeliveryExceeded
 
setMessageProcessors(List<MessageProcessor>) - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
setMessageProcessors(List<MessageProcessor>) - Method in class org.mule.routing.Foreach
 
setMessageProcessors(List<MessageProcessor>) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
Deprecated.
setMessageProcessors(List<MatchableMessageProcessor>) - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
setMessageProcessors(List<MessageProcessor>) - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
setMessageProperties(FlowConstruct, MuleMessage, MessageProcessor) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
setMessageRootId(String) - Method in interface org.mule.api.MuleMessage
set the root ID for the message
setMessageRootId(String) - Method in class org.mule.DefaultMuleMessage
 
setMessageService(MessageService) - Method in interface org.mule.module.bpm.BPMS
MessageService contains a callback method used to generate Mule messages from your process.
setMessageService(MessageService) - Method in interface org.mule.module.bpm.RulesEngine
Inject a callback so that the Rules Engine may generate messages within Mule.
setMessageService(MessageService) - Method in class org.mule.module.drools.Drools
 
setMessageService(MessageService) - Method in class org.mule.module.jbpm.Jbpm
 
setMessageService(MessageService) - Method in class org.mule.module.jbpm.MuleMessageService
 
setMessageSize(int) - Method in class org.mule.routing.MessageChunkSplitter
 
setMessageSize(int) - Method in class org.mule.routing.outbound.MessageChunkingRouter
Deprecated.
 
setMessageSource(MessageSource) - Method in interface org.mule.api.construct.Pipeline
 
setMessageSource(MessageSource) - Method in interface org.mule.api.service.Service
Deprecated.
 
setMessageSource(MessageSource) - Method in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
setMessageSource(MessageSource) - Method in class org.mule.construct.AbstractPipeline
 
setMessageSource(MessageSource) - Method in class org.mule.routing.requestreply.SimpleAsyncRequestReplyRequester
Deprecated.
setMessageSource(MessageSource) - Method in class org.mule.service.AbstractService
Deprecated.
 
setMessageSources(List<MessageSource>) - Method in class org.mule.config.spring.factories.CompositeMessageSourceFactoryBean
 
setMessageSources(List<MessageSource>) - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
setMessageSources(List<MessageSource>) - Method in class org.mule.source.StartableCompositeMessageSource
 
setMessageThreadPoolSize(int) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in interface org.mule.api.exception.MessagingExceptionHandlerAware
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.component.AbstractComponent
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.component.DefaultInterfaceBinding
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.endpoint.DefaultOutboundEndpoint
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.endpoint.DynamicOutboundEndpoint
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.exception.AbstractExceptionListener
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.processor.AbstractMuleObjectOwner
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.processor.AbstractNonBlockingMessageProcessor
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.processor.AbstractRedeliveryPolicy
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.processor.AsyncInterceptingMessageProcessor
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.routing.ForwardingCatchAllStrategy
Deprecated.
 
setMessagingExceptionHandler(MessagingExceptionHandler) - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
setMeta(String) - Method in class org.mule.endpoint.URIBuilder
 
setMetaInfo(Map<Object, Object>) - Method in interface org.mule.api.retry.RetryPolicyTemplate
 
setMetaInfo(Map<Object, Object>) - Method in class org.mule.retry.async.AsynchronousRetryTemplate
 
setMetaInfo(Map<Object, Object>) - Method in class org.mule.retry.policies.AbstractPolicyTemplate
 
setMethod(String) - Method in interface org.mule.api.component.InterfaceBinding
 
setMethod(String) - Method in class org.mule.component.DefaultInterfaceBinding
 
setMethod(String) - Method in class org.mule.module.http.internal.domain.request.HttpRequestBuilder
 
setMethod(String) - Method in class org.mule.module.http.internal.listener.HttpMessagePropertiesResolver
 
setMethod(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setMethodName(String) - Method in class org.mule.module.scripting.component.GroovyRefreshableBeanBuilder
 
setMethodName(String) - Method in class org.mule.processor.InvokerMessageProcessor
 
setMethodProperty(String) - Method in class org.mule.model.resolvers.MethodHeaderPropertyEntryPointResolver
 
setMethods(Set<String>) - Method in class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
 
setMethods(Set<String>) - Method in class org.mule.model.resolvers.ExplicitMethodEntryPointResolver
 
setMillisBetweenRetries(long) - Method in class org.mule.routing.UntilSuccessful
 
setMimeType(String) - Method in interface org.mule.api.transformer.DataType
The mime type of the the source object to transform.
setMimeType(String) - Method in class org.mule.DefaultMuleMessage
 
setMimeType(String) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setMimeType(String) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
setMimeType(String) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
setMimeType(String) - Method in class org.mule.transformer.AbstractTransformer
 
setMimeType(String) - Method in class org.mule.transformer.simple.SetPayloadMessageProcessor
 
setMimeType(String) - Method in class org.mule.transformer.types.SimpleDataType
 
setMinEvictionMillis(int) - Method in class org.mule.config.PoolingProfile
 
setMinPoolSize(int) - Method in class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
setMinRefreshIntervalInMillis(int) - Method in class org.mule.security.oauth.DefaultRefreshTokenManager
 
setMinRefreshIntervalInMillis(int) - Method in interface org.mule.security.oauth.RefreshTokenManager
Sets the minimum interval of time in which we allow a given access token id to be refresh.
setMinThreads(Integer) - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
setMixins(Map<Class<?>, Class<?>>) - Method in class org.mule.module.json.config.MapperFactoryBean
 
setMixins(Map<Class<?>, Class<?>>) - Method in class org.mule.module.json.transformers.AbstractJsonTransformer
 
setMode(String) - Method in class org.mule.transport.soap.axis.NamedParameter
 
setModel(Model) - Method in interface org.mule.api.service.Service
Deprecated.
 
setModel(Model) - Method in class org.mule.service.AbstractService
Deprecated.
 
setModelEncoding(String) - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Set an encoding used for reading/writing the model.
setModelEncoding(String) - Method in class com.javaforge.bobber.archetype.model.Template
Set an encoding used for reading/writing the model.
setModelEncoding(String) - Method in class com.javaforge.bobber.archetype.model.Variable
Set an encoding used for reading/writing the model.
setModuleObject(Object) - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
Sets moduleObject
setMoveToDirectory(String) - Method in class org.mule.transport.file.FileConnector
 
setMoveToFolder(String) - Method in class org.mule.transport.email.AbstractRetrieveMailConnector
 
setMoveToPattern(String) - Method in class org.mule.transport.file.FileConnector
 
setMtomEnabled(String) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setMtomEnabled(boolean) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setMtomEnabled(boolean) - Method in class org.mule.module.ws.consumer.WSConsumer
 
setMuleConfiguration(MuleConfiguration) - Method in interface org.mule.api.context.MuleContextBuilder
 
setMuleConfiguration(MuleConfiguration) - Method in class org.mule.context.DefaultMuleContextBuilder
 
setMuleConfiguration(MuleConfiguration) - Method in class org.mule.DefaultMuleContext
 
setMuleContext(MuleContext) - Method in class org.mule.AbstractAgent
 
setMuleContext(MuleContext) - Method in interface org.mule.api.context.MuleContextAware
 
setMuleContext(MuleContext) - Method in class org.mule.api.context.notification.ServerNotification
 
setMuleContext(MuleContext) - Method in class org.mule.api.processor.LoggerMessageProcessor
 
setMuleContext(MuleContext) - Method in class org.mule.api.schedule.SchedulerFactory
 
setMuleContext(MuleContext) - Method in class org.mule.component.AbstractComponent
 
setMuleContext(MuleContext) - Method in class org.mule.config.bootstrap.AbstractRegistryBootstrap
setMuleContext(MuleContext) - Static method in class org.mule.config.builders.DeployableMuleXmlContextListener
This method is to be used only by application server or web container integrations that allow web applications to be hot-deployed.
setMuleContext(MuleContext) - Method in class org.mule.config.ChainedThreadingProfile
 
setMuleContext(MuleContext) - Method in class org.mule.config.DefaultMuleConfiguration
 
setMuleContext(MuleContext) - Method in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
setMuleContext(MuleContext) - Method in class org.mule.config.endpoint.RegistryBackedAnnotationsParserFactory
 
setMuleContext(MuleContext) - Method in class org.mule.config.ImmutableThreadingProfile.DefaultWorkManagerFactory
 
setMuleContext(MuleContext) - Method in class org.mule.config.ImmutableThreadingProfile
 
setMuleContext(MuleContext) - Method in class org.mule.config.MutableThreadingProfile
 
setMuleContext(MuleContext) - Method in class org.mule.config.pool.ThreadPoolFactory
 
setMuleContext(MuleContext) - Method in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.config.processors.LookupInjectionProcessor
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.editors.MulePropertyEditorRegistrar
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.factories.ConstantFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.factories.FlowRefFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.factories.MessageProcessorFilterPairFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.factories.ObjectStoreFromRegistryFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.factories.QueueProfileFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.factories.TransactionManagerFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.factories.WatermarkFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.processors.DecoratingFlowAnnotationsBeanProcessor
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.processors.ParentContextPropertyPlaceholderProcessor
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.processors.PropertyPlaceholderProcessor
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.processors.TransformerAnnotatedBeanProcessor
 
setMuleContext(MuleContext) - Method in class org.mule.config.spring.ServerNotificationManagerConfigurator
 
setMuleContext(MuleContext) - Method in class org.mule.config.transformer.AnnotatedTransformerObjectProcessor
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.connector.MuleConnectorOperationLocator
 
setMuleContext(MuleContext) - Method in class org.mule.context.notification.MessageProcessingFlowTraceManager
 
setMuleContext(MuleContext) - Method in class org.mule.context.notification.ServerNotificationManager
 
setMuleContext(MuleContext) - Method in class org.mule.DefaultMuleMessage
 
setMuleContext(MuleContext) - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
Sets muleContext
setMuleContext(MuleContext) - Method in class org.mule.el.ExpressionLanguageComponent
 
setMuleContext(MuleContext) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setMuleContext(MuleContext) - Method in class org.mule.endpoint.DefaultEndpointFactory
 
setMuleContext(MuleContext) - Method in class org.mule.endpoint.inbound.InboundExceptionDetailsMessageProcessor
 
setMuleContext(MuleContext) - Method in class org.mule.endpoint.URIBuilder
 
setMuleContext(MuleContext) - Method in class org.mule.execution.MuleMessageProcessingManager
 
setMuleContext(MuleContext) - Method in class org.mule.execution.NotificationFiringProcessingPhase
 
setMuleContext(MuleContext) - Method in class org.mule.expression.DefaultExpressionManager
 
setMuleContext(MuleContext) - Method in class org.mule.expression.EndpointInfoExpressionEvaluator
 
setMuleContext(MuleContext) - Method in class org.mule.expression.MessagePayloadExpressionEvaluator
 
setMuleContext(MuleContext) - Method in class org.mule.expression.MuleContextExpressionEvaluator
 
setMuleContext(MuleContext) - Method in class org.mule.expression.MuleExpressionEvaluator
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.expression.RegistryExpressionEvaluator
 
setMuleContext(MuleContext) - Method in class org.mule.expression.StringExpressionEvaluator
 
setMuleContext(MuleContext) - Method in class org.mule.expression.transformers.ExpressionArgument
 
setMuleContext(MuleContext) - Method in class org.mule.keygenerator.ExpressionMuleEventKeyGenerator
 
setMuleContext(MuleContext) - Method in class org.mule.lifecycle.MuleContextLifecycleManager
 
setMuleContext(MuleContext) - Method in class org.mule.management.stats.DefaultProcessingTimeWatcher
 
setMuleContext(MuleContext) - Method in class org.mule.model.AbstractModel
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setMuleContext(MuleContext) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setMuleContext(MuleContext) - Method in class org.mule.module.cxf.CxfConfiguration
 
setMuleContext(MuleContext) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.module.db.internal.config.domain.param.DefaultSqlParamResolverFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.module.db.internal.config.domain.query.BulkQueryResolverFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.module.db.internal.config.processor.BulkUpdateMessageProcessorFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.module.db.internal.config.resolver.database.DefaultDbConfigResolverFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.module.db.internal.config.resolver.query.QueryResolverFactoryBean
 
setMuleContext(MuleContext) - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
setMuleContext(MuleContext) - Method in class org.mule.module.db.internal.domain.database.DataSourceFactory
 
setMuleContext(MuleContext) - Method in class org.mule.module.db.internal.domain.database.GenericDbConfigFactory
 
setMuleContext(MuleContext) - Method in class org.mule.module.db.internal.el.DbModuleElExtension
 
setMuleContext(MuleContext) - Method in class org.mule.module.extension.internal.manager.DefaultExtensionManager
 
setMuleContext(MuleContext) - Method in class org.mule.module.extension.internal.runtime.processor.OperationMessageProcessor
 
setMuleContext(MuleContext) - Method in class org.mule.module.extension.internal.runtime.ReflectiveMethodOperationExecutor
 
setMuleContext(MuleContext) - Method in class org.mule.module.http.internal.HttpSingleParam
 
setMuleContext(MuleContext) - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
setMuleContext(MuleContext) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
setMuleContext(MuleContext) - Method in class org.mule.module.http.internal.listener.HttpListenerConnectionManager
 
setMuleContext(MuleContext) - Method in class org.mule.module.http.internal.listener.HttpResponseBuilder
 
setMuleContext(MuleContext) - Method in class org.mule.module.http.internal.request.client.HttpConnectorMessageProcessorProvider
 
setMuleContext(MuleContext) - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
setMuleContext(MuleContext) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setMuleContext(MuleContext) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setMuleContext(MuleContext) - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.module.json.transformers.JsonSchemaXsdValidationFilter
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.module.json.transformers.JsonTransformerResolver
 
setMuleContext(MuleContext) - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
setMuleContext(MuleContext) - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
setMuleContext(MuleContext) - Method in class org.mule.module.management.agent.YourKitProfilerAgent
 
setMuleContext(MuleContext) - Method in class org.mule.module.management.mbean.StatisticsService
 
setMuleContext(MuleContext) - Method in class org.mule.module.oauth2.internal.AbstractTokenRequestHandler
 
setMuleContext(MuleContext) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
setMuleContext(MuleContext) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
setMuleContext(MuleContext) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
setMuleContext(MuleContext) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsTokenRequestHandler
 
setMuleContext(MuleContext) - Method in class org.mule.module.oauth2.internal.mel.OAuthExpressionLanguageExtension
 
setMuleContext(MuleContext) - Method in class org.mule.module.oauth2.internal.tokenmanager.InvalidateOauthContextMessageProcessor
 
setMuleContext(MuleContext) - Method in class org.mule.module.oauth2.internal.tokenmanager.TokenManagerConfig
 
setMuleContext(MuleContext) - Method in class org.mule.module.scripting.component.Scriptable
 
setMuleContext(MuleContext) - Method in class org.mule.module.scripting.expression.AbstractScriptExpressionEvaluator
 
setMuleContext(MuleContext) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.module.sxc.SxcFilteringOutboundRouter
 
setMuleContext(MuleContext) - Method in class org.mule.module.ws.consumer.WSConsumer
 
setMuleContext(MuleContext) - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
setMuleContext(MuleContext) - Method in class org.mule.module.xml.el.XMLExpressionLanguageExtension
 
setMuleContext(MuleContext) - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.module.xml.expression.JXPathExpressionEvaluator
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.module.xml.filters.XPathFilter
 
setMuleContext(MuleContext) - Method in class org.mule.module.xml.transformer.jaxb.JAXBTransformerResolver
 
setMuleContext(MuleContext) - Method in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.module.xml.transformer.XPathExtractor
 
setMuleContext(MuleContext) - Method in class org.mule.modules.schedulers.cron.CronScheduler
 
setMuleContext(MuleContext) - Method in class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
setMuleContext(MuleContext) - Method in class org.mule.processor.AbstractMuleObjectOwner
 
setMuleContext(MuleContext) - Method in class org.mule.processor.AbstractRedeliveryPolicy
 
setMuleContext(MuleContext) - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
setMuleContext(MuleContext) - Method in class org.mule.processor.chain.DefaultMessageProcessorChain
 
setMuleContext(MuleContext) - Method in class org.mule.processor.chain.NestedProcessorChain
Sets muleContext
setMuleContext(MuleContext) - Method in class org.mule.processor.InvokerMessageProcessor
 
setMuleContext(MuleContext) - Method in class org.mule.registry.TypeBasedTransformerResolver
 
setMuleContext(MuleContext) - Method in class org.mule.retry.DefaultRetryContext
 
setMuleContext(MuleContext) - Method in class org.mule.retry.policies.AbstractPolicyTemplate
 
setMuleContext(MuleContext) - Method in class org.mule.routing.AbstractAggregator
 
setMuleContext(MuleContext) - Method in class org.mule.routing.AbstractSelectiveRouter
 
setMuleContext(MuleContext) - Method in class org.mule.routing.DynamicAll
 
setMuleContext(MuleContext) - Method in class org.mule.routing.DynamicFirstSuccessful
 
setMuleContext(MuleContext) - Method in class org.mule.routing.DynamicRoundRobin
 
setMuleContext(MuleContext) - Method in class org.mule.routing.ExpressionMessageInfoMapping
 
setMuleContext(MuleContext) - Method in class org.mule.routing.filters.ExpressionFilter
 
setMuleContext(MuleContext) - Method in class org.mule.routing.filters.RegExFilter
 
setMuleContext(MuleContext) - Method in class org.mule.routing.ForwardingCatchAllStrategy
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.routing.IdempotentSecureHashMessageFilter
 
setMuleContext(MuleContext) - Method in class org.mule.routing.MessageFilter
 
setMuleContext(MuleContext) - Method in class org.mule.routing.MessageProcessorFilterPair
 
setMuleContext(MuleContext) - Method in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
 
setMuleContext(MuleContext) - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.routing.requestreply.SimpleAsyncRequestReplyRequester
 
setMuleContext(MuleContext) - Method in class org.mule.security.AbstractSecurityFilter
 
setMuleContext(MuleContext) - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
setMuleContext(MuleContext) - Method in class org.mule.security.oauth.DefaultHttpCallback
Sets muleContext
setMuleContext(MuleContext) - Method in class org.mule.security.oauth.DefaultRefreshTokenManager
 
setMuleContext(MuleContext) - Method in class org.mule.security.oauth.process.RetryProcessInterceptor
Sets muleContext
setMuleContext(MuleContext) - Method in class org.mule.serialization.internal.AbstractObjectSerializer
setMuleContext(MuleContext) - Method in class org.mule.source.ClusterizableMessageSourceWrapper
 
setMuleContext(MuleContext) - Method in class org.mule.source.StartableCompositeMessageSource
 
setMuleContext(MuleContext) - Method in class org.mule.tck.functional.FunctionalTestComponent
 
setMuleContext(MuleContext) - Method in class org.mule.transaction.MuleTransactionConfig
 
setMuleContext(MuleContext) - Method in class org.mule.transformer.AbstractTransformer
 
setMuleContext(MuleContext) - Method in class org.mule.transformer.CompositeConverter
 
setMuleContext(MuleContext) - Method in class org.mule.transformer.simple.SetPayloadMessageProcessor
 
setMuleContext(MuleContext) - Method in class org.mule.transformer.TransformerChain
 
setMuleContext(MuleContext) - Method in class org.mule.transformer.wire.TransformerPairWireFormat
 
setMuleContext(MuleContext) - Method in class org.mule.transport.file.ExpressionFilenameParser
 
setMuleContext(MuleContext) - Method in class org.mule.transport.polling.watermark.selector.SelectorWatermark
 
setMuleContext(MuleContext) - Method in class org.mule.transport.polling.watermark.UpdateExpressionWatermark
 
setMuleContext(MuleContext) - Method in class org.mule.transport.quartz.config.AbstractJobConfig
 
setMuleContext(MuleContext) - Method in class org.mule.transport.quartz.jobs.PollEndpointJob
 
setMuleContext(MuleContext) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
setMuleContext(MuleContext) - Method in class org.mule.transport.tcp.protocols.MuleMessageDirectProtocol
 
setMuleContext(MuleContext) - Method in class org.mule.transport.tcp.protocols.MuleMessageEOFProtocol
 
setMuleContext(MuleContext) - Method in class org.mule.transport.tcp.protocols.MuleMessageLengthProtocol
 
setMuleContext(MuleContext) - Method in class org.mule.transport.tcp.protocols.MuleMessageSafeProtocol
 
setMuleContext(MuleContext) - Method in class org.mule.util.DefaultStreamCloserService
 
setMuleContext(MuleContext) - Method in class org.mule.util.lock.MuleLockFactory
 
setMuleContext(MuleContext) - Method in class org.mule.util.queue.AbstractQueueManager
 
setMuleContext(MuleContext) - Method in class org.mule.util.queue.DelegateQueueManager
 
setMuleContext(MuleContext) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
setMuleContext(MuleContext) - Method in class org.mule.util.store.ManagedObjectStore
 
setMuleContext(MuleContext) - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
setMuleContext(MuleContext) - Method in class org.mule.util.store.MuleObjectStoreManager
 
setMuleContext(MuleContext) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
setMuleContext(MuleContext) - Method in class org.mule.util.store.QueuePersistenceObjectStore
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.util.store.QueueStoreAdapter
Deprecated.
 
setMuleContext(MuleContext) - Method in class org.mule.work.MuleWorkManager
 
setMuleHome(File) - Method in class org.mule.tools.anttasks.MuleDeploy
Specify the Mule home directory
setMuleMqMaxRedelivery(int) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setMuleRegistry(MuleRegistryHelper) - Method in class org.mule.DefaultMuleContext
 
setMultiFrameInterval(int) - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
setMultiFrameInterval(int) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setMustRevalidate(String) - Method in class org.mule.transport.http.CacheControlHeader
 
setNackExpression(String) - Method in class org.mule.config.spring.factories.ValidatorFactoryBean
 
setName(String) - Method in class com.javaforge.bobber.archetype.model.Variable
Set the name field.
setName(String) - Method in class org.mule.AbstractAgent
 
setName(String) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setName(String) - Method in interface org.mule.api.NameableObject
Sets the name of the object
setName(String) - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
setName(String) - Method in class org.mule.config.spring.factories.AbstractFlowConstructFactoryBean
 
setName(String) - Method in class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
setName(String) - Method in class org.mule.config.spring.factories.FlowRefFactoryBean
 
setName(String) - Method in class org.mule.config.spring.factories.MessageProcessorChainFactoryBean
 
setName(String) - Method in class org.mule.config.spring.parsers.generic.NamedDefinitionParser
 
setName(String) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setName(String) - Method in class org.mule.expression.AttachmentExpressionEnricher
 
setName(String) - Method in class org.mule.expression.MessageAttachmentsListExpressionEvaluator
setName(String) - Method in class org.mule.expression.MessageHeaderExpressionEnricher
 
setName(String) - Method in class org.mule.expression.OutboundAttachmentsExpressionEvaluator
setName(String) - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator
setName(String) - Method in class org.mule.expression.transformers.ExpressionArgument
 
setName(String) - Method in class org.mule.expression.VariableExpressionEnricher
 
setName(String) - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
 
setName(String) - Method in class org.mule.model.AbstractModel
Deprecated.
 
setName(String) - Method in class org.mule.module.bpm.ProcessComponent
 
setName(String) - Method in class org.mule.module.cxf.config.WsSecurity
 
setName(String) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setName(String) - Method in class org.mule.module.drools.Drools
 
setName(String) - Method in class org.mule.module.http.api.requester.proxy.ProxyConfigBuilder
 
setName(String) - Method in class org.mule.module.http.internal.HttpMessageBuilder
 
setName(String) - Method in class org.mule.module.http.internal.HttpSingleParam
 
setName(String) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
setName(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setName(String) - Method in class org.mule.module.http.internal.request.DefaultProxyConfig
 
setName(String) - Method in class org.mule.module.jbpm.Jbpm
 
setName(String) - Method in class org.mule.module.json.config.MapperFactoryBean
 
setName(String) - Method in class org.mule.module.launcher.descriptor.ArtifactDescriptor
 
setName(String) - Method in class org.mule.module.launcher.plugin.PluginDescriptor
 
setName(String) - Method in class org.mule.module.management.agent.JmxAgentConfigurer
 
setName(String) - Method in class org.mule.module.management.agent.YourKitProfilerAgent
 
setName(String) - Method in class org.mule.module.oauth2.internal.tokenmanager.TokenManagerConfig
 
setName(String) - Method in class org.mule.module.ognl.expression.OgnlExpressionEvaluator
 
setName(String) - Method in class org.mule.module.scripting.filter.ScriptFilter
 
setName(String) - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
setName(String) - Method in class org.mule.module.xml.config.JaxbContextFactoryBean
 
setName(String) - Method in class org.mule.processor.chain.AbstractMessageProcessorChainBuilder
 
setName(String) - Method in class org.mule.processor.InvokerMessageProcessor
 
setName(String) - Method in class org.mule.security.AbstractNamedEncryptionStrategy
 
setName(String) - Method in class org.mule.security.AbstractSecurityProvider
 
setName(String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
setName(String) - Method in class org.mule.service.AbstractService
Deprecated.
 
setName(String) - Method in class org.mule.tck.functional.InvocationCountMessageProcessor
 
setName(String) - Method in class org.mule.tck.security.Named
 
setName(String) - Method in class org.mule.transformer.AbstractTransformer
 
setName(String) - Method in class org.mule.transformer.CompositeConverter
 
setName(String) - Method in class org.mule.transformer.simple.SetPayloadMessageProcessor
Deprecated.
setName(String) - Method in class org.mule.transport.AbstractConnector
 
setName(String) - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
setName(String) - Method in class org.mule.transport.jms.JmsTransactionFactory
 
setName(String) - Method in class org.mule.transport.polling.schedule.PollScheduler
 
setName(String) - Method in class org.mule.transport.quartz.config.ScheduleConfigBuilder
 
setName(String) - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
setName(String) - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
setName(String) - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
setNamespace(String) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setNamespaceManager(NamespaceManager) - Method in class org.mule.module.xml.expression.AbstractXPathExpressionEvaluator
Deprecated.
 
setNamespaceManager(NamespaceManager) - Method in class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
 
setNamespaces(Map<String, String>) - Method in class org.mule.module.sxc.SxcFilteringOutboundRouter
 
setNamespaces(Map<String, String>) - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
setNamespaces(Map<String, String>) - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
setNamespaces(Map<String, String>) - Method in class org.mule.module.xml.filters.XPathFilter
The prefix-to-namespace map for the namespace context to be applied to the XPath evaluation.
setNamespaces(Map<String, String>) - Method in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
 
setNamespaces(Map<String, String>) - Method in class org.mule.module.xml.transformer.XPathExtractor
The prefix-to-namespace map.
setNamespaces(Map<String, String>) - Method in class org.mule.module.xml.util.NamespaceManager
 
setNetworkTimeout(Executor, int) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
setNetworkTimeout(Executor, int) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setNetworkTimeout(Executor, int) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setNewLineAfterDeclaration(boolean) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setNewLineAfterNTags(int) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setNewlines(boolean) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setNextFactory(VariableResolverFactory) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
setNextMessage(Message) - Method in class org.mule.config.i18n.Message
 
setNoCache(String) - Method in class org.mule.transport.http.CacheControlHeader
 
setNoLocal(boolean) - Method in class org.mule.transport.jms.JmsConnector
 
setNonProxyHosts(String) - Method in class org.mule.module.http.api.requester.proxy.NtlmProxyConfigBuilder
 
setNonProxyHosts(String) - Method in class org.mule.module.http.api.requester.proxy.ProxyConfigBuilder
 
setNonProxyHosts(String) - Method in class org.mule.module.http.internal.request.DefaultProxyConfig
 
setNoRecurseOnDefinition(BeanDefinition) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
setNoStore(String) - Method in class org.mule.transport.http.CacheControlHeader
 
setNotificationDynamic(boolean) - Method in class org.mule.config.spring.ServerNotificationManagerConfigurator
 
setNotificationDynamic(boolean) - Method in class org.mule.context.notification.ServerNotificationManager
 
setNotificationManager(ServerNotificationManager) - Method in interface org.mule.api.context.MuleContextBuilder
 
setNotificationManager(ServerNotificationManager) - Method in class org.mule.context.DefaultMuleContextBuilder
 
setNotificationManager(ServerNotificationManager) - Method in class org.mule.DefaultMuleContext
 
setNotifier(RetryNotifier) - Method in interface org.mule.api.retry.RetryPolicyTemplate
 
setNotifier(RetryNotifier) - Method in class org.mule.retry.async.AsynchronousRetryTemplate
 
setNotifier(RetryNotifier) - Method in class org.mule.retry.policies.AbstractPolicyTemplate
 
setNotifier(SftpNotifier) - Method in class org.mule.transport.sftp.SftpClient
 
setNtlmDomain(String) - Method in class org.mule.module.http.api.requester.proxy.NtlmProxyConfigBuilder
 
setNtlmDomain(String) - Method in class org.mule.module.http.internal.request.NtlmProxyConfig
 
setNullReturnsTrue(boolean) - Method in class org.mule.routing.filters.ExpressionFilter
 
setNumberOfConcurrentTransactedReceivers(int) - Method in class org.mule.transport.AbstractConnector
 
setNumberOfConsumers(int) - Method in class org.mule.transport.jms.JmsConnector
setNumberOfExecutionsRequired(int) - Method in class org.mule.tck.listener.ConnectionListener
 
setNumberOfExecutionsRequired(int) - Method in class org.mule.tck.listener.ExceptionListener
 
setNumberOfExecutionsRequired(int) - Method in class org.mule.tck.listener.FlowExecutionListener
 
setNumberOfExecutionsRequired(int) - Method in class org.mule.tck.listener.SystemExceptionListener
 
setNumberOfMessages(int) - Method in class org.mule.routing.outbound.MessageChunkingRouter
Deprecated.
 
setOauthCallback(HttpCallback) - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
setOauthConfig(AuthorizationCodeGrantType) - Method in class org.mule.module.oauth2.internal.authorizationcode.AbstractAuthorizationCodeTokenRequestHandler
 
setOauthConfig(AuthorizationCodeGrantType) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
setOauthResponseParser(OAuthResponseParser) - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
setOauthRestoreAccessToken(RestoreAccessTokenCallback) - Method in interface org.mule.security.oauth.OAuth1Adapter
Set the callback to be called when the access token and secret need to be restored
setOauthSaveAccessToken(SaveAccessTokenCallback) - Method in interface org.mule.security.oauth.OAuth1Adapter
Set the callback to be called when the access token and secret need to be saved for later restoration
setOauthVerifier(String) - Method in interface org.mule.security.oauth.OAuthAdapter
Set OAuth verifier
setObject(Object) - Method in class org.mule.processor.InvokerMessageProcessor
 
setObjectClass(Class<?>) - Method in class org.mule.object.AbstractObjectFactory
 
setObjectClassName(String) - Method in class org.mule.object.AbstractObjectFactory
 
setObjectFactory(ObjectFactory) - Method in interface org.mule.api.component.JavaComponent
The object factory used to obtain the component object instance.
setObjectFactory(ObjectFactory) - Method in class org.mule.component.AbstractJavaComponent
 
setObjectFactory(ObjectFactory) - Method in class org.mule.component.SimpleCallableJavaComponent
 
setObjectFactory(ObjectFactory) - Method in class org.mule.util.pool.CommonsPoolObjectPool
 
setObjectFactory(ObjectFactory) - Method in interface org.mule.util.pool.ObjectPool
 
setObjectName(String) - Method in class org.mule.object.JndiObjectFactory
 
setObjectSerializer(ObjectSerializer) - Method in class org.mule.DefaultMuleContext
 
setObjectSerializer(ObjectSerializer) - Method in class org.mule.session.AbstractSessionHandler
 
setObjectSerializer(ObjectSerializer) - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
 
setObjectSerializer(ObjectSerializer) - Method in class org.mule.transport.tcp.protocols.SafeProtocol
 
setObjectStore(String, ListableObjectStore<Serializable>) - Method in interface org.mule.api.MuleContext
 
setObjectStore(ObjectStore<Serializable>) - Method in class org.mule.config.spring.factories.WatermarkFactoryBean
 
setObjectStore(String, ListableObjectStore<Serializable>) - Method in class org.mule.DefaultMuleContext
 
setObjectStore(ListableObjectStore) - Method in class org.mule.module.oauth2.internal.tokenmanager.TokenManagerConfig
 
setObjectStore(ObjectStore<AtomicInteger>) - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
setObjectStore(ListableObjectStore<MuleEvent>) - Method in class org.mule.routing.UntilSuccessful
 
setObjectType(Class<?>) - Method in class org.mule.processor.InvokerMessageProcessor
 
setOk() - Method in interface org.mule.api.retry.RetryContext
Typically called by validation logic to mark no problems with the current connection.
setOk() - Method in class org.mule.retry.async.FutureRetryContext
 
setOk() - Method in class org.mule.retry.DefaultRetryContext
 
setOmitEncoding(boolean) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setOnNoTokenPolicy(OnNoTokenPolicy) - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
setOnNoTokenPolicy(OnNoTokenPolicy) - Method in interface org.mule.security.oauth.OnNoTokenPolicyAware
 
setOperation(String) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setOperation(String) - Method in class org.mule.module.cxf.component.WebServiceWrapperComponent
Deprecated.
 
setOperation(String) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
setOperation(String) - Method in class org.mule.module.ws.consumer.WSConsumer
 
setOperationConfig(HttpRequestOptions) - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
setOperationStyle(MessageContext) - Method in class org.mule.transport.soap.axis.extensions.MuleMsgProvider
Deprecated.
I dont think this is necessary, but leaving it here for a while
setOptional(boolean) - Method in class org.mule.expression.transformers.ExpressionArgument
 
setOptionalParams(Map) - Method in class org.mule.transport.http.components.RestServiceWrapper
 
setOptionIfNotset(SOAPService, String, Object) - Method in class org.mule.transport.soap.axis.AxisMessageReceiver
 
setOrderedLifecycleObjects(Set<LifecycleObject>) - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
setOrderedLifecycleObjects(Set<LifecycleObject>) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
setOutboundAddress(String) - Method in class org.mule.config.spring.factories.BridgeFactoryBean
 
setOutboundAddress(String) - Method in class org.mule.config.spring.factories.ValidatorFactoryBean
 
setOutboundAddress(String) - Method in class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
setOutboundAddress(String) - Method in class org.mule.transport.http.config.spring.factories.HttpProxyFactoryBean
 
setOutboundEndpoint(EndpointBuilder) - Method in class org.mule.config.spring.factories.BridgeFactoryBean
 
setOutboundEndpoint(EndpointBuilder) - Method in class org.mule.config.spring.factories.ValidatorFactoryBean
 
setOutboundEndpoint(EndpointBuilder) - Method in class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
setOutboundEndpoint(EndpointBuilder) - Method in class org.mule.transport.http.config.spring.factories.HttpProxyFactoryBean
 
setOutboundMessageProcessor(MessageProcessor) - Method in interface org.mule.api.service.Service
Deprecated.
Outbound message processor controls how events are published by a service once the event has been processed.
setOutboundMessageProcessor(MessageProcessor) - Method in class org.mule.service.AbstractService
Deprecated.
 
setOutboundProperty(String, Object) - Method in interface org.mule.api.MuleMessage
 
setOutboundProperty(String, Object, DataType<?>) - Method in interface org.mule.api.MuleMessage
 
setOutboundProperty(String, Object) - Method in class org.mule.DefaultMuleMessage
 
setOutboundProperty(String, Object, DataType<?>) - Method in class org.mule.DefaultMuleMessage
 
setOutboundRouterStat(RouterStatistics) - Method in class org.mule.management.stats.ServiceStatistics
Deprecated.
 
setOutboundTransformer(Transformer) - Method in class org.mule.transformer.wire.TransformerPairWireFormat
 
setOutFaultInterceptors(List<Interceptor<? extends Message>>) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setOutFaultInterceptors(List<Interceptor<? extends Message>>) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setOutInterceptors(List<Interceptor<? extends Message>>) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setOutInterceptors(List<Interceptor<? extends Message>>) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setOutput(String) - Method in class com.javaforge.bobber.archetype.model.Template
Set the output field.
setOutputAppend(boolean) - Method in class org.mule.transport.file.FileConnector
 
setOutputEncoding(String) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
setOutputMessage(String) - Method in class org.mule.transport.stdio.PromptStdioConnector
 
setOutputMessageCode(String) - Method in class org.mule.transport.stdio.PromptStdioConnector
 
setOutputPattern(String) - Method in class org.mule.transport.file.FileConnector
 
setOutputPattern(String) - Method in class org.mule.transport.ftp.FtpConnector
 
setOutputPattern(String) - Method in class org.mule.transport.sftp.SftpConnector
 
setOutputStream(OutputStream) - Method in class org.mule.module.cxf.support.DelegatingOutputStream
 
setOutputStream(FileOutputStream) - Method in class org.mule.transport.file.FileConnector
 
setOutputStream(OutputStream) - Method in class org.mule.transport.stdio.StdioConnector
 
setOutputType(String) - Method in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
 
setOverride(MessageProcessorPollingOverride) - Method in class org.mule.config.spring.factories.PollingMessageSourceFactoryBean
 
setOverride(Boolean) - Method in class org.mule.util.PropertyChecker
 
setOverrideHost(String) - Method in class org.mule.module.management.agent.FixedHostRmiClientSocketFactory
Deprecated.
Setter for property 'overrideHost'.
setOverrides(Properties) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
 
setOverwrite(boolean) - Method in class org.mule.config.spring.processors.MuleObjectNameProcessor
 
setOverwrite(boolean) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
setOwnerName(String) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setPackageNames(String) - Method in class org.mule.module.xml.config.JaxbContextFactoryBean
 
setPackages(Set<String>) - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
setPackagesToScan(String) - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
setPadText(boolean) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setParameterExtractors(List<ParameterExtractor>) - Method in class org.mule.module.oauth2.internal.authorizationcode.TokenResponseConfiguration
 
setParameterValue(PreparedStatement, int, Object) - Method in class org.mule.module.db.internal.domain.type.ArrayResolvedDbType
 
setParameterValue(PreparedStatement, int, Object) - Method in class org.mule.module.db.internal.domain.type.BlobResolvedDataType
 
setParameterValue(PreparedStatement, int, Object) - Method in class org.mule.module.db.internal.domain.type.ClobResolvedDataType
 
setParameterValue(PreparedStatement, int, Object) - Method in interface org.mule.module.db.internal.domain.type.DbType
Sets the value of an input parameter
setParameterValue(PreparedStatement, int, Object) - Method in class org.mule.module.db.internal.domain.type.DynamicDbType
 
setParameterValue(PreparedStatement, int, Object) - Method in class org.mule.module.db.internal.domain.type.oracle.OracleXmlType
 
setParameterValue(PreparedStatement, int, Object) - Method in class org.mule.module.db.internal.domain.type.ResolvedDbType
 
setParameterValue(PreparedStatement, int, Object) - Method in class org.mule.module.db.internal.domain.type.StructDbType
 
setParameterValue(PreparedStatement, int, Object) - Method in class org.mule.module.db.internal.domain.type.UnknownDbType
 
setParamName(String) - Method in class org.mule.module.oauth2.internal.ParameterExtractor
 
setParams(HttpConnectionParams) - Method in class org.apache.commons.httpclient.HttpConnection
Assigns HTTP protocol parameters for this method.
setParams(List<HttpParam>) - Method in class org.mule.module.http.internal.HttpMessageBuilder
 
setParams(List<AnnotationInfo.NameValue>) - Method in class org.mule.util.scan.annotations.AnnotationInfo
Deprecated.
 
setParent(MessageProcessorPathElement) - Method in class org.mule.api.processor.DefaultMessageProcessorPathElement
 
setParent(MessageProcessorPathElement) - Method in interface org.mule.api.processor.MessageProcessorPathElement
 
setParentContext(ApplicationContext) - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
setParserContext(ParserContext) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
setParseRequest(boolean) - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
setParseRequest(Boolean) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
setParseResponse(boolean) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setParseResponse(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setParseResponse(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setParseResponseExpression(String) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setPassive(boolean) - Method in class org.mule.transport.ftp.FtpConnector
Setter for FTP passive mode.
setPassphrase(String) - Method in class org.mule.transport.sftp.SftpConnector
 
setPassword(String) - Method in class org.mule.endpoint.URIBuilder
 
setPassword(String) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setPassword(String) - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
setPassword(String) - Method in class org.mule.module.http.api.requester.authentication.BasicAuthenticationBuilder
 
setPassword(String) - Method in class org.mule.module.http.api.requester.proxy.NtlmProxyConfigBuilder
 
setPassword(String) - Method in class org.mule.module.http.api.requester.proxy.ProxyConfigBuilder
 
setPassword(String) - Method in class org.mule.module.http.internal.domain.request.HttpRequestAuthentication
 
setPassword(String) - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
setPassword(String) - Method in class org.mule.module.http.internal.request.DefaultProxyConfig
 
setPassword(String) - Method in class org.mule.module.management.agent.Mx4jAgent
 
setPassword(String) - Method in class org.mule.module.ws.security.WssUsernameTokenSecurityStrategy
 
setPassword(String) - Method in class org.mule.security.PasswordBasedEncryptionStrategy
 
setPassword(String) - Method in class org.mule.security.UsernamePasswordAuthenticationFilter
 
setPassword(String) - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
setPassword(String) - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
setPassword(String) - Method in class org.mule.transport.jms.JmsConnector
 
setPassword(String) - Method in class org.mule.transport.sftp.config.SftpProxyConfig
 
setPassword(String) - Method in class org.mule.transport.xmpp.XmppConnector
 
setPasswordAuthenticator(PasswordAuthenticator) - Method in class org.mule.tck.util.sftp.SftpServer
 
setPasswordType(PasswordType) - Method in class org.mule.module.ws.security.WssUsernameTokenSecurityStrategy
 
setPath(String) - Method in class org.mule.endpoint.URIBuilder
 
setPath(String) - Method in class org.mule.module.http.api.listener.HttpListenerBuilder
 
setPath(String) - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
setPath(String) - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
setPath(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setPath(String) - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
Sets path
setPath(String) - Method in interface org.mule.security.oauth.callback.HttpCallbackAdapter
Sets path
setPath(String) - Method in class org.mule.transport.http.CookieWrapper
 
setPathInJar(String) - Method in class org.mule.module.management.agent.Mx4jAgent
 
setPattern(String) - Method in class org.mule.module.sxc.SxcFilter
 
setPattern(String) - Method in class org.mule.module.xml.filters.JaxenFilter
Deprecated.
 
setPattern(String) - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
 
setPattern(String) - Method in class org.mule.module.xml.filters.XPathFilter
 
setPattern(Object) - Method in class org.mule.routing.filters.EqualsFilter
 
setPattern(String) - Method in class org.mule.routing.filters.MessagePropertyFilter
 
setPattern(String) - Method in class org.mule.routing.filters.RegExFilter
 
setPattern(String) - Method in class org.mule.routing.filters.WildcardFilter
 
setPattern(String) - Method in class org.mule.transport.file.filters.FilenameRegexFilter
 
setPattern(String) - Method in class org.mule.transport.jms.filters.JmsPropertyFilter
Return the regex pattern to match on
setPattern(String) - Method in class org.mule.transport.xmpp.filters.XmppFromContainsFilter
 
setPayload(Object) - Method in interface org.mule.api.MuleMessage
Update the message payload.
setPayload(Object, DataType<?>) - Method in interface org.mule.api.MuleMessage
Updates the message payload.
setPayload(Object) - Method in class org.mule.DefaultMessageCollection
 
setPayload(Object, DataType) - Method in class org.mule.DefaultMessageCollection
 
setPayload(Object) - Method in class org.mule.DefaultMuleMessage
Update the message payload.
setPayload(Object, DataType<?>) - Method in class org.mule.DefaultMuleMessage
 
setPayload(Object) - Method in class org.mule.el.context.MessageContext
 
setPayload(Object) - Method in class org.mule.message.ExceptionMessage
 
setPayload(String) - Method in class org.mule.module.cxf.builder.ProxyClientMessageProcessorBuilder
 
setPayload(String) - Method in class org.mule.module.cxf.builder.ProxyServiceMessageProcessorBuilder
 
setPayload(Object) - Method in class org.mule.transport.quartz.jobs.EventGeneratorJobConfig
 
setPayloadClass(String) - Method in class org.mule.module.jbpm.MuleReceiveActivity
 
setPayloadExpression(String) - Method in class org.mule.module.jbpm.MuleSendActivity
 
SetPayloadMessageProcessor - Class in org.mule.transformer.simple
Modifies the payload of a MuleMessage according to the provided value.
SetPayloadMessageProcessor() - Constructor for class org.mule.transformer.simple.SetPayloadMessageProcessor
 
setPayloadParameterNames(List) - Method in class org.mule.transport.http.components.RestServiceWrapper
 
setPayloadToArguments(CxfPayloadToArguments) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setPayloadToArguments(CxfPayloadToArguments) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
SetPayloadTransformer - Class in org.mule.transformer.simple
Transformer that modifies the payload of the message according to the provided value.
SetPayloadTransformer() - Constructor for class org.mule.transformer.simple.SetPayloadTransformer
 
setPersistent(boolean) - Method in class org.mule.util.store.ManagedObjectStore
 
setPersistentDelivery(boolean) - Method in class org.mule.transport.jms.JmsConnector
 
setPersistentStores(boolean) - Method in class org.mule.routing.AbstractAggregator
 
setPerson(Person) - Method in class org.mule.tck.testmodels.services.PersonResponse
 
setPgpOutputMode(PGPOutputMode) - Method in class org.mule.module.pgp.KeyBasedEncryptionStrategy
 
setPluginClassLoaderManager(PluginClassLoaderManager) - Method in class org.mule.module.launcher.coreextension.DefaultMuleCoreExtensionManager
 
setPluginClassLoaderManager(PluginClassLoaderManager) - Method in interface org.mule.module.launcher.PluginClassLoaderManagerAware
 
setPlugins(Set<PluginDescriptor>) - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
setPollingController(PollingController) - Method in class org.mule.DefaultMuleContext
 
setPollingFrequency(long) - Method in class org.mule.transport.file.FileConnector
 
setPollingFrequency(long) - Method in class org.mule.transport.ftp.FtpConnector
 
setPollingFrequency(long) - Method in class org.mule.transport.http.HttpPollingConnector
 
setPollingFrequency(long) - Method in class org.mule.transport.http.HttpsPollingConnector
 
setPollingFrequency(long) - Method in class org.mule.transport.jdbc.JdbcConnector
 
setPollingFrequency(long) - Method in class org.mule.transport.rmi.RmiConnector
 
setPollingFrequency(long) - Method in class org.mule.transport.sftp.SftpConnector
 
setPollingFrequency(long) - Method in class org.mule.transport.tcp.PollingTcpConnector
 
setPoolExhaustedAction(int) - Method in interface org.mule.api.config.ThreadingProfile
 
setPoolExhaustedAction(int) - Method in class org.mule.config.ChainedThreadingProfile
 
setPoolExhaustedAction(int) - Method in class org.mule.config.ImmutableThreadingProfile
 
setPoolExhaustedAction(int) - Method in class org.mule.config.MutableThreadingProfile
 
setPoolExhaustedAction(Integer) - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
setPoolingProfile(PoolingProfile) - Method in class org.mule.component.PooledJavaComponent
 
setPoolingProfile(PoolingProfile) - Method in class org.mule.model.seda.SedaModel
Deprecated.
 
setPoolingProfile(DbPoolingProfile) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setPoolingProfile(DbPoolingProfile) - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
setPort(int) - Method in class org.apache.commons.httpclient.HttpConnection
Sets the port to connect to.
setPort(int) - Method in class org.mule.endpoint.URIBuilder
For backwards compatibility
setPort(String) - Method in class org.mule.endpoint.URIBuilder
Allows ports to be Mule expressions
setPort(String) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setPort(String) - Method in class org.mule.module.cxf.builder.JaxWsClientMessageProcessorBuilder
 
setPort(String) - Method in class org.mule.module.cxf.builder.WsdlClientMessageProcessorBuilder
 
setPort(int) - Method in class org.mule.module.db.internal.config.domain.database.AbstractVendorConfigResolverFactoryBean
 
setPort(int) - Method in class org.mule.module.http.api.listener.HttpListenerBuilder
 
setPort(int) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setPort(int) - Method in class org.mule.module.http.api.requester.proxy.NtlmProxyConfigBuilder
 
setPort(int) - Method in class org.mule.module.http.api.requester.proxy.ProxyConfigBuilder
 
setPort(int) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
setPort(int) - Method in class org.mule.module.http.internal.listener.HttpListenerConfigBuilder
 
setPort(String) - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
setPort(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setPort(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setPort(int) - Method in class org.mule.module.http.internal.request.DefaultProxyConfig
 
setPort(String) - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
 
setPort(String) - Method in class org.mule.module.management.agent.JdmkAgent
 
setPort(String) - Method in class org.mule.module.management.agent.Mx4jAgent
 
setPort(String) - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
setPort(String) - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
setPort(int) - Method in class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
setPort(int) - Method in class org.mule.transport.jdbc.config.OracleDataSourceFactoryBean
 
setPort(int) - Method in class org.mule.transport.servlet.jetty.WebappsConfiguration
 
setPort(int) - Method in class org.mule.transport.sftp.config.SftpProxyConfig
 
setPort(int) - Method in class org.mule.transport.sftp.SftpClient
 
setPort(int) - Method in class org.mule.transport.xmpp.XmppConnector
 
setPortExpression(String) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setPostcode(String) - Method in class org.mule.tck.testmodels.services.Address
 
setPostfix(String) - Method in class org.mule.component.simple.StaticComponent
 
setPostNotification(ServerNotification) - Method in class org.mule.lifecycle.LifecycleObject
 
setPostNotificationName(String) - Method in class org.mule.lifecycle.NotificationLifecycleObject
 
setPreemptive(boolean) - Method in class org.mule.module.http.api.requester.authentication.BasicAuthenticationBuilder
 
setPreemptive(boolean) - Method in class org.mule.module.http.internal.domain.request.HttpRequestAuthentication
 
setPreemptive(String) - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
setPreemptiveExpression(String) - Method in class org.mule.module.http.api.requester.authentication.BasicAuthenticationBuilder
 
setPreferredAuthenticationMethods(String) - Method in class org.mule.transport.sftp.SftpClient
 
setPreferredAuthenticationMethods(String) - Method in class org.mule.transport.sftp.SftpConnectionFactory
 
setPreferredAuthenticationMethods(String) - Method in class org.mule.transport.sftp.SftpConnector
 
setPrefix(String) - Method in class org.mule.component.simple.StaticComponent
 
setPreNotification(ServerNotification) - Method in class org.mule.lifecycle.LifecycleObject
 
setPreNotificationName(String) - Method in class org.mule.lifecycle.NotificationLifecycleObject
 
setPreparedStatementCacheSize(int) - Method in class org.mule.module.db.internal.domain.connection.DbPoolingProfile
 
setPrintHeaders(boolean) - Method in class org.mule.management.stats.printers.CSVPrinter
 
setPriorityWeighting(int) - Method in interface org.mule.api.transformer.Converter
If 2 or more discoverable transformers are equal, this value can be used to select the correct one
setPriorityWeighting(int) - Method in class org.mule.config.transformer.AnnotatedTransformerProxy
 
setPriorityWeighting(int) - Method in class org.mule.module.json.transformers.AbstractJsonTransformer
 
setPriorityWeighting(int) - Method in class org.mule.module.xml.transformer.DomDocumentToXml
 
setPriorityWeighting(int) - Method in class org.mule.module.xml.transformer.XmlToDomDocument
 
setPriorityWeighting(int) - Method in class org.mule.module.xml.transformer.XmlToOutputHandler
 
setPriorityWeighting(int) - Method in class org.mule.module.xml.transformer.XmlToXMLStreamReader
 
setPriorityWeighting(int) - Method in class org.mule.transformer.AbstractDiscoverableTransformer
 
setPriorityWeighting(int) - Method in class org.mule.transformer.CompositeConverter
 
setPriorityWeighting(int) - Method in class org.mule.transformer.simple.BeanToMap
 
setPriorityWeighting(int) - Method in class org.mule.transformer.simple.ByteArrayToSerializable
 
setPriorityWeighting(int) - Method in class org.mule.transformer.simple.MapToBean
 
setPriorityWeighting(int) - Method in class org.mule.transformer.simple.NumberToString
 
setPriorityWeighting(int) - Method in class org.mule.transformer.simple.ObjectArrayToString
 
setPriorityWeighting(int) - Method in class org.mule.transformer.simple.ObjectToOutputHandler
 
setPriorityWeighting(int) - Method in class org.mule.transformer.simple.ObjectToString
 
setPriorityWeighting(int) - Method in class org.mule.transformer.simple.PropertyEditorTextToValueTransformer
 
setPriorityWeighting(int) - Method in class org.mule.transformer.simple.PropertyEditorValueToTextTransformer
 
setPriorityWeighting(int) - Method in class org.mule.transformer.simple.SerializableToByteArray
 
setPriorityWeighting(int) - Method in class org.mule.transformer.simple.StringToBoolean
 
setPriorityWeighting(int) - Method in class org.mule.transformer.simple.StringToNumber
 
setPriorityWeighting(int) - Method in class org.mule.transport.file.transformers.FileToByteArray
 
setPriorityWeighting(int) - Method in class org.mule.transport.http.transformers.ServletRequestToOutputHandler
If 2 or more discoverable transformers are equal, this value can be used to select the correct one
setPriorityWeighting(int) - Method in class org.mule.transport.jms.transformers.AbstractJmsTransformer
 
setProcess(Process) - Method in class org.mule.test.infrastructure.process.TestProcess
 
setProcessDefinitions(Properties) - Method in class org.mule.module.jbpm.Jbpm
 
setProcessedEvent(MuleEvent) - Method in exception org.mule.api.MessagingException
Sets the event that should be processed once this exception is caught
setProcessedGroupsObjectStore(ObjectStore<Long>) - Method in class org.mule.routing.AbstractAggregator
 
setProcessEngine(ProcessEngine) - Method in class org.mule.module.jbpm.Jbpm
 
setProcessIdField(String) - Method in class org.mule.module.bpm.ProcessComponent
 
setProcessingStrategy(ProcessingStrategy) - Method in interface org.mule.api.construct.Pipeline
 
setProcessingStrategy(ProcessingStrategy) - Method in class org.mule.config.spring.factories.AsyncMessageProcessorsFactoryBean
 
setProcessingStrategy(ProcessingStrategy) - Method in class org.mule.construct.AbstractConfigurationPattern
 
setProcessingStrategy(ProcessingStrategy) - Method in class org.mule.construct.AbstractPipeline
 
setProcessor(MessageProcessor) - Method in class org.mule.processor.ResponseMessageProcessorAdapter
 
setPromptMessage(String) - Method in class org.mule.transport.stdio.PromptStdioConnector
 
setPromptMessageCode(String) - Method in class org.mule.transport.stdio.PromptStdioConnector
 
setPropagateMuleProperties(boolean) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setProperties(Map<Object, Object>) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setProperties(Map<String, Object>) - Method in interface org.mule.api.security.Authentication
 
setProperties(Map) - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
setProperties(Map<Object, Object>) - Method in class org.mule.endpoint.AbstractEndpointBuilder
NOTE - this appends properties.
setProperties(Map<Object, Object>) - Method in class org.mule.endpoint.AbstractMetaEndpointBuilder
 
setProperties(Map<String, Object>) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setProperties(Map<String, Object>) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setProperties(Map<String, Object>) - Method in class org.mule.module.jaas.JaasAuthentication
 
setProperties(Map<String, String>) - Method in class org.mule.module.jboss.transaction.JBossArjunaTransactionManagerFactory
 
setProperties(Map<String, Object>) - Method in class org.mule.module.jersey.JerseyResourcesComponent
 
setProperties(Map<String, Object>) - Method in class org.mule.module.pgp.PGPAuthentication
 
setProperties(Properties) - Method in class org.mule.module.scripting.component.Scriptable
 
setProperties(Map<String, Object>) - Method in class org.mule.module.spring.security.SpringAuthenticationAdapter
 
setProperties(Map) - Method in class org.mule.object.AbstractObjectFactory
 
setProperties(Map) - Method in class org.mule.object.JndiObjectFactory
 
setProperties(Map<String, Object>) - Method in class org.mule.security.DefaultMuleAuthentication
 
setProperties(Map) - Static method in class org.mule.transport.soap.axis.AxisServiceProxy
 
setProperties(Map<String, Object>) - Method in class org.mule.transport.soap.axis.component.WebServiceWrapperComponent
 
setPropertiesFromFile(MuleMessage, File) - Method in class org.mule.transport.file.FileMuleMessageFactory
 
setPropertiesFromProperties(Map<Object, Object>) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setProperty(Object, Object) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setProperty(String, Object) - Method in interface org.mule.api.MuleMessage
Deprecated.
use MuleMessage.setProperty(String, Object, org.mule.api.transport.PropertyScope) or preferrably any of the scope-specific set methods.
setProperty(String, Object, PropertyScope) - Method in interface org.mule.api.MuleMessage
Set a property on the message.
setProperty(String, Object, PropertyScope, DataType<?>) - Method in interface org.mule.api.MuleMessage
Sets a property on the message
setProperty(String, Serializable) - Method in interface org.mule.api.MuleSession
Will set a session scope property.
setProperty(String, Serializable, DataType<?>) - Method in interface org.mule.api.MuleSession
Will set a session scope property.
setProperty(String, Object) - Method in interface org.mule.api.MuleSession
Deprecated.
setProperty(String, Object, PropertyScope) - Method in class org.mule.DefaultMuleMessage
Set a property on the message.
setProperty(String, Object, PropertyScope, DataType<?>) - Method in class org.mule.DefaultMuleMessage
 
setProperty(String, Object) - Method in class org.mule.DefaultMuleMessage
Deprecated.
use DefaultMuleMessage.setProperty(String, Object, org.mule.api.transport.PropertyScope) or preferrably any of the scope-specific set methods.
setProperty(Object, Object) - Method in class org.mule.endpoint.AbstractEndpointBuilder
Sets a property on the endpoint
setProperty(String, Object) - Method in class org.mule.message.ExceptionMessage
 
setProperty(String, Object) - Method in class org.mule.MessagePropertiesContext
setProperty(String, Object, PropertyScope) - Method in class org.mule.MessagePropertiesContext
Set a property on the message
setProperty(String, Object, PropertyScope, DataType<?>) - Method in class org.mule.MessagePropertiesContext
Set a property on the message
setProperty(String, Object) - Method in class org.mule.module.client.MuleClient
 
setProperty(Object, Object) - Method in class org.mule.module.client.remoting.notification.RemoteDispatcherNotification
Deprecated.
 
setProperty(Object, Object) - Method in class org.mule.module.spring.events.MuleApplicationEvent
Deprecated.
 
setProperty(String, Object) - Method in class org.mule.module.xml.stax.StaxSource.PseudoReader
 
setProperty(String, Object) - Method in class org.mule.session.DefaultMuleSession
Will set a session level property.
setProperty(String, Serializable) - Method in class org.mule.session.DefaultMuleSession
 
setProperty(String, Serializable, DataType<?>) - Method in class org.mule.session.DefaultMuleSession
 
setProperty(String, Object) - Method in class org.mule.transport.soap.axis.AxisStringWriter
 
setPropertyClass(String) - Method in class org.mule.transport.jms.filters.JmsPropertyFilter
Sets the class type of the property
setPropertyFromEndpoint(MuleEvent, MuleMessage, String) - Method in class org.mule.transport.http.HttpClientMessageDispatcher
 
setPropertyName(String) - Method in class org.mule.transformer.simple.AddPropertyTransformer
 
setPropertyName(String) - Method in class org.mule.transformer.simple.CopyPropertiesTransformer
 
setPropertyName(String) - Method in class org.mule.transformer.simple.GetBeanProperty
 
setPropertyName(String) - Method in class org.mule.transformer.simple.RemovePropertyTransformer
 
setPropertyName(String) - Method in class org.mule.transport.jms.filters.JmsPropertyFilter
Sets the name of the property
setProtocol(Protocol) - Method in class org.apache.commons.httpclient.HttpConnection
Sets the protocol used to establish the connection
setProtocol(String) - Method in class org.mule.endpoint.URIBuilder
 
setProtocol(HttpConstants.Protocols) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setProtocol(HttpConstants.Protocols) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
setProtocol(String) - Method in class org.mule.module.http.internal.listener.HttpMessagePropertiesResolver
 
setProtocol(HttpConstants.Protocols) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setProtocol(String) - Method in class org.mule.transport.sftp.config.SftpProxyConfig
 
setProvider(Provider) - Method in class org.mule.module.atom.AbderaServiceComponent
 
setProviders(Collection<SecurityProvider>) - Method in interface org.mule.api.security.SecurityManager
 
setProviders(Collection<SecurityProvider>) - Method in class org.mule.security.MuleSecurityManager
 
setProxy(boolean) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
setProxy(boolean) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
 
setProxyConfig(ProxyConfig) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
setProxyConfig(ProxyConfig) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setProxyConfig(ProxyConfig) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setProxyConfig(ProxyConfig) - Method in class org.mule.module.ws.consumer.MuleWSDLLocatorConfig.Builder
 
setProxyConfig(SftpProxyConfig) - Method in class org.mule.transport.sftp.SftpClient
 
setProxyConfig(SftpProxyConfig) - Method in class org.mule.transport.sftp.SftpConnectionFactory
 
setProxyConfig(SftpProxyConfig) - Method in class org.mule.transport.sftp.SftpConnector
 
setProxyHost(String) - Method in class org.apache.commons.httpclient.HttpConnection
Sets the host to proxy through.
setProxyHostname(String) - Method in class org.mule.transport.http.HttpConnector
 
setProxyNtlmAuthentication(boolean) - Method in class org.mule.transport.http.HttpConnector
 
setProxyPassword(String) - Method in class org.mule.transport.http.HttpConnector
 
setProxyPort(int) - Method in class org.apache.commons.httpclient.HttpConnection
Sets the port of the host to proxy through.
setProxyPort(int) - Method in class org.mule.transport.http.HttpConnector
 
setProxyUsername(String) - Method in class org.mule.transport.http.HttpConnector
 
setPublicId(String) - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
setPublicKey(PGPPublicKey) - Method in class org.mule.module.pgp.PGPCryptInfo
 
setPublicKeyRingFileName(String) - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
setQuartzScheduler(Scheduler) - Method in class org.mule.transport.quartz.QuartzConnector
 
setQueries(Map) - Method in class org.mule.transport.jdbc.JdbcConnector
 
setQueryLoggerFactory(QueryLoggerFactory) - Method in class org.mule.module.db.internal.domain.executor.AbstractExecutor
 
setQueryMap(Map) - Method in class org.mule.endpoint.URIBuilder
 
setQueryMetadataProvider(QueryMetadataProvider) - Method in class org.mule.module.db.internal.config.processor.BulkUpdateMessageProcessorFactoryBean
 
setQueryMetadataProvider(QueryMetadataProvider) - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
setQueryParams(ParameterMap) - Method in class org.mule.module.http.internal.domain.request.HttpRequestBuilder
 
setQueryRunner(QueryRunner) - Method in class org.mule.transport.jdbc.JdbcConnector
 
setQueryTimeout(int) - Method in interface org.mule.module.db.internal.domain.statement.ConfigurableStatementFactory
Indicates the minimum amount of time in seconds before the JDBC driver attempts to cancel a running statement.
setQueryTimeout(int) - Method in class org.mule.module.db.internal.domain.statement.QueryStatementFactory
 
setQueryTimeout(int) - Method in class org.mule.transport.jdbc.JdbcConnector
 
setQueueConfiguration(String, QueueConfiguration) - Method in class org.mule.util.queue.AbstractQueueManager
Specifies a QueueConfiguration for the queue which name matches queueName
setQueueConfiguration(String, QueueConfiguration) - Method in class org.mule.util.queue.DelegateQueueManager
 
setQueueConfiguration(String, QueueConfiguration) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
Specifies a QueueConfiguration for the queue which name matches queueName
setQueueConfiguration(String, QueueConfiguration) - Method in interface org.mule.util.queue.QueueManager
Specifies a QueueConfiguration for the queue which name matches queueName
setQueueManager(QueueManager) - Method in interface org.mule.api.MuleContext
Sets the queue manager used by mule for queuing events.
setQueueManager(QueueManager) - Method in class org.mule.DefaultMuleContext
 
setQueueProfile(QueueProfile) - Method in class org.mule.model.seda.SedaModel
Deprecated.
 
setQueueProfile(QueueProfile) - Method in class org.mule.model.seda.SedaService
Deprecated.
 
setQueueProfile(QueueProfile) - Method in class org.mule.transport.vm.VMConnector
 
setQueueStatistics(QueueStatistics) - Method in interface org.mule.management.stats.QueueStatisticsAware
 
setQueueStatistics(QueueStatistics) - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
setQueueStore(QueueStore<Serializable>) - Method in class org.mule.config.QueueProfile
 
setQueueStore(QueueStore<Serializable>) - Method in class org.mule.config.spring.factories.QueueProfileFactoryBean
 
setQueueStore(QueueStore<Serializable>) - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
setQueueTimeout(int) - Method in class org.mule.model.seda.SedaModel
Deprecated.
 
setQueueTimeout(Integer) - Method in class org.mule.model.seda.SedaService
Deprecated.
 
setQueueTimeout(Integer) - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
 
setQueueTimeout(int) - Method in class org.mule.transport.vm.VMConnector
 
setQueueWindowSize(int) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setRadius(Double) - Method in class org.mule.tck.testmodels.fruit.FloridaSunnyOrangeFactoryBean
 
setRandomiseRNames(boolean) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setRawValue(double) - Method in interface org.mule.util.counters.Counter
Set the counter's value to a new value.
setRawValue(double) - Method in class org.mule.util.counters.impl.AbstractCounter
 
setRawValue(double) - Method in class org.mule.util.counters.impl.AggregateCounter
 
setRawValue(double) - Method in class org.mule.util.counters.impl.Number
 
setReadFromDirectory(String) - Method in class org.mule.transport.file.FileConnector
 
setReadOnly(boolean) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
setReadOnly(boolean) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setReadOnly(boolean) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setRealm(String) - Method in class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
 
setRealmRequired(boolean) - Method in class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
 
setRealmURL(String) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setReasonPhrase(String) - Method in class org.mule.module.http.internal.domain.response.DefaultHttpResponse
 
setReasonPhrase(String) - Method in interface org.mule.module.http.internal.domain.response.HttpResponse
 
setReasonPhrase(String) - Method in class org.mule.module.http.internal.domain.response.HttpResponseBuilder
 
setReasonPhrase(String) - Method in class org.mule.module.http.internal.domain.response.ResponseStatus
 
setReasonPhrase(String) - Method in class org.mule.module.http.internal.listener.HttpResponseBuilder
 
setReceiveBacklog(Integer) - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
setReceiveBacklog(int) - Method in class org.mule.transport.tcp.TcpConnector
 
setReceiveBufferSize(Integer) - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
setReceiveBufferSize(Integer) - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
setReceiveBufferSize(int) - Method in class org.mule.transport.tcp.TcpConnector
 
setReceiveBufferSize(int) - Method in class org.mule.transport.udp.UdpConnector
 
setReceiveMessagesInTransaction(boolean) - Method in class org.mule.transport.TransactedPollingMessageReceiver
 
setReceiver(RmiMessageReceiver) - Method in interface org.mule.transport.rmi.RmiAble
Set Mule receiver as parameter for callback
setReceiverKey(String) - Method in interface org.mule.api.transport.MessageReceiver
 
setReceiverKey(String) - Method in class org.mule.transport.AbstractMessageReceiver
 
setReceiverServlet(JettyReceiverServlet) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
setReceiverThreadingProfile(ThreadingProfile) - Method in class org.mule.transport.AbstractConnector
Setter for property 'receiverThreadingProfile'.
setRecipients(List<?>) - Method in class org.mule.routing.outbound.StaticRecipientList
Deprecated.
 
setRecursive(boolean) - Method in class org.mule.transport.file.FileConnector
 
setRedeliveryExceeded(RedeliveryExceeded) - Method in class org.mule.exception.RollbackMessagingExceptionStrategy
 
setRedeliveryHandlerFactory(RedeliveryHandlerFactory) - Method in class org.mule.transport.jms.JmsConnector
 
setRedeliveryPolicy(AbstractRedeliveryPolicy) - Method in class org.mule.config.spring.factories.OutboundEndpointFactoryBean
 
setRedeliveryPolicy(AbstractRedeliveryPolicy) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setRedeploymentEnabled(boolean) - Method in class org.mule.module.launcher.descriptor.ArtifactDescriptor
 
setRedirectionUrl(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
setRedirectUri(String) - Method in class org.mule.security.oauth.processor.FetchAccessTokenMessageProcessor
Sets redirectUri
setRedirectUrl(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestUrlBuilder
 
setRef(AggregationStrategy) - Method in class org.mule.config.spring.factories.AggregationStrategyDefinitionParser.AggregationStrategyDelegate
 
setRef(String) - Method in class org.mule.config.spring.parsers.specific.DataObjectDefinitionParser.DataObjectFactoryBean
 
setRef(WsSecurity) - Method in class org.mule.module.cxf.config.WsSecurity
 
setRef(HttpMessageBuilder) - Method in class org.mule.module.http.internal.HttpMessageBuilderRef
 
setRef(BeanDefinitionBuilder, String, String) - Method in class org.mule.security.oauth.config.AbstractDevkitBasedDefinitionParser
 
setReference() - Method in interface org.mule.config.spring.parsers.assembly.configuration.SingleProperty
 
setReference() - Method in class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyLiteral
 
setReference() - Method in class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyWrapper
 
setRefreshableBean(Object) - Method in class org.mule.module.scripting.component.GroovyRefreshableBeanBuilder
 
setRefreshedTokensStore(ObjectStore<Boolean>) - Method in class org.mule.security.oauth.DefaultRefreshTokenManager
 
setRefreshedTokensStore(ObjectStore<Boolean>) - Method in interface org.mule.security.oauth.RefreshTokenManager
Sets the ObjectStore to use for the tokens refresh state.
setRefreshToken(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
setRefreshToken(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.TokenResponseConfiguration
 
setRefreshToken(String) - Method in interface org.mule.security.oauth.OAuth2Adapter
Set refresh token
setRefreshTokenManager(RefreshTokenManager) - Method in class org.mule.security.oauth.BaseOAuth2Manager
 
setRefreshTokenWhen(String) - Method in class org.mule.module.oauth2.internal.AbstractTokenRequestHandler
 
setRefreshUserOAuthContextLock(Lock) - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
setRefsThreshold(int) - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
setRefsThreshold(int) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setRegisterTraceInterceptor(boolean) - Method in class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
setRegistry(BeanDefinitionRegistry) - Method in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
setRegistry(MuleRegistry) - Method in class org.mule.module.oauth2.internal.mel.OAuthContextExpressionLanguageFunction
 
setRegistryBroker(DefaultRegistryBroker) - Method in class org.mule.DefaultMuleContext
 
setRegistryId(String) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setRegistryId(String) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setRejectedExecutionHandler(RejectedExecutionHandler) - Method in interface org.mule.api.config.ThreadingProfile
 
setRejectedExecutionHandler(RejectedExecutionHandler) - Method in class org.mule.config.ChainedThreadingProfile
 
setRejectedExecutionHandler(RejectedExecutionHandler) - Method in class org.mule.config.ImmutableThreadingProfile
 
setRejectedExecutionHandler(RejectedExecutionHandler) - Method in class org.mule.config.MutableThreadingProfile
 
setRemoteHostAddress(String) - Method in class org.mule.module.http.internal.listener.HttpMessagePropertiesResolver
 
setRemoteInvocationExecutor(RemoteInvocationExecutor) - Method in class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
setRemotePort(Integer) - Method in class org.mule.security.oauth.callback.DefaultHttpCallbackAdapter
Sets remotePort
setRemotePort(Integer) - Method in interface org.mule.security.oauth.callback.HttpCallbackAdapter
Sets remotePort
setRenameProperties(Map<String, String>) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
setReplyProcessor(MessageProcessor) - Method in interface org.mule.api.processor.RequestReplyReplierMessageProcessor
 
setReplyProcessor(MessageProcessor) - Method in class org.mule.routing.requestreply.AbstractReplyToPropertyRequestReplyReplier
 
setReplyProcessor(MessageProcessor) - Method in class org.mule.routing.requestreply.SimpleRequestReplyReplier
 
setReplySource(MessageSource) - Method in interface org.mule.api.processor.RequestReplyRequesterMessageProcessor
 
setReplySource(MessageSource) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
setReplyTo(Object) - Method in interface org.mule.api.MuleMessage
Sets a replyTo address for this message.
setReplyTo(String) - Method in interface org.mule.api.routing.OutboundRouter
Sets the replyTo route for any outgoing messages.
setReplyTo(Object) - Method in class org.mule.DefaultMuleMessage
Sets a replyTo address for this message.
setReplyTo(String) - Method in class org.mule.el.context.MessageContext
 
setReplyTo(String) - Method in class org.mule.module.cxf.MuleSoapHeaders
 
setReplyTo(String) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
setReplyToAddresses(String) - Method in class org.mule.transport.email.SmtpConnector
 
setRequestAvailable(boolean) - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
setRequestAvailable(boolean) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setRequestBuilder(HttpRequesterRequestBuilder) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setRequesterFactory(MessageRequesterFactory) - Method in interface org.mule.api.transport.Connector
The requester factory is used to create a message requester of the current request
setRequesterFactory(MessageRequesterFactory) - Method in class org.mule.transport.AbstractConnector
 
setRequesterPoolMaxWait(int) - Method in class org.mule.transport.AbstractConnector
Allows a maxWait timeout to be configured on the requester object pool See: GenericKeyedObjectPool.setMaxWait(long)
setRequesterPoolWhenExhaustedAction(byte) - Method in class org.mule.transport.AbstractConnector
Allows an ExhaustedAction to be configured on the requester object pool See: GenericKeyedObjectPool.setWhenExhaustedAction(byte)
setRequesterThreadingProfile(ThreadingProfile) - Method in class org.mule.transport.AbstractConnector
Setter for property 'requesterThreadingProfile'.
setRequestLine(RequestLine) - Method in class org.mule.transport.http.HttpRequest
 
setRequestStreamingMode(HttpStreamingType) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setRequestStreamingMode(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setRequestStreamingMode(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setRequestStreamingModeExpression(String) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setRequestToken(String) - Method in interface org.mule.security.oauth.OAuth1Adapter
Sets the request token
setRequestTokenSecret(String) - Method in interface org.mule.security.oauth.OAuth1Adapter
Sets the request token secret
setRequestTokenUrl(String) - Method in interface org.mule.security.oauth.OAuth1Adapter
Sets requestTokenUrl
setRequestTokenUrl(String) - Method in class org.mule.security.oauth.processor.BaseOAuth1AuthorizeMessageProcessor
Sets requestTokenUrl
setRequestTokenUrl(String) - Method in class org.mule.security.oauth.processor.OAuth1FetchAccessTokenMessageProcessor
Sets requestTokenUrl
setRequireClientAuthentication(boolean) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setRequireClientAuthentication(boolean) - Method in interface org.mule.api.security.TlsDirectTrustStore
If a server socket is constructed directly (see TlsConfiguration) then this flag will control whether client authenticatin is required.
setRequireClientAuthentication(boolean) - Method in class org.mule.transport.http.HttpsConnector
 
setRequireClientAuthentication(boolean) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setRequiredAuthorities(String) - Method in class org.mule.module.spring.security.AuthorizationFilter
 
setRequiredParams(Map) - Method in class org.mule.transport.http.components.RestServiceWrapper
Required params that are pulled from the message.
setResolvedDomain(String) - Method in class org.mule.module.management.support.JmxRegistrationContext
Setter for property 'resolvedDomain'.
setResource(String) - Method in class org.mule.module.bpm.ProcessComponent
 
setResource(String) - Method in class org.mule.module.bpm.RulesComponent
 
setResource(String) - Method in class org.mule.transport.xmpp.XmppConnector
 
setResourceBase(String) - Method in class org.mule.transport.http.components.StaticResourceMessageProcessor
 
setResourceBase(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
setResourceBundle(String) - Method in class org.mule.transport.stdio.PromptStdioConnector
 
setResourceOwnerId(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
setResourceOwnerId(String) - Method in class org.mule.module.oauth2.internal.tokenmanager.InvalidateOauthContextMessageProcessor
 
setResourceReleaserClassLocation(String) - Method in class org.mule.module.launcher.artifact.AbstractArtifactClassLoader
 
setResourceResolver(LSResourceResolver) - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
setResourceResolver(LSResourceResolver) - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
setResourceResolver(LSResourceResolver) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
setResourceResolver(LSResourceResolver) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
setResponseBufferSize(int) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setResponseBufferSize(int) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setResponseBuilder(HttpResponseBuilder) - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
setResponseCount(int) - Method in class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
setResponseExpression(String) - Method in class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
setResponseMessageProcessors(List<MessageProcessor>) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setResponseMessageProcessors(List<MessageProcessor>) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setResponsePayloadClass(String) - Method in class org.mule.module.jbpm.MuleSendActivity
 
setResponseSameThread(boolean) - Method in class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
setResponseStreaming(HttpStreamingType) - Method in class org.mule.module.http.internal.listener.HttpResponseBuilder
 
setResponseStreamingMode(HttpStreamingType) - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
setResponseTimeout(int) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setResponseTimeout(int) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setResponseTimeout(int) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setResponseTimeout(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setResponseTimeout(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setResponseTimeout(int) - Method in class org.mule.transport.ftp.FtpConnectionFactory
 
setResponseTimeoutExpression(String) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setResponseTransformers(List<Transformer>) - Method in interface org.mule.api.endpoint.EndpointBuilder
Deprecated.
Use setResponseMessageProcessors()
setResponseTransformers(Transformer...) - Method in class org.mule.config.spring.factories.BridgeFactoryBean
 
setResponseTransformers(Transformer...) - Method in class org.mule.config.spring.factories.SimpleServiceFactoryBean
 
setResponseTransformers(List<Transformer>) - Method in class org.mule.endpoint.AbstractEndpointBuilder
Deprecated.
Use setResponseMessageProcessors()
setResponseTransformers(Transformer...) - Method in class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
setResponseTransformers(Transformer...) - Method in class org.mule.transport.http.config.spring.factories.HttpProxyFactoryBean
 
setResponseValidator(ResponseValidator) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setResponseVariableName(String) - Method in class org.mule.module.jbpm.MuleSendActivity
 
setResultAggregator(RouterResultsHandler) - Method in class org.mule.routing.DynamicAll
 
setResultSetHandler(ResultSetHandler) - Method in class org.mule.transport.jdbc.JdbcConnector
 
setResultsHandler(RouterResultsHandler) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
setResultType(XPathReturnType) - Method in class org.mule.module.xml.transformer.XPathExtractor
Result type from this transformer.
setRethrowExceptionOnRead(boolean) - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
 
setRetryCommit(boolean) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setRetryPolicyTemplate(RetryPolicyTemplate) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setRetryPolicyTemplate(RetryPolicyTemplate) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setRetryPolicyTemplate(RetryPolicyTemplate) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setRetryPolicyTemplate(RetryPolicyTemplate) - Method in interface org.mule.module.db.internal.domain.database.ConfigurableDbConfigFactory
Sets the retry policy template for the created DbConfig
setRetryPolicyTemplate(RetryPolicyTemplate) - Method in class org.mule.module.db.internal.domain.database.GenericDbConfigFactory
 
setRetryPolicyTemplate(RetryPolicyTemplate) - Method in class org.mule.transport.AbstractConnector
 
setReturnClass(Class<?>) - Method in interface org.mule.api.transformer.Transformer
setReturnClass(Class<?>) - Method in class org.mule.transformer.AbstractTransformer
Deprecated.
setReturnClass(Class<?>) - Method in class org.mule.transformer.CompositeConverter
 
setReturnClass(String) - Method in class org.mule.transformer.simple.SetPayloadMessageProcessor
 
setReturnData(Object) - Method in class org.mule.tck.functional.FunctionalTestComponent
Often you will may want to return a fixed message payload to simulate and external system call.
setReturnDataType(DataType<?>) - Method in interface org.mule.api.transformer.Transformer
Sets the expected return type for the transformed data.
setReturnDataType(Class<?>) - Method in class org.mule.expression.transformers.ExpressionArgument
 
setReturnDataType(DataType<?>) - Method in class org.mule.transformer.AbstractTransformer
 
setReturnDataType(DataType<?>) - Method in class org.mule.transformer.CompositeConverter
 
setReturnDataType(DataType<?>) - Method in class org.mule.transformer.simple.StringToBoolean
 
setReturnDataType(DataType<?>) - Method in class org.mule.transformer.simple.StringToNumber
 
setReturnDataType(Class<?>) - Method in class org.mule.transport.soap.axis.SoapMethod
 
setReturnFirstResult(boolean) - Method in class org.mule.config.spring.parsers.delegate.AbstractFirstResultSerialDefinitionParser
 
setReturnMessages(MuleMessage[]) - Method in interface org.mule.api.retry.RetryContext
 
setReturnMessages(MuleMessage[]) - Method in class org.mule.retry.async.FutureRetryContext
 
setReturnMessages(MuleMessage[]) - Method in class org.mule.retry.DefaultRetryContext
 
setReturnOriginalMessageAsReply(boolean) - Method in class org.mule.transport.jms.JmsConnector
 
setReturnResult(boolean) - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
setReturnResult(boolean) - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
setReturnResult(boolean) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
setReturnResult(boolean) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
setReturnSourceIfNull(boolean) - Method in class org.mule.expression.transformers.ExpressionTransformer
 
setReturnType(QName) - Method in class org.mule.module.xml.expression.JaxpXPathExpressionEvaluator
Deprecated.
 
setReturnType(QName) - Method in class org.mule.transport.soap.axis.SoapMethod
 
setReuseAddress(Boolean) - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
setReuseAddress(Boolean) - Method in class org.mule.transport.tcp.TcpConnector
This allows closed sockets to be reused while they are still in TIME_WAIT state
setReuseObject(boolean) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setReuseObject(boolean) - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
 
setReuseObject(boolean) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setReversible(boolean) - Method in class org.mule.module.xml.transformer.XmlToXMLStreamReader
 
setRevocationCheck(RevocationCheck) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setRightFilter(PacketFilter) - Method in class org.mule.transport.xmpp.filters.XmppAndFilter
 
setRmiRegistry(Registry) - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
setRmiRegistry(Registry) - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
setRollback(boolean) - Method in class org.mule.tck.functional.TransactionalFunctionalTestComponent
 
setRollbackOnly() - Method in interface org.mule.api.transaction.Transaction
 
setRollbackOnly() - Method in class org.mule.module.spring.transaction.SpringTransactionFactory.SpringTransaction
 
setRollbackOnly() - Method in class org.mule.processor.DelegateTransaction
 
setRollbackOnly() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
setRollbackOnly() - Method in class org.mule.transaction.XaTransaction
 
setRollbackTxFilter(WildcardFilter) - Method in class org.mule.exception.AbstractExceptionListener
 
setRootMessageVariableName(String) - Method in class org.mule.routing.Foreach
 
setRoute(String) - Method in class org.mule.module.atom.routing.URIRouteFilter
 
setRouterStatistics(RouterStatistics) - Method in interface org.mule.api.routing.RouterStatisticsRecorder
 
setRouterStatistics(RouterStatistics) - Method in class org.mule.routing.AbstractCatchAllStrategy
Deprecated.
 
setRouterStatistics(RouterStatistics) - Method in class org.mule.routing.AbstractSelectiveRouter
 
setRouterStatistics(RouterStatistics) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
setRouterStatistics(RouterStatistics) - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
setRouterStatistics(RouterStatistics) - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
setRoutes(Collection<MessageProcessorFilterPair>) - Method in class org.mule.config.spring.factories.AbstractSelectiveRouterFactoryBean
 
setRoutes(List<MessageProcessor>) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
setRoutes(List<MessageProcessor>) - Method in class org.mule.routing.outbound.OutboundPassThroughRouter
Deprecated.
 
setRoutes(List<MessageProcessor>) - Method in class org.mule.routing.ScatterGatherRouter
 
setRuntimeClassesDir(URL) - Method in class org.mule.module.launcher.plugin.PluginClasspath
 
setRuntimeLibs(URL[]) - Method in class org.mule.module.launcher.plugin.PluginClasspath
 
setSalt(byte[]) - Method in class org.mule.security.PasswordBasedEncryptionStrategy
 
setSameRMOverrideValue(Boolean) - Method in class org.mule.transport.jms.JmsConnector
 
setSavepoint() - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
setSavepoint(String) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
setSavepoint() - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setSavepoint(String) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setSavepoint() - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setSavepoint(String) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setScheduler(Scheduler) - Method in class org.mule.transport.quartz.config.ScheduleConfigBuilder
 
setScheduler(ScheduledThreadPoolExecutor) - Method in class org.mule.util.store.AbstractMonitoredObjectStore
 
setSchedulerFactory(SchedulerFactory<Runnable>) - Method in class org.mule.config.spring.factories.PollingMessageSourceFactoryBean
 
setSchema(String) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
setSchema(String) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setSchema(String) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setSchemaLanguage(String) - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
setSchemaLanguage(String) - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
setSchemaLanguage(String) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
setSchemaLanguage(String) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
setSchemaLocation(Element, Map<String, String>) - Method in class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
setSchemaLocation(String) - Method in class org.mule.module.json.validation.JsonSchemaValidator.Builder
A location in which the json schema is present.
setSchemaLocation(String) - Method in class org.mule.module.json.validation.ValidateJsonSchemaMessageProcessor
 
setSchemaLocations(List<String>) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setSchemaLocations(String) - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
setSchemaLocations(String) - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
setSchemaLocations(String) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
setSchemaLocations(String) - Method in class org.mule.module.json.transformers.JsonSchemaXsdValidationFilter
Deprecated.
 
setSchemaLocations(String) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
setSchemaObject(Schema) - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
setSchemaObject(Schema) - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
setSchemaObject(Schema) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
setSchemaObject(Schema) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
setSchemaRedirects(Map<String, String>) - Method in class org.mule.module.json.validation.ValidateJsonSchemaMessageProcessor
 
setScheme(String) - Method in class org.mule.module.http.internal.listener.HttpMessagePropertiesResolver
 
setScope(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestUrlBuilder
 
setScope(String) - Method in class org.mule.routing.filters.MessagePropertyFilter
 
setScope(String) - Method in class org.mule.security.oauth.BaseOAuth2Manager
Sets scope
setScope(PropertyScope) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
setScopeName(String) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
For XML-based config
setScopes(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
setScopes(String) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsTokenRequestHandler
 
setScript(Scriptable) - Method in class org.mule.module.scripting.component.ScriptComponent
 
setScript(Scriptable) - Method in class org.mule.module.scripting.filter.ScriptFilter
 
setScript(Scriptable) - Method in class org.mule.module.scripting.transformer.ScriptTransformer
 
setScriptEngine(ScriptEngine) - Method in class org.mule.module.scripting.component.Scriptable
 
setScriptEngineName(String) - Method in class org.mule.module.scripting.component.Scriptable
 
setScriptFile(String) - Method in class org.mule.module.scripting.component.Scriptable
 
setScriptText(String) - Method in class org.mule.module.scripting.component.Scriptable
 
setSecondsBetweenRetries(long) - Method in class org.mule.routing.UntilSuccessful
setSecretAliasId(String) - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
setSecretKeyRingFileName(String) - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
setSecretPassphrase(String) - Method in class org.mule.module.pgp.PGPKeyRingImpl
 
setSecure(String) - Method in class org.mule.transport.http.CookieWrapper
 
setSecurity(WSSecurity) - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
setSecurityContext(SecurityContext) - Method in interface org.mule.api.MuleSession
The security context for this session.
setSecurityContext(SecurityContext) - Method in class org.mule.session.DefaultMuleSession
The security context for this session.
setSecurityContextFactory(SecurityContextFactory) - Method in class org.mule.security.AbstractSecurityProvider
 
setSecurityManager(SecurityManager) - Method in interface org.mule.api.MuleContext
Sets the security manager used by this Mule instance to authenticate and authorise incoming and outgoing event traffic and service invocations
setSecurityManager(SecurityManager) - Method in interface org.mule.api.security.SecurityFilter
 
setSecurityManager(SecurityManager) - Method in class org.mule.DefaultMuleContext
Sets the security manager used by this Mule instance to authenticate and authorise incoming and outgoing event traffic and service invocations
setSecurityManager(MuleSecurityManagerValidator) - Method in class org.mule.module.cxf.config.WsSecurity
 
setSecurityManager(SecurityManager) - Method in class org.mule.module.cxf.support.MuleSecurityManagerValidator
 
setSecurityManager(SecurityManager) - Method in class org.mule.security.AbstractSecurityFilter
 
setSecurityManager(SecurityManager) - Method in class org.mule.transport.rmi.RmiConnector
 
setSecurityPolicy(String) - Method in class org.mule.transport.rmi.RmiConnector
 
setSecurityProperties(Map) - Method in class org.mule.module.spring.security.SpringProviderAdapter
 
setSecurityProviders(String) - Method in interface org.mule.api.security.SecurityFilter
 
setSecurityProviders(String) - Method in class org.mule.security.AbstractSecurityFilter
 
setSegments(Integer) - Method in class org.mule.tck.testmodels.fruit.FloridaSunnyOrangeFactoryBean
 
setSelector(WatermarkSelectorBroker) - Method in class org.mule.config.spring.factories.WatermarkFactoryBean
 
setSelectorExpression(String) - Method in class org.mule.config.spring.factories.WatermarkFactoryBean
 
setSelectorRunnersCount(Integer) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setSelectors(int) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
Set the number of "selector" threads Jetty should use.
setSelectQueryKey(String) - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
setSendBodyMode(HttpSendBodyMode) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setSendBodyMode(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setSendBodyMode(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setSendBodyModeExpression(String) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setSendBufferSize(int) - Method in class org.apache.commons.httpclient.HttpConnection
setSendBufferSize(Integer) - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
setSendBufferSize(Integer) - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
setSendBufferSize(int) - Method in class org.mule.transport.tcp.TcpConnector
 
setSendBufferSize(int) - Method in class org.mule.transport.udp.UdpConnector
 
setSendTcpNoDelay(Boolean) - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
setSendTcpNoDelay(Boolean) - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
setSendTcpNoDelay(boolean) - Method in class org.mule.transport.tcp.TcpConnector
 
setSendTransformed(boolean) - Method in class org.mule.routing.ForwardingCatchAllStrategy
Deprecated.
 
setSerialiseObjects(boolean) - Method in class org.mule.transport.file.FileConnector
 
setSerializationId(String) - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
Specify an id for serialization purposes, allowing this BeanFactory to be deserialized from this id back into the BeanFactory object, if needed.
setSerializationMixins(Map<Class<?>, Class<?>>) - Method in class org.mule.module.json.transformers.ObjectToJson
 
setServer(Server) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
setServerClasses(String[]) - Method in class org.mule.transport.servlet.jetty.WebappsConfiguration
 
setServerClassName(String) - Method in class org.mule.transport.rmi.RmiConnector
 
setServerCodebase(String) - Method in class org.mule.transport.rmi.RmiConnector
 
setServerConfig(String) - Method in class org.mule.transport.soap.axis.AxisConnector
 
setServerProvider(SimpleProvider) - Method in class org.mule.transport.soap.axis.AxisConnector
 
setServerSocketFactory(SimpleServerSocketFactory) - Method in class org.mule.transport.tcp.TcpConnector
 
setServerSocketProperties(TcpServerSocketProperties) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
setServerSoTimeout(int) - Method in class org.mule.transport.tcp.TcpConnector
 
setServerTimeout(Integer) - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
setServerUri(String) - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
setServerUrl(URL) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setService(Service) - Method in interface org.mule.api.service.ServiceAware
Deprecated.
 
setService(String) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setService(String) - Method in class org.mule.module.cxf.builder.WsdlClientMessageProcessorBuilder
 
setService(Service) - Method in class org.mule.module.cxf.WSProxyService
Deprecated.
 
setService(String) - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
setServiceAddress(String) - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
setServiceBean(Object) - Method in class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
setServiceClass(Class<?>) - Method in class org.mule.module.cxf.builder.AbstractClientMessageProcessorBuilder
 
setServiceClass(Class<?>) - Method in class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
setServiceClass(Class) - Method in class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
setServiceInterface(Class) - Method in class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
setServiceName(String) - Method in class org.mule.transport.xmpp.XmppConnector
 
setServiceOverrides(Map) - Method in class org.mule.transport.AbstractConnector
Set the Service overrides on this connector.
setServiceUrl(String) - Method in class org.mule.transport.http.components.RestServiceWrapper
 
setServletUrl(String) - Method in class org.mule.transport.servlet.ServletConnector
 
setSession(SSLSession) - Method in class org.mule.module.http.internal.listener.properties.SSLSessionProperties
 
setSessionCacheSize(int) - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
setSessionHandler(SessionHandler) - Method in class org.mule.transport.AbstractConnector
Setter for property 'sessionHandler'.
setSessionProperty(String, Object) - Method in interface org.mule.api.MuleMessage
setSessionProperty(String, Object) - Method in class org.mule.DefaultMuleMessage
 
setSessionVariable(String, Object) - Method in interface org.mule.api.MuleEvent
Deprecated.
use getSession() to manipulate session state
setSessionVariable(String, Serializable, DataType) - Method in interface org.mule.api.MuleEvent
Deprecated.
use getSession() to manipulate session state
setSessionVariable(String, Object) - Method in class org.mule.DefaultMuleEvent
 
setSessionVariable(String, Serializable, DataType) - Method in class org.mule.DefaultMuleEvent
 
setSessionVariable(String, Object) - Method in class org.mule.VoidMuleEvent
 
setSessionVariable(String, Serializable, DataType) - Method in class org.mule.VoidMuleEvent
 
setSharedPluginLibs(URL[]) - Method in class org.mule.module.launcher.descriptor.ApplicationDescriptor
 
setShutdownScreen(SplashScreen) - Method in class org.mule.context.DefaultMuleContextBuilder
 
setShutdownTimeout(int) - Method in class org.mule.config.DefaultMuleConfiguration
 
setShutdownTimeout(int) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setSignatureKeyIdentifier(SignatureKeyIdentifier) - Method in class org.mule.module.ws.security.WssSignSecurityStrategy
 
setSignRequested(boolean) - Method in class org.mule.module.pgp.PGPCryptInfo
 
setSignRequired(boolean) - Method in class org.mule.module.pgp.filters.PGPSecurityFilter
 
setSingleResult(boolean) - Method in class org.mule.module.xml.transformer.JXPathExtractor
Deprecated.
If multiple results are expected from the JXPathExtractor.expression evaluation, set this to false.
setSizeCheckWaitTime(Long) - Method in class org.mule.transport.sftp.SftpConnector
 
setSoapAction(MuleEvent, EndpointURI, Call) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
setSoapVersion(String) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setSoapVersion(String) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setSoapVersion(String) - Method in class org.mule.module.cxf.support.ProxyServiceConfiguration
 
setSoapVersion(String) - Method in class org.mule.module.cxf.support.ProxyServiceFactoryBean
 
setSocketFactory(String) - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
setSocketFactory(String) - Method in class org.mule.transport.email.SmtpsConnector
 
setSocketFactory(AbstractTcpSocketFactory) - Method in class org.mule.transport.tcp.TcpConnector
 
setSocketFactoryFallback(String) - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
setSocketFactoryFallback(String) - Method in class org.mule.transport.email.SmtpsConnector
 
setSocketFactoryProperties(Map) - Method in class org.mule.module.management.agent.Mx4jAgent
 
setSocketMaxWait(int) - Method in class org.mule.transport.tcp.TcpConnector
 
setSocketSoLinger(int) - Method in class org.mule.transport.tcp.TcpConnector
 
setSocketTimeout(int) - Method in class org.apache.commons.httpclient.HttpConnection
Sets SO_TIMEOUT value directly on the underlying socket.
setSocketTimeout(int) - Method in class org.mule.transport.http.HttpServerConnection
 
setSoTimeout(int) - Method in class org.apache.commons.httpclient.HttpConnection
setSource(String) - Method in class org.mule.enricher.MessageEnricher.EnrichExpressionPair
 
setSource(String) - Method in class org.mule.module.db.internal.config.processor.BulkUpdateMessageProcessorFactoryBean
 
setSource(String) - Method in class org.mule.module.db.internal.processor.AbstractBulkUpdateMessageProcessor
 
setSource(String) - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
setSource(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setSourceClass(Class<?>) - Method in class org.mule.module.json.transformers.ObjectToJson
 
setSourceClass(Class<?>) - Method in class org.mule.module.xml.transformer.jaxb.JAXBMarshallerTransformer
 
setSpecification(String) - Method in class org.mule.transport.jms.JmsConnector
 
setSpecification(String) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setSqlStatementStrategyFactory(SqlStatementStrategyFactory) - Method in class org.mule.transport.jdbc.JdbcConnector
 
setSslHandshakeTimeout(long) - Method in class org.mule.transport.http.HttpsConnector
 
setSslSessionProperties(SSLSession) - Method in class org.mule.module.http.internal.listener.HttpMessagePropertiesResolver
 
setSslType(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setSslType(String) - Method in class org.mule.transport.http.HttpsConnector
 
setSslType(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setStackTraceFilter(String) - Method in class org.mule.module.management.mbean.MuleConfigurationService
 
setStackTraceFilter(String) - Method in interface org.mule.module.management.mbean.MuleConfigurationServiceMBean
Comma-separated list of packages and/or classes to remove.
setStaleCheckingEnabled(boolean) - Method in class org.apache.commons.httpclient.HttpConnection
setStartDelay(long) - Method in class org.mule.transport.polling.schedule.FixedFrequencySchedulerFactory
 
setStartDelay(long) - Method in class org.mule.transport.quartz.config.ScheduleConfigBuilder
 
setStartLatch(Latch) - Method in class org.mule.retry.async.AsynchronousRetryTemplate
 
setStartTime(long) - Method in class org.mule.management.stats.AllStatistics
 
setStartupOptions(Map<String, Object>) - Method in class org.mule.config.StartupContext
 
setStartupPropertiesFile(String) - Static method in class org.mule.module.launcher.MuleContainer
 
setStartupPropertiesFile(String) - Static method in class org.mule.MuleServer
 
setStartupScreen(SplashScreen) - Method in class org.mule.context.DefaultMuleContextBuilder
 
setState(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestHandler
 
setState(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.AuthorizationRequestUrlBuilder
 
setState(String) - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
setState(String) - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
Sets state
setStateful(boolean) - Method in class org.mule.transport.quartz.config.AbstractJobConfig
 
setStateless(boolean) - Method in class org.mule.module.bpm.RulesComponent
 
setStatementStreamingResultSetCloser(StatementStreamingResultSetCloser) - Method in class org.mule.module.db.internal.config.processor.BulkUpdateMessageProcessorFactoryBean
 
setStatementStreamingResultSetCloser(StatementStreamingResultSetCloser) - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
setStatus(String) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setStatus(int) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
setStatus(int, String) - Method in class org.mule.transport.http.servlet.MuleHttpServletResponse
 
setStatusCode(int) - Method in class org.mule.module.http.internal.domain.response.DefaultHttpResponse
 
setStatusCode(int) - Method in interface org.mule.module.http.internal.domain.response.HttpResponse
 
setStatusCode(Integer) - Method in class org.mule.module.http.internal.domain.response.HttpResponseBuilder
 
setStatusCode(int) - Method in class org.mule.module.http.internal.domain.response.ResponseStatus
 
setStatusCode(String) - Method in class org.mule.module.http.internal.listener.HttpResponseBuilder
 
setStatusLine(HttpVersion, int, String) - Method in class org.mule.transport.http.HttpResponse
 
setStatusLine(HttpVersion, int) - Method in class org.mule.transport.http.HttpResponse
 
setStopFurtherProcessing(boolean) - Method in interface org.mule.api.MuleEvent
Determines whether the default processing for this event will be executed.
setStopFurtherProcessing(boolean) - Method in interface org.mule.api.MuleEventContext
Determines whether the default processing for this event will be executed.
setStopFurtherProcessing(boolean) - Method in class org.mule.DefaultMuleEvent
Setting this parameter will stop the Mule framework from processing this event in the standard way.
setStopFurtherProcessing(boolean) - Method in class org.mule.DefaultMuleEventContext
Determines whether the default processing for this event will be executed.
setStopFurtherProcessing(boolean) - Method in class org.mule.VoidMuleEvent
 
setStopMessageProcessing(boolean) - Method in class org.mule.exception.AbstractMessagingExceptionStrategy
 
setStore(ObjectStore<String>) - Method in class org.mule.routing.IdempotentMessageFilter
 
setStoreName(String) - Method in class org.mule.util.store.ManagedObjectStore
 
setStorePrefix(String) - Method in class org.mule.routing.AbstractAggregator
 
setStorePrefix(String) - Method in class org.mule.routing.IdempotentMessageFilter
 
setStorePrefix(String) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
setStrategies(List<SecurityStrategy>) - Method in class org.mule.module.ws.security.WSSecurity
 
setStrategy(EncryptionStrategy) - Method in class org.mule.module.pgp.filters.PGPSecurityFilter
 
setStrategy(EncryptionStrategy) - Method in class org.mule.security.filters.MuleEncryptionEndpointSecurityFilter
 
setStrategy(CompressionStrategy) - Method in class org.mule.transformer.compression.AbstractCompressionTransformer
 
setStrategy(EncryptionStrategy) - Method in class org.mule.transformer.encryption.AbstractEncryptionTransformer
 
setStrategyName(String) - Method in class org.mule.module.pgp.filters.PGPSecurityFilter
 
setStrategyName(String) - Method in class org.mule.transformer.encryption.AbstractEncryptionTransformer
 
setStreaming(boolean) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setStreaming(boolean) - Method in class org.mule.transport.file.FileConnector
 
setStreaming(boolean) - Method in class org.mule.transport.ftp.FtpConnector
 
setStreaming(boolean) - Method in class org.mule.transport.ftp.FtpMuleMessageFactory
 
setStreaming(boolean) - Method in class org.mule.transport.tcp.TcpInputStream
 
setStreamResponse(boolean) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setStringData(String) - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
setStringProperty(String, String) - Method in interface org.mule.api.MuleMessage
setStringProperty(String, String) - Method in class org.mule.DefaultMuleMessage
Deprecated.
setStyle(String) - Method in class org.mule.transport.soap.axis.component.WebServiceWrapperComponent
 
setSubject(String) - Method in class org.mule.transport.email.SmtpConnector
 
setSubscription(String) - Method in class org.mule.context.notification.ListenerSubscriptionPair
 
setSubscriptionFilter(Class<? extends Filter>) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
sets the type of filter used to filter subscriptions
setSubscriptions(String[]) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
A list of endpoints the eventMulticaster will receive events on Note that if this eventMulticaster has a Mule Descriptor associated with it, these endpoints are ignored and the ones on the Mule Descriptor are used.
setSubscriptions(String[]) - Method in interface org.mule.module.spring.events.MuleSubscriptionEventListener
Deprecated.
 
setSubscriptionsOnService(Service) - Method in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
 
setSuccessReasonPhrase(String) - Method in class org.mule.module.http.api.listener.HttpListenerBuilder
 
setSuccessStatusCode(String) - Method in class org.mule.module.http.api.listener.HttpListenerBuilder
 
setSupportedArtifactType(ArtifactType) - Method in class org.mule.config.bootstrap.AbstractRegistryBootstrap
This attributes define which types or registry bootstrap entries will be created depending on the entry applyToArtifactType parameter value.
setSupportedPhases(Set<String>) - Method in interface org.mule.api.lifecycle.LifecyclePhase
 
setSupportedPhases(Set<String>) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
 
setSupportedProtocols(List) - Method in class org.mule.transport.AbstractConnector
Sets A list of protocols that the connector can accept
setSupportedSchemes(List<String>) - Method in class org.mule.transport.soap.axis.AxisConnector
 
setSupportJms102bSpec(boolean) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setSuppressDeclaration(boolean) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setSyncBatchSize(int) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setSynchronizeCall(boolean) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
setSynchronous(Boolean) - Method in class org.mule.routing.outbound.AbstractRecipientList
 
setSynchronous(boolean) - Method in class org.mule.routing.UntilSuccessful
 
setSynchronousEventTimeout(int) - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
setSyncTime(int) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setSyncWrites(boolean) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setSystemClasses(String[]) - Method in class org.mule.transport.servlet.jetty.WebappsConfiguration
 
setSystemId(String) - Method in class org.mule.module.xml.util.LocalResourceResolverInput
 
setSystemModelType(String) - Method in class org.mule.config.DefaultMuleConfiguration
 
setSystemProperties(Map<String, String>) - Method in class org.mule.config.spring.util.SystemPropertyInitializingBean
 
setTap(MessageProcessor) - Method in class org.mule.routing.WireTap
 
setTarget(String) - Method in class org.mule.enricher.MessageEnricher.EnrichExpressionPair
 
setTarget(String) - Method in class org.mule.module.db.internal.config.processor.BulkUpdateMessageProcessorFactoryBean
 
setTarget(String) - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
setTarget(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setTcpProtocol(TcpProtocol) - Method in class org.mule.transport.tcp.TcpConnector
 
setTempDirInbound(String) - Method in class org.mule.transport.sftp.SftpConnector
 
setTempDirOutbound(String) - Method in class org.mule.transport.sftp.SftpConnector
 
setTemplates(List) - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Set list of all the templates in the archetype that need to .
SETTER - Static variable in class org.mule.config.spring.parsers.specific.AggregatorDefinitionParser
 
SETTER - Static variable in class org.mule.config.spring.parsers.specific.SplitterDefinitionParser
 
setterMethod - Variable in class org.mule.config.spring.parsers.generic.ChildDefinitionParser
 
setterMethod - Variable in class org.mule.config.spring.parsers.specific.ObjectFactoryDefinitionParser
 
settersFor(Capable) - Static method in class org.mule.module.extension.internal.util.GroupValueSetter
Returns a List containing one ValueSetter instance per each ParameterGroup defined in the ParameterGroupCapability extracted from the given capable.
setThreadFactory(ThreadFactory) - Method in interface org.mule.api.config.ThreadingProfile
 
setThreadFactory(ThreadFactory) - Method in class org.mule.config.ChainedThreadingProfile
 
setThreadFactory(ThreadFactory) - Method in class org.mule.config.ImmutableThreadingProfile
 
setThreadFactory(ThreadFactory) - Method in class org.mule.config.MutableThreadingProfile
 
setThreadingProfile(ThreadingProfile) - Method in class org.mule.config.spring.factories.ScatterGatherRouterFactoryBean
 
setThreadingProfile(ThreadingProfile) - Method in class org.mule.model.seda.SedaService
Deprecated.
 
setThreadingProfile(ThreadingProfile) - Method in class org.mule.routing.ScatterGatherRouter
 
setThreadingProfile(ThreadingProfile) - Method in class org.mule.routing.UntilSuccessful
 
setThreadNamePrefix(String) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setThreadPriority(int) - Method in class org.mule.work.WorkerContext
Defines the thread priority level of the thread, which will be dispatched to process this work.
setThreadTTL(long) - Method in interface org.mule.api.config.ThreadingProfile
 
setThreadTTL(long) - Method in class org.mule.config.ChainedThreadingProfile
 
setThreadTTL(long) - Method in class org.mule.config.ImmutableThreadingProfile
 
setThreadTTL(long) - Method in class org.mule.config.MutableThreadingProfile
 
setThreadTTL(Long) - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
setThreadWaitTimeout(long) - Method in interface org.mule.api.config.ThreadingProfile
 
setThreadWaitTimeout(long) - Method in class org.mule.config.ChainedThreadingProfile
 
setThreadWaitTimeout(long) - Method in class org.mule.config.ImmutableThreadingProfile
 
setThreadWaitTimeout(long) - Method in class org.mule.config.MutableThreadingProfile
 
setThreadWaitTimeout(Long) - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
setThrottlingPolicyStatistics(long, long, long) - Method in interface org.mule.execution.ThrottlingPhaseTemplate
Set up throttling policy state to be used by the MessageSource for debugging or information purpose.
setThrottlingPolicyStatistics(long, long, long) - Method in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
setThrottlingPolicyStatistics(long, long, long) - Method in class org.mule.module.http.internal.listener.HttpThrottlingHeadersMapBuilder
 
setThrottlingPolicyStatistics(long, long, long) - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
setThrottlingPolicyStatistics(long, long, long) - Method in class org.mule.transport.servlet.jetty.JettyMessageProcessTemplate
 
setThrowException(boolean) - Method in class org.mule.tck.functional.FunctionalTestComponent
Sometimes you will want the service to always throw an exception, if this is the case you can set the 'throwException' property to true.
setThrowOnUnaccepted(boolean) - Method in class org.mule.processor.AbstractFilteringMessageProcessor
 
setTiltFlag(boolean) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
setTime(long) - Method in class org.mule.tck.testmodels.services.PersonResponse
 
setTimeout(int) - Method in interface org.mule.api.MuleEvent
The number of milliseconds to wait for a return event when running synchronously.
setTimeout(long) - Method in interface org.mule.api.routing.Aggregator
 
setTimeout(int) - Method in interface org.mule.api.transaction.Transaction
 
setTimeout(int) - Method in interface org.mule.api.transaction.TransactionConfig
 
setTimeout(long) - Method in class org.mule.config.spring.factories.ScatterGatherRouterFactoryBean
 
setTimeout(int) - Method in class org.mule.DefaultMuleEvent
 
setTimeout(int) - Method in class org.mule.processor.DelegateTransaction
 
setTimeout(long) - Method in class org.mule.routing.AbstractAggregator
 
setTimeout(long) - Method in class org.mule.routing.correlation.EventCorrelator
 
setTimeout(long) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
setTimeout(long) - Method in class org.mule.routing.ScatterGatherRouter
 
setTimeout(Long) - Method in class org.mule.service.ServiceAsyncReplyCompositeMessageSource
Deprecated.
 
setTimeout(int) - Method in class org.mule.transaction.AbstractTransaction
 
setTimeout(int) - Method in class org.mule.transaction.MuleTransactionConfig
 
setTimeout(int) - Method in class org.mule.transaction.XaTransactionFactory
 
setTimeout(int) - Method in class org.mule.transport.ajax.container.AjaxServletConnector
 
setTimeout(int) - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
setTimeout(int) - Method in class org.mule.transport.quartz.jobs.EndpointPollingJobConfig
 
setTimeout(int) - Method in class org.mule.transport.soap.axis.extensions.AxisMuleSession
 
setTimeout(Integer) - Method in class org.mule.transport.tcp.DefaultTcpClientSocketProperties
 
setTimeout(Integer) - Method in class org.mule.transport.tcp.DefaultTcpServerSocketProperties
 
setTimeout(int) - Method in class org.mule.transport.tcp.TcpConnector
Deprecated.
The time out should be set explicitly for each
setTimeout(int) - Method in class org.mule.transport.udp.UdpConnector
 
setTimeout(int) - Method in class org.mule.VoidMuleEvent
 
setTimeoutInMillis(int) - Method in class org.mule.tck.listener.ConnectionListener
 
setTimeoutInMillis(int) - Method in class org.mule.tck.listener.ExceptionListener
 
setTimeoutInMillis(int) - Method in class org.mule.tck.listener.FlowExecutionListener
 
setTimeoutInMillis(int) - Method in class org.mule.tck.listener.SystemExceptionListener
 
setTimeToLive(int) - Method in class org.mule.transport.multicast.MulticastConnector
 
setTimeUnit(TimeUnit) - Method in class org.mule.transport.AbstractPollingMessageReceiver
 
setTimeUnit(TimeUnit) - Method in class org.mule.transport.polling.schedule.FixedFrequencySchedulerFactory
 
setTimeZone(String) - Method in class org.mule.modules.schedulers.cron.CronSchedulerFactory
 
setTlsContext(TlsContextFactory) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
To create instance of TlsContextFactory use TlsContextFactoryBuilder
setTlsContext(TlsContextFactory) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
setTlsContext(TlsContextFactory) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setTlsContext(TlsContextFactory) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
setTlsContext(TlsContextFactory) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
setTlsContext(TlsContextFactory) - Method in class org.mule.module.ws.security.WssDecryptSecurityStrategy
 
setTlsContext(TlsContextFactory) - Method in class org.mule.module.ws.security.WssEncryptSecurityStrategy
 
setTlsContext(TlsContextFactory) - Method in class org.mule.module.ws.security.WssSignSecurityStrategy
 
setTlsContext(TlsContextFactory) - Method in class org.mule.module.ws.security.WssVerifySignatureSecurityStrategy
 
setTlsContextFactory(TlsContextFactory) - Method in class org.mule.module.http.api.listener.HttpListenerBuilder
 
setTlsContextFactory(TlsContextFactory) - Method in class org.mule.module.http.internal.listener.HttpListenerConfigBuilder
 
setTlsContextFactory(TlsContextFactory) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setTlsContextFactory(TlsContextFactory) - Method in class org.mule.module.oauth2.internal.AbstractTokenRequestHandler
 
setTlsContextFactory(TlsContextFactory) - Method in class org.mule.module.ws.consumer.MuleWSDLLocatorConfig.Builder
 
setTokenManager(TokenManagerConfig) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
setTokenManager(TokenManagerConfig) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
setTokenManager(TokenManagerConfig) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsTokenRequestHandler
 
setTokenRequestHandler(AbstractAuthorizationCodeTokenRequestHandler) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
setTokenRequestHandler(ClientCredentialsTokenRequestHandler) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
setTokenResponseConfiguration(TokenResponseConfiguration) - Method in class org.mule.module.oauth2.internal.authorizationcode.AutoAuthorizationCodeTokenRequestHandler
 
setTokenResponseConfiguration(TokenResponseConfiguration) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsTokenRequestHandler
 
setTokenResponseParameters(Map<String, Object>) - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ResourceOwnerOAuthContext
 
setTokenUrl(String) - Method in class org.mule.module.oauth2.internal.AbstractTokenRequestHandler
 
setTopicResolver(JmsTopicResolver) - Method in class org.mule.transport.jms.JmsConnector
Setter for property 'topicResolver'.
setTracking(boolean) - Method in class org.mule.module.xml.stax.ReversibleXMLStreamReader
 
setTransacted(boolean) - Method in class org.mule.config.spring.factories.BridgeFactoryBean
 
setTransactionConfig(TransactionConfig) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setTransactionConfig(TransactionConfig) - Method in interface org.mule.api.routing.OutboundRouter
 
setTransactionConfig(TransactionConfig) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setTransactionConfig(MuleTransactionConfig) - Method in class org.mule.processor.TransactionalInterceptingMessageProcessor
 
setTransactionConfig(TransactionConfig) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
setTransactionConfig(TransactionConfig) - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
setTransactionIsolation(int) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setTransactionIsolation(int) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
setTransactionIsolation(int) - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
setTransactionIsolation(int) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setTransactionIsolation(int) - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
setTransactionIsolation(int) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setTransactionManager(TransactionManager) - Method in interface org.mule.api.MuleContext
Deprecated.
Use only for test cases.
setTransactionManager(TransactionManager) - Method in class org.mule.DefaultMuleContext
Sets the JTA Transaction Manager to use with this Mule server instance
setTransactionManager(TransactionManager) - Method in class org.mule.module.spring.transaction.SpringTransactionManagerFactory
 
setTransactionPerMessage(boolean) - Method in class org.mule.transport.jdbc.JdbcConnector
 
setTransactionRollbackOnly(AbstractTransactionContext) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
setTransactionRollbackOnly(AbstractTransactionContext) - Method in class org.mule.util.xa.AbstractResourceManager
 
setTransactionTimeout(int) - Method in class org.mule.transport.jms.xa.XAResourceWrapper
 
setTransactionTimeout(int) - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
setTransactionTimeout(int) - Method in class org.mule.util.queue.TransactionalQueueSession
 
setTransactionTimeout(int) - Method in class org.mule.util.xa.DefaultXASession
 
setTransformer(Transformer) - Method in class org.mule.routing.outbound.TransformerRouter
Deprecated.
 
setTransformers(List<Transformer>) - Method in interface org.mule.api.endpoint.EndpointBuilder
Deprecated.
Use setMessageProcessors()
setTransformers(List) - Method in class org.mule.api.FutureMessageResult
Set a post-invocation transformer.
setTransformers(String) - Method in class org.mule.config.endpoint.AnnotatedEndpointData
 
setTransformers(Transformer...) - Method in class org.mule.config.spring.factories.BridgeFactoryBean
 
setTransformers(Transformer...) - Method in class org.mule.config.spring.factories.SimpleServiceFactoryBean
 
setTransformers(List<Transformer>) - Method in class org.mule.endpoint.AbstractEndpointBuilder
Deprecated.
Use setMessageProcessors()
setTransformers(Transformer...) - Method in class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
setTransformers(List<Transformer>) - Method in class org.mule.routing.outbound.FilteringOutboundRouter
 
setTransformers(Transformer...) - Method in class org.mule.transport.http.config.spring.factories.HttpProxyFactoryBean
 
setTransientServiceName(Object) - Method in class org.mule.DefaultMuleEvent
Used to fetch the DefaultMuleEvent.flowConstruct after deserealization since its a transient value.
setTransportName(String) - Method in class org.mule.transport.soap.axis.AxisServiceComponent
 
setTreatMapAsNamedParams(boolean) - Method in class org.mule.transport.soap.axis.AxisConnector
 
setTrimText(boolean) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setTrustManagerAlgorithm(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setTrustManagerAlgorithm(String) - Method in interface org.mule.api.security.TlsDirectTrustStore
 
setTrustManagerAlgorithm(String) - Method in class org.mule.transport.http.HttpsConnector
 
setTrustManagerAlgorithm(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setTrustManagerFactory(TrustManagerFactory) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setTrustManagerFactory(TrustManagerFactory) - Method in interface org.mule.api.security.TlsDirectTrustStore
 
setTrustManagerFactory(TrustManagerFactory) - Method in class org.mule.transport.http.HttpsConnector
 
setTrustManagerFactory(TrustManagerFactory) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setTrustStore(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setTrustStore(String) - Method in interface org.mule.api.security.TlsIndirectTrustStore
 
setTrustStore(String) - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
setTrustStore(String) - Method in class org.mule.transport.email.SmtpsConnector
 
setTrustStore(String) - Method in class org.mule.transport.http.HttpsConnector
 
setTrustStore(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setTrustStorePassword(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setTrustStorePassword(String) - Method in interface org.mule.api.security.TlsIndirectTrustStore
 
setTrustStorePassword(String) - Method in class org.mule.transport.email.AbstractTlsRetrieveMailConnector
 
setTrustStorePassword(String) - Method in class org.mule.transport.email.SmtpsConnector
 
setTrustStorePassword(String) - Method in class org.mule.transport.http.HttpsConnector
 
setTrustStorePassword(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setTrustStoreType(String) - Method in class org.mule.api.security.tls.TlsConfiguration
 
setTrustStoreType(String) - Method in interface org.mule.api.security.TlsDirectTrustStore
 
setTrustStoreType(String) - Method in class org.mule.transport.http.HttpsConnector
 
setTrustStoreType(String) - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
setTxManager(TransactionManager) - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
 
setTxManagerFactory(TransactionManagerFactory) - Method in class org.mule.config.spring.factories.TransactionManagerFactoryBean
 
setType(SimpleService.Type) - Method in class org.mule.config.spring.factories.SimpleServiceFactoryBean
 
setType(Class) - Method in class org.mule.lifecycle.LifecycleObject
 
setTypeIndexForCurrentLevel(int) - Method in class org.mule.util.generics.MethodParameter
Set the type index for the current nesting level.
setTypeMap(Map<String, Class<?>>) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
setTypeMap(Map<String, Class<?>>) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
setTypeMap(Map<String, Class<?>>) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
setUnacceptedMessageProcessor(MessageProcessor) - Method in class org.mule.processor.AbstractFilteringMessageProcessor
 
setUnauthenticated(MuleEvent) - Method in class org.mule.transport.http.filters.HttpBasicAuthenticationFilter
 
setUniqueId(String) - Method in class org.mule.DefaultMuleMessage
 
setUntilSuccessfulConfiguration(UntilSuccessfulConfiguration) - Method in class org.mule.routing.AbstractUntilSuccessfulProcessingStrategy
 
setUntilSuccessfulConfiguration(UntilSuccessfulConfiguration) - Method in interface org.mule.routing.UntilSuccessfulProcessingStrategy
 
setUp() - Method in class org.mule.test.infrastructure.deployment.AbstractFakeMuleServerTestCase
 
setupCharacterEncoding(HttpServletRequest, DefaultMuleMessage) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
setupClientAuthorization(MuleEvent, HttpMethod, HttpClient, ImmutableEndpoint) - Method in class org.mule.transport.http.HttpConnector
 
setupContentType(HttpServletRequest, DefaultMuleMessage) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
setUpdateExpression(String) - Method in class org.mule.config.spring.factories.WatermarkFactoryBean
 
setupDispatchReturn(OutboundEndpoint, MessageDispatcher, MuleMessage) - Method in class org.mule.transport.AbstractConnector
This method will return the dispatcher to the pool or, if the payload is an inputstream, replace the payload with a new DelegatingInputStream which returns the dispatcher to the pool when the stream is closed.
setupEncoding(HttpServletRequest, MuleMessage) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
setupEntityMethod(Object, String, MuleMessage, EntityEnclosingMethod) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
setupEvaluator() - Method in class org.mule.transport.quartz.jobs.CustomJobFromMessageConfig
 
setupFileType(FTPClient, ImmutableEndpoint) - Method in class org.mule.transport.ftp.FtpConnector
Transfer type is BINARY by default.
setupFromConnector(Connector) - Method in class org.mule.transport.http.PollingHttpMessageReceiver
 
setupFromConnector(Connector) - Method in class org.mule.transport.http.PollingHttpsMessageReceiver
 
setupJettyLogging() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
setupKeepAliveFromRequestVersion(HttpVersion) - Method in class org.mule.transport.http.HttpResponse
The HTTTP spec suggests that for HTTP 1.1 persistent connections should be used, for HTTP 1.0 the connection should not be kept alive.
setupMessageProperties(HttpServletRequest, DefaultMuleMessage) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
setupMuleContext() - Method in class org.mule.transport.servlet.AbstractReceiverServlet
 
setUpMuleContexts() - Method in class org.mule.tck.junit4.DomainFunctionalTestCase
 
setupObjectClassFromObjectClassName() - Method in class org.mule.object.AbstractObjectFactory
 
setUpperCase(boolean) - Method in class org.mule.transformer.simple.ByteArrayToHexString
 
setupRemoteAddress(HttpServletRequest, DefaultMuleMessage) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
setupRequestMessage(HttpServletRequest, MuleMessage, MessageReceiver) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
setupRequestMessage(HttpServletRequest, MuleMessage) - Method in class org.mule.transport.servlet.MuleReceiverServlet
 
setupRequestParameters(HttpServletRequest, DefaultMuleMessage) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
setupRequestReturn(InboundEndpoint, MessageRequester, MuleMessage) - Method in class org.mule.transport.AbstractConnector
This method will return the requester to the pool or, if the payload is an inputstream, replace the payload with a new DelegatingInputStream which returns the requester to the pool when the stream is closed.
setupResponseTransformer() - Method in class org.mule.transport.servlet.AbstractReceiverServlet
 
setupSessionId(HttpServletRequest, MuleMessage) - Method in class org.mule.transport.servlet.ServletMuleMessageFactory
 
setupURL(Message) - Method in class org.mule.module.cxf.transport.MuleUniversalConduit
 
setUri(String) - Method in class org.mule.module.http.internal.domain.request.HttpRequestBuilder
 
setUri(String) - Method in class org.mule.module.http.internal.listener.HttpMessagePropertiesResolver
 
setURIBuilder(URIBuilder) - Method in interface org.mule.api.endpoint.EndpointBuilder
 
setURIBuilder(URIBuilder) - Method in class org.mule.endpoint.AbstractEndpointBuilder
 
setUriResolver(URIResolver) - Method in class org.mule.module.xml.transformer.XsltTransformer
 
setUrl(String) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setUrl(String) - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
setUrl(URL) - Method in class org.mule.module.http.api.listener.HttpListenerBuilder
Configures the protocol, host, port and path using the provided url.
setUrl(String) - Method in class org.mule.module.http.internal.request.client.HttpRequesterBuilder
 
setUrl(String) - Method in class org.mule.module.http.internal.request.DefaultHttpRequester
 
setUrl(String) - Method in class org.mule.object.JndiObjectFactory
 
setUrl(String) - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
setUse(String) - Method in class org.mule.transport.soap.axis.component.WebServiceWrapperComponent
 
setUseCachedHttpServletRequest(boolean) - Method in class org.mule.transport.servlet.ServletConnector
 
setUseConnectorToRetrieveWsdl(boolean) - Method in class org.mule.module.ws.consumer.MuleWSDLLocatorConfig.Builder
 
setUseConnectorToRetrieveWsdl(boolean) - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
setUseContinuations(boolean) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
setUseDefaultConfigResource(boolean) - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
setUseExtendedTransformations(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
 
setUseExtendedTransformations(boolean) - Method in class org.mule.config.spring.MuleConfigurationConfigurator
 
setUseInboundAttachments(boolean) - Method in class org.mule.transport.email.transformers.ObjectToMimeMessage
Set whether inbound attachments should be transformed into MIME parts
setUseJMSEngine(boolean) - Method in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
setUseMinimalConfigResource(boolean) - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
setUseMultipleTransactedReceivers(boolean) - Method in class org.mule.transport.TransactedPollingMessageReceiver
 
setUseOutboundAttachments(boolean) - Method in class org.mule.transport.email.transformers.ObjectToMimeMessage
Set whether outbound attachments should be transformed into MIME parts
setUsePersistentConnections(boolean) - Method in class org.mule.module.http.api.requester.HttpRequesterConfigBuilder
 
setUsePersistentConnections(boolean) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
setUsePersistentConnections(boolean) - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
setUsePersistentConnections(boolean) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setUser(String) - Method in class org.mule.endpoint.URIBuilder
 
setUser(String) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setUser(String) - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
setUser(String) - Method in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
setUser(String) - Method in class org.mule.transport.xmpp.XmppConnector
 
setUserCredentials(EndpointURI, Call) - Method in class org.mule.transport.soap.axis.AxisMessageDispatcher
 
setUsername(String) - Method in class org.mule.module.http.api.requester.authentication.BasicAuthenticationBuilder
 
setUsername(String) - Method in class org.mule.module.http.api.requester.proxy.NtlmProxyConfigBuilder
 
setUsername(String) - Method in class org.mule.module.http.api.requester.proxy.ProxyConfigBuilder
 
setUsername(String) - Method in class org.mule.module.http.internal.domain.request.HttpRequestAuthentication
 
setUsername(String) - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
setUsername(String) - Method in class org.mule.module.http.internal.request.DefaultProxyConfig
 
setUsername(String) - Method in class org.mule.module.ws.security.WssUsernameTokenSecurityStrategy
 
setUsername(String) - Method in class org.mule.security.UsernamePasswordAuthenticationFilter
 
setUsername(String) - Method in class org.mule.transport.jms.config.CachingConnectionFactoryFactoryBean
Deprecated.
 
setUsername(String) - Method in class org.mule.transport.jms.JmsConnector
 
setUsername(String) - Method in class org.mule.transport.sftp.config.SftpProxyConfig
 
setUseSecureHash(boolean) - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
setUseStaxSource(boolean) - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
setUseStaxSource(boolean) - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
setUseStaxSource(boolean) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
setUseStaxSource(boolean) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
setUseStaxSource(boolean) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
setUseTempFileTimestampSuffix(Boolean) - Method in class org.mule.transport.sftp.SftpConnector
 
setUseTemplates(boolean) - Method in class org.mule.routing.outbound.FilteringOutboundRouter
 
setUseTransportForUris(boolean) - Method in class org.mule.module.http.internal.config.HttpConfiguration
 
setUseXaTransactions(boolean) - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
setUseXaTransactions(boolean) - Method in class org.mule.module.db.internal.domain.database.DataSourceConfig
 
setValid(boolean) - Method in interface org.mule.api.MuleSession
Determines if this session is valid.
setValid(boolean) - Method in class org.mule.session.DefaultMuleSession
 
setValidateConnections(boolean) - Method in class org.mule.transport.AbstractConnector
Whether to test a connection on each take.
setValidateParsing(boolean) - Method in class org.mule.module.json.filters.IsJsonFilter
 
setValidationEnabled(boolean) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setValidationFilter(Filter) - Method in class org.mule.config.spring.factories.ValidatorFactoryBean
 
setValidatorFeatures(Map<String, Boolean>) - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
setValidatorFeatures(Map<String, Boolean>) - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
setValidatorFeatures(Map<String, Boolean>) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
setValidatorFeatures(Map<String, Boolean>) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
setValidatorProperties(Map<String, Object>) - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
setValidatorProperties(Map<String, Object>) - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
setValidatorProperties(Map<String, Object>) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
setValidatorProperties(Map<String, Object>) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
setValue(Object) - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
setValue(Object) - Method in class org.mule.config.spring.parsers.collection.ChildListEntryDefinitionParser.ListEntry
 
setValue(Object) - Method in class org.mule.config.spring.parsers.collection.ChildMapEntryDefinitionParser.KeyValuePair
 
setValue(String) - Method in class org.mule.module.http.internal.HttpSingleParam
 
setValue(String) - Method in class org.mule.module.oauth2.internal.ParameterExtractor
 
setValue(String) - Method in class org.mule.module.xml.filters.JXPathFilter
Deprecated.
Use setExpectedValue(String expectedValue).
setValue(String) - Method in class org.mule.routing.filters.RegExFilter
 
setValue(String) - Method in class org.mule.transformer.simple.AbstractAddVariablePropertyTransformer
 
setValue(String) - Method in class org.mule.transformer.simple.AddAttachmentTransformer
 
setValue(String) - Method in class org.mule.transformer.simple.SetPayloadMessageProcessor
 
setValue(String) - Method in class org.mule.transformer.simple.SetPayloadTransformer
 
setValueExpression(String) - Method in class org.mule.routing.IdempotentMessageFilter
 
setValues(String) - Method in class org.mule.module.http.internal.request.RangeStatusCodeValidator
 
setVariable(String) - Method in class org.mule.config.spring.factories.WatermarkFactoryBean
 
setVariableName(String) - Method in class org.mule.module.jbpm.MuleReceiveActivity
 
setVariableName(String) - Method in class org.mule.transformer.simple.AddFlowVariableTransformer
 
setVariableName(String) - Method in class org.mule.transformer.simple.AddSessionVariableTransformer
 
setVariableName(String) - Method in class org.mule.transformer.simple.RemoveFlowVariableTransformer
 
setVariableName(String) - Method in class org.mule.transformer.simple.RemoveSessionVariableTransformer
 
setVariables(List) - Method in class com.javaforge.bobber.archetype.model.BobberArchetype
Set variable expressions that will use the System.properties values to be used as input into the velocity template engine .
setVariables(List) - Method in class com.javaforge.bobber.archetype.model.Variable
Set Variables that depend on their parent.
setVerbs(String) - Method in class org.mule.module.atom.routing.URIRouteFilter
 
setVersion(String) - Method in class org.mule.transport.http.components.HttpResponseBuilder
 
setVersion(String) - Method in class org.mule.transport.http.CookieWrapper
 
setVirtualHost(String) - Method in class org.apache.commons.httpclient.HttpConnection
Deprecated.
no longer applicable
setWaitTime(long) - Method in class org.mule.tck.functional.FunctionalTestComponent
 
setWebappsConfiguration(WebappsConfiguration) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
setWhen(String) - Method in class org.mule.exception.TemplateMessagingExceptionStrategy
 
setWhenExhaustedAction(byte) - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
Sets the action to take when the KeyedObjectPool.borrowObject(K) method is invoked when the pool is exhausted.
setWhenExhaustedAction(byte) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
 
setWireFormat(WireFormat) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
setWireFormat(WireFormat) - Method in class org.mule.module.client.remoting.RemoteDispatcherAgent
Deprecated.
 
setWireFormat(WireFormat) - Method in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
setWireFormatClass(String) - Method in class org.mule.module.client.remoting.ServerHandshake
Deprecated.
 
setWork(Work) - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager.WorkDelegate
Deprecated.
 
setWorkDirectory(String) - Method in class org.mule.transport.file.FileConnector
 
setWorkerCoreSize(Integer) - Method in class org.mule.module.http.internal.request.HttpClientConfiguration.Builder
 
setWorkerThreadingProfile(ThreadingProfile) - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
setWorkFileNamePattern(String) - Method in class org.mule.transport.file.FileConnector
 
setWorkingDirectory(String) - Method in class org.mule.config.DefaultMuleConfiguration
 
setWorkListener(WorkListener) - Method in interface org.mule.api.context.MuleContextBuilder
 
setWorkListener(WorkListener) - Method in class org.mule.context.DefaultMuleContextBuilder
 
setworkListener(WorkListener) - Method in class org.mule.DefaultMuleContext
 
setWorkListenerWrapperFactory(WorkListenerWrapperFactory) - Method in class org.mule.transport.TrackingWorkManager
 
setWorkManager(WorkManager) - Method in interface org.mule.api.context.MuleContextBuilder
 
setWorkManager(WorkManager) - Method in class org.mule.context.DefaultMuleContextBuilder
 
setWorkManager(WorkManager) - Method in class org.mule.DefaultMuleContext
 
setWorkManagerFactory(ThreadingProfile.WorkManagerFactory) - Method in interface org.mule.api.config.ThreadingProfile
 
setWorkManagerFactory(ThreadingProfile.WorkManagerFactory) - Method in class org.mule.config.ChainedThreadingProfile
 
setWorkManagerFactory(ThreadingProfile.WorkManagerFactory) - Method in class org.mule.config.ImmutableThreadingProfile
 
setWorkManagerFactory(ThreadingProfile.WorkManagerFactory) - Method in class org.mule.config.MutableThreadingProfile
 
setWorkstation(String) - Method in class org.mule.module.http.internal.domain.request.HttpRequestAuthentication
 
setWorkstation(String) - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
setWorkTracker(WorkTracker) - Method in class org.mule.transport.TrackingWorkManager
 
setWriteToDirectory(String) - Method in class org.mule.transport.file.FileConnector
 
setWsConfig(WsConfig) - Method in class org.mule.module.cxf.config.WsSecurity
 
setWsdlEndpoint(String) - Method in class org.mule.module.cxf.WSProxyService
Deprecated.
 
setWsdlFile(String) - Method in class org.mule.module.cxf.WSProxyService
Deprecated.
 
setWsdlFile(File) - Method in class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
setWsdlLocation(String) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setWsdlLocation(String) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setWsdlLocation(URI) - Method in class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
setWsdlLocation(String) - Method in class org.mule.module.ws.consumer.WSConsumerConfig
 
setWsdlPort(String) - Method in class org.mule.module.cxf.component.WebServiceWrapperComponent
Deprecated.
 
setWSDLQueryHandler(QueryHandler) - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
setWsSecurity(WsSecurity) - Method in class org.mule.module.cxf.builder.AbstractInboundMessageProcessorBuilder
 
setWsSecurity(WsSecurity) - Method in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
setXaDataSource(XADataSource) - Method in class org.mule.transport.jdbc.xa.DataSourceWrapper
 
setXHTML(boolean) - Method in class org.mule.module.xml.transformer.XmlPrettyPrinter
 
setXmlInputFactory(String) - Method in class org.mule.module.cxf.support.StaxFeature
 
setXMLInputFactory(XMLInputFactory) - Method in interface org.mule.module.json.transformers.JsonSchemaFilter
Deprecated.
 
setXMLInputFactory(XMLInputFactory) - Method in class org.mule.module.json.transformers.JsonSchemaJsonValidationFilter
Deprecated.
 
setXMLInputFactory(XMLInputFactory) - Method in class org.mule.module.json.transformers.JsonSchemaValidationFilter
Deprecated.
 
setXMLInputFactory(XMLInputFactory) - Method in class org.mule.module.xml.filters.SchemaValidationFilter
 
setXMLInputFactory(XMLInputFactory) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
setXmlOutputFactory(String) - Method in class org.mule.module.cxf.support.StaxFeature
 
setXMLOutputFactory(XMLOutputFactory) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
setXpathEvaluator(XPathEvaluator) - Method in class org.mule.module.xml.filters.XPathFilter
 
setXpathEvaluator(XPathEvaluator) - Method in class org.mule.module.xml.transformer.XPathExtractor
 
setXquery(String) - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
setXqueryFile(String) - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
setXslFile(String) - Method in class org.mule.module.xml.transformer.XsltTransformer
 
setXslFilePath(String) - Method in class org.mule.module.management.agent.Mx4jAgent
 
setXslt(String) - Method in class org.mule.module.xml.transformer.XsltTransformer
 
setXslTransformerFactory(String) - Method in class org.mule.module.xml.transformer.XsltTransformer
Configures the javax.xml.transform.Transformer factory class This is provided only to override through configuration beans, in the code just override getTransformerFactory.
SFTP_DELETE_ACTION - Static variable in class org.mule.transport.sftp.notification.SftpTransportNotification
 
SFTP_DELETE_ACTION_MSG - Static variable in class org.mule.transport.sftp.notification.SftpTransportNotification
 
SFTP_GET_ACTION - Static variable in class org.mule.transport.sftp.notification.SftpTransportNotification
 
SFTP_GET_ACTION_MSG - Static variable in class org.mule.transport.sftp.notification.SftpTransportNotification
 
SFTP_PUT_ACTION - Static variable in class org.mule.transport.sftp.notification.SftpTransportNotification
 
SFTP_PUT_ACTION_MSG - Static variable in class org.mule.transport.sftp.notification.SftpTransportNotification
 
SFTP_RENAME_ACTION - Static variable in class org.mule.transport.sftp.notification.SftpTransportNotification
 
SFTP_RENAME_ACTION_MSG - Static variable in class org.mule.transport.sftp.notification.SftpTransportNotification
 
SftpClient - Class in org.mule.transport.sftp
SftpClient Wrapper around jsch sftp library.
SftpClient(String) - Constructor for class org.mule.transport.sftp.SftpClient
 
SftpClient(String, SftpNotifier) - Constructor for class org.mule.transport.sftp.SftpClient
 
SftpClient.WriteMode - Enum in org.mule.transport.sftp
 
SftpConnectionFactory - Class in org.mule.transport.sftp
 
SftpConnectionFactory(ImmutableEndpoint) - Constructor for class org.mule.transport.sftp.SftpConnectionFactory
 
SftpConnector - Class in org.mule.transport.sftp
SftpConnector sends and receives file messages over sftp using jsch library Improves on SFTP with VFS Connector in the following ways: 1.
SftpConnector(MuleContext) - Constructor for class org.mule.transport.sftp.SftpConnector
 
SftpFileArchiveInputStream - Class in org.mule.transport.sftp
Ensures that the file is moved to the archiveFile folder after a successful consumption of the file
SftpFileArchiveInputStream(File, SftpInputStream) - Constructor for class org.mule.transport.sftp.SftpFileArchiveInputStream
 
SftpFileArchiveInputStream(File, File, SftpInputStream) - Constructor for class org.mule.transport.sftp.SftpFileArchiveInputStream
 
SftpInputStream - Class in org.mule.transport.sftp
SftpInputStream wraps an sftp InputStream.
SftpInputStream(SftpClient, InputStream, String, boolean, ImmutableEndpoint) - Constructor for class org.mule.transport.sftp.SftpInputStream
A special sftp InputStream.
SftpMessageDispatcher - Class in org.mule.transport.sftp
SftpMessageDispatcher dispatches files via sftp to a remote sftp service.
SftpMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.sftp.SftpMessageDispatcher
 
SftpMessageDispatcherFactory - Class in org.mule.transport.sftp
Creates a SftpMessageDispatcher
SftpMessageDispatcherFactory() - Constructor for class org.mule.transport.sftp.SftpMessageDispatcherFactory
 
SftpMessageReceiver - Class in org.mule.transport.sftp
SftpMessageReceiver polls and receives files from an sftp service using jsch.
SftpMessageReceiver(SftpConnector, FlowConstruct, InboundEndpoint, long) - Constructor for class org.mule.transport.sftp.SftpMessageReceiver
 
SftpMessageReceiver(SftpConnector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.sftp.SftpMessageReceiver
 
SftpMessageRequester - Class in org.mule.transport.sftp
SftpMessageRequester polls files on request (e.g.
SftpMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.sftp.SftpMessageRequester
 
SftpMessageRequesterFactory - Class in org.mule.transport.sftp
 
SftpMessageRequesterFactory() - Constructor for class org.mule.transport.sftp.SftpMessageRequesterFactory
 
SftpMessages - Class in org.mule.transport.sftp.i18n
 
SftpMessages() - Constructor for class org.mule.transport.sftp.i18n.SftpMessages
 
SftpNamespaceHandler - Class in org.mule.transport.sftp.config
Registers a Bean Definition Parser for handling elements.
SftpNamespaceHandler() - Constructor for class org.mule.transport.sftp.config.SftpNamespaceHandler
 
SftpNotifier - Class in org.mule.transport.sftp.notification
 
SftpNotifier(SftpConnector, MuleMessage, ImmutableEndpoint, String) - Constructor for class org.mule.transport.sftp.notification.SftpNotifier
 
SftpProxyConfig - Class in org.mule.transport.sftp.config
A Proxy configuration for the SFTP connector.
SftpProxyConfig() - Constructor for class org.mule.transport.sftp.config.SftpProxyConfig
 
SftpProxyConfig.Protocol - Enum in org.mule.transport.sftp.config
 
SftpReceiverRequesterUtil - Class in org.mule.transport.sftp
Contains reusable methods not directly related to usage of the jsch sftp library (they can be found in the class SftpClient).
SftpReceiverRequesterUtil(ImmutableEndpoint) - Constructor for class org.mule.transport.sftp.SftpReceiverRequesterUtil
 
SftpServer - Class in org.mule.tck.util.sftp
 
SftpServer(int) - Constructor for class org.mule.tck.util.sftp.SftpServer
 
SftpTransportNotification - Class in org.mule.transport.sftp.notification
 
SftpTransportNotification(MuleMessage, ImmutableEndpoint, String, int, String, long) - Constructor for class org.mule.transport.sftp.notification.SftpTransportNotification
 
SftpTransportNotificationListener - Interface in org.mule.transport.sftp.notification
SftpTransportNotificationListener is an observer interface that objects can use to receive notifications about sftp operations such as put, get, rename and delete being performed by the sftp transport.
SftpUtil - Class in org.mule.transport.sftp
Contains reusable methods not directly related to usage of the jsch sftp library (they can be found in the class SftpClient).
SftpUtil(ImmutableEndpoint) - Constructor for class org.mule.transport.sftp.SftpUtil
 
SHA256MuleEventKeyGenerator - Class in org.mule.keygenerator
Implements MuleEventKeyGenerator applying SHA-256 digest to the event's message payload.
SHA256MuleEventKeyGenerator() - Constructor for class org.mule.keygenerator.SHA256MuleEventKeyGenerator
 
SHORT_PAYLOAD_CLASS_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 
ShortcutComponentDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
ShortcutComponentDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.ShortcutComponentDefinitionParser
 
shouldAggregateEvents(EventGroup) - Method in class org.mule.routing.correlation.CollectionCorrelatorCallback
 
shouldAggregateEvents(EventGroup) - Method in interface org.mule.routing.correlation.EventCorrelatorCallback
Determines if the event group is ready to be aggregated.
shouldConnect() - Method in class org.mule.transport.http.OldHttpMessageReceiver
 
shouldConsumeInEveryNode() - Method in class org.mule.transport.AbstractMessageReceiver
Determines whether to start or not the MessageSource base on the running node state.
shouldConsumeInEveryNode() - Method in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
shouldConsumeInEveryNode() - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver
 
shouldConsumeInEveryNode() - Method in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
shouldConsumeInEveryNode() - Method in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
shouldConsumeInEveryNode() - Method in class org.mule.transport.multicast.MulticastMessageReceiver
 
shouldInject(PropertyValues, PropertyDescriptor[], Object, String) - Method in class org.mule.config.spring.processors.ContextExclusiveInjectorProcessor
Only returns true if beanName is a key currently registered in the ContextExclusiveInjectorProcessor.applicationContext or if beanName equals the bean classname, which in spring jargon means that we're injecting a non registered object (most likely through Injector.inject(Object)
shouldInject(PropertyValues, PropertyDescriptor[], Object, String) - Method in class org.mule.config.spring.processors.NoDevkitInjectorProcessor
 
shouldProcessEvent(MuleEvent) - Method in class org.mule.routing.requestreply.AbstractReplyToPropertyRequestReplyReplier
 
shouldProcessEvent(MuleEvent) - Method in class org.mule.routing.requestreply.AsyncReplyToPropertyRequestReplyReplier
 
shouldProcessEvent(MuleEvent) - Method in class org.mule.routing.requestreply.ReplyToPropertyRequestReplyReplier
 
shouldRetry(MuleEvent) - Method in interface org.mule.module.http.api.HttpAuthentication
Detects if there was an authentication failure in the response.
shouldRetry(MuleEvent) - Method in class org.mule.module.http.internal.request.DefaultHttpAuthentication
 
shouldRetry(MuleEvent) - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
shouldRetry(MuleEvent) - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
shouldSoapActionHeader() - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
shouldWrap(Element) - Method in interface org.mule.config.spring.parsers.generic.WrappingChildDefinitionParser.WrappingController
 
shouldWrap(Element) - Method in class org.mule.config.spring.parsers.specific.FilterDefinitionParser
 
shouldWrap(Element) - Method in class org.mule.config.spring.parsers.specific.SecurityFilterDefinitionParser
 
showSplashScreen() - Method in class org.mule.module.launcher.MuleContainer
 
shutdown() - Method in class org.mule.module.cxf.transport.MuleUniversalDestination
 
shutdown(Throwable) - Method in class org.mule.module.launcher.MuleContainer
Will shut down the server displaying the cause and time of the shutdown
shutdown() - Method in class org.mule.module.launcher.MuleContainer
shutdown the server.
shutdown(Throwable) - Method in class org.mule.MuleServer
Will shut down the server displaying the cause and time of the shutdown
shutdown() - Method in class org.mule.MuleServer
shutdown the server.
shutdown(int, long) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
shutdown(int, long) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
shutdown(int, long) - Method in class org.mule.util.xa.AbstractResourceManager
 
SHUTDOWN_MODE_KILL - Static variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
Shutdown mode: Try to stop active transaction NOW, do no rollbacks
SHUTDOWN_MODE_KILL - Static variable in class org.mule.util.xa.AbstractResourceManager
Shutdown mode: Try to stop active transaction NOW, do no rollbacks
SHUTDOWN_MODE_NORMAL - Static variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
Shutdown mode: Wait for all transactions to complete
SHUTDOWN_MODE_NORMAL - Static variable in class org.mule.util.xa.AbstractResourceManager
Shutdown mode: Wait for all transactions to complete
SHUTDOWN_MODE_ROLLBACK - Static variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
Shutdown mode: Try to roll back all active transactions
SHUTDOWN_MODE_ROLLBACK - Static variable in class org.mule.util.xa.AbstractResourceManager
Shutdown mode: Try to roll back all active transactions
ShutdownListener - Interface in org.mule.module.launcher.artifact
Optional hook, invoked synchronously right before the class loader is disposed and closed.
shutdownListeners - Variable in class org.mule.module.launcher.artifact.AbstractArtifactClassLoader
 
shutdownNormally(Date) - Static method in class org.mule.config.i18n.CoreMessages
 
shutdownOutput() - Method in class org.apache.commons.httpclient.HttpConnection
Deprecated.
unused
shutdownScheduler() - Method in class org.mule.transport.AbstractConnector
 
shutdownScreen - Variable in class org.mule.context.DefaultMuleContextBuilder
 
shutdownSocket() - Method in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
signal(ActivityExecution, String, Map<String, ?>) - Method in class org.mule.module.jbpm.MuleReceiveActivity
 
SignatureKeyIdentifier - Enum in org.mule.module.ws.security
an Enum with all the possible Signature Key Identifier values.
SignedMessage - Class in org.mule.module.pgp
 
SignedMessage(InputStream, PGPSecretKey, String, PGPSecretKeyRingCollection) - Constructor for class org.mule.module.pgp.SignedMessage
 
SIMPLE_FRONTEND - Static variable in class org.mule.module.cxf.CxfConstants
 
SimpleAsyncRequestReplyRequester - Class in org.mule.routing.requestreply
 
SimpleAsyncRequestReplyRequester() - Constructor for class org.mule.routing.requestreply.SimpleAsyncRequestReplyRequester
 
SimpleCallableJavaComponent - Class in org.mule.component
Simple JavaComponent implementation to be used when LifecycleAdapter is not required because i) the object instance implements Callable and so entry-point resolution is required and ii) component bindings are not used.
An ObjectFactory can be set but must return object instances that implement Callable.
SimpleCallableJavaComponent() - Constructor for class org.mule.component.SimpleCallableJavaComponent
 
SimpleCallableJavaComponent(Callable) - Constructor for class org.mule.component.SimpleCallableJavaComponent
Create an SimpleCallableJavaComponent instance using an object instance that implements Callable
SimpleCallableJavaComponent(Class) - Constructor for class org.mule.component.SimpleCallableJavaComponent
Create an SimpleCallableJavaComponent instance using an object class.
SimpleCallableJavaComponent(ObjectFactory) - Constructor for class org.mule.component.SimpleCallableJavaComponent
 
SimpleClientFactoryBean - Class in org.mule.module.cxf.config
 
SimpleClientFactoryBean() - Constructor for class org.mule.module.cxf.config.SimpleClientFactoryBean
 
SimpleClientMessageProcessorBuilder - Class in org.mule.module.cxf.builder
 
SimpleClientMessageProcessorBuilder() - Constructor for class org.mule.module.cxf.builder.SimpleClientMessageProcessorBuilder
 
SimpleCollectionAggregator - Class in org.mule.routing
This router will return all aggregated events as a MuleMessageCollection.
SimpleCollectionAggregator() - Constructor for class org.mule.routing.SimpleCollectionAggregator
 
SimpleComponentDefinitionParser - Class in org.mule.config.spring.parsers.specific
Used to parse shortcut elements for simple built-in components such as EchoComponent and LogComponent.
SimpleComponentDefinitionParser(Class, Class) - Constructor for class org.mule.config.spring.parsers.specific.SimpleComponentDefinitionParser
 
SimpleConfigurationBuilder - Class in org.mule.config.builders
This simple ConfgurationBuilder implementation.
SimpleConfigurationBuilder(Map) - Constructor for class org.mule.config.builders.SimpleConfigurationBuilder
 
SimpleConnectionFactory - Class in org.mule.module.db.internal.domain.connection
Creates a Connection from a DataSource
SimpleConnectionFactory(Map<String, Class<?>>) - Constructor for class org.mule.module.db.internal.domain.connection.SimpleConnectionFactory
 
SimpleConnectionProvider - Class in org.hibernate.connection
This is the Hibernate class org.hibernate.connection.connection.DriverManagerConnectionProvider, tweaked in order to work with Mule's hot deployment.
SimpleConnectionProvider() - Constructor for class org.hibernate.connection.SimpleConnectionProvider
 
SimpleConsumer<T> - Class in org.mule.streaming
Basic implementation of Consumer that simply returns the objects returned by the underlying Producer
SimpleConsumer(Producer<T>) - Constructor for class org.mule.streaming.SimpleConsumer
 
SimpleContext - Class in org.mule.jndi
 
SimpleContext() - Constructor for class org.mule.jndi.SimpleContext
 
SimpleDataType<T> - Class in org.mule.transformer.types
A data type that simply wraps a Java type.
SimpleDataType(Class<?>, String) - Constructor for class org.mule.transformer.types.SimpleDataType
 
SimpleDataType(Class) - Constructor for class org.mule.transformer.types.SimpleDataType
 
SimpleEndpointCache - Class in org.mule.endpoint
Cache endpoints in order to prevent memory leaks.
SimpleEndpointCache(MuleContext) - Constructor for class org.mule.endpoint.SimpleEndpointCache
 
SimpleFieldDebugInfo - Class in org.mule.api.debug
Provides debug information for an object's field that contains a simple value.
SimpleJndiNameResolver - Class in org.mule.transport.jms.jndi
Defines a simple JndiNameResolver that maintains a Context instance opened all the time and always relies on the context to do the look ups.
SimpleJndiNameResolver() - Constructor for class org.mule.transport.jms.jndi.SimpleJndiNameResolver
 
SimpleLifecycleManager<O> - Class in org.mule.lifecycle
This LifecycleManager implementation is designed to track the lifecycle of objects that support the Initialisable.PHASE_NAME, Startable.PHASE_NAME, Stoppable.PHASE_NAME and Disposable.PHASE_NAME phases and adds convenience methods for firing these phases by callbacks.
SimpleLifecycleManager(String, O) - Constructor for class org.mule.lifecycle.SimpleLifecycleManager
 
SimpleLoggingTable - Class in org.mule.util
Provides a simple table implementation useful to log information in a tabular form.
SimpleLoggingTable() - Constructor for class org.mule.util.SimpleLoggingTable
 
SimpleMemoryObjectStore<T extends Serializable> - Class in org.mule.util.store
 
SimpleMemoryObjectStore() - Constructor for class org.mule.util.store.SimpleMemoryObjectStore
 
SimpleMemoryQueueStoreFactoryBean - Class in org.mule.config.spring.factories
 
SimpleMemoryQueueStoreFactoryBean() - Constructor for class org.mule.config.spring.factories.SimpleMemoryQueueStoreFactoryBean
 
SimpleMessageProcessorChain - Class in org.mule.processor.chain
 
SimpleMessageProcessorChain(List<MessageProcessor>) - Constructor for class org.mule.processor.chain.SimpleMessageProcessorChain
 
SimpleMessageProcessorChain(MessageProcessor...) - Constructor for class org.mule.processor.chain.SimpleMessageProcessorChain
 
SimpleMessageProcessorChain(String, List<MessageProcessor>) - Constructor for class org.mule.processor.chain.SimpleMessageProcessorChain
 
SimpleMessageProcessorChain(String, MessageProcessor...) - Constructor for class org.mule.processor.chain.SimpleMessageProcessorChain
 
SimpleMessageProcessorChainBuilder - Class in org.mule.processor.chain
 
SimpleMessageProcessorChainBuilder() - Constructor for class org.mule.processor.chain.SimpleMessageProcessorChainBuilder
 
SimpleMessageProcessorChainBuilder(FlowConstruct) - Constructor for class org.mule.processor.chain.SimpleMessageProcessorChainBuilder
 
SimpleOptions - Class in org.mule.client
Default implementation for OperationOptions
SimpleOptions(Long) - Constructor for class org.mule.client.SimpleOptions
 
SimpleOptionsBuilder - Class in org.mule.api.client
Most basic options builder that every connector must be able to use for configuration.
SimpleOptionsBuilder() - Constructor for class org.mule.api.client.SimpleOptionsBuilder
 
SimplePasswordJmxAuthenticator - Class in org.mule.module.management.support
A JMX authenticator for a simple username/password scheme.
SimplePasswordJmxAuthenticator() - Constructor for class org.mule.module.management.support.SimplePasswordJmxAuthenticator
 
SimplePrinter - Class in org.mule.management.stats.printers
SimplePrinter Default stats printer
SimplePrinter(Writer) - Constructor for class org.mule.management.stats.printers.SimplePrinter
 
SimplePrinter(OutputStream) - Constructor for class org.mule.management.stats.printers.SimplePrinter
 
SimplePropertyConfiguration - Class in org.mule.config.spring.parsers.assembly.configuration
A direct implementation of PropertyConfiguration
SimplePropertyConfiguration() - Constructor for class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
SimplePropertyConfiguration.IndentityMapValueMap - Class in org.mule.config.spring.parsers.assembly.configuration
 
SimplePropertyConfiguration.IndentityMapValueMap(Map<String, Object>) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration.IndentityMapValueMap
 
SimplePropertyConfiguration.MapValueMap - Class in org.mule.config.spring.parsers.assembly.configuration
 
SimplePropertyConfiguration.MapValueMap(Map<String, Object>) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration.MapValueMap
 
SimplePropertyConfiguration.MapValueMap(String) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration.MapValueMap
 
SimplePropertyConfiguration.NamedValueMap - Class in org.mule.config.spring.parsers.assembly.configuration
 
SimplePropertyConfiguration.NamedValueMap(String, String) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration.NamedValueMap
 
SimplePropertyConfiguration.NamedValueMap(String, Map<String, Object>) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration.NamedValueMap
 
SimplePropertyConfiguration.NamedValueMap(String, ValueMap) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration.NamedValueMap
 
SimplePropertyDefinitionParser - Class in org.mule.config.spring.parsers.specific.properties
 
SimplePropertyDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.properties.SimplePropertyDefinitionParser
 
SimpleQueryTemplateParser - Class in org.mule.module.db.internal.parser
Simple SQL parser
SimpleQueryTemplateParser() - Constructor for class org.mule.module.db.internal.parser.SimpleQueryTemplateParser
 
SimpleRegistry - Class in org.mule.registry
A very simple implementation of LifecycleRegistry.
SimpleRegistry(MuleContext) - Constructor for class org.mule.registry.SimpleRegistry
 
SimpleRegistryBootstrap - Class in org.mule.config.bootstrap
Deprecated.
as of 3.7.0. Try to use SpringRegistryBootstrap instead.
SimpleRegistryBootstrap() - Constructor for class org.mule.config.bootstrap.SimpleRegistryBootstrap
Deprecated.
 
SimpleRegistryBootstrap(RegistryBootstrapDiscoverer) - Constructor for class org.mule.config.bootstrap.SimpleRegistryBootstrap
Deprecated.
 
SimpleRequestReplyReplier - Class in org.mule.routing.requestreply
 
SimpleRequestReplyReplier() - Constructor for class org.mule.routing.requestreply.SimpleRequestReplyReplier
 
SimpleRetryPolicy - Class in org.mule.retry.policies
Allows to configure how many times a retry should be attempted and how long to wait between retries.
SimpleRetryPolicy(long, int) - Constructor for class org.mule.retry.policies.SimpleRetryPolicy
 
SimpleRetryPolicy.RetryCounter - Class in org.mule.retry.policies
 
SimpleRetryPolicy.RetryCounter() - Constructor for class org.mule.retry.policies.SimpleRetryPolicy.RetryCounter
 
SimpleRetryPolicyTemplate - Class in org.mule.retry.policies
This policy allows the user to configure how many times a retry should be attempted and how long to wait between retries.
SimpleRetryPolicyTemplate() - Constructor for class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
SimpleRetryPolicyTemplate(long, int) - Constructor for class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
SimpleServerSocketFactory - Interface in org.mule.transport.tcp
 
SimpleService - Class in org.mule.construct
In-out SOA-style simple service, with no outbound router.
SimpleService(String, MuleContext, MessageSource, List<MessageProcessor>, List<MessageProcessor>, Component, SimpleService.Type) - Constructor for class org.mule.construct.SimpleService
 
SimpleService.Type - Enum in org.mule.construct
 
SimpleServiceBuilder - Class in org.mule.construct.builder
Fluent API for the creation of a SimpleService.
SimpleServiceBuilder() - Constructor for class org.mule.construct.builder.SimpleServiceBuilder
 
SimpleServiceDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
SimpleServiceDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.SimpleServiceDefinitionParser
 
SimpleServiceFactoryBean - Class in org.mule.config.spring.factories
Builds SimpleService instances by using the SimpleServiceBuilder.
SimpleServiceFactoryBean() - Constructor for class org.mule.config.spring.factories.SimpleServiceFactoryBean
 
SimpleServiceTypePropertyEditor - Class in org.mule.config.spring.editors
 
SimpleServiceTypePropertyEditor() - Constructor for class org.mule.config.spring.editors.SimpleServiceTypePropertyEditor
 
SimpleSessionHandler - Class in org.mule.session
A session handler used to store and retrieve session information on an event.
SimpleSessionHandler() - Constructor for class org.mule.session.SimpleSessionHandler
 
SimpleTypeDataQualifierVisitor - Class in org.mule.module.extension.internal.introspection
Base implementation for a DataQualifierVisitor which adds the new method SimpleTypeDataQualifierVisitor.onSimpleType() which is invoked by all the DataQualifiers which refer to a simple type.
SimpleTypeDataQualifierVisitor() - Constructor for class org.mule.module.extension.internal.introspection.SimpleTypeDataQualifierVisitor
 
SimpleUpdateSqlStatementStrategy - Class in org.mule.transport.jdbc.sqlstrategy
Implements strategy for handling individual insert, update, and delete statements
SimpleUpdateSqlStatementStrategy() - Constructor for class org.mule.transport.jdbc.sqlstrategy.SimpleUpdateSqlStatementStrategy
 
simpleUpdateSQLStrategy - Variable in class org.mule.transport.jdbc.sqlstrategy.DefaultSqlStatementStrategyFactory
 
SINGLE_DISPATCHER_PER_ENDPOINT_SYSTEM_PROPERTY - Static variable in class org.mule.transport.http.HttpConnector
 
SINGLE_TX - Static variable in class org.mule.config.bootstrap.AbstractRegistryBootstrap
 
SingleJmsMessageReceiver - Class in org.mule.transport.jms
Registers a single Jms MessageListener for an endpoint
SingleJmsMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.jms.SingleJmsMessageReceiver
 
SingleParentFamilyDefinitionParser - Class in org.mule.config.spring.parsers.delegate
 
SingleParentFamilyDefinitionParser(MuleDefinitionParser) - Constructor for class org.mule.config.spring.parsers.delegate.SingleParentFamilyDefinitionParser
 
SingleProperty - Interface in org.mule.config.spring.parsers.assembly.configuration
 
SinglePropertyLiteral - Class in org.mule.config.spring.parsers.assembly.configuration
 
SinglePropertyLiteral(boolean, boolean, boolean) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyLiteral
 
SinglePropertyLiteral(boolean) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyLiteral
 
SinglePropertyLiteral() - Constructor for class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyLiteral
 
SinglePropertyWrapper - Class in org.mule.config.spring.parsers.assembly.configuration
 
SinglePropertyWrapper(String, PropertyConfiguration) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.SinglePropertyWrapper
 
SingleQueryLogger - Interface in org.mule.module.db.internal.domain.logger
Logs a single query
SingleResourceTransactionFactoryManager - Class in org.mule.api
 
SingleResourceTransactionFactoryManager() - Constructor for class org.mule.api.SingleResourceTransactionFactoryManager
 
SingleResultResultSetCloser - Class in org.mule.module.db.internal.result.resultset
Closes a ResultSet and related Statement
SingleResultResultSetCloser() - Constructor for class org.mule.module.db.internal.result.resultset.SingleResultResultSetCloser
 
SingleServerLockProvider - Class in org.mule.util.lock
LockProvider implementation for applications running in a single mule server
SingleServerLockProvider() - Constructor for class org.mule.util.lock.SingleServerLockProvider
 
singleton - Variable in class org.mule.config.spring.parsers.AbstractMuleBeanDefinitionParser
 
SINGLETON_PROPERTY - Static variable in class org.mule.config.endpoint.ConfigurableTransportFactory
 
singletonChain(MessageProcessor) - Static method in class org.mule.api.processor.MessageProcessors
 
singletonComponentLifecycleAdapter - Variable in class org.mule.component.DefaultJavaComponent
 
singletonList(Object) - Static method in class org.mule.util.CollectionUtils
 
SingletonObjectFactory - Class in org.mule.object
Creates an instance of the object once and then always returns the same instance.
SingletonObjectFactory() - Constructor for class org.mule.object.SingletonObjectFactory
For Spring only
SingletonObjectFactory(String) - Constructor for class org.mule.object.SingletonObjectFactory
 
SingletonObjectFactory(String, Map) - Constructor for class org.mule.object.SingletonObjectFactory
 
SingletonObjectFactory(Class) - Constructor for class org.mule.object.SingletonObjectFactory
 
SingletonObjectFactory(Class<?>, Map) - Constructor for class org.mule.object.SingletonObjectFactory
 
SingletonObjectFactory(Object) - Constructor for class org.mule.object.SingletonObjectFactory
Create the singleton based on a previously created object.
SingleUpdateProcessorDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
SingleUpdateProcessorDefinitionParser(List<QueryType>) - Constructor for class org.mule.module.db.internal.config.processor.SingleUpdateProcessorDefinitionParser
 
SingleValueSetter - Class in org.mule.module.extension.internal.util
An implementation of ValueSetter for assigning the value of a single, non grouped Parameter

For performance reasons, it caches the setter to be used

SingleValueSetter(Parameter, Field) - Constructor for class org.mule.module.extension.internal.util.SingleValueSetter
 
singularize(String) - Static method in class org.mule.module.extension.internal.util.NameUtils
Return the singularized version of a word.
size() - Method in interface org.mule.api.MuleMessageCollection
 
size() - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
size() - Method in class org.mule.config.spring.parsers.delegate.AbstractDelegatingDefinitionParser
 
size() - Method in class org.mule.DefaultMessageCollection
 
size() - Method in class org.mule.el.context.AbstractMapContext
 
size() - Method in class org.mule.expression.InboundAttachmentsMap
 
size() - Method in class org.mule.expression.OutboundAttachmentsMap
 
size() - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
size() - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
size() - Method in class org.mule.module.http.internal.ParameterMap
 
size() - Method in class org.mule.module.launcher.util.ObservableList
 
size() - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
size() - Method in class org.mule.routing.EventGroup
Returns the number of events collected so far.
size() - Method in interface org.mule.routing.MessageSequence
The number of members of the sequence.
size() - Method in class org.mule.routing.outbound.ArrayMessageSequence
 
size() - Method in class org.mule.routing.outbound.CollectionMessageSequence
 
size() - Method in class org.mule.routing.outbound.IteratorMessageSequence
 
size() - Method in class org.mule.routing.outbound.NodeListMessageSequence
 
size() - Method in class org.mule.routing.outbound.PartitionedMessageSequence
 
size() - Method in class org.mule.routing.outbound.SplitMessage
 
size() - Method in class org.mule.streaming.AbstractConsumer
returns the total amount of items available for storage/processing.
size() - Method in class org.mule.streaming.CompositeProducer
Accumulates the total available count of all the producers.
size() - Method in class org.mule.streaming.ConsumerIterator
 
size() - Method in class org.mule.streaming.ListableObjectStoreProducer
 
size() - Method in class org.mule.streaming.ListConsumer
returns the total amount of items available for storage/processing.
size() - Method in class org.mule.streaming.PagingDelegateProducer
Returns the total amount of available results informed by delegate
size() - Method in interface org.mule.streaming.ProvidesTotalHint
returns the total amount of items available for storage/processing.
size() - Method in class org.mule.streaming.QueueProducer
 
size(Object) - Static method in class org.mule.transport.http.multipart.LazyList
The size of a lazy List
size() - Method in class org.mule.transport.http.multipart.MultiMap
 
size() - Method in class org.mule.util.CaseInsensitiveMapWrapper
 
size() - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
size() - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
size() - Method in class org.mule.util.MapCombiner
 
size() - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
 
size() - Method in class org.mule.util.queue.DefaultQueueStoreDelegate
 
size() - Method in class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
 
size(QueueStore) - Method in class org.mule.util.queue.LocalTxQueueTransactionContext
 
size(QueueInfo) - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
size(QueueStore) - Method in class org.mule.util.queue.PersistentQueueTransactionContext
 
size(QueueStore) - Method in class org.mule.util.queue.PersistentXaTransactionContext
 
size() - Method in interface org.mule.util.queue.Queue
Returns the number of elements in this queue.
size(QueueStore) - Method in interface org.mule.util.queue.QueueTransactionContext
 
size(QueueStore) - Method in class org.mule.util.queue.QueueTypeTransactionContextAdapter
 
size() - Method in class org.mule.util.queue.TransactionAwareQueueStore
 
size(QueueStore) - Method in class org.mule.util.queue.TransientQueueTransactionContext
 
size(QueueStore) - Method in class org.mule.util.queue.TransientXaTransactionAdapter
 
size(QueueStore) - Method in class org.mule.util.queue.XaQueueTypeTransactionContextAdapter
 
size() - Method in class org.mule.util.store.ObjectStoreToMapAdapter
 
skip(long) - Method in class org.mule.model.streaming.DelegatingInputStream
 
skipAttributes() - Method in class org.mule.util.ClassReader
 
skipFully(int) - Method in class org.mule.util.ClassReader
skip n bytes in the input stream.
SMALLINT_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
SMTP - Static variable in class org.mule.transport.email.SmtpConnector
 
SmtpConnector - Class in org.mule.transport.email
SmtpConnector is used to connect to and send data to an SMTP mail server
SmtpConnector(MuleContext) - Constructor for class org.mule.transport.email.SmtpConnector
 
SmtpMessageDispatcher - Class in org.mule.transport.email
SmtpMessageDispatcher will dispatch Mule events as Mime email messages over an SMTP gateway.
SmtpMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.email.SmtpMessageDispatcher
 
SmtpMessageDispatcherFactory - Class in org.mule.transport.email
SmtpMessageDispatcherFactory creates an instance of an SmtpMessage dispatcher used for sending email events via an SMTP gateway
SmtpMessageDispatcherFactory() - Constructor for class org.mule.transport.email.SmtpMessageDispatcherFactory
 
SmtpNamespaceHandler - Class in org.mule.transport.email.config
Namespace handler for the namespace
SmtpNamespaceHandler() - Constructor for class org.mule.transport.email.config.SmtpNamespaceHandler
 
SMTPS - Static variable in class org.mule.transport.email.SmtpsConnector
 
SmtpsConnector - Class in org.mule.transport.email
Creates a secure SMTP connection
SmtpsConnector(MuleContext) - Constructor for class org.mule.transport.email.SmtpsConnector
 
SmtpsNamespaceHandler - Class in org.mule.transport.email.config
Namespace handler for the namespace
SmtpsNamespaceHandler() - Constructor for class org.mule.transport.email.config.SmtpsNamespaceHandler
 
SmtpsSocketFactory - Class in org.mule.transport.email
A socket factor that reads "indirect" configuration (see TlsConfiguration) for SMTPS from System properties.
SmtpsSocketFactory() - Constructor for class org.mule.transport.email.SmtpsSocketFactory
 
SNAPSHOT_CAPTURING - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
this mark is added to getStatus to indicate that captureEverySec was stated
SNAPSHOT_HPROF - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
SNAPSHOT_WITH_HEAP - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
SNAPSHOT_WITHOUT_HEAP - Static variable in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
SOAP_ACTION_PROPERTY - Static variable in interface org.mule.module.cxf.SoapConstants
 
SOAP_ACTION_PROPERTY_CAPS - Static variable in interface org.mule.module.cxf.SoapConstants
 
SOAP_ENDPOINT_PREFIX - Static variable in interface org.mule.module.cxf.SoapConstants
 
SOAP_HEADERS_PROPERTY_PREFIX - Static variable in class org.mule.module.ws.consumer.WSConsumer
 
SOAP_METHODS - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
SOAP_NAMESPACE_PROPERTY - Static variable in interface org.mule.module.cxf.SoapConstants
 
SoapActionInterceptor - Class in org.mule.module.ws.consumer
CXF interceptor that adds the SOAP action to the message.
SoapActionInterceptor(String) - Constructor for class org.mule.module.ws.consumer.SoapActionInterceptor
 
SoapConstants - Interface in org.mule.module.cxf
Common SOAP constants
SoapFaultException - Exception in org.mule.module.ws.consumer
Exception thrown by the Web Services Consumer when processing a SOAP fault.
SoapFaultException(MuleEvent, QName, QName, String, Element, MessageProcessor) - Constructor for exception org.mule.module.ws.consumer.SoapFaultException
Deprecated.
SoapFaultException(MuleEvent, SoapFault, MessageProcessor) - Constructor for exception org.mule.module.ws.consumer.SoapFaultException
 
SoapMethod - Class in org.mule.transport.soap.axis
A SOAP method representation where the parameters are named
SoapMethod(String, String) - Constructor for class org.mule.transport.soap.axis.SoapMethod
 
SoapMethod(String, List<String>) - Constructor for class org.mule.transport.soap.axis.SoapMethod
Creates a Soap Method using the param string set in the MUle configuration file
SoapMethod(QName, String) - Constructor for class org.mule.transport.soap.axis.SoapMethod
 
SoapMethod(QName, List<String>) - Constructor for class org.mule.transport.soap.axis.SoapMethod
 
SoapMethod(QName) - Constructor for class org.mule.transport.soap.axis.SoapMethod
 
SoapMethod(QName, QName) - Constructor for class org.mule.transport.soap.axis.SoapMethod
 
SoapMethod(QName, QName, Class<?>) - Constructor for class org.mule.transport.soap.axis.SoapMethod
 
SoapMethod(QName, Class<?>) - Constructor for class org.mule.transport.soap.axis.SoapMethod
 
SoapMethod(QName, List<NamedParameter>, QName) - Constructor for class org.mule.transport.soap.axis.SoapMethod
 
soapService - Variable in class org.mule.transport.soap.axis.AxisMessageReceiver
 
SoapServiceFinder - Class in org.mule.transport.soap.axis
SoapServiceFinder finds a the connector service to use by checking the classpath for jars required for each of the soap connector implementations
SoapServiceFinder() - Constructor for class org.mule.transport.soap.axis.SoapServiceFinder
 
soapVersion - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
SoapVersion - Enum in org.mule.module.ws.consumer
 
socket - Variable in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
socket - Variable in class org.mule.transport.udp.UdpMessageReceiver
 
SOCKET_ATTRIBUTES - Static variable in class org.mule.endpoint.URIBuilder
 
SocketConfigTransportCustomizer - Class in org.mule.module.http.internal.request.grizzly
Transport customizer that configures socket properties.
SocketConfigTransportCustomizer(TcpClientSocketProperties) - Constructor for class org.mule.module.http.internal.request.grizzly.SocketConfigTransportCustomizer
 
SocketEndpointURIBuilder - Class in org.mule.endpoint
SocketEndpointBuilder builds an endpointUri based on host and port only
SocketEndpointURIBuilder() - Constructor for class org.mule.endpoint.SocketEndpointURIBuilder
 
socketFactory - Variable in class org.mule.transport.udp.UdpConnector
 
sortLifecycleInstances(Collection<?>, LifecycleObject) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
Subclasses can override this method to order objects before the lifecycle method is applied to them.
source - Variable in class org.mule.module.db.internal.processor.AbstractBulkUpdateMessageProcessor
 
SOURCE_DOCUMENT_NAMESPACE - Static variable in class org.mule.module.xml.transformer.XQueryTransformer
 
SOURCE_MESSAGE_PROCESSOR_PROPERTY_NAME - Static variable in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
The InboundEndpoint property for poll that contains the poll message source.
SourceCallback - Interface in org.mule.api.callback
Callback interface used by message source annotated methods to dispatch messages.
sourceClass - Variable in class org.mule.module.json.transformers.ObjectToJson
 
sourceClass - Variable in class org.mule.module.xml.transformer.jaxb.JAXBMarshallerTransformer
 
sourceMessageProcessor - Variable in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
The poll message source, configured inside the poll element in the xml configuration.
sources - Variable in class org.mule.config.spring.factories.CompositeMessageSourceFactoryBean
 
sources - Variable in class org.mule.source.StartableCompositeMessageSource
 
sourceTypes - Variable in class org.mule.transformer.AbstractTransformer
A list of supported Class types that the source payload passed into this transformer
SPACE_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
SpiServiceRegistry - Class in org.mule.registry
Implementation of ServiceRegistry that uses standard ServiceLoader to get the providers
SpiServiceRegistry() - Constructor for class org.mule.registry.SpiServiceRegistry
 
SpiUtils - Class in org.mule.util
 
SpiUtils() - Constructor for class org.mule.util.SpiUtils
 
SplashScreen - Class in org.mule.util
Implements singleton pattern to allow different splash-screen implementations following the concept of header, body, and footer.
SplashScreen() - Constructor for class org.mule.util.SplashScreen
 
split(String) - Method in class org.mule.config.expression.ExpressionFilterParser
 
split(MuleEvent) - Method in class org.mule.util.collection.EventToMessageSequenceSplittingStrategy
 
split(Input) - Method in interface org.mule.util.collection.SplittingStrategy
 
splitAndTrim(String, String) - Static method in class org.mule.util.StringUtils
Like StringUtils.split(String, String), but additionally trims whitespace from the result tokens.
splitArgumentsExpression(String) - Static method in class org.mule.api.processor.util.InvokerMessageProcessorUtil
Split and merge comma separated mule expressions when they falls within an array
splitCamelCase(String) - Static method in class org.mule.config.spring.handlers.AbstractPojoNamespaceHandler
 
splitMessage(MuleEvent) - Method in class org.mule.module.atom.routing.FeedSplitter
 
splitMessage(MuleEvent) - Method in class org.mule.module.rss.routing.FeedSplitter
 
splitMessage(MuleEvent) - Method in class org.mule.routing.AbstractSplitter
 
splitMessage(MuleEvent) - Method in class org.mule.routing.ExpressionSplitter
 
splitMessage(MuleEvent) - Method in class org.mule.routing.MapSplitter
 
splitMessage(MuleEvent) - Method in class org.mule.routing.MessageChunkSplitter
 
splitMessage(MuleMessage) - Method in class org.mule.routing.outbound.AbstractRoundRobinMessageSplitter
Method used just to split the message into parts.
splitMessage(MuleMessage) - Method in class org.mule.routing.outbound.ExpressionMessageSplitter
Deprecated.
 
splitMessage(MuleMessage) - Method in class org.mule.routing.outbound.ListMessageSplitter
Deprecated.
 
SplitMessage - Class in org.mule.routing.outbound
A Split message contains one or more message parts with an endpoint associated with each part.
SplitMessage() - Constructor for class org.mule.routing.outbound.SplitMessage
 
SplitMessage.MessagePart - Class in org.mule.routing.outbound
 
SplitMessage.MessagePart(OutboundEndpoint, Object) - Constructor for class org.mule.routing.outbound.SplitMessage.MessagePart
 
splitMessageIntoSequence(MuleEvent) - Method in class org.mule.routing.AbstractSplitter
 
splitMessageIntoSequence(MuleEvent) - Method in class org.mule.routing.CollectionSplitter
 
splitMessageIntoSequence(MuleEvent) - Method in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
Converts the event into a MessageSequence that will retrieve each of the event elements
splitMessageNoEndpointMatch(List<?>, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
SplitterDefinitionParser - Class in org.mule.config.spring.parsers.specific
Generic router definition parser for parsing all Router elements.
SplitterDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.SplitterDefinitionParser
 
SplitterDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.SplitterDefinitionParser
 
SplittingStrategy<Input,Output> - Interface in org.mule.util.collection
 
SPRING_APPLICATION_CONTEXT - Static variable in class org.mule.config.spring.SpringRegistry
Key used to lookup Spring Application Context from SpringRegistry via Mule's Registry interface.
SpringAuthenticationAdapter - Class in org.mule.module.spring.security
 
SpringAuthenticationAdapter(Authentication) - Constructor for class org.mule.module.spring.security.SpringAuthenticationAdapter
 
SpringAuthenticationAdapter(Authentication, Map<String, Object>) - Constructor for class org.mule.module.spring.security.SpringAuthenticationAdapter
 
SpringAuthenticationAdapter(Authentication, Map<String, Object>, MuleEvent) - Constructor for class org.mule.module.spring.security.SpringAuthenticationAdapter
 
SpringAuthenticationProvider - Interface in org.mule.module.spring.security
A provider for spring authentication
springAuthenticationRequired() - Static method in class org.mule.module.spring.security.i18n.SpringSecurityMessages
 
SpringBeanLookup - Class in org.mule.config.spring.util
This is an implementation of the ObjectFactory interface which simply delegates to the Spring ApplicationContext.
SpringBeanLookup() - Constructor for class org.mule.config.spring.util.SpringBeanLookup
 
SpringConfigurationBuilder - Class in org.mule.config.spring
Adds an existing Spring ApplicationContext to Mule's internal collection of Registries.
SpringConfigurationBuilder(ApplicationContext) - Constructor for class org.mule.config.spring.SpringConfigurationBuilder
 
SpringConfigurationBuilder(ConfigurableApplicationContext, ApplicationContext) - Constructor for class org.mule.config.spring.SpringConfigurationBuilder
 
springContextInitialised - Variable in class org.mule.config.spring.SpringRegistry
 
SpringInitialContextFactory - Class in org.mule.config.spring.jndi
TODO
SpringInitialContextFactory() - Constructor for class org.mule.config.spring.jndi.SpringInitialContextFactory
 
SpringMessages - Class in org.mule.module.spring.i18n
 
SpringMessages() - Constructor for class org.mule.module.spring.i18n.SpringMessages
 
SpringProviderAdapter - Class in org.mule.module.spring.security
SpringProviderAdapter is a wrapper for a Spring Security provider to use with the SecurityManager
SpringProviderAdapter() - Constructor for class org.mule.module.spring.security.SpringProviderAdapter
For Spring IoC only
SpringProviderAdapter(AuthenticationManager) - Constructor for class org.mule.module.spring.security.SpringProviderAdapter
 
SpringProviderAdapter(AuthenticationManager, String) - Constructor for class org.mule.module.spring.security.SpringProviderAdapter
 
SpringRegistry - Class in org.mule.config.spring
 
SpringRegistry(ApplicationContext, MuleContext) - Constructor for class org.mule.config.spring.SpringRegistry
 
SpringRegistry(String, ApplicationContext, MuleContext) - Constructor for class org.mule.config.spring.SpringRegistry
 
SpringRegistry(ConfigurableApplicationContext, ApplicationContext, MuleContext) - Constructor for class org.mule.config.spring.SpringRegistry
 
SpringRegistry(String, ConfigurableApplicationContext, ApplicationContext, MuleContext) - Constructor for class org.mule.config.spring.SpringRegistry
 
SpringRegistryBootstrap - Class in org.mule.config.spring
SpringRegistryBootstrap() - Constructor for class org.mule.config.spring.SpringRegistryBootstrap
 
SpringRegistryLifecycleManager - Class in org.mule.config.spring
 
SpringRegistryLifecycleManager(String, SpringRegistry, MuleContext) - Constructor for class org.mule.config.spring.SpringRegistryLifecycleManager
 
SpringRemoteInvokerComponent - Class in org.mule.module.spring.remoting
 
SpringRemoteInvokerComponent() - Constructor for class org.mule.module.spring.remoting.SpringRemoteInvokerComponent
 
SpringSecurityContext - Class in org.mule.module.spring.security
SpringSecurityContext is a SecurityContext wrapper used to interface with an Spring's SecurityContext.
SpringSecurityContext(SecurityContext) - Constructor for class org.mule.module.spring.security.SpringSecurityContext
 
SpringSecurityContextFactory - Class in org.mule.module.spring.security
SpringSecurityContextFactory creates an SpringSecurityContext for an Authentication object.
SpringSecurityContextFactory() - Constructor for class org.mule.module.spring.security.SpringSecurityContextFactory
 
SpringSecurityMessages - Class in org.mule.module.spring.security.i18n
 
SpringSecurityMessages() - Constructor for class org.mule.module.spring.security.i18n.SpringSecurityMessages
 
SpringSecurityNamespaceHandler - Class in org.mule.module.spring.security.config
Registers a Bean Definition Parser for handling Spring Security related elements.
SpringSecurityNamespaceHandler() - Constructor for class org.mule.module.spring.security.config.SpringSecurityNamespaceHandler
 
SpringTransactionFactory - Class in org.mule.module.spring.transaction
TODO: document this class
SpringTransactionFactory() - Constructor for class org.mule.module.spring.transaction.SpringTransactionFactory
 
SpringTransactionFactory.SpringTransaction - Class in org.mule.module.spring.transaction
TODO: document this class
SpringTransactionFactory.SpringTransaction(MuleContext) - Constructor for class org.mule.module.spring.transaction.SpringTransactionFactory.SpringTransaction
 
SpringTransactionManagerFactory - Class in org.mule.module.spring.transaction
A holder to a transaction manager set via a Spring Application context
SpringTransactionManagerFactory() - Constructor for class org.mule.module.spring.transaction.SpringTransactionManagerFactory
 
SpringXmlConfigurationBuilder - Class in org.mule.config.spring
SpringXmlConfigurationBuilder enables Mule to be configured from a Spring XML Configuration file used with Mule name-spaces.
SpringXmlConfigurationBuilder(String[]) - Constructor for class org.mule.config.spring.SpringXmlConfigurationBuilder
 
SpringXmlConfigurationBuilder(String) - Constructor for class org.mule.config.spring.SpringXmlConfigurationBuilder
 
SpringXmlConfigurationBuilder(ConfigResource[]) - Constructor for class org.mule.config.spring.SpringXmlConfigurationBuilder
 
SpringXmlConfigurationMuleArtifactFactory - Class in org.mule.config.spring
 
SpringXmlConfigurationMuleArtifactFactory() - Constructor for class org.mule.config.spring.SpringXmlConfigurationMuleArtifactFactory
 
SpringXmlDomainConfigurationBuilder - Class in org.mule.config.spring
Spring configuration builder used to create domains.
SpringXmlDomainConfigurationBuilder(String) - Constructor for class org.mule.config.spring.SpringXmlDomainConfigurationBuilder
 
SpringXMLUtils - Class in org.mule.config.spring.util
These only depend on standard (JSE) XML classes and are used by Spring config code.
SpringXMLUtils() - Constructor for class org.mule.config.spring.util.SpringXMLUtils
 
SQL_STATEMENT_FACTORY_PROPERTY - Static variable in class org.mule.transport.jdbc.config.JdbcNamespaceHandler
 
SQL_TEXT_DEBUG_FIELD - Static variable in class org.mule.module.db.internal.processor.DbDebugInfoUtils
 
SQLExceptionReader - Class in org.mule.transport.jdbc
Surfaces information about SQLExceptions such as the code and sql state.
SQLExceptionReader() - Constructor for class org.mule.transport.jdbc.SQLExceptionReader
 
SqlStatementStrategy - Interface in org.mule.transport.jdbc.sqlstrategy
 
SqlStatementStrategyExecutor - Class in org.mule.transport.jdbc.sqlstrategy
 
SqlStatementStrategyExecutor() - Constructor for class org.mule.transport.jdbc.sqlstrategy.SqlStatementStrategyExecutor
 
SqlStatementStrategyFactory - Interface in org.mule.transport.jdbc.sqlstrategy
Factory that selects appropriate implementation of SQLStrategy for a particular SQL string
SQLXML_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
SQUARE_TEMPLATE_PATTERN - Static variable in class org.mule.util.TemplateParser
 
SQUARE_TEMPLATE_STYLE - Static variable in class org.mule.util.TemplateParser
 
SSL_SESSION_ATTRIBUTE_KEY - Static variable in class org.mule.module.http.internal.listener.grizzly.MuleSslFilter
 
sslHandshakeDidNotComplete() - Static method in class org.mule.transport.http.i18n.HttpMessages
 
SSLSessionProperties - Class in org.mule.module.http.internal.listener.properties
Wrapper to contain SSL context and avoid errors due to serialization
SSLSessionProperties(SSLSession) - Constructor for class org.mule.module.http.internal.listener.properties.SSLSessionProperties
 
stackToAssert - Static variable in class org.mule.tck.util.FlowTraceUtils.FlowStackAsserter
 
stackTraceFilter - Static variable in class org.mule.config.DefaultMuleConfiguration
A comma-separated list of internal packages/classes which are removed from sanitized stacktraces.
stage - Variable in class org.mule.module.guice.GuiceConfigurationBuilder
Deprecated.
 
StageNameSource - Interface in org.mule.api.processor
A component capable of generating names for staged queues.
StageNameSourceProvider - Interface in org.mule.api.processor
This interface defines a contract for a component able to name staged queues through a StageNameSource implementation
standaloneSet() - Method in class org.mule.module.xml.stax.DelegateXMLStreamReader
 
standardOptions() - Method in class org.mule.config.spring.parsers.specific.BindingDefinitionParser
 
start() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
start() - Method in interface org.mule.api.lifecycle.Startable
 
start() - Method in class org.mule.component.AbstractComponent
 
start() - Method in class org.mule.component.DefaultComponentLifecycleAdapter
Propagates start() life-cycle to component object implementations if they implement the mule Startable interface.
start() - Method in class org.mule.component.NullLifecycleAdapter
 
start() - Method in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
start() - Method in class org.mule.config.spring.factories.ConstantFactoryBean
 
start() - Method in class org.mule.construct.AbstractFlowConstruct
 
start(WorkManager, WorkListener) - Method in class org.mule.context.notification.ServerNotificationManager
 
start() - Method in class org.mule.DefaultMuleContext
 
start() - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
 
start() - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
start() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
start() - Method in class org.mule.management.stats.DefaultProcessingTimeWatcher
 
start() - Method in class org.mule.model.AbstractModel
Deprecated.
Starts all registered components
start(String[]) - Method in class org.mule.module.boot.MuleServerWrapper
The start method is called when the WrapperManager is signaled by the native wrapper code that it can start its application.
start(String[]) - Method in class org.mule.module.boot.VersionWrapper
 
start() - Method in class org.mule.module.client.remoting.RemoteDispatcherAgent
Deprecated.
 
start() - Method in class org.mule.module.cxf.config.FlowConfiguringMessageProcessor
 
start() - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
start() - Method in class org.mule.module.extension.internal.runtime.processor.OperationMessageProcessor
 
start() - Method in class org.mule.module.extension.internal.runtime.ReflectiveMethodOperationExecutor
 
start() - Method in interface org.mule.module.http.api.listener.HttpListener
Starts an stopped listener.
start() - Method in interface org.mule.module.http.api.listener.HttpListenerConfig
Starts the listening for incoming request.
start() - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
start() - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
start() - Method in class org.mule.module.http.internal.listener.DefaultRequestHandlerManager
 
start() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyServer
 
start() - Method in class org.mule.module.http.internal.listener.grizzly.ResponseCompletionHandler
Start the sending the response asynchronously
start() - Method in class org.mule.module.http.internal.listener.grizzly.ResponseStreamingCompletionHandler
 
start() - Method in interface org.mule.module.http.internal.listener.RequestHandlerManager
 
start() - Method in interface org.mule.module.http.internal.listener.Server
Binds the ServerSocket to the network interface and starts listening for requests
start() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
start() - Method in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
start() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
start() - Method in interface org.mule.module.launcher.artifact.Artifact
Starts the artifact execution
start() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
start() - Method in class org.mule.module.launcher.coreextension.DefaultMuleCoreExtensionManager
 
start() - Method in class org.mule.module.launcher.DeploymentDirectoryWatcher
Starts the process of deployment / undeployment of artifact.
start() - Method in interface org.mule.module.launcher.DeploymentService
 
start(DomainWrapper) - Method in class org.mule.module.launcher.domain.DefaultDomainFactory
 
start() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
start() - Method in class org.mule.module.launcher.domain.DomainWrapper
 
start(boolean) - Method in class org.mule.module.launcher.MuleContainer
 
start() - Method in class org.mule.module.launcher.MuleDeploymentService
 
start() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
start() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
start() - Method in class org.mule.module.management.agent.JdmkAgent
 
start() - Method in class org.mule.module.management.agent.Log4jAgent
Deprecated.
 
start() - Method in class org.mule.module.management.agent.Mx4jAgent
 
start() - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
start() - Method in class org.mule.module.management.agent.WrapperManagerAgent
 
start() - Method in class org.mule.module.management.agent.YourKitProfilerAgent
 
start() - Method in class org.mule.module.management.mbean.ModelService
Deprecated.
 
start() - Method in interface org.mule.module.management.mbean.ModelServiceMBean
 
start() - Method in class org.mule.module.management.mbean.MuleService
 
start() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
start() - Method in interface org.mule.module.management.mbean.RegistryServiceMBean
 
start() - Method in class org.mule.module.management.mbean.ServiceService
 
start() - Method in class org.mule.module.oauth2.internal.authorizationcode.DefaultAuthorizationCodeGrantType
 
start() - Method in class org.mule.module.oauth2.internal.clientcredentials.ClientCredentialsGrantType
 
start() - Method in class org.mule.module.oauth2.internal.mel.OAuthExpressionLanguageExtension
 
start(String[]) - Method in class org.mule.module.reboot.MuleContainerWrapper
The start method is called when the WrapperManager is signaled by the native wrapper code that it can start its application.
start() - Method in class org.mule.modules.schedulers.cron.CronScheduler
 
start(boolean, boolean) - Method in class org.mule.MuleServer
Start the mule server
start() - Method in class org.mule.processor.AbstractMuleObjectOwner
 
start() - Method in class org.mule.processor.AbstractRedeliveryPolicy
 
start() - Method in class org.mule.processor.AsyncInterceptingMessageProcessor
 
start() - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
start() - Method in class org.mule.processor.IdempotentRedeliveryPolicy
 
start() - Method in class org.mule.processor.ResponseMessageProcessorAdapter
 
start() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
start() - Method in class org.mule.processor.TransactionalInterceptingMessageProcessor
 
start() - Method in class org.mule.routing.AbstractAggregator
 
start() - Method in class org.mule.routing.AbstractSelectiveRouter
 
start() - Method in class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
 
start() - Method in class org.mule.routing.correlation.EventCorrelator
 
start() - Method in class org.mule.routing.MessageFilter
 
start() - Method in class org.mule.routing.MessageProcessorFilterPair
 
start() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
start() - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
start() - Method in class org.mule.routing.requestreply.SimpleAsyncRequestReplyRequester
 
start() - Method in class org.mule.routing.ScatterGatherRouter
 
start() - Method in class org.mule.routing.UntilSuccessful
 
start() - Method in class org.mule.security.oauth.BaseOAuth2Manager
start() - Method in class org.mule.security.oauth.DefaultHttpCallback
Starts a http inbound endpoint served by the underlying connector.
start() - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
start() - Method in class org.mule.security.oauth.processor.BaseOAuth1AuthorizeMessageProcessor
 
start() - Method in class org.mule.security.oauth.processor.BaseOAuth2AuthorizeMessageProcessor
 
start() - Method in class org.mule.service.AbstractService
Deprecated.
 
start() - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
start() - Method in class org.mule.source.ClusterizableMessageSourceWrapper
 
start() - Method in class org.mule.source.StartableCompositeMessageSource
 
start() - Method in class org.mule.tck.functional.AssertionMessageProcessor
 
start() - Method in class org.mule.tck.functional.FunctionalTestComponent
 
start() - Method in class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
start() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
start() - Method in class org.mule.tck.util.ftp.FtpServer
 
start() - Method in class org.mule.tck.util.sftp.SftpServer
 
start() - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
start() - Method in class org.mule.test.infrastructure.process.CommandServer
 
start(String[]) - Method in class org.mule.test.infrastructure.process.Controller
 
start(String...) - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
start(String[]) - Method in class org.mule.test.infrastructure.process.WindowsController
 
start() - Method in class org.mule.transport.AbstractConnector
 
start() - Method in class org.mule.transport.AbstractTransportMessageHandler
This method will start the connectable, calling AbstractTransportMessageHandler.connect() if it is needed.
start() - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
start() - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
start(Xid, int) - Method in class org.mule.transport.jms.xa.XAResourceWrapper
 
start() - Method in class org.mule.transport.polling.schedule.FixedFrequencyScheduler
Starts the Scheduling of a Task.
start() - Method in class org.mule.transport.quartz.jobs.PollEndpointJob
 
start() - Method in class org.mule.transport.servlet.jetty.AbstractConnectorHolder
 
start() - Method in interface org.mule.transport.servlet.jetty.ConnectorHolder
 
start() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector.MuleReceiverConnectorHolder
 
start() - Method in class org.mule.transport.servlet.jetty.JettyWebappServerAgent
 
start() - Method in class org.mule.transport.servlet.jetty.util.EmbeddedJettyServer
 
start() - Method in class org.mule.transport.TrackingWorkManager
 
start() - Method in class org.mule.util.monitor.FileMonitor
 
start() - Method in class org.mule.util.pool.DefaultLifecycleEnabledObjectPool
 
start() - Method in class org.mule.util.queue.DelegateQueueManager
 
start() - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
start(Xid, int) - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
Deprecated.
 
start() - Method in class org.mule.util.queue.TransactionalQueueManager
 
start(Xid, int) - Method in class org.mule.util.queue.TransactionalQueueSession
 
start() - Method in class org.mule.util.timer.EventTimerTask
 
start() - Method in class org.mule.util.xa.AbstractResourceManager
 
start(Xid, int) - Method in class org.mule.util.xa.DefaultXASession
 
start() - Method in class org.mule.work.MuleWorkManager
 
start() - Method in class org.mule.work.SerialWorkManager
 
Startable - Interface in org.mule.api.lifecycle
Startable provides an object with a Startable.start() method which gets called when the Mule instance gets started.
startable - Variable in class org.mule.lifecycle.processor.ProcessIfStartedMessageProcessor
 
StartableCompositeMessageSource - Class in org.mule.source
Implementation of CompositeMessageSource that propagates both injection of FlowConstruct and lifecycle to nested MessageSources.
StartableCompositeMessageSource() - Constructor for class org.mule.source.StartableCompositeMessageSource
 
startAfterConnect() - Method in class org.mule.transport.AbstractConnector
 
startAllocationRecording(long) - Method in class org.mule.module.management.mbean.YourKitProfilerService
Start object allocation recording.
startAllocationRecording(long) - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
Start object allocation recording.
startAsync() - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
startAsync(ServletRequest, ServletResponse) - Method in class org.mule.transport.http.servlet.MuleHttpServletRequest
 
startCallback(HttpCallbackAdapter, FetchAccessTokenMessageProcessor) - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
startCallback(HttpCallbackAdapter, FetchAccessTokenMessageProcessor) - Method in class org.mule.security.oauth.processor.BaseOAuth1AuthorizeMessageProcessor
 
startCapturingMemSnapshot(int) - Method in class org.mule.module.management.mbean.YourKitProfilerService
Starts new daemon thread which calls YourKitProfilerServiceMBean.captureMemorySnapshot() every N seconds.
startCapturingMemSnapshot(int) - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
Starts new daemon thread which calls YourKitProfilerServiceMBean.captureMemorySnapshot() every N seconds.
startConnector() - Method in class org.mule.module.management.mbean.ConnectorService
 
startConnector() - Method in interface org.mule.module.management.mbean.ConnectorServiceMBean
 
startCPUProfiling(long, String) - Method in class org.mule.module.management.mbean.YourKitProfilerService
Start CPU profiling.
startCPUProfiling(long, String) - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
Start CPU profiling.
startDatabase() - Method in class org.mule.tck.util.MuleDerbyTestDatabase
Creates an empty database with a table named TEST.
startDataBase(String) - Static method in class org.mule.tck.util.MuleDerbyTestUtils
Start a previously created (and stopped) database
started - Variable in class org.mule.routing.outbound.AbstractOutboundRouter
 
started - Variable in class org.mule.source.StartableCompositeMessageSource
 
started - Variable in class org.mule.transaction.AbstractSingleResourceTransaction
 
started - Variable in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver.SubReceiver
 
started - Variable in class org.mule.transport.servlet.jetty.AbstractConnectorHolder
 
started - Variable in class org.mule.util.pool.DefaultLifecycleEnabledObjectPool
 
StartElementEventX - Class in org.mule.module.xml.stax
 
StartElementEventX(QName, List, List, NamespaceContext, Location, QName) - Constructor for class org.mule.module.xml.stax.StartElementEventX
 
StartException - Exception in org.mule.api.lifecycle
DisposeException TODO (document class)
StartException(Message, Startable) - Constructor for exception org.mule.api.lifecycle.StartException
 
StartException(Message, Throwable, Startable) - Constructor for exception org.mule.api.lifecycle.StartException
 
StartException(Throwable, Startable) - Constructor for exception org.mule.api.lifecycle.StartException
 
startIfNeeded(Object) - Static method in class org.mule.api.lifecycle.LifecycleUtils
Invokes Startable.start() on object if it implements the Startable interface
startIfNeeded(Collection<? extends Object>) - Static method in class org.mule.api.lifecycle.LifecycleUtils
For each item in the objects collection, it invokes the the Startable.start() if it implements the Startable interface.
startIfNotStarted() - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
startIfStartable(Object) - Method in class org.mule.construct.AbstractFlowConstruct
 
startIfStartable(Object) - Method in class org.mule.service.AbstractService
Deprecated.
 
starting - Variable in class org.mule.source.StartableCompositeMessageSource
 
startMonitorProfiling() - Method in class org.mule.module.management.mbean.YourKitProfilerService
Start monitor profiling (requires that the profiled application runs on Java 5 or newer)
startMonitorProfiling() - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
Start monitor profiling (requires that the profiled application runs on Java 5 or newer)
startOnConnect - Variable in class org.mule.transport.AbstractConnector
Indicates whether the connector should start upon connecting.
startOnConnect - Variable in class org.mule.transport.jms.JmsMessageReceiver
Deprecated.
 
startOnConnect - Variable in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
startPart(String) - Method in class org.mule.transport.http.multipart.MultiPartOutputStream
Start creation of the next Content.
startPart(String, String[]) - Method in class org.mule.transport.http.multipart.MultiPartOutputStream
Start creation of the next Content.
startProcess(Object, Object, Map) - Method in interface org.mule.module.bpm.BPMS
Start a new process.
startProcess(Object) - Method in class org.mule.module.jbpm.Jbpm
Start a new process.
startProcess(Object, Object, Map) - Method in class org.mule.module.jbpm.Jbpm
Start a new process.
startSubReceivers() - Method in class org.mule.transport.jms.MultiConsumerJmsMessageReceiver
 
startTransaction(Object) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
Starts a new transaction and associates it with the current thread.
StartupContext - Class in org.mule.config
A class holding cross-cutting startup info.
StartupContext() - Constructor for class org.mule.config.StartupContext
 
StartupListener - Interface in org.mule.module.launcher
Notifies when all mule apps has been started
startupScreen - Variable in class org.mule.context.DefaultMuleContextBuilder
 
StartupSummaryDeploymentListener - Class in org.mule.module.launcher
Prints application status summary table on Mule startup.
StartupSummaryDeploymentListener(DeploymentStatusTracker, DeploymentService) - Constructor for class org.mule.module.launcher.StartupSummaryDeploymentListener
 
startWork(Work) - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
startWork(Work, long, ExecutionContext, WorkListener) - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
startWork(Work) - Method in class org.mule.transport.TrackingWorkManager
 
startWork(Work, long, ExecutionContext, WorkListener) - Method in class org.mule.transport.TrackingWorkManager
 
startWork(Work) - Method in class org.mule.work.MuleWorkManager
 
startWork(Work, long, ExecutionContext, WorkListener) - Method in class org.mule.work.MuleWorkManager
 
startWork(Work) - Method in class org.mule.work.SerialWorkManager
 
startWork(Work, long, ExecutionContext, WorkListener) - Method in class org.mule.work.SerialWorkManager
 
StartWorkExecutor - Class in org.mule.work
 
StartWorkExecutor() - Constructor for class org.mule.work.StartWorkExecutor
 
state - Variable in class org.mule.lifecycle.AbstractLifecycleManager
 
STATE_INVOKE_NOT_SUPPORTED - Static variable in class org.mule.api.model.InvocationResult
Deprecated.
STATE_INVOKED_FAILED - Static variable in class org.mule.api.model.InvocationResult
Deprecated.
STATE_INVOKED_SUCESSFUL - Static variable in class org.mule.api.model.InvocationResult
Deprecated.
STATE_PARAMETER - Static variable in interface org.mule.module.oauth2.internal.OAuthConstants
 
StateDecoder - Class in org.mule.module.oauth2.internal
Decoder for the oauth state.
StateDecoder(String) - Constructor for class org.mule.module.oauth2.internal.StateDecoder
 
StateEncoder - Class in org.mule.module.oauth2.internal
State parameter encoder.
StateEncoder(String) - Constructor for class org.mule.module.oauth2.internal.StateEncoder
 
StatefulCustomJob - Class in org.mule.transport.quartz.jobs
Same as CustomJob except the JobDetail state is persistent for each request and only one instance of the job will fire at any given trigger.
StatefulCustomJob() - Constructor for class org.mule.transport.quartz.jobs.StatefulCustomJob
 
StatefulEndpointPollingJob - Class in org.mule.transport.quartz.jobs
Same as EndpointPollingJob except the JobDetail state is persistent for each request and only one instance of the job will fire at any given trigger.
StatefulEndpointPollingJob() - Constructor for class org.mule.transport.quartz.jobs.StatefulEndpointPollingJob
 
StatefulEventGeneratorJob - Class in org.mule.transport.quartz.jobs
Same as EventGeneratorJob except the JobDetail state is persistent for each request and only one instance of the job will fire at any given trigger.
StatefulEventGeneratorJob() - Constructor for class org.mule.transport.quartz.jobs.StatefulEventGeneratorJob
 
StatefulScheduledDispatchJob - Class in org.mule.transport.quartz.jobs
Same as ScheduledDispatchJob except the JobDetail state is persistent for each request and only one instance of the job will fire at any given trigger.
StatefulScheduledDispatchJob() - Constructor for class org.mule.transport.quartz.jobs.StatefulScheduledDispatchJob
 
STATEMENT_STREAMING_RESULTSET_CLOSER_PROPERTY - Static variable in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
statementFactory - Variable in class org.mule.module.db.internal.domain.executor.AbstractExecutor
 
StatementFactory - Interface in org.mule.module.db.internal.domain.statement
Creates JDBC statements for a given connection
StatementInvocationHandler - Class in org.mule.module.db.internal.domain.xa
Invocation handler for statements
StatementInvocationHandler(Statement) - Constructor for class org.mule.module.db.internal.domain.xa.StatementInvocationHandler
 
StatementInvocationHandler - Class in org.mule.transport.jdbc.xa
 
StatementInvocationHandler(ConnectionWrapper, Statement) - Constructor for class org.mule.transport.jdbc.xa.StatementInvocationHandler
 
StatementResult - Interface in org.mule.module.db.internal.result.statement
Represents a single result from a Statement execution
StatementResultHandler - Interface in org.mule.module.db.internal.result.statement
Processes the results returned by a Statement execution
StatementResultIterator - Class in org.mule.module.db.internal.result.statement
Iterates across all the StatementResult returned by a Statement execution.
StatementResultIterator(DbConnection, Statement, QueryTemplate, AutoGeneratedKeyStrategy, ResultSetHandler) - Constructor for class org.mule.module.db.internal.result.statement.StatementResultIterator
 
StatementResultIteratorFactory - Interface in org.mule.module.db.internal.result.statement
Creates StatementResultIterator to process a Statement execution result
StatementStreamingResultSetCloser - Class in org.mule.module.db.internal.result.statement
Closes a ResultSet once it has been processed
StatementStreamingResultSetCloser() - Constructor for class org.mule.module.db.internal.result.statement.StatementStreamingResultSetCloser
 
StaticBulkQueryResolver - Class in org.mule.module.db.internal.resolver.query
Resolves a bulk query to a static value without using the current event
StaticBulkQueryResolver(String, QueryTemplateParser) - Constructor for class org.mule.module.db.internal.resolver.query.StaticBulkQueryResolver
 
StaticComponent - Class in org.mule.component.simple
A service that will return a static data object as a result.
StaticComponent() - Constructor for class org.mule.component.simple.StaticComponent
 
StaticComponentDefinitionParser - Class in org.mule.config.spring.parsers.specific
BDP which parses the element of the .
StaticComponentDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.StaticComponentDefinitionParser
 
StaticConfigurationInstanceProvider<T> - Class in org.mule.module.extension.internal.runtime
ConfigurationInstanceProvider which provides always the same StaticConfigurationInstanceProvider.configurationInstance.
StaticConfigurationInstanceProvider(T) - Constructor for class org.mule.module.extension.internal.runtime.StaticConfigurationInstanceProvider
 
staticContext - Variable in class org.mule.el.mvel.MVELExpressionLanguage
 
StaticDbConfigResolver - Class in org.mule.module.db.internal.resolver.database
Resolves a DbConfig to a static value without using the current event
StaticDbConfigResolver(DbConfig) - Constructor for class org.mule.module.db.internal.resolver.database.StaticDbConfigResolver
 
StaticDbTypeManager - Class in org.mule.module.db.internal.domain.type
Provides a way to statically resolve DbType using a predefined set of types.
StaticDbTypeManager(List<DbType>) - Constructor for class org.mule.module.db.internal.domain.type.StaticDbTypeManager
 
staticLogger - Static variable in class org.mule.transport.jdbc.JdbcMessageDispatcher
 
StaticParamValueResolver - Class in org.mule.module.db.internal.resolver.param
Resolves a query parameters to a static value without using the current event
StaticParamValueResolver() - Constructor for class org.mule.module.db.internal.resolver.param.StaticParamValueResolver
 
StaticQueryParamResolverFactoryBean - Class in org.mule.module.db.internal.config.domain.param
 
StaticQueryParamResolverFactoryBean() - Constructor for class org.mule.module.db.internal.config.domain.param.StaticQueryParamResolverFactoryBean
 
StaticQueryResolver - Class in org.mule.module.db.internal.resolver.query
Resolves a query to a static value without using the current event
StaticQueryResolver(Query) - Constructor for class org.mule.module.db.internal.resolver.query.StaticQueryResolver
 
StaticRecipientList - Class in org.mule.routing.outbound
Deprecated.
StaticRecipientList() - Constructor for class org.mule.routing.outbound.StaticRecipientList
Deprecated.
 
StaticResourceMessageProcessor - Class in org.mule.transport.http.components
A MessageProcessor that can be used by HTTP endpoints to serve static files from a directory on the filesystem.
StaticResourceMessageProcessor() - Constructor for class org.mule.transport.http.components.StaticResourceMessageProcessor
 
StaticValueResolver<T> - Class in org.mule.module.extension.internal.runtime.resolver
A ValueResolver which always returns the same constant value.
StaticValueResolver(T) - Constructor for class org.mule.module.extension.internal.runtime.resolver.StaticValueResolver
 
StaticVariableResolverFactory - Class in org.mule.el.mvel
 
StaticVariableResolverFactory(ParserConfiguration, MuleContext) - Constructor for class org.mule.el.mvel.StaticVariableResolverFactory
 
Statistics - Interface in org.mule.api.management.stats
Statistics TODO
statistics - Variable in class org.mule.component.AbstractComponent
 
statistics - Variable in class org.mule.construct.AbstractFlowConstruct
 
statistics - Variable in class org.mule.module.management.mbean.FlowConstructService
 
statistics - Variable in class org.mule.routing.AbstractCatchAllStrategy
Deprecated.
Router statistics used to monitor if a catch all strategy is invoked and if any events are dispatched from the strategy i.e.
statistics - Variable in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
statistics - Variable in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
StatisticsService - Class in org.mule.module.management.mbean
StatisicsService exposes Mule processing statistics
StatisticsService() - Constructor for class org.mule.module.management.mbean.StatisticsService
 
StatisticsServiceMBean - Interface in org.mule.module.management.mbean
StatisticsServiceMBean is a JMX interfaces for querying Mule event processing statistics.
stats - Variable in class org.mule.service.AbstractService
Deprecated.
 
statsName - Variable in class org.mule.module.management.mbean.FlowConstructService
 
status - Variable in class org.mule.module.spring.transaction.SpringTransactionFactory.SpringTransaction
 
STATUS - Static variable in class org.mule.test.infrastructure.process.Controller
 
status(String...) - Method in class org.mule.test.infrastructure.process.Controller
 
status(String...) - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
status(String[]) - Method in class org.mule.test.infrastructure.process.UnixController
 
status(String[]) - Method in class org.mule.test.infrastructure.process.WindowsController
 
status - Variable in class org.mule.util.queue.objectstore.xa.AbstractTransactionContext
Deprecated.
 
status - Variable in class org.mule.util.xa.AbstractTransactionContext
 
STATUS_ACTIVE - Static variable in interface org.mule.api.transaction.Transaction
 
STATUS_COMMITTED - Static variable in interface org.mule.api.transaction.Transaction
 
STATUS_COMMITTING - Static variable in interface org.mule.api.transaction.Transaction
 
STATUS_MARKED_ROLLBACK - Static variable in interface org.mule.api.transaction.Transaction
 
STATUS_NO_TRANSACTION - Static variable in interface org.mule.api.transaction.Transaction
 
STATUS_PATTERN - Static variable in class org.mule.test.infrastructure.process.Controller
 
STATUS_PREPARED - Static variable in interface org.mule.api.transaction.Transaction
 
STATUS_PREPARING - Static variable in interface org.mule.api.transaction.Transaction
 
STATUS_ROLLEDBACK - Static variable in interface org.mule.api.transaction.Transaction
 
STATUS_ROLLING_BACK - Static variable in interface org.mule.api.transaction.Transaction
 
STATUS_UNKNOWN - Static variable in interface org.mule.api.transaction.Transaction
 
StaxFeature - Class in org.mule.module.cxf.support
Configures the StAX XMLInputFactory and XMLOutputFactory which CXF uses.
StaxFeature() - Constructor for class org.mule.module.cxf.support.StaxFeature
 
StaxSource - Class in org.mule.module.xml.stax
A StaxSource which gives us access to the underlying XMLStreamReader if we are StaxCapable down the line.
StaxSource(XMLStreamReader) - Constructor for class org.mule.module.xml.stax.StaxSource
 
StaxSource.PseudoReader - Class in org.mule.module.xml.stax
 
StaxSource.PseudoReader() - Constructor for class org.mule.module.xml.stax.StaxSource.PseudoReader
 
STDIO - Static variable in class org.mule.transport.stdio.StdioConnector
 
StdioConnector - Class in org.mule.transport.stdio
StdioConnector can send and receive Mule events over IO streams.
StdioConnector(MuleContext) - Constructor for class org.mule.transport.stdio.StdioConnector
 
StdioMessageDispatcher - Class in org.mule.transport.stdio
StdioMessageDispatcher is a simple stream dispatcher that obtains a stream from the Stream Connector to write to.
StdioMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.stdio.StdioMessageDispatcher
 
StdioMessageDispatcherFactory - Class in org.mule.transport.stdio
StdioMessageDispatcherFactory creates a Stream dispatcher suitable for writing to fixed streams such as System.in or System.out.
StdioMessageDispatcherFactory() - Constructor for class org.mule.transport.stdio.StdioMessageDispatcherFactory
 
StdioMessageReceiver - Class in org.mule.transport.stdio
StdioMessageReceiver is a listener for events from Mule components which then simply passes the events on to the target components.
StdioMessageReceiver(Connector, FlowConstruct, InboundEndpoint, long) - Constructor for class org.mule.transport.stdio.StdioMessageReceiver
 
StdioMessages - Class in org.mule.transport.stdio.i18n
 
StdioMessages() - Constructor for class org.mule.transport.stdio.i18n.StdioMessages
 
StdioNamespaceHandler - Class in org.mule.transport.stdio.config
Reigsters a Bean Definition Parser for handling elements.
StdioNamespaceHandler() - Constructor for class org.mule.transport.stdio.config.StdioNamespaceHandler
 
stepIn() - Method in interface org.mule.api.debug.ExecutionManager
Resumes the execution and stop in the next instruction.
stop() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
 
stop() - Method in interface org.mule.api.callback.StopSourceCallback
 
stop() - Method in interface org.mule.api.lifecycle.Stoppable
 
stop() - Method in class org.mule.component.AbstractComponent
 
stop() - Method in class org.mule.component.DefaultComponentLifecycleAdapter
Propagates stop() life-cycle to component object implementations if they implement the mule Stoppable interface.
stop() - Method in class org.mule.component.NullLifecycleAdapter
 
stop() - Method in class org.mule.config.spring.factories.ConstantFactoryBean
 
stop() - Method in class org.mule.construct.AbstractFlowConstruct
 
stop() - Method in class org.mule.DefaultMuleContext
Stops the MuleContext which stops all sessions and connectors
stop() - Method in class org.mule.devkit.processor.DevkitBasedMessageProcessor
 
stop() - Method in class org.mule.endpoint.DefaultInboundEndpoint
 
stop() - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
 
stop() - Method in class org.mule.management.stats.DefaultProcessingTimeWatcher
 
stop() - Method in class org.mule.model.AbstractModel
Deprecated.
Stops any registered components
stop(int) - Method in class org.mule.module.boot.MuleServerWrapper
Called when the application is shutting down.
stop(int) - Method in class org.mule.module.boot.VersionWrapper
 
stop() - Method in class org.mule.module.client.remoting.RemoteDispatcherAgent
Deprecated.
 
stop() - Method in class org.mule.module.cxf.config.FlowConfiguringMessageProcessor
 
stop() - Method in class org.mule.module.cxf.CxfInboundMessageProcessor
 
stop() - Method in class org.mule.module.extension.internal.runtime.processor.OperationMessageProcessor
 
stop() - Method in class org.mule.module.extension.internal.runtime.ReflectiveMethodOperationExecutor
 
stop() - Method in interface org.mule.module.http.api.listener.HttpListener
Stops this listener.
stop() - Method in interface org.mule.module.http.api.listener.HttpListenerConfig
Stops listening for incoming request.
stop() - Method in class org.mule.module.http.internal.listener.DefaultHttpListener
 
stop() - Method in class org.mule.module.http.internal.listener.DefaultHttpListenerConfig
 
stop() - Method in class org.mule.module.http.internal.listener.DefaultRequestHandlerManager
 
stop() - Method in class org.mule.module.http.internal.listener.grizzly.GrizzlyServer
 
stop() - Method in interface org.mule.module.http.internal.listener.RequestHandlerManager
 
stop() - Method in interface org.mule.module.http.internal.listener.Server
Unbinds the ServerSocket to the network interface and stops listening for requests.
stop() - Method in class org.mule.module.http.internal.request.DefaultHttpRequesterConfig
 
stop() - Method in class org.mule.module.http.internal.request.grizzly.GrizzlyHttpClient
 
stop() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
stop() - Method in interface org.mule.module.launcher.artifact.Artifact
Stops the artifact execution
stop() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
stop() - Method in class org.mule.module.launcher.coreextension.DefaultMuleCoreExtensionManager
 
stop() - Method in class org.mule.module.launcher.DeploymentDirectoryWatcher
Stops the deployment scan service.
stop() - Method in interface org.mule.module.launcher.DeploymentService
 
stop() - Method in class org.mule.module.launcher.domain.DefaultMuleDomain
 
stop() - Method in class org.mule.module.launcher.MuleContainer
 
stop() - Method in class org.mule.module.launcher.MuleDeploymentService
 
stop() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
stop() - Method in class org.mule.module.management.agent.DefaultJmxSupportAgent
stop() - Method in class org.mule.module.management.agent.JdmkAgent
 
stop() - Method in class org.mule.module.management.agent.Log4jAgent
Deprecated.
 
stop() - Method in class org.mule.module.management.agent.Mx4jAgent
 
stop() - Method in class org.mule.module.management.agent.RmiRegistryAgent
 
stop() - Method in class org.mule.module.management.agent.WrapperManagerAgent
 
stop() - Method in class org.mule.module.management.agent.YourKitProfilerAgent
 
stop() - Method in class org.mule.module.management.mbean.ModelService
Deprecated.
 
stop() - Method in interface org.mule.module.management.mbean.ModelServiceMBean
 
stop() - Method in class org.mule.module.management.mbean.MuleService
 
stop() - Method in interface org.mule.module.management.mbean.MuleServiceMBean
 
stop() - Method in interface org.mule.module.management.mbean.RegistryServiceMBean
 
stop() - Method in class org.mule.module.management.mbean.ServiceService
 
stop(int) - Method in class org.mule.module.reboot.MuleContainerWrapper
Called when the application is shutting down.
stop() - Method in class org.mule.modules.schedulers.cron.CronScheduler
 
stop() - Method in class org.mule.processor.AbstractMuleObjectOwner
 
stop() - Method in class org.mule.processor.AbstractRedeliveryPolicy
 
stop() - Method in class org.mule.processor.AsyncInterceptingMessageProcessor
 
stop() - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
stop() - Method in class org.mule.processor.ResponseMessageProcessorAdapter
 
stop() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
stop() - Method in class org.mule.processor.TransactionalInterceptingMessageProcessor
 
stop() - Method in class org.mule.routing.AbstractAggregator
 
stop() - Method in class org.mule.routing.AbstractSelectiveRouter
 
stop() - Method in class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
 
stop() - Method in class org.mule.routing.correlation.EventCorrelator
 
stop() - Method in class org.mule.routing.MessageFilter
 
stop() - Method in class org.mule.routing.MessageProcessorFilterPair
 
stop() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
 
stop() - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
stop() - Method in class org.mule.routing.requestreply.SimpleAsyncRequestReplyRequester
 
stop() - Method in class org.mule.routing.UntilSuccessful
 
stop() - Method in class org.mule.security.oauth.BaseOAuth2Manager
stop() - Method in class org.mule.security.oauth.DefaultHttpCallback
Stops and disposes the processor chain and the inbound endpoint.
stop() - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
stop() - Method in class org.mule.service.AbstractService
Deprecated.
 
stop() - Method in class org.mule.service.ServiceCompositeMessageSource
Deprecated.
 
stop() - Method in class org.mule.source.ClusterizableMessageSourceWrapper
 
stop() - Method in class org.mule.source.StartableCompositeMessageSource
 
stop() - Method in class org.mule.tck.functional.FunctionalTestComponent
 
stop() - Method in class org.mule.tck.util.endpoint.InboundEndpointWrapper
 
stop() - Method in class org.mule.tck.util.ftp.FtpServer
 
stop() - Method in class org.mule.tck.util.ftp.Server
Stop the ftp server TODO DZ: we may want to put a port check + wait time in here to make sure that the port is released before we continue.
stop() - Method in class org.mule.tck.util.sftp.SftpServer
 
stop() - Method in class org.mule.test.infrastructure.deployment.FakeMuleServer
 
stop() - Method in class org.mule.test.infrastructure.process.CommandServer
 
stop(String[]) - Method in class org.mule.test.infrastructure.process.Controller
 
stop(String...) - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
stop(String[]) - Method in class org.mule.test.infrastructure.process.WindowsController
 
stop() - Method in class org.mule.transport.AbstractConnector
 
stop() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
stop() - Method in class org.mule.transport.jms.jndi.AbstractJndiNameResolver
 
stop() - Method in class org.mule.transport.jms.jndi.CachedJndiNameResolver

Cleans up the cache.

stop() - Method in class org.mule.transport.jms.reconnect.ReconnectWorkManager
 
stop() - Method in class org.mule.transport.polling.schedule.FixedFrequencyScheduler
Stops the Scheduling of a Task.
stop() - Method in class org.mule.transport.quartz.jobs.PollEndpointJob
 
stop() - Method in class org.mule.transport.servlet.jetty.AbstractConnectorHolder
 
stop() - Method in interface org.mule.transport.servlet.jetty.ConnectorHolder
 
stop() - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector.MuleReceiverConnectorHolder
 
stop() - Method in class org.mule.transport.servlet.jetty.JettyWebappServerAgent
 
stop() - Method in class org.mule.transport.servlet.jetty.util.EmbeddedJettyServer
 
stop() - Method in class org.mule.util.monitor.FileMonitor
Stop the file monitor polling.
stop() - Method in class org.mule.util.pool.DefaultLifecycleEnabledObjectPool
 
stop() - Method in class org.mule.util.queue.DelegateQueueManager
 
stop() - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
stop(int) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
stop(int, long) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
stop() - Method in class org.mule.util.queue.TransactionalQueueManager
 
stop() - Method in class org.mule.util.timer.EventTimerTask
 
stop() - Method in class org.mule.util.xa.AbstractResourceManager
 
stop(int) - Method in class org.mule.util.xa.AbstractResourceManager
 
stop(int, long) - Method in class org.mule.util.xa.AbstractResourceManager
 
stopAllocationRecording() - Method in class org.mule.module.management.mbean.YourKitProfilerService
stopAllocationRecording() - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
 
stopCapturingMemSnapshot() - Method in class org.mule.module.management.mbean.YourKitProfilerService
stopCapturingMemSnapshot() - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
stopConnector() - Method in class org.mule.module.management.mbean.ConnectorService
 
stopConnector() - Method in interface org.mule.module.management.mbean.ConnectorServiceMBean
 
stopCPUProfiling() - Method in class org.mule.module.management.mbean.YourKitProfilerService
Stop CPU profiling.
stopCPUProfiling() - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
Stop CPU profiling.
stopDatabase() - Method in class org.mule.tck.util.MuleDerbyTestDatabase
Stops the created database.
stopDatabase() - Static method in class org.mule.tck.util.MuleDerbyTestUtils
Properly shutdown an embedded Derby database
StopException - Exception in org.mule.api.lifecycle
DisposeException TODO (document class)
StopException(Message, Stoppable) - Constructor for exception org.mule.api.lifecycle.StopException
 
StopException(Message, Throwable, Stoppable) - Constructor for exception org.mule.api.lifecycle.StopException
 
StopException(Throwable, Stoppable) - Constructor for exception org.mule.api.lifecycle.StopException
 
stopFlow(FlowConstruct) - Method in class org.mule.exception.AbstractMessagingExceptionStrategy
 
stopFlowConstruct(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
 
stopFlowSchedulers(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
 
StopFurtherMessageProcessingMessageProcessor - Class in org.mule.processor
 
StopFurtherMessageProcessingMessageProcessor() - Constructor for class org.mule.processor.StopFurtherMessageProcessingMessageProcessor
 
stopIfNeeded(Collection<? extends Object>) - Static method in class org.mule.api.lifecycle.LifecycleUtils
For each item in the objects collection, it invokes the Stoppable.stop() if it implements the Stoppable interface.
stopIfNeeded(Object) - Static method in class org.mule.api.lifecycle.LifecycleUtils
Invokes the Stoppable.stop() on object if it implements the Stoppable interface.
stopIfStoppable(Object) - Method in class org.mule.construct.AbstractFlowConstruct
 
stopIfStoppable(Object) - Method in class org.mule.service.AbstractService
Deprecated.
 
stopMonitorProfiling() - Method in class org.mule.module.management.mbean.YourKitProfilerService
Stop monitor profiling (requires that the profiled application runs on Java 5 or newer)
stopMonitorProfiling() - Method in interface org.mule.module.management.mbean.YourKitProfilerServiceMBean
Stop monitor profiling (requires that the profiled application runs on Java 5 or newer)
Stoppable - Interface in org.mule.api.lifecycle
Stoppable is a lifecycle interfaqce that introduces a Stoppable.stop() method to an object.
stopPausedSedaStageNonPeristentQueueMessageLoss(int, String) - Static method in class org.mule.config.i18n.CoreMessages
 
stopProcessing() - Method in class org.mule.routing.EventProcessingThread
Stops the monitoring of the expired groups.
StopProcessingException - Exception in org.mule.module.sxc
 
StopProcessingException() - Constructor for exception org.mule.module.sxc.StopProcessingException
 
stopRequested - Variable in class org.mule.routing.EventProcessingThread
 
StopSourceCallback - Interface in org.mule.api.callback
Callback returned by methods that are annotated with @Source

It will be executed when the MessageSource is being stopped.

store(Serializable, T) - Method in interface org.mule.api.store.ObjectStore
Store the given Object.
store(Serializable, T, String) - Method in interface org.mule.api.store.PartitionableObjectStore
 
store - Variable in class org.mule.routing.IdempotentMessageFilter
 
store - Variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
store(Serializable, T) - Method in class org.mule.tck.util.FakeObjectStore
 
store(Serializable, T, String[]) - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
 
store(Serializable, T) - Method in class org.mule.transport.jdbc.store.JdbcObjectStore
Store the given Object.
store(Serializable, T) - Method in class org.mule.util.store.AbstractObjectStore
 
store(Serializable, T) - Method in class org.mule.util.store.AbstractPartitionedObjectStore
 
store - Variable in class org.mule.util.store.InMemoryObjectStore
 
store(Serializable, T) - Method in class org.mule.util.store.InMemoryObjectStore
 
store(Serializable, T) - Method in class org.mule.util.store.ManagedObjectStore
 
store(Serializable, T) - Method in class org.mule.util.store.MonitoredObjectStoreWrapper
 
store(Serializable, T) - Method in class org.mule.util.store.ObjectStorePartition
 
store(Serializable, T, String) - Method in class org.mule.util.store.PartitionedInMemoryObjectStore
 
store(Serializable, T) - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
 
store(Serializable, T, String) - Method in class org.mule.util.store.PartitionedPersistentObjectStore
 
store(Serializable, T) - Method in class org.mule.util.store.PersistentObjectStorePartition
 
store(Serializable, T) - Method in class org.mule.util.store.ProvidedObjectStoreWrapper
 
store(Serializable, T, String) - Method in class org.mule.util.store.ProvidedPartitionableObjectStoreWrapper
 
store(Serializable, T) - Method in class org.mule.util.store.QueueStoreAdapter
Deprecated.
 
store(Serializable, String) - Method in class org.mule.util.store.TextFileObjectStore
 
storeAuthorizationEvent(MuleEvent) - Method in class org.mule.security.oauth.BaseOAuth2Manager
This method is expected to receive the MuleEvent corresponding to the execution of an OAuth2 authorize processor.
storeAuthorizationEvent(MuleEvent) - Method in interface org.mule.security.oauth.OAuth2Manager
This method is expected to receive the MuleEvent corresponding to the execution of an OAuth2 authorize processor.
STORED_PROCEDURE_PREFIX - Static variable in class org.mule.transport.jdbc.sqlstrategy.CallableSqlStatementStrategy
 
STORED_PROCEDURE_SUFFIX - Static variable in class org.mule.transport.jdbc.sqlstrategy.CallableSqlStatementStrategy
 
StoredProcedureExecutor - Class in org.mule.module.db.internal.domain.executor
Executes stored procedure queries
StoredProcedureExecutor(StatementFactory, StatementResultHandler) - Constructor for class org.mule.module.db.internal.domain.executor.StoredProcedureExecutor
 
StoredProcedureExecutorFactory - Class in org.mule.module.db.internal.domain.executor
Creates StoredProcedureExecutor instances
StoredProcedureExecutorFactory(StatementFactory, StatementResultHandler) - Constructor for class org.mule.module.db.internal.domain.executor.StoredProcedureExecutorFactory
 
StoredProcedureMessageProcessor - Class in org.mule.module.db.internal.processor
Executes an stored procedure query on a database.
StoredProcedureMessageProcessor(DbConfigResolver, QueryResolver, QueryExecutorFactory, TransactionalAction, boolean) - Constructor for class org.mule.module.db.internal.processor.StoredProcedureMessageProcessor
 
StoredProcedureParamTypeResolver - Class in org.mule.module.db.internal.resolver.param
Resolves parameter types for stored procedure queries
StoredProcedureParamTypeResolver(DbTypeManager) - Constructor for class org.mule.module.db.internal.resolver.param.StoredProcedureParamTypeResolver
 
StoredProcedureProcessorBeanDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
StoredProcedureProcessorBeanDefinitionParser() - Constructor for class org.mule.module.db.internal.config.processor.StoredProcedureProcessorBeanDefinitionParser
 
storeFile(String, InputStream) - Method in class org.mule.transport.sftp.SftpClient
 
storeFile(String, InputStream, SftpClient.WriteMode) - Method in class org.mule.transport.sftp.SftpClient
 
storeFile(String, MuleEvent, OutputHandler) - Method in class org.mule.transport.sftp.SftpClient
 
storeFile(String, MuleEvent, OutputHandler, SftpClient.WriteMode) - Method in class org.mule.transport.sftp.SftpClient
 
storeFile(String, String) - Method in class org.mule.transport.sftp.SftpClient
 
storeFile(String, String, SftpClient.WriteMode) - Method in class org.mule.transport.sftp.SftpClient
 
storeMessage(Message) - Method in class org.mule.transport.email.RetrieveMessageReceiver
Helper method for testing which stores a copy of the message locally as the POP3

message will be deleted from the server

storePrefix - Variable in class org.mule.routing.AbstractAggregator
 
storePrefix - Variable in class org.mule.routing.IdempotentMessageFilter
 
storeSessionInfoToMessage(MuleSession, MuleMessage) - Method in interface org.mule.api.transport.SessionHandler
 
storeSessionInfoToMessage(MuleSession, MuleMessage) - Method in class org.mule.session.LegacySessionHandler
Deprecated.
 
storeSessionInfoToMessage(MuleSession, MuleMessage) - Method in class org.mule.session.NullSessionHandler
 
storeSessionInfoToMessage(MuleSession, MuleMessage) - Method in class org.mule.session.SerializeAndEncodeSessionHandler
 
storeSessionInfoToMessage(MuleSession, MuleMessage) - Method in class org.mule.session.SerializeOnlySessionHandler
 
storeSessionInfoToMessage(MuleSession, MuleMessage) - Method in class org.mule.session.SimpleSessionHandler
 
STREAM_BUFFER_SIZE - Static variable in class org.mule.tck.functional.FunctionalStreamingTestComponent
 
STREAM_BUFFER_SIZE - Static variable in class org.mule.tck.functional.FunctionalTestComponent
 
STREAM_OK - Static variable in class org.mule.transport.tcp.protocols.AbstractByteProtocol
 
STREAM_SAMPLE_SIZE - Static variable in class org.mule.tck.functional.FunctionalStreamingTestComponent
 
STREAM_SAMPLE_SIZE - Static variable in class org.mule.tck.functional.FunctionalTestComponent
 
STREAM_SYSTEM_ERR - Static variable in class org.mule.transport.stdio.StdioConnector
 
STREAM_SYSTEM_IN - Static variable in class org.mule.transport.stdio.StdioConnector
 
STREAM_SYSTEM_OUT - Static variable in class org.mule.transport.stdio.StdioConnector
 
StreamCloser - Interface in org.mule.api.util
Closes a stream.
StreamCloserService - Interface in org.mule.api.util
Simple service to close streams of different types.
StreamClosingInterceptor - Class in org.mule.module.cxf.support
Replaces the original XMLStreamReader with another one which closes the underlying InputStream.
StreamClosingInterceptor() - Constructor for class org.mule.module.cxf.support.StreamClosingInterceptor
 
streaming - Variable in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
STREAMING_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.processor.AbstractDbProcessorDefinitionParser
 
streamingComponentMustHaveOneEndpoint(String) - Static method in class org.mule.config.i18n.CoreMessages
 
streamingEndpointsDoNotSupportTransformers() - Static method in class org.mule.config.i18n.CoreMessages
 
streamingEndpointsMustBeUsedWithStreamingModel() - Static method in class org.mule.config.i18n.CoreMessages
 
streamingFailedForEndpoint(String) - Static method in class org.mule.config.i18n.CoreMessages
 
streamingFailedNoStream() - Static method in class org.mule.config.i18n.CoreMessages
 
streamingNotSupported(String) - Static method in class org.mule.config.i18n.CoreMessages
 
StreamingProtocol - Class in org.mule.transport.tcp.protocols
 
StreamingProtocol() - Constructor for class org.mule.transport.tcp.protocols.StreamingProtocol
 
StreamingResultSetCloser - Interface in org.mule.module.db.internal.result.resultset
Closes a ResultSet that was processed in streaming mode
StreamingStatementResultHandler - Class in org.mule.module.db.internal.result.statement
Processes Statement results without closing the statement.
StreamingStatementResultHandler(ResultSetHandler) - Constructor for class org.mule.module.db.internal.result.statement.StreamingStatementResultHandler
 
streamNotAvailble(String) - Static method in class org.mule.module.xml.i18n.XmlMessages
 
StreamPayloadRequestEntity - Class in org.mule.transport.http
 
StreamPayloadRequestEntity(OutputHandler, MuleEvent) - Constructor for class org.mule.transport.http.StreamPayloadRequestEntity
 
StreamTransformer - Interface in org.mule.module.pgp
 
STRICT_HOST_KEY_CHECKING - Static variable in class org.mule.transport.sftp.SftpClient
 
STRING - Static variable in class org.mule.transformer.types.DataTypeFactory
 
STRING_DATA_TYPE - Static variable in interface org.mule.api.transformer.DataType
 
StringAppendTestTransformer - Class in org.mule.tck.functional
 
StringAppendTestTransformer() - Constructor for class org.mule.tck.functional.StringAppendTestTransformer
 
StringAppendTransformer - Class in org.mule.transformer.simple
 
StringAppendTransformer() - Constructor for class org.mule.transformer.simple.StringAppendTransformer
 
StringAppendTransformer(String) - Constructor for class org.mule.transformer.simple.StringAppendTransformer
 
StringDataSource - Class in org.mule.message.ds
 
StringDataSource(String) - Constructor for class org.mule.message.ds.StringDataSource
 
StringDataSource(String, String) - Constructor for class org.mule.message.ds.StringDataSource
 
StringDataSource(String, String, String) - Constructor for class org.mule.message.ds.StringDataSource
 
StringExpressionEvaluator - Class in org.mule.expression
Will process an expression string that can contain other expressions
StringExpressionEvaluator() - Constructor for class org.mule.expression.StringExpressionEvaluator
 
StringMessageUtils - Class in org.mule.util
Useful methods for formatting message strings for logging or exceptions.
stringsToClasses(Collection) - Method in class org.mule.transport.rmi.RmiConnector
 
StringToBoolean - Class in org.mule.transformer.simple
ByteArrayToSerializable converts a serialized object to its object representation
StringToBoolean() - Constructor for class org.mule.transformer.simple.StringToBoolean
 
StringToEmailMessage - Class in org.mule.transport.email.transformers
StringToEmailMessage will convert a String to a JavaMail Message, using the String as the contents.
StringToEmailMessage() - Constructor for class org.mule.transport.email.transformers.StringToEmailMessage
 
stringToFile(String, String) - Static method in class org.mule.util.FileUtils
Reads the incoming String into a file at at the given destination.
stringToFile(String, String, boolean) - Static method in class org.mule.util.FileUtils
 
stringToFile(String, String, boolean, boolean) - Static method in class org.mule.util.FileUtils
 
stringToInternetAddresses(String) - Static method in class org.mule.transport.email.MailUtils
 
StringToNumber - Class in org.mule.transformer.simple
StringToNumber converts a String to a Number.
StringToNumber() - Constructor for class org.mule.transformer.simple.StringToNumber
 
StringToNumber(NumberFormat) - Constructor for class org.mule.transformer.simple.StringToNumber
 
StringToObjectArray - Class in org.mule.transformer.simple
StringToObjectArray converts a String into an object array.
StringToObjectArray() - Constructor for class org.mule.transformer.simple.StringToObjectArray
 
StringUtils - Class in org.mule.util
StringUtils contains useful methods for manipulating Strings.
StringUtils() - Constructor for class org.mule.util.StringUtils
 
STRUCT_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
StructDbType - Class in org.mule.module.db.internal.domain.type
Defines a structured data type
StructDbType(int, String) - Constructor for class org.mule.module.db.internal.domain.type.StructDbType
Creates a new DB type
StructuredDbType - Class in org.mule.module.db.internal.domain.type
Defines a structured data type
StructuredDbType(int, String) - Constructor for class org.mule.module.db.internal.domain.type.StructuredDbType
 
STYLE - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
STYLE_MAP - Static variable in class org.mule.transport.soap.axis.config.AxisNamespaceHandler
 
STYLESHEET - Static variable in class org.mule.module.xml.config.XsltTextDefinitionParser
 
SubflowInterceptingChainLifecycleWrapper - Class in org.mule.processor.chain
Generates message processor identfiers specific for subflows.
SubflowInterceptingChainLifecycleWrapper(MessageProcessorChain, List<MessageProcessor>, String) - Constructor for class org.mule.processor.chain.SubflowInterceptingChainLifecycleWrapper
 
SubFlowMessageProcessor - Interface in org.mule.processor.chain
Marker interface for MessageProcessors that actually represent a subflow.
SubflowMessageProcessorChainBuilder - Class in org.mule.processor.chain
Constructs a custom chain for subflows using the subflow name as the chain name.
SubflowMessageProcessorChainBuilder() - Constructor for class org.mule.processor.chain.SubflowMessageProcessorChainBuilder
 
SubflowMessageProcessorChainFactoryBean - Class in org.mule.config.spring.factories
Uses a custom message processor chain builder for subflows in order to genearte the proper message processor ids.
SubflowMessageProcessorChainFactoryBean() - Constructor for class org.mule.config.spring.factories.SubflowMessageProcessorChainFactoryBean
 
SUBJECT_PROPERTY - Static variable in interface org.mule.transport.email.MailProperties
 
subList(int, int) - Method in class org.mule.module.launcher.util.ObservableList
 
submitForProcessing(Serializable) - Method in class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
 
subscriptionFilter - Variable in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
The filter used to match subscriptions
subscriptions - Variable in class org.mule.module.spring.events.MuleEventMulticaster
Deprecated.
A list of endpoints the eventMulticaster will receive events on Note that if this eventMulticaster has a Mule Descriptor associated with it, these endpoints are ignored and the ones on the Mule Descriptor are used.
subsubprotocol - Variable in class org.mule.transport.jdbc.config.DerbyDataSourceFactoryBean
 
SuccessStatusCodeValidator - Class in org.mule.module.http.internal.request
 
SuccessStatusCodeValidator() - Constructor for class org.mule.module.http.internal.request.SuccessStatusCodeValidator
 
SuccessStatusCodeValidator(String) - Constructor for class org.mule.module.http.internal.request.SuccessStatusCodeValidator
 
SUM - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter representing the sum of two counters
Sum - Class in org.mule.util.counters.impl
 
Sum(String, AbstractCounter) - Constructor for class org.mule.util.counters.impl.Sum
 
summarise(Throwable, int) - Static method in class org.mule.config.ExceptionHelper
Removes some internal Mule entries from the stacktrace.
supportedArtifactType - Variable in class org.mule.config.bootstrap.AbstractRegistryBootstrap
 
SupportedMEPs - Annotation Type in org.mule.api.annotations.meta
 
supportJms102bSpec - Variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
supports(Annotation, Class, Member) - Method in interface org.mule.api.EndpointAnnotationParser
Determines whether this parser can process the current annotation.
supports(Annotation) - Method in interface org.mule.api.expression.ExpressionAnnotationParser
 
supports(Annotation, Class, Member) - Method in interface org.mule.api.MessageProcessorAnnotationParser
Determines whether this parser can process the current annotation.
supports(Class<?>) - Method in interface org.mule.api.security.SecurityProvider
 
supports(Class) - Method in class org.mule.api.SingleResourceTransactionFactoryManager
 
supports(Object, Object) - Method in interface org.mule.api.transaction.Transaction
 
supports(Annotation, Class, Member) - Method in class org.mule.config.endpoint.AbstractEndpointAnnotationParser
 
supports(Annotation) - Method in class org.mule.config.expression.ExprAnnotationParser
 
supports(Annotation) - Method in class org.mule.config.expression.FunctionAnnotationParser
 
supports(Annotation) - Method in class org.mule.config.expression.LookupAnnotationParser
 
supports(Annotation) - Method in class org.mule.config.expression.MuleAnnotationParser
 
supports(Annotation) - Method in class org.mule.config.parsers.InboundAttachmentsAnnotationParser
 
supports(Annotation) - Method in class org.mule.config.parsers.InboundHeadersAnnotationParser
 
supports(Annotation) - Method in class org.mule.config.parsers.OutboundAttachmentsAnnotationParser
 
supports(Annotation) - Method in class org.mule.config.parsers.OutboundHeadersAnnotationParser
 
supports(Annotation) - Method in class org.mule.config.parsers.PayloadAnnotationParser
 
supports(Annotation) - Method in class org.mule.module.json.config.JsonPathAnnotationParser
 
supports(Annotation) - Method in class org.mule.module.ognl.config.OgnlAnnotationParser
 
supports(Class<?>) - Method in class org.mule.module.pgp.PGPSecurityProvider
 
supports(Annotation) - Method in class org.mule.module.scripting.config.GroovyAnnotationParser
 
supports(Annotation) - Method in class org.mule.module.xml.config.XPathAnnotationParser
 
supports(Object, Object) - Method in class org.mule.processor.DelegateTransaction
 
supports(Class<?>) - Method in class org.mule.security.AbstractSecurityProvider
 
supports(Object, Object) - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
supports(Object, Object) - Method in class org.mule.transaction.XaTransaction
 
supports(Object, Object) - Method in class org.mule.transport.jms.JmsClientAcknowledgeTransaction
 
supports(Annotation, Class, Member) - Method in class org.mule.transport.quartz.config.ScheduleAnnotationParser
Validates that this parser can parse the supplied annotation.
supportsAggressiveRelease() - Method in class org.hibernate.connection.SimpleConnectionProvider
 
supportsAsynchronousProcessing() - Method in interface org.mule.execution.MessageProcessContext
 
supportsAsynchronousProcessing() - Method in class org.mule.module.http.internal.listener.HttpMessageProcessContext
 
supportsAsynchronousProcessing() - Method in class org.mule.transport.TransportMessageProcessContext
 
supportsInnerTransaction(Transaction) - Method in class org.mule.processor.DelegateTransaction
 
supportsProperty(String) - Method in class org.mule.transport.jms.JmsConnector
This method may be overridden in case a certain JMS implementation does not support all the standard JMS properties.
supportsProtocol(String) - Method in interface org.mule.api.transport.Connector
 
supportsProtocol(String) - Method in class org.mule.transport.AbstractConnector
 
supportsTemplate(MessageProcessTemplate) - Method in class org.mule.execution.AsyncResponseFlowProcessingPhase
 
supportsTemplate(MessageProcessTemplate) - Method in class org.mule.execution.EndProcessPhase
 
supportsTemplate(MessageProcessTemplate) - Method in class org.mule.execution.FlowProcessingPhase
 
supportsTemplate(MessageProcessTemplate) - Method in interface org.mule.execution.MessageProcessPhase
Determines if a certain phase supports a given template.
supportsTemplate(MessageProcessTemplate) - Method in class org.mule.execution.ValidationPhase
 
supportsUrl(String) - Method in interface org.mule.api.connector.ConnectorOperationProvider
 
supportsUrl(String) - Method in class org.mule.module.http.internal.request.client.HttpConnectorMessageProcessorProvider
 
suspend() - Method in interface org.mule.api.transaction.Transaction
Suspend the XA transaction
suspend() - Method in class org.mule.processor.DelegateTransaction
 
suspend() - Method in class org.mule.transaction.AbstractTransaction
 
suspend() - Method in class org.mule.transaction.XaTransaction
 
suspendCurrentTransaction() - Method in class org.mule.transaction.TransactionCoordination
 
suspended() - Method in class org.mule.transport.servlet.jetty.JettyContinuationsMessageProcessTemplate
 
suspended - Variable in class org.mule.util.queue.objectstore.xa.AbstractTransactionContext
Deprecated.
 
suspended - Variable in class org.mule.util.xa.AbstractTransactionContext
 
suspendedContexts - Variable in class org.mule.util.queue.objectstore.xa.AbstractXAResourceManager
Deprecated.
 
suspendedContexts - Variable in class org.mule.util.xa.AbstractXAResourceManager
 
suspendEncoding() - Method in class org.mule.util.Base64.OutputStream
Suspends encoding of the stream.
suspendXATransaction(Transaction) - Method in class org.mule.execution.SuspendXaTransactionInterceptor
 
SuspendXaTransactionInterceptor<T> - Class in org.mule.execution
 
SuspendXaTransactionInterceptor(ExecutionInterceptor<T>, TransactionConfig, boolean) - Constructor for class org.mule.execution.SuspendXaTransactionInterceptor
 
SxcFilter - Class in org.mule.module.sxc
 
SxcFilter() - Constructor for class org.mule.module.sxc.SxcFilter
 
SxcFilter(String) - Constructor for class org.mule.module.sxc.SxcFilter
 
SxcFilteringOutboundRouter - Class in org.mule.module.sxc
FilteringRouter is a router that accepts events based on a filter set.
SxcFilteringOutboundRouter() - Constructor for class org.mule.module.sxc.SxcFilteringOutboundRouter
 
SxcNamespaceHandler - Class in org.mule.module.sxc
 
SxcNamespaceHandler() - Constructor for class org.mule.module.sxc.SxcNamespaceHandler
 
SYNC_BATCH_SIZE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
SYNC_PROCESSING_STRATEGY - Static variable in class org.mule.config.spring.util.ProcessingStrategyUtils
 
SYNC_TIME - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
SYNC_WRITES - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
synchronous - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
SYNCHRONOUS_NONBLOCKING_EVENT_ERROR_MESSAGE - Static variable in class org.mule.processor.AsyncInterceptingMessageProcessor
 
SYNCHRONOUS_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
Specifies whether mule should process messages synchronously, i.e.
synchronousEventTimeout - Variable in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
 
synchronousProcessingStrategy - Variable in class org.mule.processor.strategy.AsynchronousProcessingStrategy
 
SynchronousProcessingStrategy - Class in org.mule.processor.strategy
This strategy processes all message processors in the calling thread.
SynchronousProcessingStrategy() - Constructor for class org.mule.processor.strategy.SynchronousProcessingStrategy
 
SynchronousUntilSuccessfulProcessingStrategy - Class in org.mule.routing
Until successful synchronous processing strategy.
SynchronousUntilSuccessfulProcessingStrategy() - Constructor for class org.mule.routing.SynchronousUntilSuccessfulProcessingStrategy
 
SyncWorkExecutor - Class in org.mule.work
 
SyncWorkExecutor() - Constructor for class org.mule.work.SyncWorkExecutor
 
SYSTEM_ATTRIBUTE - Static variable in class org.mule.transport.stdio.config.StdioNamespaceHandler
 
SYSTEM_ATTRIBUTE_ARRAY - Static variable in class org.mule.transport.stdio.config.StdioNamespaceHandler
 
SYSTEM_MAP - Static variable in class org.mule.transport.stdio.config.StdioNamespaceHandler
 
SYSTEM_PROPERTY_OVERRIDE - Static variable in class org.mule.module.launcher.DefaultAppBloodhound
 
SYSTEM_PROPERTY_PREFIX - Static variable in class org.mule.api.config.MuleProperties
The prefix for any Mule-specific properties set in the system properties
SystemExceptionHandler - Interface in org.mule.api.exception
Take some action when a system exception has occurred (i.e., there was no message in play when the exception occurred).
SystemExceptionListener - Class in org.mule.tck.listener
Listener for exceptions managed by the SystemExceptionHandler.
SystemExceptionListener(MuleContext) - Constructor for class org.mule.tck.listener.SystemExceptionListener
 
systemPackages - Variable in class org.mule.module.launcher.FineGrainedControlClassLoader
 
SystemPropertyInitializingBean - Class in org.mule.config.spring.util
Sets system properties from the configured list.
SystemPropertyInitializingBean() - Constructor for class org.mule.config.spring.util.SystemPropertyInitializingBean
 
systemPropertyNotSet(String) - Static method in class org.mule.config.builders.i18n.BuildersMessages
 
SystemUtils - Class in org.mule.util
 
SystemUtils() - Constructor for class org.mule.util.SystemUtils
 
SYSTIME_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 

T

take() - Method in interface org.mule.util.queue.Queue
Blocks and retrieves an object from this queue.
take() - Method in class org.mule.util.queue.TransactionAwareQueueStore
 
takeFromObjectStore(long) - Method in interface org.mule.util.queue.objectstore.TakingQueueStoreDelegate
Deprecated.
Poll the queue for its first member, and, if there is one, remove and return the corresponding object from the object store
takeNextItemFromStore(long) - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
TakingQueueStoreDelegate - Interface in org.mule.util.queue.objectstore
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
tap - Variable in class org.mule.routing.WireTap
 
target - Variable in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
target - Variable in class org.mule.processor.AsyncWorkListener
 
targetConfig - Variable in class org.mule.config.spring.parsers.assembly.DefaultBeanAssembler
 
TargetInvocationHandler - Interface in org.mule.util.proxy
 
TCP - Static variable in class org.mule.transport.tcp.TcpConnector
 
TcpClientSocketProperties - Interface in org.mule.transport.tcp
Interface for objects that provide TCP configuration for client sockets.
TcpConnector - Class in org.mule.transport.tcp
TcpConnector can bind or sent to a given TCP port on a given host.
TcpConnector(MuleContext) - Constructor for class org.mule.transport.tcp.TcpConnector
 
TcpInputStream - Class in org.mule.transport.tcp
The TcpMessageDispatcher and the TcpMessageReceiver use this class as the input parameter to the read() method on the TcpProtocol interface.
TcpInputStream(InputStream) - Constructor for class org.mule.transport.tcp.TcpInputStream
 
TcpMessageDispatcher - Class in org.mule.transport.tcp
Send transformed Mule events over TCP.
TcpMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.tcp.TcpMessageDispatcher
 
TcpMessageDispatcherFactory - Class in org.mule.transport.tcp
 
TcpMessageDispatcherFactory() - Constructor for class org.mule.transport.tcp.TcpMessageDispatcherFactory
 
TcpMessageReceiver - Class in org.mule.transport.tcp
TcpMessageReceiver acts like a TCP server to receive socket requests.
TcpMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.tcp.TcpMessageReceiver
 
TcpMessageReceiver.TcpWorker - Class in org.mule.transport.tcp
 
TcpMessageReceiver.TcpWorker(Socket, AbstractMessageReceiver) - Constructor for class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
TcpMessageRequester - Class in org.mule.transport.tcp
Request transformed Mule events from TCP.
TcpMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.tcp.TcpMessageRequester
 
TcpMessageRequesterFactory - Class in org.mule.transport.tcp
 
TcpMessageRequesterFactory() - Constructor for class org.mule.transport.tcp.TcpMessageRequesterFactory
 
TcpMessages - Class in org.mule.transport.tcp.i18n
 
TcpMessages() - Constructor for class org.mule.transport.tcp.i18n.TcpMessages
 
TcpNamespaceHandler - Class in org.mule.transport.tcp.config
Registers a Bean Definition Parser for handling elements.
TcpNamespaceHandler() - Constructor for class org.mule.transport.tcp.config.TcpNamespaceHandler
 
TcpPropertyHelper - Class in org.mule.transport.tcp
Helper class to read properties for the TCP transport.
TcpPropertyHelper() - Constructor for class org.mule.transport.tcp.TcpPropertyHelper
 
TcpProtocol - Interface in org.mule.transport.tcp
The TcpProtocol interface enables to plug different application level protocols on a TcpConnector.
TcpServerSocketFactory - Class in org.mule.transport.tcp
 
TcpServerSocketFactory() - Constructor for class org.mule.transport.tcp.TcpServerSocketFactory
 
TcpServerSocketProperties - Interface in org.mule.transport.tcp
Interface for objects that provide TCP configuration for server sockets.
TcpSocketFactory - Class in org.mule.transport.tcp
 
TcpSocketFactory() - Constructor for class org.mule.transport.tcp.TcpSocketFactory
 
TcpSocketKey - Class in org.mule.transport.tcp
This is used to adapt an endpoint so that it can be used as a key for sockets.
TcpSocketKey(ImmutableEndpoint) - Constructor for class org.mule.transport.tcp.TcpSocketKey
 
TE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
tearDown() - Method in class org.mule.test.infrastructure.deployment.AbstractFakeMuleServerTestCase
 
TEMP_FOLDER - Static variable in class org.mule.module.launcher.MuleFoldersUtil
 
Template - Class in com.javaforge.bobber.archetype.model
Represents a template in the archetype to be processed .
Template() - Constructor for class com.javaforge.bobber.archetype.model.Template
 
TEMPLATE_QUERY_REF - Static variable in class org.mule.module.db.internal.config.domain.query.QueryDefinitionParser
 
TEMPLATE_QUERY_REF - Static variable in class org.mule.module.db.internal.config.domain.query.QueryTemplateBeanDefinitionParser
 
templateCausedMalformedEndpoint(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
TemplateMessagingExceptionStrategy - Class in org.mule.exception
 
TemplateMessagingExceptionStrategy() - Constructor for class org.mule.exception.TemplateMessagingExceptionStrategy
 
TemplateParser - Class in org.mule.util
TemplateParser is a simple string parser that will substitute tokens in a string with values supplied in a Map.
TemplateParser.PatternInfo - Class in org.mule.util
 
TemplateParser.TemplateCallback - Interface in org.mule.util
 
TempWrapperPropertyConfiguration - Class in org.mule.config.spring.parsers.assembly.configuration
Wrap a PropertyConfiguration so that changes are kept in the wrapper
TempWrapperPropertyConfiguration(PropertyConfiguration) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
TempWrapperPropertyConfiguration(PropertyConfiguration, boolean) - Constructor for class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
test() - Method in class org.mule.module.db.internal.domain.database.GenericDbConfig
 
test() - Method in class org.mule.module.db.internal.resolver.database.AbstractDbConfigResolver
 
test() - Method in class org.mule.module.db.internal.resolver.database.DynamicDbConfigResolver
 
test() - Method in class org.mule.transport.jdbc.JdbcConnector
 
TEST_APPLICATION_NAME - Static variable in class org.mule.test.infrastructure.process.MuleContextProcessApplication
 
TEST_CONNECTION_ERROR - Static variable in class org.mule.module.db.internal.resolver.database.DynamicDbConfigResolver
 
TEST_URL - Static variable in class org.mule.tck.util.WebServiceOnlineCheck
 
TestAppender - Class in org.mule.tck.logging
Allows to check log events occurrences in a test case.
TestAppender(String, Filter, Layout<? extends Serializable>) - Constructor for class org.mule.tck.logging.TestAppender
 
TestAppender(String, Filter, Layout<? extends Serializable>, boolean) - Constructor for class org.mule.tck.logging.TestAppender
 
TestAppender.Expectation - Class in org.mule.tck.logging
 
TestAppender.Expectation(String, String, String) - Constructor for class org.mule.tck.logging.TestAppender.Expectation
 
testBindingConfig() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
testBindngProxyCreation() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
TestComponent - Class in org.mule.tck.testmodels.services
 
TestComponent() - Constructor for class org.mule.tck.testmodels.services.TestComponent
 
TestComponentDefinitionParser - Class in org.mule.tck.config
Configures a FunctionalTestComponent wrapped as a JavaComponent.
TestComponentDefinitionParser() - Constructor for class org.mule.tck.config.TestComponentDefinitionParser
 
TestComponentDefinitionParser(Class<?>) - Constructor for class org.mule.tck.config.TestComponentDefinitionParser
 
TestComponentException - Exception in org.mule.tck.testmodels.services
 
TestComponentException(String) - Constructor for exception org.mule.tck.testmodels.services.TestComponentException
 
testConnection() - Method in class org.mule.tck.util.ftp.FtpClient
 
testConnectorConfig() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testConnectorConfig() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
TestContextFactory - Class in org.mule.tck.jndi
Creates an in-memory context and populates it with test data.
TestContextFactory() - Constructor for class org.mule.tck.jndi.TestContextFactory
 
testDescriptorEndpoints() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
testEndpointConfig() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testEndpointConfig() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
testEndpointProperties() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testEndpointPropertiesConfig() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
testEnvironmentProperties() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testExceptionStrategy() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
testExceptionStrategy2() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testFlag(BeanDefinition, String) - Static method in class org.mule.config.spring.MuleHierarchicalBeanDefinitionParserDelegate
 
testFlow(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
Tests the given flow with a one-way message exchange pattern
testFlow(String, MuleEvent) - Method in class org.mule.tck.junit4.FunctionalTestCase
Looks up the given flow in the registry and processes it with the given event.
testFlow(String, MessageExchangePattern) - Method in class org.mule.tck.junit4.FunctionalTestCase
Looks up the given flow in the registry and processes it with the given message exchange pattern.
testFlowNonBlocking(String) - Method in class org.mule.tck.junit4.FunctionalTestCase
Runs the given flow before ensuring all assertions defined in the flow configuration were met.
testFlowNonBlocking(String, MessageExchangePattern) - Method in class org.mule.tck.junit4.FunctionalTestCase
Runs the given flow before ensuring all assertions defined in the flow configuration were met.
testFlowNonBlocking(String, MuleEvent) - Method in class org.mule.tck.junit4.FunctionalTestCase
Runs the given flow before ensuring all assertions defined in the flow configuration were met.
testGlobalEndpointConfig() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testGlobalEndpointConfig() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
testGlobalInterceptorStack() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testInboundRouterConfig() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
testInboundRouterConfig2() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
TestingThread - Class in org.mule.tck.concurrency
This class is very useful for test cases which need to make assertions concurrently in different threads.
TestingThread() - Constructor for class org.mule.tck.concurrency.TestingThread
 
testInterceptors() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testManagerConfig() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testManagerConfig() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
testMatch(MuleMessage) - Method in class org.mule.module.sxc.SxcFilteringOutboundRouter
 
testModelConfig() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testModelConfig() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
testMuleConfiguration() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
TestMultiuserSecurityProvider - Class in org.mule.tck.security
A security provider which holds authentications for multiple users concurrently.
TestMultiuserSecurityProvider() - Constructor for class org.mule.tck.security.TestMultiuserSecurityProvider
 
TestNamespaceHandler - Class in org.mule.tck.config
 
TestNamespaceHandler() - Constructor for class org.mule.tck.config.TestNamespaceHandler
 
testOutboundRouterConfig() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
testOutboundRouterConfig2() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testPoolingConfig() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
TestProcess - Class in org.mule.test.infrastructure.process
 
TestProcess(String, int, int) - Constructor for class org.mule.test.infrastructure.process.TestProcess
 
testQueueProfileConfig() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
TestReceiver - Class in org.mule.tck.testmodels.services
 
TestReceiver() - Constructor for class org.mule.tck.testmodels.services.TestReceiver
 
testResponseRouterConfig() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
TestSecurityComponent - Class in org.mule.tck.security
 
TestSecurityComponent() - Constructor for class org.mule.tck.security.TestSecurityComponent
 
TestServiceComponent - Class in org.mule.tck.testmodels.services
TestServiceComponent is a test WebServices service.
TestServiceComponent() - Constructor for class org.mule.tck.testmodels.services.TestServiceComponent
 
TestSingleUserSecurityProvider - Class in org.mule.tck.security
A security provider which only authenticates a single user at a time (i.e., authentication of a new user overwrites the previous authentication).
TestSingleUserSecurityProvider() - Constructor for class org.mule.tck.security.TestSingleUserSecurityProvider
 
TestSingleUserSecurityProvider(String) - Constructor for class org.mule.tck.security.TestSingleUserSecurityProvider
 
testThreadingConfig() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testTransactionConfig() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testTransformerConfig() - Method in class org.mule.tck.AbstractConfigBuilderTestCase
 
testTransformerConfig() - Method in class org.mule.tck.AbstractScriptConfigBuilderTestCase
 
TestUtils - Class in org.mule.tck.util
 
TestUtils() - Constructor for class org.mule.tck.util.TestUtils
 
TestUtils - Class in org.mule.test.infrastructure.process
 
TestUtils() - Constructor for class org.mule.test.infrastructure.process.TestUtils
 
TEXT - Static variable in interface org.mule.transformer.types.MimeTypes
 
TEXT_STRING - Static variable in class org.mule.transformer.types.DataTypeFactory
 
TextDefinitionParser - Class in org.mule.config.spring.parsers.generic
Grabs the text from an element and injects it into the parent, for example: A bunch of text. registerBeanDefinitionParser("foo", new OrphanDefinitionParser(Foo.class)); registerBeanDefinitionParser("bar-text", new TextDefinitionParser("barText")); will result in a call to Foo.setBarText("A bunch of text.")
TextDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.generic.TextDefinitionParser
 
TextDefinitionParser(String, boolean) - Constructor for class org.mule.config.spring.parsers.generic.TextDefinitionParser
 
TextFileObjectStore - Class in org.mule.util.store
A Simple object store that stores String objects by key to a text file.
TextFileObjectStore() - Constructor for class org.mule.util.store.TextFileObjectStore
 
thenTo(String) - Method in class org.mule.config.dsl.OutRouteBuilder
Deprecated.
 
THREAD_PER_PROCESSOR_PROCESSING_STRATEGY - Static variable in class org.mule.config.spring.util.ProcessingStrategyUtils
 
THREAD_POLL_CLASS - Static variable in class org.mule.modules.schedulers.cron.CronScheduler
 
THREAD_POLL_CLASS_PROPERTY - Static variable in class org.mule.modules.schedulers.cron.CronScheduler
 
THREAD_POOL_COUNT_PROPERTY - Static variable in class org.mule.modules.schedulers.cron.CronScheduler
 
ThreadingProfile - Interface in org.mule.api.config
Mule uses a few different pools i.e.
threadingProfile - Variable in class org.mule.model.seda.SedaService
Deprecated.
The threading profile to use for this service.
ThreadingProfile.WorkManagerFactory - Interface in org.mule.api.config
 
ThreadingProfileDefinitionParser - Class in org.mule.config.spring.parsers.specific
This parser is responsible for processing the configuration elements.
ThreadingProfileDefinitionParser(String, String) - Constructor for class org.mule.config.spring.parsers.specific.ThreadingProfileDefinitionParser
 
ThreadingProfileDefinitionParser(String, String, Class<? extends ThreadingProfile>) - Constructor for class org.mule.config.spring.parsers.specific.ThreadingProfileDefinitionParser
 
ThreadNameHelper - Class in org.mule.util.concurrent
Encapsulates thread naming logic for Mule standalone and embedded scenarios.
ThreadPerProcessorProcessingStrategy - Class in org.mule.processor.strategy
This strategy uses a WorkManager to schedule the processing of each message processors in a new worker thread.
ThreadPerProcessorProcessingStrategy() - Constructor for class org.mule.processor.strategy.ThreadPerProcessorProcessingStrategy
 
ThreadPoolFactory - Class in org.mule.config.pool
Uses a standard JDK's mechanism to locate implementations.
ThreadPoolFactory() - Constructor for class org.mule.config.pool.ThreadPoolFactory
 
ThreadSafeAccess - Interface in org.mule.api
Interface implemented by message-related objects that avoid exposing mutable data to multiple threads by providing immutable copies.
ThreadSafeAccess.AccessControl - Class in org.mule.api
This helper class can be used by code implementing this interface to determine whether the thread safety of a message should be enforced or not.
ThreadSafeAccess.AccessControl() - Constructor for class org.mule.api.ThreadSafeAccess.AccessControl
 
threadSafeCopy(MuleEvent) - Method in class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
 
threadTimeout - Variable in class org.mule.processor.AsyncInterceptingMessageProcessor
 
threadTTL - Variable in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
threadWaitTimeout - Variable in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
 
ThrottlingPhaseTemplate - Interface in org.mule.execution
Template that a MessageSource must implement if it wants to participate in the throttling phase when processing a message
throwException() - Method in class org.mule.tck.functional.FunctionalTestComponent
Always throws a FunctionalTestException.
throwOnUnaccepted - Variable in class org.mule.processor.AbstractFilteringMessageProcessor
Throw a FilterUnacceptedException when a message is rejected by the filter?
throwsException(String) - Method in interface org.mule.tck.testmodels.services.ITestComponent
 
throwsException(String) - Method in class org.mule.tck.testmodels.services.TestComponent
 
tiltFlag() - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
Time - Interface in org.mule.api.el.datetime
 
TIME_AVERAGE - Static variable in class org.mule.util.counters.CounterFactory.Type
Counter representing the time average value of a counter
TIME_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
TIME_TO_LIVE_PROPERTY - Static variable in class org.mule.transport.jms.JmsConstants
 
TimeAverage - Class in org.mule.util.counters.impl
 
TimeAverage(String, AbstractCounter) - Constructor for class org.mule.util.counters.impl.TimeAverage
 
TimedSocket - Class in org.mule.util
This class implements a timeout feature on socket connections.
TimeEvent - Class in org.mule.util.timer
TimeEvent TODO is an event that occurs at a specified number of milliseconds.
TimeEvent(Object, String, long) - Constructor for class org.mule.util.timer.TimeEvent
 
TimeEventListener - Interface in org.mule.util.timer
TimeEventListener provides a method to pass timer events to implementing objects.
timeExpired(TimeEvent) - Method in interface org.mule.util.timer.TimeEventListener
Passes the TimeEvent to an object
TIMEOUT - Static variable in class org.mule.config.spring.parsers.specific.TransactionDefinitionParser
 
timeout - Variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
timeout - Variable in class org.mule.service.ServiceAsyncReplyCompositeMessageSource
Deprecated.
 
timeout - Variable in class org.mule.tck.functional.AssertionMessageProcessor
 
TIMEOUT - Static variable in class org.mule.tck.util.ftp.FtpClient
 
timeout - Variable in class org.mule.test.infrastructure.process.Controller
 
timeout - Variable in class org.mule.transaction.AbstractTransaction
 
timeout - Variable in class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
timeout - Variable in class org.mule.transport.servlet.AbstractReceiverServlet
 
timeout - Variable in class org.mule.transport.udp.UdpConnector
 
timeout - Variable in class org.mule.util.queue.objectstore.xa.AbstractTransactionContext
Deprecated.
 
timeout - Variable in class org.mule.util.xa.AbstractTransactionContext
 
TIMEOUT_DO_NOT_WAIT - Static variable in interface org.mule.api.MuleEvent
 
TIMEOUT_IN_SECONDS - Static variable in class org.mule.test.infrastructure.process.MuleContextProcessBuilder
 
TIMEOUT_NOT_SET_VALUE - Static variable in interface org.mule.api.MuleEvent
 
TIMEOUT_WAIT_FOREVER - Static variable in interface org.mule.api.MuleEvent
 
TimerInterceptor - Class in org.mule.interceptor
TimerInterceptor simply times and displays the time taken to process an event.
TimerInterceptor() - Constructor for class org.mule.interceptor.TimerInterceptor
 
timestamp - Variable in class org.mule.api.context.notification.ServerNotification
 
TIMESTAMP_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
TINYINT_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
TlsConfiguration - Class in org.mule.api.security.tls
Support for configuring TLS/SSL connections.
TlsConfiguration(String) - Constructor for class org.mule.api.security.tls.TlsConfiguration
Support for TLS connections with a given initial value for the key store
tlsContextFactory(TlsContextFactory) - Method in class org.mule.module.http.api.client.HttpRequestOptionsBuilder
 
TlsDirectKeyStore - Interface in org.mule.api.security
Configure direct key stores.
TlsDirectTrustStore - Interface in org.mule.api.security
Configure direct trust stores.
TlsIndirectKeyStore - Interface in org.mule.api.security
Configure indirect key stores.
TlsIndirectTrustStore - Interface in org.mule.api.security
Configure indirect trust stores.
TlsProperties - Class in org.mule.api.security.tls
 
TlsProperties() - Constructor for class org.mule.api.security.tls.TlsProperties
 
TlsPropertiesMapper - Class in org.mule.api.security.tls
Move a TlsConfiguration to and from Properties (typically System Properties).
TlsPropertiesMapper(String) - Constructor for class org.mule.api.security.tls.TlsPropertiesMapper
 
TlsPropertiesSocketFactory - Class in org.mule.api.security.tls
A socket factory that is configured via Properties, using a TlsConfiguration that has been stored via TlsPropertiesMapper.
TlsPropertiesSocketFactory(boolean, String) - Constructor for class org.mule.api.security.tls.TlsPropertiesSocketFactory
 
to(String) - Method in class org.mule.config.dsl.ComponentBuilder
Deprecated.
 
to(String) - Method in class org.mule.config.dsl.OutRouteBuilder
Deprecated.
 
to(String) - Method in class org.mule.config.dsl.ServiceBuilder
Deprecated.
 
TO_ADDRESSES_PROPERTY - Static variable in interface org.mule.transport.email.MailProperties
 
toAbsoluteFile(String, String) - Method in class org.mule.module.launcher.descriptor.PropertiesDescriptorParser
Resolve a resource relative to an application root.
toArray() - Method in class org.mule.module.json.JsonData
 
toArray() - Method in class org.mule.module.launcher.util.ObservableList
 
toArray(Object[]) - Method in class org.mule.module.launcher.util.ObservableList
 
toArray() - Method in class org.mule.routing.EventGroup
Returns a snapshot of collected events in this group sorted by their arrival time.
toArray(boolean) - Method in class org.mule.routing.EventGroup
Returns a snapshot of collected events in this group, optionally sorted by their arrival time.
toArray(Object, Class<?>) - Static method in class org.mule.transport.http.multipart.LazyList
Convert a lazylist to an array
toArray() - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
toArray(Object[]) - Method in class org.mule.util.concurrent.ConcurrentHashSet
 
toArrayOfComponentType(Object[], Class) - Static method in class org.mule.util.ArrayUtils
Creates a copy of the given array, but with the given Class as element type.
toArrayOfComponentType(Collection, Class<T>) - Static method in class org.mule.util.CollectionUtils
Creates an array of the given Collection's elements, but with the given Class as element type.
toByteArray(Message, String, String) - Static method in class org.mule.transport.jms.JmsMessageUtils
 
toByteArray(InputStream) - Static method in class org.mule.util.IOUtils
This method wraps IOUtils' toByteArray(InputStream) method but catches any IOException and wraps it into a RuntimeException.
toByteArray() - Method in class org.springframework.asm.ClassWriter
Returns the bytecode of the class that was build with this class writer.
toCalendar() - Method in interface org.mule.api.el.datetime.Instant
 
toCalendar() - Method in class org.mule.el.datetime.AbstractInstant
 
toComponent(Class) - Method in class org.mule.config.dsl.ServiceBuilder
Deprecated.
 
toComponent(Object) - Method in class org.mule.config.dsl.ServiceBuilder
Deprecated.
 
toDate() - Method in interface org.mule.api.el.datetime.Instant
 
toDate() - Method in class org.mule.el.datetime.AbstractInstant
 
toDocument(Object, MuleContext) - Static method in class org.mule.module.xml.util.XMLUtils
 
toDocument(Object, String, MuleContext) - Static method in class org.mule.module.xml.util.XMLUtils
Converts an object of unknown type to an org.dom4j.Document if possible.
toDOMNode(Object) - Method in class org.mule.module.xml.filters.AbstractJaxpFilter
toDOMNode(Object, MuleEvent) - Method in class org.mule.module.xml.filters.AbstractJaxpFilter
 
toDOMNode(Object, MuleEvent) - Static method in class org.mule.module.xml.util.XMLUtils
 
toDOMNode(Object, MuleEvent, DocumentBuilderFactory) - Static method in class org.mule.module.xml.util.XMLUtils
 
toDouble(Object) - Static method in class org.mule.util.NumberUtils
 
toDouble(String) - Static method in class org.mule.util.NumberUtils
 
toFloat(Object) - Static method in class org.mule.util.NumberUtils
 
toFloat(String) - Static method in class org.mule.util.NumberUtils
 
toHexString(byte[]) - Static method in class org.mule.util.StringUtils
 
toHexString(byte[], boolean) - Static method in class org.mule.util.StringUtils
Convert a byte array to a hexadecimal string.
toImmutableParameterMap() - Method in class org.mule.module.http.internal.ParameterMap
 
toInt(Object) - Static method in class org.mule.util.NumberUtils
 
toInt(String) - Static method in class org.mule.util.NumberUtils
 
TOKEN_DELIM - Static variable in class org.mule.security.MuleCredentials
 
TOKEN_NOT_FOUND_STATUS - Static variable in class org.mule.module.oauth2.internal.authorizationcode.AutoAuthorizationCodeTokenRequestHandler
 
TOKEN_URL_CALL_FAILED_STATUS - Static variable in class org.mule.module.oauth2.internal.authorizationcode.AutoAuthorizationCodeTokenRequestHandler
 
TokenManagerConfig - Class in org.mule.module.oauth2.internal.tokenmanager
Token manager stores all the OAuth State (access token, refresh token).
TokenManagerConfig() - Constructor for class org.mule.module.oauth2.internal.tokenmanager.TokenManagerConfig
 
TokenNotFoundException - Exception in org.mule.module.oauth2.internal
It was not possible to retrieve the access token or the refresh token from the token URL response
TokenNotFoundException(MuleEvent, TokenResponseProcessor) - Constructor for exception org.mule.module.oauth2.internal.TokenNotFoundException
 
TokenResponseConfiguration - Class in org.mule.module.oauth2.internal.authorizationcode
Provides configuration to handle a token url call response.
TokenResponseConfiguration() - Constructor for class org.mule.module.oauth2.internal.authorizationcode.TokenResponseConfiguration
 
TokenResponseProcessor - Class in org.mule.module.oauth2.internal
Process a token url response and extracts all the oauth context variables based on the user configuration.
toListHeader(String) - Static method in class org.mule.transport.email.MailUtils
Convert a header name to the property name associated with a list of header values (ie prepend the prefix)
toListValuesMap() - Method in interface org.mule.module.http.api.HttpParameters
 
toListValuesMap() - Method in class org.mule.module.http.internal.ParameterMap
 
toLong(Object) - Static method in class org.mule.util.NumberUtils
 
toLong(String) - Static method in class org.mule.util.NumberUtils
 
toMap(Annotation[]) - Static method in class org.mule.module.extension.internal.introspection.MuleExtensionAnnotationParser
 
toMap(List<T>) - Static method in class org.mule.module.extension.internal.util.MuleExtensionUtils
Returns a Map in which the keys are the names of the items in the objects List, and the values are the items themselves.
toMap(ResultSet) - Method in class org.mule.transport.jdbc.ColumnAliasRowProcessor
 
toMessage(Object, Session) - Static method in class org.mule.transport.jms.JmsMessageUtils
 
toMessageCollection() - Method in class org.mule.routing.EventGroup
 
toMessageCollection(boolean) - Method in class org.mule.routing.EventGroup
 
toObject(Message, String, String) - Static method in class org.mule.transport.jms.JmsMessageUtils
 
tooManyAcceptableMethodsOnObjectForTypes(Object, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
tooManyAcceptableMethodsOnObjectUsingResolverForTypes(Object, Object, String) - Static method in class org.mule.config.i18n.CoreMessages
 
tooManyMatchingMethodsOnObjectUsingResolverWhichReturn(Object, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
tooManyMatchingMethodsOnObjectWhichReturn(Object, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
tooManyRedeliveries(String, int, int, ImmutableEndpoint) - Static method in class org.mule.transport.jms.i18n.JmsMessages
 
TooManySatisfiableMethodsException - Exception in org.mule.model.resolvers
TooManySatisfiableMethodsException is thrown by EntryPointResolvers when the service passed has more than one method that meets the criteria of the configured EntryPointResolver.
TooManySatisfiableMethodsException(Object, Object[]) - Constructor for exception org.mule.model.resolvers.TooManySatisfiableMethodsException
 
TooManySatisfiableMethodsException(Object, Class<?>) - Constructor for exception org.mule.model.resolvers.TooManySatisfiableMethodsException
 
TOPIC - Static variable in class org.mule.transport.jms.config.JmsNamespaceHandler
 
TOPIC_PROPERTY - Static variable in class org.mule.transport.jms.JmsConstants
 
toPooledComponent(Class) - Method in class org.mule.config.dsl.ServiceBuilder
Deprecated.
 
toQName() - Method in enum org.mule.module.xml.xpath.XPathReturnType
Returns the QName related to each value
toQueueConfiguration(MuleContext) - Method in class org.mule.config.QueueProfile
 
toResponse(Throwable) - Method in class org.mule.module.jersey.exception.FallbackErrorMapper
 
toStreamSource(XMLInputFactory, boolean, InputStream) - Static method in class org.mule.module.xml.util.XMLUtils
 
toString() - Method in class org.mule.api.context.notification.FlowStackElement
 
toString() - Method in class org.mule.api.context.notification.ServerNotification
 
toString() - Method in class org.mule.api.debug.FieldDebugInfo
 
toString() - Method in enum org.mule.api.registry.ServiceType
 
toString() - Method in class org.mule.api.transport.PropertyScope
 
toString() - Method in class org.mule.component.AbstractComponent
 
toString() - Method in class org.mule.component.BindingInvocationHandler
 
toString() - Method in class org.mule.component.DefaultInterfaceBinding
 
toString() - Method in class org.mule.config.ChainedThreadingProfile
 
toString() - Method in class org.mule.config.ConfigResource
 
toString() - Method in class org.mule.config.i18n.Message
 
toString() - Method in class org.mule.config.ImmutableThreadingProfile
 
toString() - Method in class org.mule.config.QueueProfile
 
toString() - Method in class org.mule.config.spring.DefaultMuleArtifact
 
toString() - Method in class org.mule.construct.AbstractFlowConstruct
 
toString() - Method in class org.mule.construct.processor.FlowConstructStatisticsMessageProcessor
 
toString() - Method in class org.mule.context.DefaultMuleContextBuilder
 
toString() - Method in class org.mule.context.notification.BaseConnectorMessageNotification
 
toString() - Method in class org.mule.context.notification.ComponentMessageNotification
 
toString() - Method in class org.mule.context.notification.DefaultFlowCallStack
 
toString() - Method in class org.mule.context.notification.ListenerSubscriptionPair
 
toString() - Method in class org.mule.context.notification.MessageProcessorNotification
 
toString() - Method in class org.mule.context.notification.MuleContextNotification
 
toString() - Method in class org.mule.context.notification.RegistryNotification
 
toString() - Method in class org.mule.context.notification.TransactionNotification
 
toString() - Method in class org.mule.DefaultMuleEvent
 
toString() - Method in class org.mule.DefaultMuleEventContext
 
toString() - Method in class org.mule.DefaultMuleMessage
 
toString() - Method in class org.mule.el.context.MessageContext
 
toString() - Method in class org.mule.el.context.MessagePropertyMapContext
 
toString() - Method in class org.mule.el.datetime.DateTime
 
toString() - Method in class org.mule.endpoint.AbstractEndpoint
 
toString() - Method in class org.mule.endpoint.inbound.InboundEndpointMimeTypeCheckingMessageProcessor
 
toString() - Method in class org.mule.endpoint.inbound.InboundEndpointPropertyMessageProcessor
 
toString() - Method in class org.mule.endpoint.inbound.InboundExceptionDetailsMessageProcessor
 
toString() - Method in class org.mule.endpoint.inbound.InboundLoggingMessageProcessor
 
toString() - Method in class org.mule.endpoint.inbound.InboundNotificationMessageProcessor
 
toString() - Method in class org.mule.endpoint.MuleEndpointURI
 
toString() - Method in class org.mule.endpoint.outbound.OutboundEndpointMimeTypeCheckingMessageProcessor
 
toString() - Method in class org.mule.endpoint.outbound.OutboundEndpointPropertyMessageProcessor
 
toString() - Method in class org.mule.endpoint.outbound.OutboundEventTimeoutMessageProcessor
 
toString() - Method in class org.mule.endpoint.outbound.OutboundLoggingMessageProcessor
 
toString() - Method in class org.mule.endpoint.outbound.OutboundNotificationMessageProcessor
 
toString() - Method in class org.mule.endpoint.outbound.OutboundRootMessageIdPropertyMessageProcessor
 
toString() - Method in class org.mule.endpoint.outbound.OutboundSessionHandlerMessageProcessor
 
toString() - Method in class org.mule.endpoint.URIBuilder
 
toString() - Method in class org.mule.impl.model.resolvers.AnnotatedEntryPointResolver
 
toString() - Method in class org.mule.lifecycle.LifecycleObject
 
toString() - Method in class org.mule.message.ExceptionMessage
 
toString() - Method in class org.mule.MessagePropertiesContext
 
toString() - Method in class org.mule.model.AbstractModel
Deprecated.
 
toString() - Method in class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
 
toString() - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
 
toString() - Method in class org.mule.model.resolvers.CallableEntryPointResolver
 
toString() - Method in class org.mule.model.resolvers.ExplicitMethodEntryPointResolver
 
toString() - Method in class org.mule.model.resolvers.MethodHeaderPropertyEntryPointResolver
 
toString() - Method in class org.mule.model.resolvers.ReflectionEntryPointResolver
 
toString() - Method in class org.mule.module.client.remoting.RemoteDispatcherAgent
Deprecated.
 
toString() - Method in class org.mule.module.cxf.support.DelegatingOutputStream
 
toString() - Method in class org.mule.module.db.internal.domain.type.AbstractDbType
 
toString() - Method in class org.mule.module.http.internal.listener.matcher.ListenerRequestMatcher
 
toString() - Method in class org.mule.module.http.internal.listener.matcher.MethodRequestMatcher
 
toString() - Method in class org.mule.module.http.internal.listener.ServerAddress
 
toString() - Method in class org.mule.module.http.internal.ParameterMap
 
toString() - Method in class org.mule.module.jaas.MuleJaasPrincipal
 
toString() - Method in class org.mule.module.json.JsonData
 
toString() - Method in class org.mule.module.launcher.application.ApplicationWrapper
 
toString() - Method in class org.mule.module.launcher.application.DefaultMuleApplication
 
toString() - Method in class org.mule.module.launcher.application.EnumerationAdapter
 
toString() - Method in class org.mule.module.launcher.artifact.ArtifactWrapper
 
toString() - Method in class org.mule.module.launcher.MuleApplicationClassLoader
 
toString() - Method in class org.mule.module.launcher.MuleSharedDomainClassLoader
 
toString() - Method in class org.mule.module.ws.construct.WSProxy
 
toString() - Method in class org.mule.processor.AbstractDynamicMessageProcessor
 
toString() - Method in class org.mule.processor.AbstractInterceptingMessageProcessorBase
 
toString() - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
 
toString() - Method in class org.mule.processor.InvokerMessageProcessor
 
toString() - Method in class org.mule.processor.NullMessageProcessor
 
toString() - Method in class org.mule.retry.policies.NoRetryPolicyTemplate
 
toString() - Method in class org.mule.retry.policies.RetryForeverPolicyTemplate
 
toString() - Method in class org.mule.retry.policies.SimpleRetryPolicyTemplate
 
toString() - Method in class org.mule.routing.AbstractSelectiveRouter
 
toString() - Method in class org.mule.routing.EventGroup
 
toString() - Method in class org.mule.routing.MessageFilter
 
toString() - Method in class org.mule.routing.MessageProcessorFilterPair
 
toString() - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
Deprecated.
 
toString() - Method in class org.mule.routing.outbound.SplitMessage.MessagePart
 
toString() - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
toString() - Method in class org.mule.routing.WireTap
 
toString() - Method in class org.mule.security.AbstractJCEEncryptionStrategy
 
toString() - Method in class org.mule.security.oauth.notification.OAuthAuthorizeNotification
 
toString(MuleEvent, Object) - Method in class org.mule.security.oauth.processor.AbstractAuthorizeMessageProcessor
 
toString() - Method in class org.mule.service.AbstractService
Deprecated.
 
toString() - Method in class org.mule.source.StartableCompositeMessageSource
 
toString() - Method in class org.mule.tck.functional.FunctionalStreamingTestComponent
 
toString() - Method in class org.mule.tck.logging.TestAppender.Expectation
 
toString() - Method in class org.mule.tck.testmodels.services.Person
 
toString() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
 
toString() - Method in class org.mule.transaction.AbstractTransaction
 
toString() - Method in class org.mule.transaction.MuleTransactionConfig
 
toString() - Method in class org.mule.transaction.XaTransaction
 
toString() - Method in class org.mule.transformer.AbstractTransformer
 
toString(List<Transformer>) - Static method in class org.mule.transformer.TransformerUtils
 
toString() - Method in class org.mule.transformer.TransformerWeighting
 
toString() - Method in class org.mule.transformer.types.CollectionDataType
 
toString() - Method in class org.mule.transformer.types.SimpleDataType
 
toString() - Method in class org.mule.transport.AbstractConnector
 
toString() - Method in class org.mule.transport.AbstractMessageDispatcherFactory
 
toString() - Method in class org.mule.transport.AbstractMessageReceiver
 
toString() - Method in class org.mule.transport.AbstractMessageRequesterFactory
 
toString() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
toString() - Method in class org.mule.transport.http.CacheControlHeader
 
toString() - Method in class org.mule.transport.http.construct.HttpProxy
 
toString(Object) - Static method in class org.mule.transport.http.multipart.LazyList
 
toString() - Method in class org.mule.transport.http.RequestLine
 
toString() - Method in class org.mule.transport.jms.xa.XAResourceWrapper
 
toString() - Method in class org.mule.transport.NullPayload
 
toString() - Method in class org.mule.transport.servlet.events.ServletContextNotification
 
toString() - Method in class org.mule.transport.sftp.notification.SftpTransportNotification
 
toString() - Method in class org.mule.transport.sftp.SftpInputStream
 
toString() - Method in class org.mule.transport.tcp.TcpSocketKey
 
toString() - Method in class org.mule.util.annotation.AnnotationMetaData
 
toString(Object, int) - Static method in class org.mule.util.ArrayUtils
Like ArrayUtils.toString(Object) but considers at most maxElements values; overflow is indicated by an appended "[..]" ellipsis.
toString(Collection, boolean) - Static method in class org.mule.util.CollectionUtils
Creates a String representation of the given Collection, with optional newlines between elements.
toString(Collection, int) - Static method in class org.mule.util.CollectionUtils
toString(Collection, int, boolean) - Static method in class org.mule.util.CollectionUtils
Creates a String representation of the given Collection, with optional newlines between elements.
toString() - Method in class org.mule.util.concurrent.WaitableBoolean
 
toString() - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
toString(InputStream) - Static method in class org.mule.util.IOUtils
This method wraps IOUtils' toString(InputStream) method but catches any IOException and wraps it into a RuntimeException.
toString() - Method in class org.mule.util.MapCombiner
 
toString(Map, boolean) - Static method in class org.mule.util.MapUtils
Creates a String representation of the given Map, with optional newlines between elements.
toString(Object) - Static method in class org.mule.util.ObjectUtils
 
toString() - Method in class org.mule.util.queue.DefaultQueueConfiguration
 
toString() - Method in class org.mule.util.queue.objectstore.QueueKey
Deprecated.
 
toString() - Method in class org.mule.util.queue.objectstore.xa.AbstractTransactionContext
Deprecated.
 
toString() - Method in class org.mule.util.scan.annotations.AnnotationInfo.NameValue
Deprecated.
 
toString() - Method in class org.mule.util.scan.annotations.AnnotationInfo
Deprecated.
 
toString() - Method in class org.mule.util.SimpleLoggingTable
 
toString() - Method in class org.mule.util.SplashScreen
 
toString() - Method in class org.mule.util.store.InMemoryObjectStore.StoredObject
 
toString() - Method in class org.mule.util.store.InMemoryObjectStore
 
toString(Object) - Static method in class org.mule.util.StringMessageUtils
 
toString() - Method in class org.mule.util.VersionRange
 
toString() - Method in class org.mule.util.xa.AbstractTransactionContext
 
toString() - Method in class org.mule.VoidResult
 
toString() - Method in class org.mule.work.WorkerContext
 
toString() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
toStringArray(Object) - Static method in class org.mule.transport.http.multipart.LazyList
 
toStringArrayMap() - Method in class org.mule.transport.http.multipart.MultiMap
 
touch() - Method in class org.mule.transport.soap.axis.extensions.AxisMuleSession
 
toURLs() - Method in class org.mule.module.launcher.plugin.PluginClasspath
 
toW3cDocument(Object) - Static method in class org.mule.module.xml.util.XMLUtils
Converts a payload to a Document representation.
toXml(Document) - Static method in class org.mule.module.xml.util.XMLUtils
Converts a DOM to an XML string.
toXMLCalendar() - Method in interface org.mule.api.el.datetime.Instant
 
toXMLCalendar() - Method in class org.mule.el.datetime.AbstractInstant
 
toXmlSource(XMLStreamReader) - Static method in class org.mule.module.xml.util.XMLUtils
 
toXmlSource(XMLInputFactory, boolean, Object) - Static method in class org.mule.module.xml.util.XMLUtils
Convert our object to a Source type efficiently.
toXMLStreamReader(XMLInputFactory, Object) - Static method in class org.mule.module.xml.util.XMLUtils
toXMLStreamReader(XMLInputFactory, MuleEvent, Object) - Static method in class org.mule.module.xml.util.XMLUtils
Returns an XMLStreamReader for an object of unknown type if possible.
trace(Object) - Method in class org.mule.util.MuleLogger
 
trace(Object, Throwable) - Method in class org.mule.util.MuleLogger
 
tracker - Variable in class org.mule.module.launcher.StartupSummaryDeploymentListener
 
TrackerWorkListener - Class in org.mule.transport
Wraps a WorkListener associated with a given Work to delegate notifications originated in a work's wrapper.
TrackerWorkListener(Work, WorkListener) - Constructor for class org.mule.transport.TrackerWorkListener
 
TrackerWorkListenerWrapperFactory - Class in org.mule.transport
 
TrackerWorkListenerWrapperFactory() - Constructor for class org.mule.transport.TrackerWorkListenerWrapperFactory
 
TrackingWorkManager - Class in org.mule.transport
Wraps a WorkManager to track the work that in process.
TrackingWorkManager(WorkManagerHolder, int) - Constructor for class org.mule.transport.TrackingWorkManager
 
trackResultSet(DbConnection, ResultSet) - Method in class org.mule.module.db.internal.result.statement.StatementStreamingResultSetCloser
Adds a resultSet for tracking in order to be able to close it later
TRAILER - Static variable in class org.mule.module.http.api.HttpHeaders.Names
TRAILERS - Static variable in class org.mule.module.http.api.HttpHeaders.Values
transacted - Variable in class org.mule.construct.builder.BridgeBuilder
 
transacted(boolean) - Method in class org.mule.construct.builder.BridgeBuilder
 
TransactedPollingMessageReceiver - Class in org.mule.transport
The TransactedPollingMessageReceiver is an abstract receiver that handles polling and transaction management.
TransactedPollingMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.TransactedPollingMessageReceiver
 
TransactedPollingMessageReceiver(Connector, FlowConstruct, InboundEndpoint, long) - Constructor for class org.mule.transport.TransactedPollingMessageReceiver
TransactedPollingMessageReceiver.MessageProcessorWorker - Class in org.mule.transport
 
TransactedPollingMessageReceiver.MessageProcessorWorker(ExecutionTemplate<MuleEvent>, CountDownLatch, SystemExceptionHandler, Object) - Constructor for class org.mule.transport.TransactedPollingMessageReceiver.MessageProcessorWorker
 
TransactedSingleResourceJmsMessageReceiver - Class in org.mule.transport.jms
 
TransactedSingleResourceJmsMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
 
Transaction - Interface in org.mule.api.transaction
 
transaction - Variable in class org.mule.transaction.XaTransaction
The inner JTA transaction
TRANSACTION_BEGAN - Static variable in class org.mule.context.notification.TransactionNotification
 
TRANSACTION_COMMITTED - Static variable in class org.mule.context.notification.TransactionNotification
 
TRANSACTION_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
 
TRANSACTION_ISOLATION_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
TRANSACTION_ROLLEDBACK - Static variable in class org.mule.context.notification.TransactionNotification
 
TRANSACTIONAL_ACTION_PROPERTY - Static variable in class org.mule.module.db.internal.config.processor.AbstractAdvancedDbProcessorDefinitionParser
 
TransactionalAction - Enum in org.mule.module.db.internal.domain.transaction
Indicates how a connector should behave about transactions
TransactionalDbConnectionFactory - Class in org.mule.module.db.internal.domain.connection
Creates connections using a DbTransactionManager to track active transactions.
TransactionalDbConnectionFactory(DbTransactionManager, DbTypeManager, ConnectionFactory, DataSource) - Constructor for class org.mule.module.db.internal.domain.connection.TransactionalDbConnectionFactory
 
TransactionalErrorHandlingExecutionTemplate - Class in org.mule.execution
Creates an execution context that should be used when: - A flow execution starts because a message was received by a MessageReceiver - Any other entry point of execution with no parent execution context Created a ExecutionTemplate that will: Resolve non xa transactions created before it if the TransactionConfig action requires it suspend-resume xa transaction created before it if the TransactionConfig action requires it start a transaction if required by TransactionConfig action resolve transaction if was started by this TransactionTemplate route any exception to exception strategy if it was not already routed to it
TransactionalExecutionTemplate<T> - Class in org.mule.execution
ExecutionTemplate created should be used on a MessageProcessor that are previously wrapper by TransactionalErrorHandlingExecutionTemplate or ErrorHandlingExecutionTemplate Should be used when: An outbound endpoint is called An outbound router is called Any other MessageProcessor able to manage transactions is called Instance of TransactionTemplate created by this method will: Resolve non xa transactions created before it if the TransactionConfig action requires it Suspend-Resume xa transaction created before it if the TransactionConfig action requires it Start a transaction if required by TransactionConfig action Resolve transaction if was started by this TransactionTemplate Route any exception to exception strategy if it was not already routed to it
TransactionalFunctionalTestComponent - Class in org.mule.tck.functional
This service is useful for unit tests involving transactionality because it will roll back the current transaction upon message arrival.
TransactionalFunctionalTestComponent() - Constructor for class org.mule.tck.functional.TransactionalFunctionalTestComponent
 
TransactionalInterceptingMessageProcessor - Class in org.mule.processor
Wraps the invocation of the next MessageProcessor with a transaction.
TransactionalInterceptingMessageProcessor() - Constructor for class org.mule.processor.TransactionalInterceptingMessageProcessor
 
TransactionalMessageProcessorsFactoryBean - Class in org.mule.config.spring.factories
 
TransactionalMessageProcessorsFactoryBean() - Constructor for class org.mule.config.spring.factories.TransactionalMessageProcessorsFactoryBean
 
TransactionalQueueManager - Class in org.mule.util.queue.objectstore
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
TransactionalQueueManager() - Constructor for class org.mule.util.queue.objectstore.TransactionalQueueManager
Deprecated.
 
TransactionalQueueManager - Class in org.mule.util.queue
The Transactional Queue Manager is responsible for creating and Managing transactional Queues.
TransactionalQueueManager() - Constructor for class org.mule.util.queue.TransactionalQueueManager
 
TransactionalQueueSession - Class in org.mule.util.queue
A Queue session that is used to manage the transaction context of a Queue.
TransactionalQueueSession(QueueProvider, QueueXaResourceManager, AbstractResourceManager, XaTransactionRecoverer, LocalTxQueueTransactionJournal, MuleContext) - Constructor for class org.mule.util.queue.TransactionalQueueSession
 
TransactionalQueueStoreDelegate - Interface in org.mule.util.queue.objectstore
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
TransactionalQueueStoreDelegate - Interface in org.mule.util.queue
A marker interface for a QueueStoreDelegate that, along with its store, is transactional
transactionAlreadyBound() - Static method in class org.mule.config.i18n.CoreMessages
 
transactionAvailableButActionIs(String) - Static method in class org.mule.config.i18n.CoreMessages
 
TransactionAwareQueueStore - Class in org.mule.util.queue
Queue implementation that executes operations: - If there is no transaction context then executes the operation directly to the queue.
TransactionAwareQueueStore(QueueStore, TransactionContextProvider, MuleContext) - Constructor for class org.mule.util.queue.TransactionAwareQueueStore
 
TransactionCallback<T> - Interface in org.mule.api.transaction
 
transactionCannotBindNullResource() - Static method in class org.mule.config.i18n.CoreMessages
 
transactionCannotBindToNullKey() - Static method in class org.mule.config.i18n.CoreMessages
 
transactionCannotReadState() - Static method in class org.mule.config.i18n.CoreMessages
 
transactionCannotUnbind() - Static method in class org.mule.config.i18n.CoreMessages
 
transactionCanOnlyBindToResources(String) - Static method in class org.mule.config.i18n.CoreMessages
 
TransactionCollection - Interface in org.mule.transaction
Marks a collection of transactions, e.g.
transactionCommitFailed() - Static method in class org.mule.config.i18n.CoreMessages
 
TransactionCompletePredicate - Interface in org.mule.util.journal
Determines if the operation denotes a transaction complete log entry.
TransactionConfig - Interface in org.mule.api.transaction
TransactionConfig defines transaction configuration for a transactional endpoint.
transactionConfig - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
transactionConfig - Variable in class org.mule.processor.EndpointTransactionalInterceptingMessageProcessor
 
transactionConfig - Variable in class org.mule.processor.TransactionalInterceptingMessageProcessor
 
transactionConfig - Variable in class org.mule.routing.outbound.AbstractOutboundRouter
 
TransactionConfigDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
TransactionConfigDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.TransactionConfigDefinitionParser
 
TransactionContextProvider - Interface in org.mule.util.queue
Provides access to the transaction context if there is one for the current session.
TransactionCoordination - Class in org.mule.transaction
 
TransactionCoordinationDbTransactionManager - Class in org.mule.module.db.internal.domain.transaction
TransactionCoordinationDbTransactionManager() - Constructor for class org.mule.module.db.internal.domain.transaction.TransactionCoordinationDbTransactionManager
 
TransactionDefinitionParser - Class in org.mule.config.spring.parsers.specific
Generates a transaction config with embedded factory.
TransactionDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.TransactionDefinitionParser
 
TransactionDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.TransactionDefinitionParser
 
TransactionException - Exception in org.mule.api.transaction
TransactionException is thrown when an exception occurs while trying to create, start commit or rollback an exception
TransactionException(Message) - Constructor for exception org.mule.api.transaction.TransactionException
 
TransactionException(Message, Throwable) - Constructor for exception org.mule.api.transaction.TransactionException
 
TransactionException(Throwable) - Constructor for exception org.mule.api.transaction.TransactionException
 
TransactionFactory - Interface in org.mule.api.transaction
TransactionFactory creates a transaction.
transactionFactoryIsMandatory(String) - Static method in class org.mule.config.i18n.CoreMessages
 
TransactionInProgressException - Exception in org.mule.transaction
TransactionInProgressException is thrown if a new transaction is started when there is one already in progress.
TransactionInProgressException(Message) - Constructor for exception org.mule.transaction.TransactionInProgressException
 
TransactionInProgressException(Message, Throwable) - Constructor for exception org.mule.transaction.TransactionInProgressException
 
transactionIsolation - Variable in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
TransactionJournal<T,K extends JournalEntry<T>> - Class in org.mule.util.journal
Keeps track of transactional operation made over a transactional resource.
TransactionJournal(String, TransactionCompletePredicate, JournalEntrySerializer, Integer) - Constructor for class org.mule.util.journal.TransactionJournal
 
transactionManagerAlreadySet() - Static method in class org.mule.config.i18n.CoreMessages
 
TransactionManagerDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
TransactionManagerDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.TransactionManagerDefinitionParser
 
TransactionManagerDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.TransactionManagerDefinitionParser
 
TransactionManagerFactory - Interface in org.mule.api.transaction
TranactionManagerFactory is a factory class for creating a transaction manager for the MuleServer.
TransactionManagerFactoryBean - Class in org.mule.config.spring.factories
FactoryBean adapter for the configured TransactionManagerFactory.
TransactionManagerFactoryBean() - Constructor for class org.mule.config.spring.factories.TransactionManagerFactoryBean
 
transactionMarkedForRollback() - Static method in class org.mule.config.i18n.CoreMessages
 
transactionNotAvailableButActionIs(String) - Static method in class org.mule.config.i18n.CoreMessages
 
TransactionNotification - Class in org.mule.context.notification
 
TransactionNotification(Transaction, int) - Constructor for class org.mule.context.notification.TransactionNotification
 
TransactionNotification(Transaction, int, String) - Constructor for class org.mule.context.notification.TransactionNotification
 
TransactionNotificationListener<T extends TransactionNotification> - Interface in org.mule.api.context.notification
TransactionNotificationListener is an observer interface that objects can implement and then register themselves with the Mule manager to be notified when a Transaction event occurs.
TransactionNotInProgressException - Exception in org.mule.transaction
TransactionNotInProgressException TODO (document class)
TransactionNotInProgressException(Message) - Constructor for exception org.mule.transaction.TransactionNotInProgressException
 
TransactionNotInProgressException(Message, Throwable) - Constructor for exception org.mule.transaction.TransactionNotInProgressException
 
transactionPerMessage - Variable in class org.mule.transport.jdbc.JdbcConnector
Should each DB record be received in a separate transaction or should there be a single transaction for the entire ResultSet?
transactionResourceAlreadyListedForKey(Object) - Static method in class org.mule.config.i18n.CoreMessages
 
TransactionRollbackException - Exception in org.mule.transaction
 
TransactionRollbackException(Message) - Constructor for exception org.mule.transaction.TransactionRollbackException
 
TransactionRollbackException(Message, Throwable) - Constructor for exception org.mule.transaction.TransactionRollbackException
 
TransactionRollbackException(Throwable) - Constructor for exception org.mule.transaction.TransactionRollbackException
 
transactionRollbackFailed() - Static method in class org.mule.config.i18n.CoreMessages
 
transactionSetAutoCommitFailed() - Static method in class org.mule.module.db.internal.i18n.DbMessages
 
transactionSetAutoCommitFailed() - Static method in class org.mule.transport.jdbc.i18n.JdbcMessages
 
transactionSingleResourceOnly() - Static method in class org.mule.config.i18n.CoreMessages
 
TransactionStatusException - Exception in org.mule.transaction
 
TransactionStatusException(Message) - Constructor for exception org.mule.transaction.TransactionStatusException
 
TransactionStatusException(Message, Throwable) - Constructor for exception org.mule.transaction.TransactionStatusException
 
TransactionStatusException(Throwable) - Constructor for exception org.mule.transaction.TransactionStatusException
 
TRANSFER_ENCODING - Static variable in class org.mule.module.http.api.HttpHeaders.Names
TRANSFER_ENCODING_CHUNKED - Static variable in class org.mule.transport.http.HttpConstants
 
transforemrMapBeanClassNotSet() - Static method in class org.mule.config.i18n.CoreMessages
 
transform(Object, MuleEvent) - Method in interface org.mule.api.transformer.MessageTransformer
Thransforms the supplied data and returns the result
transform(Object, String, MuleEvent) - Method in interface org.mule.api.transformer.MessageTransformer
Thransforms the supplied data and returns the result
transform(Object) - Method in interface org.mule.api.transformer.Transformer
Transforms the supplied data and returns the result
transform(Object, String) - Method in interface org.mule.api.transformer.Transformer
Transforms the supplied data and returns the result
transform(MuleMessage, Type, Object) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
 
transform(MuleContext, MuleEvent, Type, String, Object) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
 
transform(MuleContext, MuleMessage, Type, String, Object) - Method in class org.mule.devkit.processor.ExpressionEvaluatorSupport
 
transform(String) - Method in class org.mule.module.cxf.feature.PrettyLoggingInInterceptor
 
transform(String) - Method in class org.mule.module.cxf.feature.PrettyLoggingOutInterceptor
 
transform(HttpRequestContext, MuleContext, FlowConstruct, Boolean, ListenerPath) - Static method in class org.mule.module.http.internal.listener.HttpRequestToMuleEvent
 
transform(MuleMessage, String) - Method in class org.mule.transformer.AbstractMessageAwareTransformer
Deprecated.
Subclasses implement this method.
transform(Object, String) - Method in class org.mule.transformer.AbstractMessageTransformer
Transform the message with no event specified.
transform(Object, MuleEvent) - Method in class org.mule.transformer.AbstractMessageTransformer
 
transform(Object, String, MuleEvent) - Method in class org.mule.transformer.AbstractMessageTransformer
 
transform(Object) - Method in class org.mule.transformer.AbstractTransformer
 
transform(Object, String) - Method in class org.mule.transformer.AbstractTransformer
 
transform(Object) - Method in class org.mule.transformer.CompositeConverter
 
transform(Object, String) - Method in class org.mule.transformer.CompositeConverter
 
transform(Object, MuleEvent) - Method in class org.mule.transport.http.servlet.ServletTransformer
 
TransformationGraph - Class in org.mule.transformer.graph
Represents the set of transformations between DataType based on the available Converter.
TransformationGraph() - Constructor for class org.mule.transformer.graph.TransformationGraph
 
TransformationGraphLookupStrategy - Class in org.mule.transformer.graph
Looks for available conversion paths inside a transformation graph.
TransformationGraphLookupStrategy(DirectedGraph<DataType<?>, TransformationEdge>) - Constructor for class org.mule.transformer.graph.TransformationGraphLookupStrategy
 
TransformationLengthConverterFilter - Class in org.mule.transformer.graph
Filters a list of Converter returning a new list containing only the converters with the lower transformation path length.
TransformationLengthConverterFilter() - Constructor for class org.mule.transformer.graph.TransformationLengthConverterFilter
 
Transformer - Annotation Type in org.mule.api.annotations
Used to mark a that a class contains methods which are Mule Transformer, which means it will be made available in the Mule container.
Transformer - Interface in org.mule.api.transformer
Transformer can be chained together to covert message payloads from one object type to another.
TRANSFORMER_FACTORY - Static variable in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
TRANSFORMER_KEY - Static variable in class org.mule.config.bootstrap.AbstractRegistryBootstrap
 
TRANSFORMER_PROPERTY - Static variable in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
TRANSFORMER_REFS_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.AbstractFlowConstructDefinitionParser
 
TransformerAnnotatedBeanProcessor - Class in org.mule.config.spring.processors
TODO
TransformerAnnotatedBeanProcessor() - Constructor for class org.mule.config.spring.processors.TransformerAnnotatedBeanProcessor
 
TransformerArgumentResolver - Interface in org.mule.config.transformer
Used by the transformer proxy to find or create context objects such as JAXB to be passed into a transform method
TransformerChain - Class in org.mule.transformer
A referencable chain of transformers that can be used as a single transformer
TransformerChain(List<Transformer>) - Constructor for class org.mule.transformer.TransformerChain
 
TransformerChain(Transformer...) - Constructor for class org.mule.transformer.TransformerChain
 
TransformerChain(String, List<Transformer>) - Constructor for class org.mule.transformer.TransformerChain
 
TransformerChain(String, Transformer...) - Constructor for class org.mule.transformer.TransformerChain
 
transformerChange(Transformer, TransformerResolver.RegistryAction) - Method in interface org.mule.api.registry.TransformerResolver
A callback that is called when a transformer is registered or unregistered from the registry.
transformerChange(Transformer, TransformerResolver.RegistryAction) - Method in class org.mule.module.json.transformers.JsonTransformerResolver
 
transformerChange(Transformer, TransformerResolver.RegistryAction) - Method in class org.mule.module.xml.transformer.jaxb.JAXBTransformerResolver
 
transformerChange(Transformer, TransformerResolver.RegistryAction) - Method in class org.mule.registry.TypeBasedTransformerResolver
 
transformerChange(Transformer, TransformerResolver.RegistryAction) - Method in class org.mule.transformer.graph.GraphTransformerResolver
 
TransformerConverter - Class in org.mule.config.converters
Converts a String list of Transformer names into a List of Transformer objects.
TransformerConverter() - Constructor for class org.mule.config.converters.TransformerConverter
 
TransformerException - Exception in org.mule.api.transformer
TransformerException is a simple exception that is thrown by transformers.
TransformerException(Message, Transformer) - Constructor for exception org.mule.api.transformer.TransformerException
 
TransformerException(Message, List<Transformer>) - Constructor for exception org.mule.api.transformer.TransformerException
 
TransformerException(Message, Transformer, Throwable) - Constructor for exception org.mule.api.transformer.TransformerException
 
TransformerException(Message, List<Transformer>, Throwable) - Constructor for exception org.mule.api.transformer.TransformerException
 
TransformerException(Transformer, Throwable) - Constructor for exception org.mule.api.transformer.TransformerException
 
TransformerException(List<Transformer>, Throwable) - Constructor for exception org.mule.api.transformer.TransformerException
 
TransformerException(Message, Throwable) - Constructor for exception org.mule.api.transformer.TransformerException
 
TransformerException(Message) - Constructor for exception org.mule.api.transformer.TransformerException
 
TransformerInputs - Class in org.mule.module.json.transformers
 
transformerInvalidReturnType(Class<?>, String) - Static method in class org.mule.config.i18n.CoreMessages
 
TransformerList - Class in org.mule.config.converters
Type definition for a transformer list.
TransformerList() - Constructor for class org.mule.config.converters.TransformerList
 
transformerListCache - Variable in class org.mule.registry.MuleRegistryHelper
 
TransformerMessagingException - Exception in org.mule.api.transformer
An exception that occurred while transforming a message.
TransformerMessagingException(Message, MuleEvent, Transformer) - Constructor for exception org.mule.api.transformer.TransformerMessagingException
 
TransformerMessagingException(Message, MuleEvent, Transformer, Throwable) - Constructor for exception org.mule.api.transformer.TransformerMessagingException
 
TransformerMessagingException(MuleEvent, Transformer, Throwable) - Constructor for exception org.mule.api.transformer.TransformerMessagingException
 
transformerMethodNotValid(Method) - Static method in class org.mule.config.i18n.AnnotationsMessages
 
transformerNotImplementDiscoverable(Transformer) - Static method in class org.mule.config.i18n.CoreMessages
 
transformerNotImplementDiscoverable(Class<? extends Transformer>) - Static method in class org.mule.config.i18n.CoreMessages
 
TransformerPairWireFormat - Class in org.mule.transformer.wire
A pairing of an outbound transformer and an inbound transformer that can be used to serialize and deserialize data.
TransformerPairWireFormat() - Constructor for class org.mule.transformer.wire.TransformerPairWireFormat
 
transformerPool - Variable in class org.mule.module.xml.transformer.XQueryTransformer
 
transformerPool - Variable in class org.mule.module.xml.transformer.XsltTransformer
 
TransformerResolver - Interface in org.mule.api.registry
A TransformResolver is used to find transformers that match a certain criteria in the registry.
TransformerResolver.RegistryAction - Enum in org.mule.api.registry
Possible registry actions that occur that will trigger an event fired via TransformerResolver.transformerChange(Transformer, RegistryAction) method.
TransformerRouter - Class in org.mule.routing.outbound
Deprecated.
TransformerRouter() - Constructor for class org.mule.routing.outbound.TransformerRouter
Deprecated.
 
transformers - Variable in class org.mule.construct.AbstractConfigurationPattern
 
transformers - Variable in class org.mule.construct.builder.AbstractFlowConstructBuilder
 
transformers(Transformer...) - Method in class org.mule.construct.builder.BridgeBuilder
 
transformers(Transformer...) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
transformers - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
transformers - Variable in class org.mule.endpoint.AbstractEndpointURIBuilder
 
transformers(Transformer...) - Method in class org.mule.module.ws.construct.builder.WSProxyBuilder
 
transformers(Transformer...) - Method in class org.mule.transport.http.construct.builder.HttpProxyBuilder
 
TRANSFORMERS_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.EndpointUtils
 
TransformerTemplate - Class in org.mule.transformer
TODO
TransformerTemplate(TransformerTemplate.TransformerCallback) - Constructor for class org.mule.transformer.TransformerTemplate
 
TransformerTemplate.OverwitePayloadCallback - Class in org.mule.transformer
 
TransformerTemplate.OverwitePayloadCallback(Object) - Constructor for class org.mule.transformer.TransformerTemplate.OverwitePayloadCallback
 
TransformerTemplate.TransformerCallback - Interface in org.mule.transformer
 
TransformerUtils - Class in org.mule.transformer
 
TransformerUtils() - Constructor for class org.mule.transformer.TransformerUtils
 
TransformerUtils.TransformerSource - Interface in org.mule.transformer
 
TransformerWeighting - Class in org.mule.transformer
Given a Transformer instance, an input class and output class this object will create a weighting for a transformer.
TransformerWeighting(Class, Class, Transformer) - Constructor for class org.mule.transformer.TransformerWeighting
 
transformFailed(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
transformFailed(String, DataType<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
transformFailedBeforeFilter() - Static method in class org.mule.config.i18n.CoreMessages
 
transformFailedFrom(Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
transformFromMessage(Message, String) - Method in class org.mule.transport.jms.transformers.AbstractJmsTransformer
 
transformHasMultipleMatches(Class<?>, Class<?>, List<? extends Transformer>) - Static method in class org.mule.config.i18n.CoreMessages
 
TransformingMatchable - Interface in org.mule.api.routing
 
transformMessage() - Method in interface org.mule.api.MuleEvent
Deprecated.
Since Mule 3.0 this method does nothing. The message is already transformed before the event reaches a component IF you need to have access to the original message, the must be no transformations before the component, this means that any 'connector-level' transfromers will have to be explicitly overriden via the service overrides on the connector.
transformMessage(Class<T>) - Method in interface org.mule.api.MuleEvent
Transforms the message into the requested format.
transformMessage(DataType<T>) - Method in interface org.mule.api.MuleEvent
Transforms the message into the requested format.
transformMessage(DataType) - Method in interface org.mule.api.MuleEventContext
Returns the message transformed into its recognised or expected format.
transformMessage(Class) - Method in interface org.mule.api.MuleEventContext
Returns the message transformed into it's recognised or expected format.
transformMessage(MuleMessage, String) - Method in class org.mule.config.transformer.AnnotatedTransformerProxy
 
transformMessage(Class<T>) - Method in class org.mule.DefaultMuleEvent
 
transformMessage(DataType<T>) - Method in class org.mule.DefaultMuleEvent
 
transformMessage() - Method in class org.mule.DefaultMuleEvent
Deprecated.
transformMessage(DataType) - Method in class org.mule.DefaultMuleEventContext
Returns the message transformed into its recognised or expected format.
transformMessage(Class) - Method in class org.mule.DefaultMuleEventContext
Returns the message transformed into its recognised or expected format.
transformMessage(MuleMessage, String) - Method in class org.mule.expression.transformers.BeanBuilderTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.expression.transformers.ExpressionTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.module.atom.transformers.AtomEntryBuilderTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.module.json.transformers.JsonToObject
 
transformMessage(MuleMessage, String) - Method in class org.mule.module.json.transformers.JsonXsltTransformer
run a JSON to JSON XSLT transformationn XML string
transformMessage(MuleMessage, String) - Method in class org.mule.module.json.transformers.ObjectToJson
 
transformMessage(MuleMessage, String) - Method in class org.mule.module.scripting.transformer.ScriptTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.module.xml.transformer.DomDocumentToXml
 
transformMessage(MuleMessage, String) - Method in class org.mule.module.xml.transformer.ObjectToXml
 
transformMessage(MuleMessage, String) - Method in class org.mule.module.xml.transformer.XmlToDomDocument
 
transformMessage(MuleMessage, String) - Method in class org.mule.module.xml.transformer.XmlToObject
 
transformMessage(MuleMessage, String) - Method in class org.mule.module.xml.transformer.XmlToOutputHandler
 
transformMessage(MuleMessage, String) - Method in class org.mule.module.xml.transformer.XmlToXMLStreamReader
 
transformMessage(MuleMessage, String) - Method in class org.mule.module.xml.transformer.XQueryTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.module.xml.transformer.XsltTransformer
Transform, using XSLT, a XML String to another String.
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.AbstractMessageAwareTransformer
Deprecated.
Transform the message.
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.AbstractMessageTransformer
Transform the message
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.simple.AbstractAddVariablePropertyTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.simple.AbstractRemoveVariablePropertyTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.simple.AddAttachmentTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.simple.AutoTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.simple.CopyAttachmentsTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.simple.CopyPropertiesTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.simple.MuleMessageToByteArray
 
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.simple.ParseTemplateTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.simple.RemoveAttachmentTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.simple.SetPayloadTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.TransformerChain
 
transformMessage(MuleMessage, String) - Method in class org.mule.transformer.TransformerTemplate
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.email.transformers.ObjectToMimeMessage
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.email.transformers.StringToEmailMessage
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.http.servlet.ServletTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.http.transformers.FormTransformer
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.http.transformers.HttpRequestBodyToParamMap
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.http.transformers.MuleMessageToHttpResponse
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.http.transformers.ObjectToHttpClientMethodRequest
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.jms.transformers.JMSMessageToObject
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.jms.transformers.ObjectToJMSMessage
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.servlet.transformers.HttpRequestToParameter
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.servlet.transformers.HttpRequestToParameterMap
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.xmpp.transformers.ObjectToXmppPacket
 
transformMessage(MuleMessage, String) - Method in class org.mule.transport.xmpp.transformers.XmppPacketToObject
 
transformMessage() - Method in class org.mule.VoidMuleEvent
 
transformMessage(Class<T>) - Method in class org.mule.VoidMuleEvent
 
transformMessage(DataType<T>) - Method in class org.mule.VoidMuleEvent
 
transformMessageToBytes() - Method in interface org.mule.api.MuleEvent
transformMessageToBytes() - Method in interface org.mule.api.MuleEventContext
transformMessageToBytes() - Method in class org.mule.DefaultMuleEvent
transformMessageToBytes() - Method in class org.mule.DefaultMuleEventContext
transformMessageToBytes() - Method in class org.mule.VoidMuleEvent
 
transformMessageToString() - Method in interface org.mule.api.MuleEvent
Returns the message transformed into it's recognised or expected format and then into a String.
transformMessageToString() - Method in interface org.mule.api.MuleEventContext
Returns the message transformed into it's recognised or expected format and then into a String.
transformMessageToString() - Method in class org.mule.DefaultMuleEvent
Returns the message transformed into it's recognised or expected format and then into a String.
transformMessageToString() - Method in class org.mule.DefaultMuleEventContext
Returns the message transformed into it's recognised or expected format and then into a String.
transformMessageToString() - Method in class org.mule.VoidMuleEvent
 
transformOnObjectNotOfSpecifiedType(DataType<?>, Object) - Static method in class org.mule.config.i18n.CoreMessages
 
transformOnObjectUnsupportedTypeOfEndpoint(String, Class<?>, ImmutableEndpoint) - Static method in class org.mule.config.i18n.CoreMessages
 
transformResponse(Object) - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
transformResponse(Object, MuleEvent) - Method in class org.mule.transport.http.OldHttpMessageReceiver
 
transformServerCookieToClientCookie(ServerCookie) - Static method in class org.mule.transport.http.CookieHelper
Transforms a ServerCookie (from Apache Tomcat) into a Cookie (from commons httpclient).
transformToAny(T, MuleContext, DataType<?>...) - Static method in class org.mule.transformer.TransformerUtils
 
transformToFeed(MuleEvent) - Method in class org.mule.module.rss.routing.FeedSplitter
 
transformToMessage(MuleMessage) - Method in class org.mule.transport.jms.transformers.AbstractJmsTransformer
 
transformToSyndEntry(MuleMessage) - Method in class org.mule.module.rss.routing.EntryLastUpdatedFilter
 
transformUnexpectedType(Class<?>, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
transformUnexpectedType(DataType<?>, DataType<?>) - Static method in class org.mule.config.i18n.CoreMessages
 
TransientQueueInfoDelegate - Interface in org.mule.util.queue.objectstore
Deprecated.
this class will be removed in Mule 4.0 in favor of the new queue implementation
TransientQueueTransactionContext - Class in org.mule.util.queue
Transaction context for transient queues
TransientQueueTransactionContext() - Constructor for class org.mule.util.queue.TransientQueueTransactionContext
 
TransientRegistry - Class in org.mule.registry
Deprecated.
as of 3.7.0. Use instead.
TransientRegistry(MuleContext) - Constructor for class org.mule.registry.TransientRegistry
Deprecated.
 
TransientRegistry(String, MuleContext) - Constructor for class org.mule.registry.TransientRegistry
Deprecated.
 
TransientRegistry.RegistryMap - Class in org.mule.registry
Deprecated.
This class encapsulates the HashMap that's used for storing the objects in the transient registry and also shields client code from having to deal with locking the ReadWriteLock for the exposed Map operations.
TransientRegistry.RegistryMap(Logger) - Constructor for class org.mule.registry.TransientRegistry.RegistryMap
Deprecated.
 
TransientXaTransactionAdapter - Class in org.mule.util.queue
TransientXaTransactionAdapter(TransientQueueTransactionContext) - Constructor for class org.mule.util.queue.TransientXaTransactionAdapter
 
translateName(String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
Extract a JavaBean property name from the supplied attribute name.
translateName(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
translateName(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
Extract a JavaBean property name from the supplied attribute name.
translateName(String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
translateName(String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
translateValue(String, String) - Method in interface org.mule.config.spring.parsers.assembly.configuration.PropertyConfiguration
 
translateValue(String, String) - Method in class org.mule.config.spring.parsers.assembly.configuration.ReusablePropertyConfiguration
 
translateValue(String, String) - Method in class org.mule.config.spring.parsers.assembly.configuration.SimplePropertyConfiguration
 
translateValue(String, String) - Method in class org.mule.config.spring.parsers.assembly.configuration.TempWrapperPropertyConfiguration
 
translateValue(String, String) - Method in class org.mule.config.spring.parsers.delegate.AllAttributeChildDefinitionParser
 
TRANSPORT_ID - Static variable in class org.mule.module.cxf.transport.MuleUniversalTransport
 
TransportArchetypeMojo - Class in org.mule.tools.maven.archetype
Builds archetype containers.
TransportArchetypeMojo() - Constructor for class org.mule.tools.maven.archetype.TransportArchetypeMojo
 
transportClass - Variable in class org.mule.module.cxf.CxfInboundMessageProcessor
 
TransportEndpointDefinitionParser - Class in org.mule.config.spring.parsers.specific.endpoint
This is intended for use by endpoint-specific parsers for non-global endpoint elements.
TransportEndpointDefinitionParser(String, Class, String[]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.TransportEndpointDefinitionParser
 
TransportEndpointDefinitionParser(String, boolean, Class, String[]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.TransportEndpointDefinitionParser
 
TransportEndpointDefinitionParser(String, boolean, Class, String[], String[]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.TransportEndpointDefinitionParser
 
TransportEndpointDefinitionParser(String, boolean, Class, String[], String[][], String[][]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.TransportEndpointDefinitionParser
 
TransportEndpointDefinitionParser(String, boolean, Class, String[], String[], String[][], String[][]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.TransportEndpointDefinitionParser
 
transportFactory - Variable in class org.mule.config.endpoint.AnnotatedEndpointHelper
 
TransportFactory - Class in org.mule.transport.service
TransportFactory can be used for generically creating endpoints from an url.
TransportFactory(MuleContext) - Constructor for class org.mule.transport.service.TransportFactory
 
TransportFactoryException - Exception in org.mule.transport.service
TransportFactoryException is thrown by the endpoint factory if the endpoint service cannot be found in the META-INF/services directory or if any part of the endpoint cannot be instanciated.
TransportFactoryException(Message) - Constructor for exception org.mule.transport.service.TransportFactoryException
 
TransportFactoryException(Message, Throwable) - Constructor for exception org.mule.transport.service.TransportFactoryException
 
TransportFactoryException(Throwable) - Constructor for exception org.mule.transport.service.TransportFactoryException
 
TransportGlobalEndpointDefinitionParser - Class in org.mule.config.spring.parsers.specific.endpoint
A parser for global endpoints.
TransportGlobalEndpointDefinitionParser(String, String[]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.TransportGlobalEndpointDefinitionParser
 
TransportGlobalEndpointDefinitionParser(String, boolean, String[]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.TransportGlobalEndpointDefinitionParser
 
TransportGlobalEndpointDefinitionParser(String, boolean, String[], String[]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.TransportGlobalEndpointDefinitionParser
 
TransportGlobalEndpointDefinitionParser(String, boolean, Class, String[], String[]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.TransportGlobalEndpointDefinitionParser
 
TransportGlobalEndpointDefinitionParser(String, boolean, String[], String[][], String[][]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.TransportGlobalEndpointDefinitionParser
 
TransportGlobalEndpointDefinitionParser(String, boolean, String[], String[], String[][], String[][]) - Constructor for class org.mule.config.spring.parsers.specific.endpoint.TransportGlobalEndpointDefinitionParser
 
TransportMessageProcessContext - Class in org.mule.transport
Generic MessageProcessContext implementations for transports.
TransportMessageProcessContext(MessageReceiver) - Constructor for class org.mule.transport.TransportMessageProcessContext
Creates an instance that executes the flow in the current thread.
TransportMessageProcessContext(MessageReceiver, WorkManager) - Constructor for class org.mule.transport.TransportMessageProcessContext
Creates an instance that executes the flow using the supplied WorkManager.
TransportServiceDescriptor - Interface in org.mule.transport.service
TransportServiceDescriptor describes the necessary information for creating a connector from a service descriptor.
TransportServiceException - Exception in org.mule.transport.service
TransportServiceException is thrown if a ProviderServicedescriptor has a service error set.
TransportServiceException(Message) - Constructor for exception org.mule.transport.service.TransportServiceException
 
TransportServiceException(Message, Throwable) - Constructor for exception org.mule.transport.service.TransportServiceException
 
TransportServiceNotFoundException - Exception in org.mule.transport.service
TransportServiceNotFoundException is thorown if no matching service endpoint descriptor is found for the connector protocol.
TransportServiceNotFoundException(String) - Constructor for exception org.mule.transport.service.TransportServiceNotFoundException
 
TransportServiceNotFoundException(String, Throwable) - Constructor for exception org.mule.transport.service.TransportServiceNotFoundException
 
traverseCauseHierarchy(Throwable, ExceptionHelper.ExceptionEvaluator<T>) - Static method in class org.mule.config.ExceptionHelper
 
treeBindings - Variable in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
TRUE - Static variable in class org.mule.config.endpoint.ConfigurableTransportFactory
 
truncate(String, int, boolean) - Static method in class org.mule.util.StringMessageUtils
 
TrustStoreDefinitionParser - Class in org.mule.config.spring.parsers.specific.tls
 
TrustStoreDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.tls.TrustStoreDefinitionParser
 
tryInboundEndpointAnnotation(AnnotationMetaData, ChannelType) - Method in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
tryLock() - Method in class org.mule.tck.util.FakeLock
 
tryLock(long, TimeUnit) - Method in class org.mule.tck.util.FakeLock
 
tryLock(String, long, TimeUnit) - Method in class org.mule.util.lock.InstanceLockGroup
 
tryLock(String) - Method in class org.mule.util.lock.InstanceLockGroup
 
tryLock() - Method in class org.mule.util.lock.LockAdapter
 
tryLock(long, TimeUnit) - Method in class org.mule.util.lock.LockAdapter
 
tryLock(String, long, TimeUnit) - Method in interface org.mule.util.lock.LockGroup
Tries to acquire the lock for a certain amount of time
tryLock(String) - Method in interface org.mule.util.lock.LockGroup
 
tryOutboundEndpointAnnotation(AnnotationMetaData, ChannelType) - Method in class org.mule.config.processors.DecoratingAnnotatedServiceProcessor
Deprecated.
 
tryToGetTheOperationInDotNetNamingConvention(Endpoint, String) - Method in class org.mule.module.cxf.CxfOutboundMessageProcessor
This method tries to call CxfOutboundMessageProcessor.getBindingOperationFromEndpoint(Endpoint, String) with the .NET naming convention for .NET webservices (method names start with a capital letter).
tryToJoinChat() - Method in class org.mule.transport.xmpp.XmppMultiUserChatConversation
 
tunnelCreated() - Method in class org.apache.commons.httpclient.HttpConnection
Instructs the proxy to establish a secure tunnel to the host.
TwoStageMapBeanAssembler - Class in org.mule.config.spring.parsers.assembly
This is used by MapDefinitionParserMutator - it takes a normal bean definition and re-packages it as a map (rather than individual values).
TwoStageMapBeanAssembler(TwoStageMapBeanAssemblerFactory.BeanAssemblerStore, PropertyConfiguration, BeanDefinitionBuilder, PropertyConfiguration, BeanDefinition) - Constructor for class org.mule.config.spring.parsers.assembly.TwoStageMapBeanAssembler
 
TwoStageMapBeanAssemblerFactory - Class in org.mule.config.spring.parsers.assembly
 
TwoStageMapBeanAssemblerFactory(TwoStageMapBeanAssemblerFactory.BeanAssemblerStore) - Constructor for class org.mule.config.spring.parsers.assembly.TwoStageMapBeanAssemblerFactory
 
TwoStageMapBeanAssemblerFactory.BeanAssemblerStore - Interface in org.mule.config.spring.parsers.assembly
 
TX1_LOG_FILE_NAME - Static variable in class org.mule.util.journal.TransactionJournal
 
TX2_LOG_FILE_NAME - Static variable in class org.mule.util.journal.TransactionJournal
 
txManager - Variable in class org.mule.transaction.XaTransaction
 
txStatusMappings - Static variable in class org.mule.transaction.AbstractSingleResourceTransaction
TX status code to human-readable string mappings.
type - Variable in class org.mule.construct.builder.SimpleServiceBuilder
 
type(SimpleService.Type) - Method in class org.mule.construct.builder.SimpleServiceBuilder
 
type - Variable in class org.mule.module.management.mbean.FlowConstructService
 
type - Variable in class org.mule.transformer.types.SimpleDataType
 
TYPE_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.param.AbstractParamDefinitionDefinitionParser
 
TYPE_BINDING - Static variable in class org.mule.management.stats.RouterStatistics
 
TYPE_DEBUG_FIELD - Static variable in class org.mule.module.db.internal.processor.DbDebugInfoUtils
 
TYPE_ERROR - Static variable in class org.mule.api.context.notification.ServerNotification
 
TYPE_FATAL - Static variable in class org.mule.api.context.notification.ServerNotification
 
TYPE_ID_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
TYPE_ID_COLUMN_INDEX - Static variable in class org.mule.module.db.internal.resolver.param.StoredProcedureParamTypeResolver
 
TYPE_INBOUND - Static variable in class org.mule.management.stats.RouterStatistics
 
TYPE_INFO - Static variable in class org.mule.api.context.notification.ServerNotification
 
TYPE_NAME_ATTIRBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
TYPE_NAME_COLUMN_INDEX - Static variable in class org.mule.module.db.internal.resolver.param.StoredProcedureParamTypeResolver
 
TYPE_OUTBOUND - Static variable in class org.mule.management.stats.RouterStatistics
 
TYPE_RESPONSE - Static variable in class org.mule.management.stats.RouterStatistics
 
TYPE_TRACE - Static variable in class org.mule.api.context.notification.ServerNotification
 
TYPE_WARNING - Static variable in class org.mule.api.context.notification.ServerNotification
 
TypeBasedTransformerResolver - Class in org.mule.registry
Will discover transformers based on type information only.
TypeBasedTransformerResolver() - Constructor for class org.mule.registry.TypeBasedTransformerResolver
 
TypedPropertyMapEntryDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
TypedPropertyMapEntryDefinitionParser(String) - Constructor for class org.mule.config.spring.parsers.specific.TypedPropertyMapEntryDefinitionParser
 
TypedValue - Class in org.mule.transformer.types
Maintains a value that has an associated DataType
TypedValue(Object, DataType<?>) - Constructor for class org.mule.transformer.types.TypedValue
 
TypeRestrictionCapability<T> - Class in org.mule.module.extension.internal.capability.metadata
A metadata capability to link a Capable object to a certain TypeRestrictionCapability.type which restricts it somehow.
TypeRestrictionCapability(Class<T>) - Constructor for class org.mule.module.extension.internal.capability.metadata.TypeRestrictionCapability
 
types - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
TypeSafeExpressionValueResolver<T> - Class in org.mule.module.extension.internal.runtime.resolver
A ValueResolver which evaluates a MEL expressions and tries to ensure that the output is always of a certain type.
TypeSafeExpressionValueResolver(String, DataType) - Constructor for class org.mule.module.extension.internal.runtime.resolver.TypeSafeExpressionValueResolver
 

U

UDP - Static variable in class org.mule.transport.udp.UdpConnector
 
UdpConnector - Class in org.mule.transport.udp
UdpConnector can send and receive Mule events as Datagram packets.
UdpConnector(MuleContext) - Constructor for class org.mule.transport.udp.UdpConnector
 
UdpMessageDispatcher - Class in org.mule.transport.udp
UdpMessageDispatcher is responsible for dispatching MuleEvents as UDP packets on the network
UdpMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.udp.UdpMessageDispatcher
 
UdpMessageDispatcherFactory - Class in org.mule.transport.udp
UdpMessageDispatcherFactory creates a dispatcher for sending UDP packets.
UdpMessageDispatcherFactory() - Constructor for class org.mule.transport.udp.UdpMessageDispatcherFactory
 
UdpMessageReceiver - Class in org.mule.transport.udp
UdpMessageReceiver receives UDP message packets.
UdpMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.udp.UdpMessageReceiver
 
UdpMessageReceiver.UdpWorker - Class in org.mule.transport.udp
 
UdpMessageReceiver.UdpWorker(DatagramSocket, DatagramPacket) - Constructor for class org.mule.transport.udp.UdpMessageReceiver.UdpWorker
 
UdpMessageRequester - Class in org.mule.transport.udp
Responsible for requesting MuleEvents as UDP packets on the network
UdpMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.udp.UdpMessageRequester
 
UdpMessageRequesterFactory - Class in org.mule.transport.udp
Creates a dispatcher for receiving UDP packets.
UdpMessageRequesterFactory() - Constructor for class org.mule.transport.udp.UdpMessageRequesterFactory
 
UdpMessages - Class in org.mule.transport.udp.i18n
 
UdpMessages() - Constructor for class org.mule.transport.udp.i18n.UdpMessages
 
UdpMuleMessageFactory - Class in org.mule.transport.udp
 
UdpMuleMessageFactory() - Constructor for class org.mule.transport.udp.UdpMuleMessageFactory
 
UdpNamespaceHandler - Class in org.mule.transport.udp.config
Reigsters a Bean Definition Parser for handling UDP specific elements.
UdpNamespaceHandler() - Constructor for class org.mule.transport.udp.config.UdpNamespaceHandler
 
UdpSocketFactory - Class in org.mule.transport.udp
Creates a client socket using the host and port address supplied in the endpoint URI.
UdpSocketFactory() - Constructor for class org.mule.transport.udp.UdpSocketFactory
 
unableToConstructAdapterForNullMessage() - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
unableToGetEndpointUri(String) - Static method in class org.mule.transport.http.i18n.HttpMessages
 
unableToInitBindingProvider(String) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
unableToLoadServiceClass(String) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
unacceptedMessageProcessor - Variable in class org.mule.processor.AbstractFilteringMessageProcessor
The MessageProcessor that should be used to handle messages that are not accepted by the filter.
UnauthorisedException - Exception in org.mule.api.security
UnauthorisedException is thrown if authentication fails
UnauthorisedException(Message) - Constructor for exception org.mule.api.security.UnauthorisedException
 
UnauthorisedException(Message, Throwable) - Constructor for exception org.mule.api.security.UnauthorisedException
 
UnauthorisedException(Message, MuleEvent) - Constructor for exception org.mule.api.security.UnauthorisedException
 
UnauthorisedException(Message, MuleEvent, Throwable) - Constructor for exception org.mule.api.security.UnauthorisedException
 
UnauthorisedException(MuleEvent, SecurityContext, SecurityFilter) - Constructor for exception org.mule.api.security.UnauthorisedException
 
UnauthorisedException(MuleEvent, SecurityContext, URI, SecurityFilter) - Constructor for exception org.mule.api.security.UnauthorisedException
Deprecated.
unbind(Name) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
unbind(String) - Method in class org.mule.config.spring.jndi.DefaultSpringJndiContext
 
unbind(Name) - Method in class org.mule.jndi.SimpleContext
 
unbind(String) - Method in class org.mule.jndi.SimpleContext
 
unbind(Name) - Method in class org.mule.tck.jndi.InMemoryContext
 
unbind(String) - Method in class org.mule.tck.jndi.InMemoryContext
 
unbindParameters(XQPreparedExpression) - Method in class org.mule.module.xml.transformer.XQueryTransformer
Removes any parameter bindings from the transformer, replacing them with empty strings
unbindTransaction() - Method in class org.mule.transaction.AbstractTransaction
Unbind this transaction when complete
unbindTransaction(Transaction) - Method in class org.mule.transaction.TransactionCoordination
 
UNBOUNDED - Static variable in interface org.mule.api.store.ObjectStoreManager
 
UnboundTransactionFactory - Interface in org.mule.api.transaction
Create an unbound transaction, to be bound and started by other parts of the transaction framework.
uncaughtException(Thread, Throwable) - Method in class org.mule.util.concurrent.LoggingUncaughtExceptionHandler
 
UNCLAIMED_INTERVAL - Static variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
UNCLAIMED_TIME_TO_LIVE - Static variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
uncompressByteArray(byte[]) - Method in interface org.mule.util.compression.CompressionStrategy
Uncompresses a compressed byte array.
uncompressByteArray(byte[]) - Method in class org.mule.util.compression.GZipCompression
Used for uncompressing a byte array into a uncompressed byte array using GZIP
uncompressInputStream(InputStream) - Method in interface org.mule.util.compression.CompressionStrategy
Uncompresses a compressed InputStream.
uncompressInputStream(InputStream) - Method in class org.mule.util.compression.GZipCompression
 
unconfigure(MuleContext) - Method in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
UNDEFINED - Static variable in class org.mule.module.xml.config.XsltTextDefinitionParser
 
UndefinedMatchException - Exception in org.mule.module.sxc
 
UndefinedMatchException() - Constructor for exception org.mule.module.sxc.UndefinedMatchException
 
undeploy(T) - Method in interface org.mule.module.launcher.ArtifactDeployer
Undeploys an artifact.
undeploy(Artifact) - Method in class org.mule.module.launcher.DefaultArtifactDeployer
 
undeploy(String) - Method in interface org.mule.module.launcher.DeploymentService
Undeploys an application from the mule container
undeploy(String) - Method in class org.mule.module.launcher.MuleDeploymentService
 
undeployAll() - Method in class org.mule.test.infrastructure.process.Controller
 
undeployAll() - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
undeployArtifact(String) - Method in interface org.mule.module.launcher.ArchiveDeployer
 
undeployArtifact(String) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
undeployArtifact(String) - Method in class org.mule.module.launcher.DomainArchiveDeployer
Undeploys a domain.
undeployArtifactWithoutUninstall(T) - Method in interface org.mule.module.launcher.ArchiveDeployer
 
undeployArtifactWithoutUninstall(T) - Method in class org.mule.module.launcher.DefaultArchiveDeployer
 
undeployArtifactWithoutUninstall(Domain) - Method in class org.mule.module.launcher.DomainArchiveDeployer
 
undeployDomain(String) - Method in interface org.mule.module.launcher.DeploymentService
Undeploys a domain from the mule container
undeployDomain(String) - Method in class org.mule.module.launcher.MuleDeploymentService
 
undeployProcess(String) - Method in interface org.mule.module.bpm.BPMS
Undeploy a process from the BPMS.
undeployProcess(String) - Method in class org.mule.module.jbpm.Jbpm
 
underlyingIn - Variable in class org.mule.transport.tcp.TcpMessageReceiver.TcpWorker
 
unexpectedMIMEType(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
uninstallLicense() - Method in class org.mule.test.infrastructure.process.Controller
 
uninstallLicense() - Method in class org.mule.test.infrastructure.process.MuleProcessController
 
uniqueIdNotSupportedByAdapter(String) - Static method in class org.mule.config.i18n.CoreMessages
 
uniqueValue(String) - Static method in class org.mule.config.spring.parsers.generic.AutoIdUtils
 
UniversalSender - Class in org.mule.transport.soap.axis.extensions
An Axis handler that will dispatch the SOAP event via a Mule endpoint
UniversalSender() - Constructor for class org.mule.transport.soap.axis.extensions.UniversalSender
 
UniversalTransactionFactory - Interface in org.mule.api.transaction
A factory than can create both bound and unbound transactions
UnixController - Class in org.mule.test.infrastructure.process
 
UnixController(String, int) - Constructor for class org.mule.test.infrastructure.process.UnixController
 
UNKNOWN - Static variable in interface org.mule.transformer.types.MimeTypes
 
UNKNOWN_SIZE - Static variable in interface org.mule.routing.MessageSequence
 
UNKNOWN_TYPE_NAME - Static variable in class org.mule.module.db.internal.domain.type.UnknownDbType
 
UnknownAuthenticationTypeException - Exception in org.mule.api.security
UnknownAuthenticationTypeException is thrown if a security context request is make with an unrecognised Authentication type.
UnknownAuthenticationTypeException(Authentication) - Constructor for exception org.mule.api.security.UnknownAuthenticationTypeException
 
UnknownDbType - Class in org.mule.module.db.internal.domain.type
Represents a data type for a template, which real type is unknown until it is instantiated
UnknownDbTypeException - Exception in org.mule.module.db.internal.domain.type
Thrown to indicate that a data type ID can not be mapped to a database type
UnknownDbTypeException(int, String) - Constructor for exception org.mule.module.db.internal.domain.type.UnknownDbTypeException
Creates an exception for a given unknown type
UnknownDbTypeException(String) - Constructor for exception org.mule.module.db.internal.domain.type.UnknownDbTypeException
 
UNLIMITED - Static variable in class org.mule.transport.tcp.protocols.DirectProtocol
 
UNLIMITED_DEPTH - Static variable in class org.mule.util.MapCombiner
 
unlock() - Method in class org.mule.tck.util.FakeLock
 
unlock(String) - Method in class org.mule.util.lock.InstanceLockGroup
 
unlock() - Method in class org.mule.util.lock.LockAdapter
 
unlock(String) - Method in interface org.mule.util.lock.LockGroup
 
unlockForReading() - Method in class org.mule.registry.TransientRegistry.RegistryMap
Deprecated.
 
unrecognisedServiceType(ServiceType) - Static method in class org.mule.config.i18n.CoreMessages
 
unregister() - Method in class org.mule.lifecycle.PrimaryNodeLifecycleNotificationListener
 
unregisterAgent(String) - Method in interface org.mule.api.registry.MuleRegistry
 
unregisterAgent(String) - Method in class org.mule.registry.MuleRegistryHelper
unregisterComponent(String) - Method in class org.mule.module.client.MuleClient
Deprecated.
Use the RegistryContext to get the registry and unregister the service there
unregisterConnector(String) - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
unregisterConnector(String) - Method in class org.mule.registry.MuleRegistryHelper
unregisterEndpoint(String) - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
unregisterEndpoint(String) - Method in class org.mule.registry.MuleRegistryHelper
unregisterEnricher(String) - Method in interface org.mule.api.expression.ExpressionManager
Deprecated.
unregisterEnricher(String) - Method in class org.mule.expression.DefaultExpressionManager
Removes the evaluator with the given name
unregisterEvaluator(String) - Method in interface org.mule.api.expression.ExpressionManager
Removes the evaluator with the given name
unregisterEvaluator(String) - Method in class org.mule.expression.DefaultExpressionManager
Removes the evaluator with the given name
unregisterFlowConstruct(String) - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
unregisterFlowConstruct(String) - Method in class org.mule.registry.MuleRegistryHelper
unregisterListener(ServerNotificationListener) - Method in interface org.mule.api.MuleContext
Unregisters a previously registered listener.
unregisterListener(InboundEndpoint, FlowConstruct) - Method in interface org.mule.api.transport.Connector
Unregisters the listener for the given endpoints.
unregisterListener(ServerNotificationListener) - Method in class org.mule.DefaultMuleContext
 
unregisterListener(InboundEndpoint, FlowConstruct) - Method in class org.mule.transport.AbstractConnector
 
unregisterListener(MessageReceiver) - Method in class org.mule.transport.servlet.jetty.JettyHttpConnector
 
unregisterLogConfigChangeListener(PropertyChangeListener) - Method in interface org.mule.logging.LogConfigChangeSubject
Unregister a listener to no longer be called when log config is changed.
unregisterMBeansIfNecessary() - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
unregisterMBeansIfNecessary(boolean) - Method in class org.mule.module.management.agent.AbstractJmxAgent
 
unregisterMBeansIfNecessary() - Method in class org.mule.module.management.agent.Mx4jAgent
Unregister all Mx4j MBeans if there are any left over the old deployment
unregisterMBeansIfNecessary() - Method in class org.mule.module.management.agent.WrapperManagerAgent
Unregister all MBeans if there are any left over the old deployment
unregisterMBeansIfNecessary() - Method in class org.mule.module.management.agent.YourKitProfilerAgent
Unregister Profiler MBean if there are any left over the old deployment
unregisterMeQuietly() - Method in class org.mule.AbstractAgent
Quietly unregister ourselves.
unregisterMeQuietly() - Method in class org.mule.module.management.agent.YourKitProfilerAgent
Quietly unregister ourselves.
unregisterModel(String) - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
unregisterModel(String) - Method in class org.mule.registry.MuleRegistryHelper
Deprecated.
unregisterObject(String) - Method in interface org.mule.api.registry.Registry
Will remove an object by name from the registry.
unregisterObject(String, Object) - Method in interface org.mule.api.registry.Registry
Deprecated.
as of 3.7.0. Use Registry.unregisterObject(String) instead
unregisterObject(String) - Method in class org.mule.registry.AbstractRegistry
 
unregisterObject(String, Object) - Method in class org.mule.registry.AbstractRegistry
Deprecated.
unregisterObject(String) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
Will remove an object by name from the registry.
unregisterObject(String, Object) - Method in class org.mule.registry.AbstractRegistryBroker
Deprecated.
unregisterObject(String, Object) - Method in class org.mule.registry.MuleRegistryHelper
Will remove an object by name from the registry.
unregisterObject(String) - Method in class org.mule.registry.MuleRegistryHelper
Will remove an object by name from the registry.
unregisterReceiverWithMuleService(MessageReceiver, EndpointURI) - Method in class org.mule.transport.soap.axis.AxisConnector
 
unregisterScheduler(Scheduler) - Method in interface org.mule.api.registry.MuleRegistry
 
unregisterScheduler(Scheduler) - Method in class org.mule.registry.MuleRegistryHelper
 
unregisterService(String) - Method in interface org.mule.api.registry.MuleRegistry
Deprecated.
unregisterService(String) - Method in class org.mule.registry.MuleRegistryHelper
unregisterShutdownHook() - Method in class org.mule.module.launcher.MuleContainer
 
unregisterShutdownHook() - Method in class org.mule.MuleServer
 
unregisterSourceType(Class<?>) - Method in class org.mule.transformer.AbstractTransformer
Deprecated.
use unregisterSourceType(DataType)
unregisterSourceType(DataType<?>) - Method in class org.mule.transformer.AbstractTransformer
Unregister a supported source type from this transformer
unregisterSupportedProtocol(String) - Method in class org.mule.transport.AbstractConnector
 
unregisterTransformer(String) - Method in interface org.mule.api.registry.MuleRegistry
 
unregisterTransformer(String) - Method in class org.mule.registry.MuleRegistryHelper
UnresolvableDbConfigException - Exception in org.mule.module.db.internal.resolver.database
Thrown to indicate that is not possible to resolve a DbConfig
UnresolvableDbConfigException(String) - Constructor for exception org.mule.module.db.internal.resolver.database.UnresolvableDbConfigException
 
UnresolvableDbConfigException(String, Throwable) - Constructor for exception org.mule.module.db.internal.resolver.database.UnresolvableDbConfigException
 
UnresolveableDependencyException - Exception in org.mule.module.launcher.coreextension
Thrown to indicate that a mule core extension dependency was not successfully resolved.
UnresolveableDependencyException(String) - Constructor for exception org.mule.module.launcher.coreextension.UnresolveableDependencyException
 
UNSAFE - Static variable in class org.mule.RequestContext
Deprecated.
 
unsafeRewriteEvent(MuleMessage) - Static method in class org.mule.OptimizedRequestContext
Deprecated.
Sets a new message payload in the RequestContext but maintains all other properties (session, endpoint, synchronous, etc.) from the previous event.
unsafeSetEvent(MuleEvent) - Static method in class org.mule.OptimizedRequestContext
Deprecated.
Set an event for out-of-scope thread access.
unschedule() - Method in class org.mule.transport.AbstractPollingMessageReceiver
This method cancels the schedules which were created in AbstractPollingMessageReceiver.schedule().
unsubscribe(String) - Method in class org.mule.transport.jms.ReusableQueueSessionWrapper
 
unsubscribe(String) - Method in class org.mule.transport.jms.ReusableSessionWrapper
 
unsubscribe(String) - Method in class org.mule.transport.jms.ReusableTopicSessionWrapper
 
UnsupportedAuthenticationSchemeException - Exception in org.mule.api.security
UnsupportedAuthenticationSchemeException is thrown when a authentication scheme is being used on the message that the Security filter does not understand
UnsupportedAuthenticationSchemeException(Message, MuleEvent) - Constructor for exception org.mule.api.security.UnsupportedAuthenticationSchemeException
 
UnsupportedAuthenticationSchemeException(Message, MuleEvent, Throwable) - Constructor for exception org.mule.api.security.UnsupportedAuthenticationSchemeException
 
UnsupportedMessageDispatcher - Class in org.mule.transport
 
UnsupportedMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.UnsupportedMessageDispatcher
 
UnsupportedMessageDispatcherFactory - Class in org.mule.transport
 
UnsupportedMessageDispatcherFactory() - Constructor for class org.mule.transport.UnsupportedMessageDispatcherFactory
 
UnsupportedMessageRequester - Class in org.mule.transport
 
UnsupportedMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.UnsupportedMessageRequester
 
UnsupportedMessageRequesterFactory - Class in org.mule.transport
 
UnsupportedMessageRequesterFactory() - Constructor for class org.mule.transport.UnsupportedMessageRequesterFactory
 
unsupportedMethod(String) - Static method in class org.mule.transport.http.i18n.HttpMessages
 
unsupportedServerWireForat(String) - Static method in class org.mule.module.client.i18n.ClientMessages
Deprecated.
UnsupportedWireFormatException - Exception in org.mule.module.client.remoting
Deprecated.
UnsupportedWireFormatException(String, Exception) - Constructor for exception org.mule.module.client.remoting.UnsupportedWireFormatException
Deprecated.
 
untake(Serializable) - Method in class org.mule.util.queue.AbstractQueueStoreDelegate
 
untake(Serializable) - Method in class org.mule.util.queue.DefaultQueueStore
 
untake(QueueStore, Serializable) - Method in class org.mule.util.queue.LocalTxQueueTransactionContext
 
untake(Serializable) - Method in class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
Deprecated.
 
untake(Serializable) - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
untake(Serializable) - Method in interface org.mule.util.queue.objectstore.QueueInfoDelegate
Deprecated.
Restore a previously removed member to the front of the queue
untake(QueueInfo, Serializable) - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
Deprecated.
 
untake(QueueStore, Serializable) - Method in class org.mule.util.queue.PersistentQueueTransactionContext
 
untake(QueueStore, Serializable) - Method in class org.mule.util.queue.PersistentXaTransactionContext
 
untake(Serializable) - Method in interface org.mule.util.queue.Queue
 
untake(Serializable) - Method in interface org.mule.util.queue.QueueStore
 
untake(Serializable) - Method in interface org.mule.util.queue.QueueStoreDelegate
Restore a previously removed member to the front of the queue
untake(QueueStore, Serializable) - Method in interface org.mule.util.queue.QueueTransactionContext
 
untake(QueueStore, Serializable) - Method in class org.mule.util.queue.QueueTypeTransactionContextAdapter
 
untake(Serializable) - Method in class org.mule.util.queue.TransactionAwareQueueStore
 
untake(QueueStore, Serializable) - Method in class org.mule.util.queue.TransientQueueTransactionContext
 
untake(QueueStore, Serializable) - Method in class org.mule.util.queue.TransientXaTransactionAdapter
 
untake(QueueStore, Serializable) - Method in class org.mule.util.queue.XaQueueTypeTransactionContextAdapter
 
UntilSuccessful - Class in org.mule.routing
UntilSuccessful attempts to route a message to the message processor it contains.
UntilSuccessful() - Constructor for class org.mule.routing.UntilSuccessful
 
UntilSuccessfulConfiguration - Interface in org.mule.routing
Configuration required for UntilSuccessful router processing strategy.
UntilSuccessfulProcessingStrategy - Interface in org.mule.routing
Defines a processing strategy for until successful router.
unwrap(T) - Static method in class org.mule.config.ExceptionHelper
 
unwrap(Class<T>) - Method in class org.mule.module.db.internal.domain.connection.DefaultDbConnection
 
unwrap(Class<T>) - Method in class org.mule.module.db.internal.domain.xa.ConnectionWrapper
 
unwrap(Class<T>) - Method in class org.mule.module.db.internal.domain.xa.DataSourceWrapper
 
unwrap(Class<T>) - Method in class org.mule.transport.jdbc.xa.ConnectionWrapper
 
unwrap(Class<T>) - Method in class org.mule.transport.jdbc.xa.DataSourceWrapper
 
UNWRAP_MULE_EXCEPTIONS - Static variable in class org.mule.module.cxf.CxfConstants
 
unzip(File, File) - Static method in class org.mule.util.FileUtils
Unzip the specified archive to the given directory
updateCachedNotificationHandler() - Method in class org.mule.transport.AbstractConnector
 
updateContext(MuleMessage, ImmutableEndpoint, boolean) - Method in class org.mule.module.client.RemoteDispatcher
Deprecated.
 
UpdateCountResult - Class in org.mule.module.db.internal.result.statement
Represents an update count after a Statement execution
UpdateCountResult(String, int) - Constructor for class org.mule.module.db.internal.result.statement.UpdateCountResult
 
UPDATED - Static variable in class org.mule.module.launcher.util.ElementEvent
 
updateDefinition(Definition, Map<String, Definition>, Map<String, SchemaReference>, String, EndpointInfo) - Method in class org.mule.module.cxf.support.WSDLQueryHandler
 
updateDoc(Document, String, Map<String, Definition>, Map<String, SchemaReference>, EndpointInfo) - Method in class org.mule.module.cxf.support.WSDLQueryHandler
 
UpdateExecutor - Class in org.mule.module.db.internal.domain.executor
Executes queries that return an update count or an update count and auto generated keys
UpdateExecutor(StatementFactory) - Constructor for class org.mule.module.db.internal.domain.executor.UpdateExecutor
 
UpdateExecutorFactory - Class in org.mule.module.db.internal.domain.executor
Creates UpdateExecutor instances
UpdateExecutorFactory(StatementFactory) - Constructor for class org.mule.module.db.internal.domain.executor.UpdateExecutorFactory
 
UpdateExpressionWatermark - Class in org.mule.transport.polling.watermark
Implementation of Watermark in which the value is updated through a MEL expression
UpdateExpressionWatermark(ObjectStore<Serializable>, String, String, String) - Constructor for class org.mule.transport.polling.watermark.UpdateExpressionWatermark
 
updateFrom(MuleEvent) - Method in class org.mule.transport.polling.watermark.Watermark
Updates the watermark in persistent storage based on the flow variable defined in the event
UpdateMessageProcessor - Class in org.mule.module.db.internal.processor
Executes an update query on a database.
UpdateMessageProcessor(DbConfigResolver, QueryResolver, QueryExecutorFactory, TransactionalAction, List<QueryType>) - Constructor for class org.mule.module.db.internal.processor.UpdateMessageProcessor
 
UpdateMetadataProvider - Class in org.mule.module.db.internal.metadata
Provides metadata for update/insert/delete queries
UpdateMetadataProvider(DbConfigResolver, Query, AutoGeneratedKeyStrategy) - Constructor for class org.mule.module.db.internal.metadata.UpdateMetadataProvider
 
updatePayload(MuleMessage, Object, MuleEvent) - Method in class org.mule.security.AbstractSecurityFilter
 
updateProcess(Object, Map) - Method in interface org.mule.module.bpm.BPMS
Update the variables/parameters for an already-running process.
updateProcess(Object, Map) - Method in class org.mule.module.jbpm.Jbpm
Update the variables for an execution.
UpdateProcessorBeanDefinitionParser - Class in org.mule.module.db.internal.config.processor
 
UpdateProcessorBeanDefinitionParser() - Constructor for class org.mule.module.db.internal.config.processor.UpdateProcessorBeanDefinitionParser
 
updatePublishedEndpointUrl(String, Definition, QName) - Method in class org.mule.module.cxf.support.WSDLQueryHandler
 
updateResourceOwnerOAuthContext(ResourceOwnerOAuthContext) - Method in class org.mule.module.oauth2.internal.authorizationcode.state.ConfigOAuthContext
Updates the resource owner oauth context information
updateRoute(MessageProcessor, Filter) - Method in interface org.mule.api.routing.SelectiveRouter
 
updateRoute(MessageProcessor, Filter) - Method in class org.mule.routing.AbstractSelectiveRouter
 
updateScheduler(SchedulerFactory) - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
Updates the configured scheduler with the SchedulerFactory.
updateSchemaImports(Schema, Map<String, SchemaReference>, String) - Method in class org.mule.module.cxf.support.WSDLQueryHandler
 
updateUrl() - Method in class org.mule.transport.jdbc.config.AbstractHostPortDatabaseDataSourceFactoryBean
 
updateUrl() - Method in class org.mule.transport.jdbc.config.DerbyDataSourceFactoryBean
 
updateUrl() - Method in class org.mule.transport.jdbc.config.OracleDataSourceFactoryBean
 
updateWith(MuleEvent, Serializable) - Method in class org.mule.transport.polling.watermark.Watermark
 
UPGRADE - Static variable in class org.mule.module.http.api.HttpHeaders.Names
UPGRADE - Static variable in class org.mule.module.http.api.HttpHeaders.Values
UPPER_BOUND_EXCLUSIVE - Static variable in class org.mule.util.VersionRange
 
UPPER_BOUND_INCLUSIVE - Static variable in class org.mule.util.VersionRange
 
URI_1999_SCHEMA_XSD - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
URI_2000_SCHEMA_XSD - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
URI_2001_SCHEMA_XSD - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
URI_BUILDER_ATTRIBUTE - Static variable in class org.mule.config.spring.parsers.specific.endpoint.support.EndpointUtils
 
URI_DEFAULT_SCHEMA_XSD - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
uriBuilder - Variable in class org.mule.endpoint.AbstractEndpointBuilder
 
URIBuilder - Class in org.mule.endpoint
This has the following logic: - if an address is specified, it is used verbatim (except for parameters); this is consistent with the generic case - otherwise, we construct from components, omitting things that aren't specified as much as possible (use required attributes to guarantee entries) In addition, parameters are handled as follows: - parameters can be given in the uri, the queryMap, or both - queryMap values override uri values - the order of parameters in the uri remains the same (even if values change) - queryMap parameters are appended after uri parameters TODO - check that we have sufficient control via XML (what about empty strings?) Not called EndpointURIBuilder because of EndpointURIBuilder
URIBuilder() - Constructor for class org.mule.endpoint.URIBuilder
 
URIBuilder(MuleContext) - Constructor for class org.mule.endpoint.URIBuilder
 
URIBuilder(EndpointURI) - Constructor for class org.mule.endpoint.URIBuilder
 
URIBuilder(String, MuleContext) - Constructor for class org.mule.endpoint.URIBuilder
 
URIBuilderBeanInfo - Class in org.mule.endpoint
Required to resolve the overload of URIBuilder.setPort() during bean assembly
URIBuilderBeanInfo() - Constructor for class org.mule.endpoint.URIBuilderBeanInfo
 
URIBuilderPropertyEditor - Class in org.mule.config.spring.editors
Translates a connector name property into the corresponding Connector instance.
URIBuilderPropertyEditor(MuleContext) - Constructor for class org.mule.config.spring.editors.URIBuilderPropertyEditor
 
uriMatchesReceiver(URI, URI) - Static method in class org.mule.transport.http.HttpConnector
 
UriParamFilter - Class in org.mule.util
filters key value pairs out of a query string
UriParamFilter() - Constructor for class org.mule.util.UriParamFilter
 
URIRouteFilter - Class in org.mule.module.atom.routing
 
URIRouteFilter() - Constructor for class org.mule.module.atom.routing.URIRouteFilter
 
url - Variable in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
URL_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
URL_ENCODER - Static variable in class org.mule.endpoint.URIBuilder
 
URL_PATTERN - Static variable in class org.mule.api.util.CredentialsMaskUtil
 
UrlEndpointURIBuilder - Class in org.mule.endpoint
UrlEndpointURIBuilder is the default endpointUri strategy suitable for most connectors
UrlEndpointURIBuilder() - Constructor for class org.mule.endpoint.UrlEndpointURIBuilder
 
urlFromEndpoint(ImmutableEndpoint) - Method in class org.mule.transport.email.AbstractMailConnector
 
URLRetrieverStrategy - Class in org.mule.module.ws.consumer
A wsdl retriever strategy implementation to get the wsdl directly.
URLRetrieverStrategy() - Constructor for class org.mule.module.ws.consumer.URLRetrieverStrategy
 
urls - Variable in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
URLWSDLRetrieverStrategyFactory - Class in org.mule.module.ws.consumer.wsdl.strategy.factory
Factory to create URLWSDLRetrievers
URLWSDLRetrieverStrategyFactory() - Constructor for class org.mule.module.ws.consumer.wsdl.strategy.factory.URLWSDLRetrieverStrategyFactory
 
USE - Static variable in class org.mule.transport.soap.axis.AxisConnector
 
USE_DISPATCHER_POOL_SYSTEM_PROPERTY - Static variable in class org.mule.transport.jdbc.JdbcConnector
 
USE_EQUALITY_ASSERT_BEHAVIOR - Static variable in class org.mule.module.drools.Drools
 
USE_HTTP_TRANSPORT_FOR_URIS - Static variable in class org.mule.module.http.internal.config.HttpConfiguration
 
USE_JMS_ENGINE - Static variable in class org.mule.transport.jms.mulemq.MuleMQJmsConnector
 
USE_MAP - Static variable in class org.mule.transport.soap.axis.config.AxisNamespaceHandler
 
USE_XA_TRANSACTIONS_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
useConnectionPool() - Method in class org.mule.transport.sftp.SftpConnector
 
useDefaultConfigResource - Variable in class org.mule.config.spring.SpringXmlConfigurationBuilder
Prepend "default-mule-config.xml" to the list of config resources.
useExtendedTransformations() - Method in interface org.mule.api.config.MuleConfiguration
 
useExtendedTransformations() - Method in class org.mule.config.DefaultMuleConfiguration
 
useMinimalConfigResource - Variable in class org.mule.config.spring.SpringXmlConfigurationBuilder
 
useMultipleReceivers - Variable in class org.mule.transport.jms.TransactedSingleResourceJmsMessageReceiver
determines whether Multiple receivers are created to improve throughput
USER - Static variable in class org.mule.endpoint.URIBuilder
 
user - Variable in class org.mule.transport.jdbc.config.AbstractDataSourceFactoryBean
 
USER_AGENT - Static variable in class org.mule.module.http.api.HttpHeaders.Names
USER_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.database.DbConfigDefinitionParser
 
USER_DIR - Static variable in class org.mule.module.boot.DefaultMuleClassPathConfig
 
USER_DIR - Static variable in class org.mule.module.reboot.DefaultMuleClassPathConfig
 
USER_FOLDER - Static variable in class org.mule.module.launcher.MuleFoldersUtil
 
USER_MASK - Static variable in class org.mule.api.util.CredentialsMaskUtil
 
USER_PATTERN_NO_QUOTES - Static variable in class org.mule.api.util.CredentialsMaskUtil
 
UserAndPasswordAuthenticationProvider - Class in org.mule.module.spring.security
A spring authentication provider that return
UserAndPasswordAuthenticationProvider() - Constructor for class org.mule.module.spring.security.UserAndPasswordAuthenticationProvider
 
USERHOST_ATTRIBUTES - Static variable in class org.mule.endpoint.URIBuilder
 
userInfo - Variable in class org.mule.endpoint.AbstractEndpointURIBuilder
 
UserInfoEndpointURIBuilder - Class in org.mule.endpoint
UserInfoEndpointBuilder builds an endpoint with the userinfo and host details.
UserInfoEndpointURIBuilder() - Constructor for class org.mule.endpoint.UserInfoEndpointURIBuilder
 
USERNAME - Static variable in class org.mule.tck.util.sftp.SftpServer
 
USERNAME - Static variable in class org.mule.transport.jms.config.ConnectionFactoryDefinitionParser
 
username - Variable in class org.mule.transport.jms.JmsConnector
 
UsernamePasswordAuthenticationFilter - Class in org.mule.security
Performs authentication based on a username and password.
UsernamePasswordAuthenticationFilter() - Constructor for class org.mule.security.UsernamePasswordAuthenticationFilter
 
usesNamedParameters() - Method in class org.mule.module.db.internal.domain.query.QueryTemplate
Indicates whether or not the query uses named parameters.
useTransportForUris(MuleContext) - Static method in class org.mule.module.http.internal.config.HttpConfiguration
 
UTF_8_ENCODING - Static variable in class org.mule.util.queue.QueueFileProvider
 
UUID - Class in org.mule.util
UUID Generates a UUID using the Johann Burkard UUID Library.
UUID_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
 
UUID_LENGTH - Static variable in class org.mule.util.UUID
 

V

VALID_VERSION_RANGES - Static variable in class org.mule.util.VersionRange
 
validate(String) - Method in interface org.mule.api.el.ExpressionExecutor
Validate the expression
validate(String) - Method in interface org.mule.api.el.ExpressionLanguage
Validates the expression returning.
validate() - Method in interface org.mule.api.transport.MessageDispatcher
Determines whether this dispatcher can be reused after message sending.
validate(OutboundEndpoint, MessageDispatcher) - Method in interface org.mule.api.transport.MessageDispatcherFactory
Invoked after the dispatcher is returned from a client but before it is prepared for return to its pool via MessageDispatcherFactory.passivate(OutboundEndpoint, MessageDispatcher).
validate() - Method in interface org.mule.api.transport.MessageRequester
Determines whether this dispatcher can be reused after message receiving.
validate(InboundEndpoint, MessageRequester) - Method in interface org.mule.api.transport.MessageRequesterFactory
Invoked after the requester is returned from a client but before it is prepared for return to its pool via MessageRequesterFactory.passivate(org.mule.api.endpoint.InboundEndpoint, org.mule.api.transport.MessageRequester).
validate(Element) - Method in interface org.mule.config.spring.ElementValidator
Validates the element and throws exception if validation failed
validate(Element) - Method in class org.mule.config.spring.parsers.specific.DomainElementsValidator
 
validate(Component) - Method in enum org.mule.construct.SimpleService.Type
 
validate(String) - Method in class org.mule.el.mvel.MVELExpressionExecutor
 
validate(String) - Method in class org.mule.el.mvel.MVELExpressionLanguage
 
validate(ExpressionManager) - Method in class org.mule.expression.ExpressionConfig
 
validate() - Method in class org.mule.expression.transformers.ExpressionArgument
 
validate(Credential, RequestData) - Method in class org.mule.module.cxf.support.MuleSecurityManagerValidator
 
validate() - Method in class org.mule.module.db.internal.config.domain.database.DbConfigResolverFactoryBean
 
validate(MuleEvent) - Method in class org.mule.module.http.internal.request.FailureStatusCodeValidator
 
validate(MuleEvent) - Method in interface org.mule.module.http.internal.request.ResponseValidator
 
validate(MuleEvent) - Method in class org.mule.module.http.internal.request.SuccessStatusCodeValidator
 
validate(MuleEvent) - Method in class org.mule.module.json.validation.JsonSchemaValidator
Parses the event's payload as a Json by the rules of DefaultJsonParser.asJsonNode(Object).
validate(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.AbstractMessageDispatcherFactory
 
validate(InboundEndpoint, MessageRequester) - Method in class org.mule.transport.AbstractMessageRequesterFactory
 
validate() - Method in class org.mule.transport.AbstractTransportMessageHandler
 
validate(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
validate(InboundEndpoint, MessageRequester) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
validate(String) - Method in class org.mule.util.TemplateParser.PatternInfo
 
validate(String) - Method in class org.mule.util.TemplateParser
 
validateAndGetDomainFolders() - Method in class org.mule.module.launcher.MuleSharedDomainClassLoader
 
validateAuthenticationMethods(String) - Static method in class org.mule.transport.sftp.AuthenticationMethodValidator
Checks that a list contains only valid authentication methods.
validateConnection(RetryContext) - Method in interface org.mule.api.transport.Connectable
Test whether the connector is able to connect to its resource(s).
validateConnection(RetryContext) - Method in class org.mule.transport.AbstractConnector
Override this method to test whether the connector is able to connect to its resource(s).
validateConnection(RetryContext) - Method in class org.mule.transport.AbstractTransportMessageHandler
 
validateConnection(RetryContext) - Method in class org.mule.transport.ftp.FtpMessageDispatcher
 
validateConnection(RetryContext) - Method in class org.mule.transport.ftp.FtpMessageReceiver
 
validateConnection(RetryContext) - Method in class org.mule.transport.jdbc.JdbcConnector
Verify that we are able to connect to the DataSource (needed for retry policies)
validateConnection(RetryContext) - Method in class org.mule.transport.tcp.LocalSocketTcpMessageDispatcher
 
validateConnection(RetryContext) - Method in class org.mule.transport.tcp.TcpMessageDispatcher
 
validateConnection(RetryContext) - Method in class org.mule.transport.tcp.TcpMessageRequester
 
validateConnection(RetryContext) - Method in class org.mule.transport.udp.UdpMessageDispatcher
 
validateConnection(RetryContext) - Method in class org.mule.transport.udp.UdpMessageRequester
 
validateConstruct() - Method in class org.mule.construct.AbstractFlowConstruct
Validates configured flow construct
validateConstruct() - Method in class org.mule.construct.AbstractPipeline
 
validateConstruct() - Method in class org.mule.construct.Bridge
 
validateConstruct() - Method in class org.mule.construct.SimpleService
 
validateConstruct() - Method in class org.mule.construct.Validator
 
validateConstruct() - Method in class org.mule.module.ws.construct.WSProxy
 
validateConstruct() - Method in class org.mule.transport.http.construct.HttpProxy
 
validateEncoding() - Method in class org.mule.config.DefaultMuleConfiguration
 
validateExpression(String) - Method in interface org.mule.api.expression.ExpressionManager
Determines if the expression is valid or not.
validateExpression(String) - Method in class org.mule.expression.DefaultExpressionManager
 
validateFile(FTPFile) - Method in class org.mule.transport.ftp.FtpConnector
Override this method to do extra checking on the file.
validateJdk() - Static method in class org.mule.util.JdkVersionUtils
Validates that the jdk version and vendor are acceptable values (either supported or not invalid).
ValidateJsonSchemaMessageProcessor - Class in org.mule.module.json.validation
A MessageProcessor that uses a JsonSchemaValidator to validate a json in the payload to a given schema
ValidateJsonSchemaMessageProcessor() - Constructor for class org.mule.module.json.validation.ValidateJsonSchemaMessageProcessor
 
ValidateJsonSchemaMessageProcessorDefinitionParser - Class in org.mule.module.json.config
 
ValidateJsonSchemaMessageProcessorDefinitionParser() - Constructor for class org.mule.module.json.config.ValidateJsonSchemaMessageProcessorDefinitionParser
 
validateLifecycleMethod(Method) - Method in class org.mule.registry.JSR250ValidatorProcessor
Deprecated.
 
validateMapMessageType(Map<?, ?>) - Static method in class org.mule.transport.jms.JmsMessageUtils
MapMessage#writeObject(Object) accepts only primitives (and wrappers), String and byte[].
validateMessage() - Method in interface org.mule.execution.ValidationPhaseTemplate
Validates the message content.
validateMessage(Object) - Method in class org.mule.transport.AbstractMuleMessageFactory
 
validateMessage() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
validateMessage() - Method in class org.mule.transport.http.HttpMessageProcessTemplate
 
validateMessageIsNotConsumable(MuleEvent, MuleMessage) - Static method in class org.mule.routing.AbstractRoutingStrategy
Validates that the payload is not consumable so it can be copied.
validateMethod(Method, Class[]) - Method in class org.mule.config.transformer.AnnotatedTransformerProxy
 
validateMethod(Object, Method) - Method in class org.mule.model.resolvers.MethodHeaderPropertyEntryPointResolver
This method can be used to validate that the method exists and is allowed to be executed.
validateNotNull(Object, Message) - Static method in class org.mule.module.pgp.util.ValidatorUtil
 
validateObject(String, OAuth2Adapter) - Method in class org.mule.security.oauth.BaseOAuthClientFactory
Validates the object by checking that it exists at the object store and that the state of the given object is consisten with the persisted state
validateObject(Object) - Method in class org.mule.transport.ftp.FtpConnectionFactory
 
validateObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
 
validateObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
 
validateObject(Object) - Method in class org.mule.transport.sftp.SftpConnectionFactory
 
validateObject(Object, Object) - Method in class org.mule.transport.tcp.AbstractTcpSocketFactory
 
validateObject(Object, Object) - Method in class org.mule.transport.udp.UdpSocketFactory
 
validateQueryType(QueryTemplate) - Method in class org.mule.module.db.internal.processor.AbstractDbMessageProcessor
 
validateRepeatedNames(Collection<? extends Described>...) - Static method in class org.mule.module.extension.internal.util.MuleExtensionUtils
Verifies that none of the Described items in describedCollection have an equivalent value for Described.getName()
ValidateResponse - Class in org.mule.tck.transformer
Throws an exception if the message does not contain "success".
ValidateResponse() - Constructor for class org.mule.tck.transformer.ValidateResponse
 
validateSslConfig() - Method in class org.mule.transport.ajax.embedded.AjaxConnector
 
validateSslConfig() - Method in class org.mule.transport.servlet.jetty.JettyHttpsConnector
 
validateStreamMessageType(Object) - Static method in class org.mule.transport.jms.JmsMessageUtils
StreamMessage.writeObject(Object) accepts only primitives (and wrappers), String and byte[].
validateUrl(String) - Method in class org.mule.endpoint.MuleEndpointURI
 
validationFilter - Variable in class org.mule.construct.builder.ValidatorBuilder
 
validationFilter(Filter) - Method in class org.mule.construct.builder.ValidatorBuilder
 
ValidationPhase - Class in org.mule.execution
This phase validates the incoming message.
ValidationPhase() - Constructor for class org.mule.execution.ValidationPhase
 
ValidationPhaseTemplate - Interface in org.mule.execution
Phase for validation of the incoming message.
Validator - Class in org.mule.construct
 
Validator(String, MuleContext, MessageSource, OutboundEndpoint, Filter, String, String) - Constructor for class org.mule.construct.Validator
 
Validator(String, MuleContext, MessageSource, OutboundEndpoint, Filter, String, String, String) - Constructor for class org.mule.construct.Validator
 
ValidatorBuilder - Class in org.mule.construct.builder
 
ValidatorBuilder() - Constructor for class org.mule.construct.builder.ValidatorBuilder
 
ValidatorDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
ValidatorDefinitionParser() - Constructor for class org.mule.config.spring.parsers.specific.ValidatorDefinitionParser
 
ValidatorFactoryBean - Class in org.mule.config.spring.factories
 
ValidatorFactoryBean() - Constructor for class org.mule.config.spring.factories.ValidatorFactoryBean
 
ValidatorUtil - Class in org.mule.module.pgp.util
 
ValidatorUtil() - Constructor for class org.mule.module.pgp.util.ValidatorUtil
 
validQueryTypes - Variable in class org.mule.module.db.internal.processor.AbstractBulkUpdateMessageProcessor
 
VALUE - Static variable in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
VALUE - Static variable in class org.mule.config.spring.parsers.collection.ChildListEntryDefinitionParser
 
VALUE - Static variable in class org.mule.config.spring.parsers.collection.ChildMapEntryDefinitionParser
 
value - Variable in class org.mule.transport.polling.watermark.selector.WatermarkSelector
The selected value
value - Variable in class org.mule.util.scan.annotations.AnnotationInfo.NameValue
Deprecated.
 
VALUE_ATTRIBUTE - Static variable in class org.mule.module.db.internal.config.domain.param.InputParamValueBeanDefinitionParser
 
VALUE_FORMAT - Static variable in class org.mule.util.SplashScreen
 
valueExpression - Variable in class org.mule.routing.IdempotentMessageFilter
 
ValueHolder<T> - Class in org.mule.util
Utility class that holds a given value, allowing to set/retrieve it.
ValueHolder() - Constructor for class org.mule.util.ValueHolder
Default constructor.
ValueHolder(T) - Constructor for class org.mule.util.ValueHolder
Initialises this holder to the given value
valueIsInvalidFor(String, String) - Static method in class org.mule.config.i18n.CoreMessages
 
ValueMap - Interface in org.mule.config.spring.parsers.assembly.configuration
Allow arbitrary processing of a value
valueOf(String) - Static method in enum org.mule.api.annotations.meta.ChannelType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.api.annotations.meta.RouterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.api.ConnectionExceptionCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.api.devkit.capability.ModuleCapability
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.api.model.InvocationResult.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.api.processor.LoggerMessageProcessor.LogLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.api.registry.ServiceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.api.registry.TransformerResolver.RegistryAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.config.bootstrap.ArtifactType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.config.dsl.ComponentBuilder.Scope
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.construct.SimpleService.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.MessageExchangePattern
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.cxf.CxfPayloadToArguments
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.db.internal.domain.query.QueryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.db.internal.domain.transaction.TransactionalAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.http.api.HttpConstants.HttpStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.http.api.HttpConstants.Methods
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.http.api.HttpConstants.Protocols
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.http.api.requester.HttpSendBodyMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.http.api.requester.HttpStreamingType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.http.internal.domain.HttpProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.http.internal.HttpMessageLogger.LoggerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.http.internal.HttpParamType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.http.internal.request.HttpAuthenticationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.json.validation.JsonSchemaDereferencing
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.launcher.application.ApplicationStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.launcher.ArtifactDeploymentStatusTracker.DeploymentState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.pgp.config.PGPOutputMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.pgp.EncryptionAlgorithm
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.ws.consumer.SoapVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.ws.security.PasswordType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.ws.security.SignatureKeyIdentifier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.module.xml.xpath.XPathReturnType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.routing.CorrelationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.security.oauth.OnNoTokenPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.tck.AbstractServiceAndFlowTestCase.ConfigVariant
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.transport.polling.watermark.selector.WatermarkSelectorBroker
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.transport.sftp.config.SftpProxyConfig.Protocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.transport.sftp.SftpClient.WriteMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.mule.transport.xmpp.XmppMessageType
Returns the enum constant of this type with the specified name.
ValueResolver<T> - Interface in org.mule.module.extension.internal.runtime.resolver
Provides a value which is dependant on a MuleEvent
values() - Static method in enum org.mule.api.annotations.meta.ChannelType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.api.annotations.meta.RouterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.api.ConnectionExceptionCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.api.devkit.capability.ModuleCapability
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.api.model.InvocationResult.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.api.processor.LoggerMessageProcessor.LogLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.api.registry.ServiceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.api.registry.TransformerResolver.RegistryAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.config.bootstrap.ArtifactType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.config.dsl.ComponentBuilder.Scope
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.mule.config.spring.parsers.assembly.MapEntryCombiner
 
values() - Static method in enum org.mule.construct.SimpleService.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.mule.el.context.AbstractMapContext
 
values() - Method in class org.mule.expression.InboundAttachmentsMap
 
values() - Method in class org.mule.expression.OutboundAttachmentsMap
 
values() - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
 
values() - Static method in enum org.mule.MessageExchangePattern
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.cxf.CxfPayloadToArguments
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.db.internal.domain.query.QueryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.db.internal.domain.transaction.TransactionalAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.mule.module.db.internal.result.statement.CloseableMap
 
values() - Static method in enum org.mule.module.http.api.HttpConstants.HttpStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.http.api.HttpConstants.Methods
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.http.api.HttpConstants.Protocols
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.http.api.requester.HttpSendBodyMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.http.api.requester.HttpStreamingType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.http.internal.domain.HttpProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.http.internal.HttpMessageLogger.LoggerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.http.internal.HttpParamType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.mule.module.http.internal.ParameterMap
 
values() - Static method in enum org.mule.module.http.internal.request.HttpAuthenticationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.json.validation.JsonSchemaDereferencing
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.launcher.application.ApplicationStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.launcher.ArtifactDeploymentStatusTracker.DeploymentState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.pgp.config.PGPOutputMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.pgp.EncryptionAlgorithm
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.mule.module.scripting.component.RegistryLookupBindings
 
values() - Static method in enum org.mule.module.ws.consumer.SoapVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.ws.security.PasswordType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.ws.security.SignatureKeyIdentifier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.module.xml.xpath.XPathReturnType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.routing.CorrelationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.security.oauth.OnNoTokenPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.tck.AbstractServiceAndFlowTestCase.ConfigVariant
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.mule.transport.http.multipart.MultiMap
 
values() - Static method in enum org.mule.transport.polling.watermark.selector.WatermarkSelectorBroker
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.transport.sftp.config.SftpProxyConfig.Protocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.transport.sftp.SftpClient.WriteMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.mule.transport.xmpp.XmppMessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.mule.util.CaseInsensitiveMapWrapper
 
values() - Method in class org.mule.util.CopyOnWriteCaseInsensitiveMap
 
values() - Method in class org.mule.util.MapCombiner
 
values() - Method in class org.mule.util.store.ObjectStoreToMapAdapter
This method is not supported for performance reasons
ValueSetter - Interface in org.mule.module.extension.internal.util
A contract for setting values into an object
ValueUtils - Class in org.mule.module.db.internal.util
This class groups utility methods to modify DB parameter values.
VARBINARY_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
VARCHAR_DB_TYPE - Static variable in class org.mule.module.db.internal.domain.type.JdbcTypes
 
Variable - Class in com.javaforge.bobber.archetype.model
Represents system variable to be put in the Velocity Context .
Variable() - Constructor for class com.javaforge.bobber.archetype.model.Variable
 
VariableAssignmentCallback<T> - Interface in org.mule.api.el
 
VariableExpressionEnricher - Class in org.mule.expression
 
VariableExpressionEnricher() - Constructor for class org.mule.expression.VariableExpressionEnricher
 
VariableExpressionEvaluator - Class in org.mule.expression
Looks up the variable on the message using the name given.
VariableExpressionEvaluator() - Constructor for class org.mule.expression.VariableExpressionEvaluator
 
variableIndexOf(String) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
 
VariableVariableResolverFactory - Class in org.mule.el.mvel
 
VariableVariableResolverFactory(ParserConfiguration, MuleContext, MuleEvent) - Constructor for class org.mule.el.mvel.VariableVariableResolverFactory
 
VariableVariableResolverFactory(ParserConfiguration, MuleContext, MuleMessage) - Constructor for class org.mule.el.mvel.VariableVariableResolverFactory
Deprecated.
variant - Variable in class org.mule.tck.AbstractServiceAndFlowTestCase
Deprecated.
 
VARY - Static variable in class org.mule.module.http.api.HttpHeaders.Names
verboseExceptions - Static variable in class org.mule.config.DefaultMuleConfiguration
When false (default), only a summary of the root exception and trail is provided.
VERIFIER - Static variable in interface org.mule.security.oauth.OAuthProperties
 
verify() - Method in class org.mule.module.pgp.SignedMessage
 
verify() - Method in class org.mule.tck.functional.AssertionMessageProcessor
If result evaluated to false in some processed event or the last processed event was null, then assert fails, otherwise: count was set & count processes were done => ok count was set & count processes were not done => fail count was not set & at least one processing were done => ok
verify() - Static method in class org.mule.tck.functional.FlowAssert
 
verify(String) - Static method in class org.mule.tck.functional.FlowAssert
 
verify() - Method in class org.mule.tck.functional.ResponseAssertionMessageProcessor
 
verify(boolean, String, Object...) - Method in class org.mule.test.infrastructure.process.Controller
 
verifyContextNotInitialized() - Method in class org.mule.config.DefaultMuleConfiguration
 
verifyContextNotStarted() - Method in class org.mule.config.DefaultMuleConfiguration
 
verifyFlags(Object) - Method in class org.mule.el.function.RegexExpressionLanguageFuntion
 
VerifyLogWithMatcher - Class in org.mule.test.infrastructure.process
 
verifyRegex(Object) - Method in class org.mule.el.function.RegexExpressionLanguageFuntion
 
verifyReplyMessageSource(MessageSource) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
 
verifyReplyMessageSource(MessageSource) - Method in class org.mule.routing.requestreply.SimpleAsyncRequestReplyRequester
 
verifyReplyMessageSource(MessageSource) - Method in class org.mule.service.processor.ServiceAsyncRequestReplyRequestor
Deprecated.
 
verifyText(Object) - Method in class org.mule.el.function.RegexExpressionLanguageFuntion
 
verifyText(Object) - Method in class org.mule.el.function.WildcardExpressionLanguageFuntion
 
verifyWildcardPattern(Object) - Method in class org.mule.el.function.WildcardExpressionLanguageFuntion
 
version() - Static method in class org.mule.config.i18n.CoreMessages
 
VERSION_RANGE - Static variable in class org.mule.util.VersionRange
 
VERSION_RANGES - Static variable in class org.mule.util.VersionRange
pattern for extracting a ranges of versions.
versionNotSet() - Static method in class org.mule.config.i18n.CoreMessages
 
VersionRange - Class in org.mule.util
 
VersionRange(String) - Constructor for class org.mule.util.VersionRange
 
VersionWrapper - Class in org.mule.module.boot
There is a need to exit from wrapper This is a good place for other information message
VersionWrapper() - Constructor for class org.mule.module.boot.VersionWrapper
 
VIA - Static variable in class org.mule.module.http.api.HttpHeaders.Names
visit(int, int, String, String, String, String[]) - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
This is the class entry.
visit(String, Object) - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
We get annotation values in this method, but have to track the current context.
visit(int, int, String, String, String, String[]) - Method in class org.mule.util.scan.ImplementationClassScanner
Deprecated.
 
visit(int, int, String, String, String, String[]) - Method in class org.mule.util.scan.InterfaceClassScanner
Deprecated.
 
visit(int, int, String, String, String, String[]) - Method in class org.springframework.asm.ClassWriter
 
visitAnnotation(String, boolean) - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
visitAnnotation(String, boolean) - Method in class org.springframework.asm.ClassWriter
 
visitAttribute(Attribute) - Method in class org.springframework.asm.ClassWriter
 
visitContentTypeHeader(PartVisitor) - Method in class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
visitDispositionHeader(PartVisitor) - Method in class org.mule.module.http.internal.request.grizzly.ByteArrayPart
 
visitEnd() - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
visitEnd() - Method in class org.springframework.asm.ClassWriter
 
visitField(int, String, String, String, Object) - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
visitField(int, String, String, String, Object) - Method in class org.springframework.asm.ClassWriter
 
visitInnerClass(String, String, String, int) - Method in class org.springframework.asm.ClassWriter
 
visitMethod(int, String, String, String, String[]) - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
visitMethod(int, String, String, String, String[]) - Method in class org.springframework.asm.ClassWriter
 
visitOuterClass(String, String, String) - Method in class org.springframework.asm.ClassWriter
 
visitParameterAnnotation(int, String, boolean) - Method in class org.mule.util.scan.annotations.AnnotationsScanner
Deprecated.
 
visitSource(String, String) - Method in class org.springframework.asm.ClassWriter
 
visitTypeAnnotation(int, TypePath, String, boolean) - Method in class org.springframework.asm.ClassWriter
 
VM - Static variable in class org.mule.transport.vm.VMConnector
 
VMConnector - Class in org.mule.transport.vm
VMConnector A simple endpoint wrapper to allow a Mule service to

be accessed from an endpoint

VMConnector(MuleContext) - Constructor for class org.mule.transport.vm.VMConnector
 
VMMessageDispatcher - Class in org.mule.transport.vm
VMMessageDispatcher is used for providing in memory interaction between components.
VMMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.vm.VMMessageDispatcher
 
VMMessageDispatcherFactory - Class in org.mule.transport.vm
VMMessageDispatcherFactory creates an in-memory event dispatcher
VMMessageDispatcherFactory() - Constructor for class org.mule.transport.vm.VMMessageDispatcherFactory
 
VMMessageReceiver - Class in org.mule.transport.vm
VMMessageReceiver is a listener for events from a Mule service which then simply passes the events on to the target service.
VMMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.vm.VMMessageReceiver
 
VMMessageReceiver.MessageProcessorWorker - Class in org.mule.transport.vm
 
VMMessageReceiver.MessageProcessorWorker(ExecutionTemplate<MuleEvent>, SystemExceptionHandler, Object) - Constructor for class org.mule.transport.vm.VMMessageReceiver.MessageProcessorWorker
 
VMMessageRequester - Class in org.mule.transport.vm
VMMessageDispatcher is used for providing in memory interaction between components.
VMMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.vm.VMMessageRequester
 
VMMessageRequesterFactory - Class in org.mule.transport.vm
VMMessageDispatcherFactory creates an in-memory event dispatcher
VMMessageRequesterFactory() - Constructor for class org.mule.transport.vm.VMMessageRequesterFactory
 
VMMessages - Class in org.mule.transport.vm.i18n
 
VMMessages() - Constructor for class org.mule.transport.vm.i18n.VMMessages
 
VmNamespaceHandler - Class in org.mule.transport.vm.config
Reigsters a Bean Definition Parser for handling elements.
VmNamespaceHandler() - Constructor for class org.mule.transport.vm.config.VmNamespaceHandler
 
VMTransaction - Class in org.mule.transport.vm
 
VMTransaction(MuleContext) - Constructor for class org.mule.transport.vm.VMTransaction
 
VMTransaction(MuleContext, boolean) - Constructor for class org.mule.transport.vm.VMTransaction
 
VMTransactionFactory - Class in org.mule.transport.vm
 
VMTransactionFactory() - Constructor for class org.mule.transport.vm.VMTransactionFactory
 
VoidMuleEvent - Class in org.mule
A VoidMuleEvent represents a void return from a MessageProcessor such as a ONE_WAY OutboundEndpoint.
VoidMuleEvent() - Constructor for class org.mule.VoidMuleEvent
 
VoidResult - Class in org.mule
 
VoidURLConnection - Class in org.mule.transport.soap.axis.transport
A fake url connection used to bypass Axis's use of the URLStreamHandler to mask uris as Urls.
VoidURLConnection(URL) - Constructor for class org.mule.transport.soap.axis.transport.VoidURLConnection
 

W

WaitableBoolean - Class in org.mule.util.concurrent
 
WaitableBoolean(boolean) - Constructor for class org.mule.util.concurrent.WaitableBoolean
 
WaitableBoolean(boolean, Object) - Constructor for class org.mule.util.concurrent.WaitableBoolean
 
waitForAllTxToStop(long) - Method in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
Deprecated.
 
waitForAllTxToStop(long) - Method in class org.mule.util.xa.AbstractResourceManager
 
waitIfPaused() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
 
WaitPolicy - Class in org.mule.util.concurrent
A handler for unexecutable tasks that waits until the task can be submitted for execution or times out.
WaitPolicy() - Constructor for class org.mule.util.concurrent.WaitPolicy
Constructs a WaitPolicy which waits (almost) forever.
WaitPolicy(long, TimeUnit) - Constructor for class org.mule.util.concurrent.WaitPolicy
Constructs a WaitPolicy with timeout.
waitUntilAllNotificationsAreReceived() - Method in class org.mule.tck.listener.ExceptionListener
 
waitUntilAllNotificationsAreReceived() - Method in class org.mule.tck.listener.SystemExceptionListener
 
waitUntilApplicationDeployed() - Method in class org.mule.test.infrastructure.process.ApplicationStartedDeploymentListener
 
waitUntilFlowIsComplete() - Method in class org.mule.tck.listener.FlowExecutionListener
 
waitUntilNotificationsAreReceived() - Method in class org.mule.tck.listener.ConnectionListener
 
waitUntilStarted(int) - Method in interface org.mule.api.MuleContext
Makes the caller wait until the MuleContext was started
waitUntilStarted(int) - Method in class org.mule.DefaultMuleContext
 
waitUntilStarted() - Method in class org.mule.test.infrastructure.process.TestProcess
 
waitUntilStarted(int) - Method in class org.mule.test.infrastructure.process.TestProcess
 
warn(String, Throwable) - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
warn(Throwable) - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
warn(String, Object...) - Method in class org.mule.transport.servlet.jetty.JettyLogger
 
warn(Object) - Method in class org.mule.util.MuleLogger
 
warn(Object, Throwable) - Method in class org.mule.util.MuleLogger
 
warn() - Method in class org.mule.util.OneTimeWarning
Fire one time warning.
warn(Object...) - Method in class org.mule.util.OneTimeWarning
Fire one time warning using arguments passing arguments to logger
warnIfMuleClientSendUsed(MuleMessage) - Method in class org.mule.transport.AbstractMessageReceiver
 
warnIfMuleClientSendUsed(MuleMessage) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
 
WARNING - Static variable in class org.mule.module.http.api.HttpHeaders.Names
warning(TransformerException) - Method in class org.mule.module.xml.transformer.XsltTransformer.DefaultErrorListener
 
Watermark - Class in org.mule.transport.polling.watermark
Poll override that provides watermarking functionality: It enriches the event passed to the polling message processor to have a flow variable fetched from the object store defined, ensures the variable is carried over to the flow event if it is going to be executed, and saves the value of the variable back to the object store at the end of the flow.
Watermark(ObjectStore<Serializable>, String, String) - Constructor for class org.mule.transport.polling.watermark.Watermark
 
watermark - Variable in class org.mule.transport.polling.watermark.WatermarkPollingInterceptor
 
WatermarkFactoryBean - Class in org.mule.config.spring.factories
 
WatermarkFactoryBean() - Constructor for class org.mule.config.spring.factories.WatermarkFactoryBean
 
WatermarkPollingInterceptor - Class in org.mule.transport.polling.watermark
Implementation of MessageProcessorPollingInterceptor that retrieves the current watermark value before the polling flow is executed and updates it when it is finished.
WatermarkPollingInterceptor(Watermark) - Constructor for class org.mule.transport.polling.watermark.WatermarkPollingInterceptor
 
watermarkRequiresSynchronousProcessing() - Static method in class org.mule.config.i18n.CoreMessages
 
WatermarkSelector - Class in org.mule.transport.polling.watermark.selector
A watermark selector receives values and selects which one should be the new watermark value
WatermarkSelector() - Constructor for class org.mule.transport.polling.watermark.selector.WatermarkSelector
 
WatermarkSelectorBroker - Enum in org.mule.transport.polling.watermark.selector
Broker for the default implementations of WatermarkSelector
WatermarkSelectorWrapper - Class in org.mule.transport.polling.watermark.selector
 
WatermarkSelectorWrapper(WatermarkSelector, String, MuleEvent) - Constructor for class org.mule.transport.polling.watermark.selector.WatermarkSelectorWrapper
 
WatermarkUtils - Class in org.mule.transport.polling.watermark
 
WatermarkUtils() - Constructor for class org.mule.transport.polling.watermark.WatermarkUtils
 
WebappMuleXmlConfigurationBuilder - Class in org.mule.config.builders
WebappMuleXmlConfigurationBuilder will first try and load config resources using the ServletContext and if this fails then it will attempt to load config resource from the classpath.
WebappMuleXmlConfigurationBuilder(ServletContext, String) - Constructor for class org.mule.config.builders.WebappMuleXmlConfigurationBuilder
 
WebappMuleXmlConfigurationBuilder(ServletContext, String[]) - Constructor for class org.mule.config.builders.WebappMuleXmlConfigurationBuilder
 
webapps - Variable in class org.mule.transport.servlet.jetty.JettyWebappServerAgent
 
WebappsConfiguration - Class in org.mule.transport.servlet.jetty
 
WebappsConfiguration() - Constructor for class org.mule.transport.servlet.jetty.WebappsConfiguration
 
WeblogicJmsConnector - Class in org.mule.transport.jms.weblogic
Weblogic-specific JMS connector.
WeblogicJmsConnector(MuleContext) - Constructor for class org.mule.transport.jms.weblogic.WeblogicJmsConnector
Constructs a new WeblogicJmsConnector.
WeblogicJmsTopicResolver - Class in org.mule.transport.jms.weblogic
Weblogic-specific JMS topic resolver.
WeblogicJmsTopicResolver(JmsConnector) - Constructor for class org.mule.transport.jms.weblogic.WeblogicJmsTopicResolver
Create an instance of the resolver.
WeblogicTransactionManagerLookupFactory - Class in org.mule.transaction.lookup
 
WeblogicTransactionManagerLookupFactory() - Constructor for class org.mule.transaction.lookup.WeblogicTransactionManagerLookupFactory
 
WebServiceFactoryBean - Class in org.mule.module.cxf.config
 
WebServiceFactoryBean() - Constructor for class org.mule.module.cxf.config.WebServiceFactoryBean
 
WebServiceMessageProcessorBuilder - Class in org.mule.module.cxf.builder
Builds a CXF web service MessageProcessor using either the JAX-WS or simple frontends.
WebServiceMessageProcessorBuilder() - Constructor for class org.mule.module.cxf.builder.WebServiceMessageProcessorBuilder
 
WebServiceOnlineCheck - Class in org.mule.tck.util
 
WebServiceOnlineCheck() - Constructor for class org.mule.tck.util.WebServiceOnlineCheck
 
WebServiceSecurityException - Exception in org.mule.module.cxf.security
 
WebServiceSecurityException(MuleEvent, Throwable, MessageProcessor) - Constructor for exception org.mule.module.cxf.security.WebServiceSecurityException
 
WebServiceWrapperComponent - Class in org.mule.module.cxf.component
Deprecated.
WebServiceWrapperComponent() - Constructor for class org.mule.module.cxf.component.WebServiceWrapperComponent
Deprecated.
 
WebServiceWrapperComponent - Class in org.mule.transport.soap.axis.component
 
WebServiceWrapperComponent() - Constructor for class org.mule.transport.soap.axis.component.WebServiceWrapperComponent
 
WEBSOCKET - Static variable in class org.mule.module.http.api.HttpHeaders.Values
WEBSOCKET_LOCATION - Static variable in class org.mule.module.http.api.HttpHeaders.Names
WEBSOCKET_ORIGIN - Static variable in class org.mule.module.http.api.HttpHeaders.Names
WEBSOCKET_PROTOCOL - Static variable in class org.mule.module.http.api.HttpHeaders.Names
WebsphereJmsConnector - Class in org.mule.transport.jms.websphere
Websphere-specific JMS connector.
WebsphereJmsConnector(MuleContext) - Constructor for class org.mule.transport.jms.websphere.WebsphereJmsConnector
Constructs a new WebsphereJmsConnector.
WebsphereTransactedJmsMessageReceiver - Class in org.mule.transport.jms.websphere
 
WebsphereTransactedJmsMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.jms.websphere.WebsphereTransactedJmsMessageReceiver
 
WebsphereTransactionManagerLookupFactory - Class in org.mule.transaction.lookup
The code borrowed from Spring's org.springframework.transaction.jta.WebSphereTransactionManagerFactoryBean.
WebsphereTransactionManagerLookupFactory() - Constructor for class org.mule.transaction.lookup.WebsphereTransactionManagerLookupFactory
 
weighting - Variable in class org.mule.module.json.transformers.AbstractJsonTransformer
 
when() - Method in class org.mule.config.dsl.routers.ChoiceDefinition
Deprecated.
 
when(String) - Method in class org.mule.config.dsl.routers.WhenDefinition
Deprecated.
 
WHEN_EXHAUSTED_ABORT - Static variable in interface org.mule.api.config.ThreadingProfile
 
WHEN_EXHAUSTED_BLOCK - Static variable in interface org.mule.transport.ConfigurableKeyedObjectPool
 
WHEN_EXHAUSTED_DISCARD - Static variable in interface org.mule.api.config.ThreadingProfile
 
WHEN_EXHAUSTED_DISCARD_OLDEST - Static variable in interface org.mule.api.config.ThreadingProfile
 
WHEN_EXHAUSTED_FAIL - Static variable in class org.mule.config.PoolingProfile
 
WHEN_EXHAUSTED_FAIL - Static variable in interface org.mule.transport.ConfigurableKeyedObjectPool
 
WHEN_EXHAUSTED_GROW - Static variable in class org.mule.config.PoolingProfile
 
WHEN_EXHAUSTED_GROW - Static variable in interface org.mule.transport.ConfigurableKeyedObjectPool
 
WHEN_EXHAUSTED_RUN - Static variable in interface org.mule.api.config.ThreadingProfile
 
WHEN_EXHAUSTED_WAIT - Static variable in interface org.mule.api.config.ThreadingProfile
Actions to perform on pool exhaustion
WHEN_EXHAUSTED_WAIT - Static variable in class org.mule.config.PoolingProfile
 
WhenDefinition - Class in org.mule.config.dsl.routers
Deprecated.
whenEqual(boolean, Runnable) - Method in class org.mule.util.concurrent.WaitableBoolean
 
whenFalse(Runnable) - Method in class org.mule.util.concurrent.WaitableBoolean
 
whenNotEqual(boolean, Runnable) - Method in class org.mule.util.concurrent.WaitableBoolean
 
whenTrue(Runnable) - Method in class org.mule.util.concurrent.WaitableBoolean
 
WHITE_SPACE - Static variable in class org.mule.util.StringUtils
 
WIGGLY_MULE_TEMPLATE_PATTERN - Static variable in class org.mule.util.TemplateParser
 
WIGGLY_MULE_TEMPLATE_STYLE - Static variable in class org.mule.util.TemplateParser
 
WilcardExpressionEvaluator - Class in org.mule.expression
 
WilcardExpressionEvaluator() - Constructor for class org.mule.expression.WilcardExpressionEvaluator
 
WildcardAttributeEvaluator - Class in org.mule.util
 
WildcardAttributeEvaluator(String) - Constructor for class org.mule.util.WildcardAttributeEvaluator
 
WildcardAttributeEvaluator.MatchCallback - Interface in org.mule.util
 
WildcardExpressionLanguageFuntion - Class in org.mule.el.function
 
WildcardExpressionLanguageFuntion() - Constructor for class org.mule.el.function.WildcardExpressionLanguageFuntion
 
WildcardFilter - Class in org.mule.routing.filters
WildcardFilter is used to match Strings against wildcards.
WildcardFilter() - Constructor for class org.mule.routing.filters.WildcardFilter
 
WildcardFilter(String) - Constructor for class org.mule.routing.filters.WildcardFilter
 
WindowsController - Class in org.mule.test.infrastructure.process
 
WindowsController(String, int) - Constructor for class org.mule.test.infrastructure.process.WindowsController
 
WireFormat - Interface in org.mule.api.transformer.wire
 
wireFormat - Variable in class org.mule.module.client.remoting.RemoteDispatcherComponent
Deprecated.
Use Serialization by default
WireTap - Class in org.mule.routing
The WireTap MessageProcessor allows inspection of messages in a flow.
WireTap() - Constructor for class org.mule.routing.WireTap
 
withLocale(String) - Method in interface org.mule.api.el.datetime.Date
 
withLocale(String) - Method in interface org.mule.api.el.datetime.Instant
 
withLocale(String) - Method in interface org.mule.api.el.datetime.Time
 
withLocale(String) - Method in class org.mule.el.datetime.AbstractInstant
 
withLocale(String) - Method in class org.mule.el.datetime.DateTime
 
withTimeZone(String) - Method in interface org.mule.api.el.datetime.Date
 
withTimeZone(String) - Method in interface org.mule.api.el.datetime.Instant
 
withTimeZone(String) - Method in interface org.mule.api.el.datetime.Time
 
withTimeZone(String) - Method in class org.mule.el.datetime.AbstractInstant
 
withTimeZone(String) - Method in class org.mule.el.datetime.DateTime
 
workAccepted(WorkEvent) - Method in class org.mule.processor.AsyncWorkListener
 
workAccepted(WorkEvent) - Method in class org.mule.transport.AbstractConnector
 
workAccepted(WorkEvent) - Method in class org.mule.transport.TrackerWorkListener
 
workAccepted(WorkEvent) - Method in class org.mule.work.DefaultWorkListener
 
workAccepted(Object) - Method in class org.mule.work.WorkerContext
Call-back method used by a Work executor in order to notify this instance that the wrapped Work instance has been accepted.
workCompleted(WorkEvent) - Method in class org.mule.processor.AsyncWorkListener
 
workCompleted(WorkEvent) - Method in class org.mule.transport.AbstractConnector
 
workCompleted(WorkEvent) - Method in class org.mule.transport.TrackerWorkListener
 
workCompleted(WorkEvent) - Method in class org.mule.work.DefaultWorkListener
 
worker - Variable in class org.mule.transport.PollingReceiverWorkerSchedule
 
WorkerContext - Class in org.mule.work
WorkerContext TODO
WorkerContext(Work) - Constructor for class org.mule.work.WorkerContext
Create a WorkWrapper.
WorkerContext(Work, long, ExecutionContext, WorkListener) - Constructor for class org.mule.work.WorkerContext
Create a WorkWrapper with the specified execution context.
WorkExecutor - Interface in org.mule.api.work
WorkExecutor TODO
WorkingMemorySLF4JLogger - Class in org.mule.module.drools
Simple implementation used to send an audit trail of the working memory to the SLF4J logger.
WorkingMemorySLF4JLogger(WorkingMemory, Logger) - Constructor for class org.mule.module.drools.WorkingMemorySLF4JLogger
 
WorkingMemorySLF4JLogger(KnowledgeRuntimeEventManager, Logger) - Constructor for class org.mule.module.drools.WorkingMemorySLF4JLogger
 
workListener - Variable in class org.mule.context.DefaultMuleContextBuilder
 
WorkListenerWrapperFactory - Interface in org.mule.transport
Creates WorkListener to delegate notifications originated in a work to another WorkListener
WorkManager - Interface in org.mule.api.context
WorkManager extends the standard JCA WorkManager with lifecycle methods and util.concurrent bridging.
workManager - Variable in class org.mule.context.DefaultMuleContextBuilder
 
workManager - Variable in class org.mule.processor.AsyncInterceptingMessageProcessor
 
workManager - Variable in class org.mule.transport.PollingReceiverWorkerSchedule
 
WorkManagerHolder - Interface in org.mule.transport
Provides a reference to a WorkManager making the client agnostic of the WorkManager lifecycle.
WorkManagerSource - Interface in org.mule.api.context
 
workManagerSource - Variable in class org.mule.processor.AsyncInterceptingMessageProcessor
 
WorkManagerSourceExecutorProvider - Class in org.mule.module.http.internal.listener.grizzly
ExecutorProvider implementation that retrieves an Executor from a WorkManagerSource
WorkManagerSourceExecutorProvider() - Constructor for class org.mule.module.http.internal.listener.grizzly.WorkManagerSourceExecutorProvider
 
workRejected(WorkEvent) - Method in class org.mule.processor.AsyncWorkListener
 
workRejected(WorkEvent) - Method in class org.mule.transport.AbstractConnector
 
workRejected(WorkEvent) - Method in class org.mule.transport.TrackerWorkListener
 
workRejected(WorkEvent) - Method in class org.mule.work.DefaultWorkListener
 
workStarted(WorkEvent) - Method in class org.mule.processor.AsyncWorkListener
 
workStarted(WorkEvent) - Method in class org.mule.transport.AbstractConnector
 
workStarted(WorkEvent) - Method in class org.mule.transport.TrackerWorkListener
 
workStarted(WorkEvent) - Method in class org.mule.work.DefaultWorkListener
 
WorkTracker - Interface in org.mule.transport
Tracks works that are running in behalf of a given component.
wrapDelegateRetryPolicy(Element, ParserContext, BeanDefinitionBuilder, String) - Method in class org.mule.config.spring.parsers.specific.RetryPolicyDefinitionParser
 
WRAPPER_JMX_NAME - Static variable in class org.mule.module.management.agent.WrapperManagerAgent
MBean name to register under.
WrapperManagerAgent - Class in org.mule.module.management.agent
This agent integrates Java Service Wrapper into Mule.
WrapperManagerAgent() - Constructor for class org.mule.module.management.agent.WrapperManagerAgent
 
wrappersToPrimitives(Class[]) - Static method in class org.mule.util.ClassUtils
 
wrapperToPrimitive(Class) - Static method in class org.mule.util.ClassUtils
 
WrappingChildDefinitionParser - Class in org.mule.config.spring.parsers.generic
A child definition parser that wraps the child object
WrappingChildDefinitionParser(String, Class, Class, boolean, Class, String, String, WrappingChildDefinitionParser.WrappingController) - Constructor for class org.mule.config.spring.parsers.generic.WrappingChildDefinitionParser
 
WrappingChildDefinitionParser.WrappingController - Interface in org.mule.config.spring.parsers.generic
Determines whether to wrap the child based on the where it appears in the DOM.
write(Writer, BobberArchetype) - Method in class com.javaforge.bobber.archetype.model.io.xpp3.BobberArchetypeXpp3Writer
Method write.
write(byte[]) - Method in class org.apache.commons.httpclient.HttpConnection
Writes the specified bytes to the output stream.
write(byte[], int, int) - Method in class org.apache.commons.httpclient.HttpConnection
Writes length bytes in data starting at offset to the output stream.
WRITE - Static variable in interface org.mule.api.ThreadSafeAccess
 
write(OutputStream, Object, String) - Method in interface org.mule.api.transformer.wire.WireFormat
 
write(MuleEvent, OutputStream) - Method in interface org.mule.api.transport.OutputHandler
Write the event payload to the stream.
write(int) - Method in class org.mule.model.streaming.CallbackOutputStream
 
write(byte[]) - Method in class org.mule.model.streaming.CallbackOutputStream
 
write(byte[], int, int) - Method in class org.mule.model.streaming.CallbackOutputStream
 
write(byte[], int, int) - Method in class org.mule.module.cxf.support.DelegatingOutputStream
 
write(byte[]) - Method in class org.mule.module.cxf.support.DelegatingOutputStream
 
write(int) - Method in class org.mule.module.cxf.support.DelegatingOutputStream
 
write(GeneratedResource) - Method in class org.mule.module.extension.internal.resources.AbstractResourcesGenerator
Template method to actually write the given resource to a persistent store
write(String) - Method in class org.mule.module.http.internal.multipart.HttpPart
 
write(byte[], int, int) - Method in class org.mule.module.jersey.DeferredForwardOutputStream
 
write(int) - Method in class org.mule.module.jersey.DeferredForwardOutputStream
 
write(Result) - Method in interface org.mule.module.xml.transformer.DelayedResult
 
write(OutputStream, Object, String) - Method in class org.mule.transformer.wire.TransformerPairWireFormat
 
write(int) - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
write(byte[], int, int) - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
write(String) - Method in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
write(String) - Method in interface org.mule.transport.http.multipart.Part
A convenience method to write this uploaded item to disk.
write(byte) - Method in class org.mule.transport.http.ResponseWriter
 
write(byte[]) - Method in class org.mule.transport.http.ResponseWriter
 
write(byte[], int, int) - Method in class org.mule.transport.http.ResponseWriter
 
write(String) - Method in class org.mule.transport.soap.axis.AxisStringWriter
 
write(String, int, int) - Method in class org.mule.transport.soap.axis.AxisStringWriter
 
write(OutputStream, Object) - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
 
write(OutputStream, Object) - Method in class org.mule.transport.tcp.protocols.MuleMessageDirectProtocol
 
write(OutputStream, Object) - Method in class org.mule.transport.tcp.protocols.MuleMessageEOFProtocol
 
write(OutputStream, Object) - Method in class org.mule.transport.tcp.protocols.MuleMessageLengthProtocol
 
write(OutputStream, Object) - Method in class org.mule.transport.tcp.protocols.MuleMessageSafeProtocol
 
write(byte[]) - Method in class org.mule.transport.tcp.protocols.ProtocolStream
 
write(byte[], int, int) - Method in class org.mule.transport.tcp.protocols.ProtocolStream
 
write(int) - Method in class org.mule.transport.tcp.protocols.ProtocolStream
 
write(OutputStream, Object) - Method in class org.mule.transport.tcp.protocols.SafeProtocol
 
write(OutputStream, Object) - Method in interface org.mule.transport.tcp.TcpProtocol
Write the specified message to the output stream.
write(DatagramSocket, byte[], int, InetAddress) - Method in class org.mule.transport.udp.UdpMessageDispatcher
 
write(int) - Method in class org.mule.util.Base64.OutputStream
Writes the byte to the output stream after converting to/from Base64 notation.
write(byte[], int, int) - Method in class org.mule.util.Base64.OutputStream
Calls Base64.OutputStream.write(int) repeatedly until len bytes are written.
write(DataOutputStream, MuleContext) - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
 
writeByteArray(OutputStream, byte[]) - Method in class org.mule.transport.tcp.protocols.AbstractByteProtocol
 
writeByteArray(OutputStream, byte[]) - Method in class org.mule.transport.tcp.protocols.LengthProtocol
 
writeControlData(File, File) - Method in class org.mule.util.queue.QueueControlDataFile
Updates the control data
writeEmptyResponse(HttpServletResponse, Map<String, String>) - Method in class org.mule.transport.servlet.ServletResponseWriter
Writes an empty HttpServletResponse.
writeErrorResponse(HttpServletResponse, MuleMessage, int, String, Map<String, String>) - Method in class org.mule.transport.servlet.ServletResponseWriter
Writes a servlet response with an error code based on a mule message.
writeErrorResponse(HttpServletResponse, int, String, Map<String, String>) - Method in class org.mule.transport.servlet.ServletResponseWriter
Writes a servlet response with an error code with html code wrapping the error message.
writeErrorResponseFromMessage(HttpServletResponse, MuleMessage, int, String) - Method in class org.mule.transport.servlet.AbstractReceiverServlet
 
writeException(Throwable) - Static method in class org.mule.config.ExceptionHelper
 
writeExternal(ObjectOutput) - Method in class org.mule.module.drools.WorkingMemorySLF4JLogger
 
writeFailureResponse(int, String) - Method in class org.mule.transport.http.HttpServerConnection
Sends to the customer a Failure response.
writeFailureResponse(int, String, Map<String, String>) - Method in class org.mule.transport.http.HttpServerConnection
Sends a customer a failure response but also adds the headers in the headers map
writeLine(byte[]) - Method in class org.apache.commons.httpclient.HttpConnection
Writes the specified bytes, followed by "\r\n".getBytes() to the output stream.
writeLine() - Method in class org.apache.commons.httpclient.HttpConnection
Writes "\r\n".getBytes() to the output stream.
writeNonHtmlErrorResponse(HttpServletResponse, int, String, Map<String, String>) - Method in class org.mule.transport.servlet.ServletResponseWriter
Writes a servlet response with an error code without html code wrapping the error message.
writeReplace() - Method in class org.springframework.beans.factory.support.DefaultListableBeanFactory
 
writeRequest(HttpRequest) - Method in class org.mule.transport.http.HttpServerConnection
 
writeRequest(OutputStream) - Method in class org.mule.transport.http.StreamPayloadRequestEntity
 
writeResponse(String, String, EndpointInfo, OutputStream) - Method in class org.mule.module.cxf.support.WSDLQueryHandler
 
writeResponse(HttpResponse) - Method in class org.mule.transport.http.HttpServerConnection
 
writeResponse(HttpResponse, Map<String, String>) - Method in class org.mule.transport.http.HttpServerConnection
Write an HttpResponse and add the map entries as headers
writeResponse(HttpServletResponse, MuleMessage) - Method in class org.mule.transport.servlet.AbstractReceiverServlet
 
writeResponse(HttpServletResponse, MuleMessage, Map<String, String>) - Method in class org.mule.transport.servlet.ServletResponseWriter
Writes a servlet response based on a mule message.
writeToObjectStore(Serializable) - Method in class org.mule.util.queue.objectstore.QueueInfo
Deprecated.
 
writeToObjectStore(Serializable) - Method in interface org.mule.util.queue.objectstore.TakingQueueStoreDelegate
Deprecated.
 
writeToProperties(Properties, TlsConfiguration) - Method in class org.mule.api.security.tls.TlsPropertiesMapper
 
writeToStream(Object, String, OutputStream) - Method in class org.mule.module.xml.transformer.AbstractXmlTransformer
 
writeXml(Object, String, OutputStream) - Method in class org.mule.module.xml.transformer.XmlToOutputHandler
 
wrongMessageSource(String) - Static method in class org.mule.config.i18n.CoreMessages
 
WS_SERVICE_URL - Static variable in class org.mule.module.cxf.component.AbstractWebServiceWrapperComponent
 
WsConfig - Class in org.mule.module.cxf.config
 
WsConfig() - Constructor for class org.mule.module.cxf.config.WsConfig
 
WsConfig(Map<String, Object>) - Constructor for class org.mule.module.cxf.config.WsConfig
 
WSConsumer - Class in org.mule.module.ws.consumer
 
WSConsumer() - Constructor for class org.mule.module.ws.consumer.WSConsumer
 
WSConsumerConfig - Class in org.mule.module.ws.consumer
 
WSConsumerConfig() - Constructor for class org.mule.module.ws.consumer.WSConsumerConfig
 
WSCryptoUtils - Class in org.mule.module.ws.security
Utility class to create objects with the required properties to configure key stores and trust stores for WS-Security.
WSCryptoUtils() - Constructor for class org.mule.module.ws.security.WSCryptoUtils
 
WsCustomValidatorDefinitionParser - Class in org.mule.module.cxf.config
 
WsCustomValidatorDefinitionParser(String) - Constructor for class org.mule.module.cxf.config.WsCustomValidatorDefinitionParser
 
WSDDFileProvider - Class in org.mule.transport.soap.axis.extensions
Override the File provider to stop exceptions being thrown in Axis if the service does not exist.
WSDDFileProvider(String) - Constructor for class org.mule.transport.soap.axis.extensions.WSDDFileProvider
Constructor which accesses a file in the current directory of the engine or at an absolute path.
WSDDFileProvider(String, String) - Constructor for class org.mule.transport.soap.axis.extensions.WSDDFileProvider
Constructor which accesses a file relative to a specific base path.
WSDDJavaMuleProvider - Class in org.mule.transport.soap.axis.extensions
WSDDJavaMuleProvider is a factory class for creating the MuleProvider.
WSDDJavaMuleProvider(AxisConnector) - Constructor for class org.mule.transport.soap.axis.extensions.WSDDJavaMuleProvider
 
WSDL_LOCATION - Static variable in class org.mule.module.cxf.CxfConstants
 
WSDL_PROPERTY - Static variable in interface org.mule.module.cxf.SoapConstants
 
WSDL_URL_PROPERTY - Static variable in interface org.mule.module.cxf.SoapConstants
 
WsdlClientMessageProcessorBuilder - Class in org.mule.module.cxf.builder
Builds an outbound CXF MessageProcessor based on a WSDL using CXF's DynamicClientFactory.
WsdlClientMessageProcessorBuilder() - Constructor for class org.mule.module.cxf.builder.WsdlClientMessageProcessorBuilder
 
WsdlCxfEndpointBuilder - Class in org.mule.module.cxf.endpoint
 
WsdlCxfEndpointBuilder(EndpointURIEndpointBuilder) - Constructor for class org.mule.module.cxf.endpoint.WsdlCxfEndpointBuilder
 
WsdlCxfEndpointBuilder(String, MuleContext) - Constructor for class org.mule.module.cxf.endpoint.WsdlCxfEndpointBuilder
 
wsdlFile - Variable in class org.mule.module.ws.construct.builder.WSProxyBuilder
 
wsdlFile(File) - Method in class org.mule.module.ws.construct.builder.WSProxyBuilder
 
wsdlLocation - Variable in class org.mule.module.cxf.builder.AbstractOutboundMessageProcessorBuilder
 
wsdlNotFound(String) - Static method in class org.mule.module.cxf.i18n.CxfMessages
 
WSDLQueryHandler - Class in org.mule.module.cxf.support
WSDLQueryHandler class preserved from cxf 2.3.
WSDLQueryHandler(Bus) - Constructor for class org.mule.module.cxf.support.WSDLQueryHandler
 
WsdlRetrieverStrategy - Interface in org.mule.module.ws.consumer
A strategy to retrieve the wsdl from the url defined
WSDLRetrieverStrategyFactory - Interface in org.mule.module.ws.consumer.wsdl.strategy.factory
Interface to build WSDL retriever strategies
WsdlServiceFinder - Class in org.mule.transport.soap.axis
WsdlServiceFinder finds a the connector service to use by checking the classpath for jars required for each of the soap connector implementations
WsdlServiceFinder() - Constructor for class org.mule.transport.soap.axis.WsdlServiceFinder
 
WsdlUrlEndpointURIBuilder - Class in org.mule.transport.soap.axis
The same as the UrlEndpointbuilder except that all parameters except the first are set as properties on the endpoint and stripped from the endpoint Uri
WsdlUrlEndpointURIBuilder() - Constructor for class org.mule.transport.soap.axis.WsdlUrlEndpointURIBuilder
 
WSDLUtils - Class in org.mule.module.ws.consumer
 
WSDLUtils() - Constructor for class org.mule.module.ws.consumer.WSDLUtils
 
wsldLocation - Variable in class org.mule.module.ws.construct.builder.WSProxyBuilder
 
wsldLocation(URI) - Method in class org.mule.module.ws.construct.builder.WSProxyBuilder
 
WSNamespaceHandler - Class in org.mule.module.ws.config
Registers a Bean Definition Parser for handling elements.
WSNamespaceHandler() - Constructor for class org.mule.module.ws.config.WSNamespaceHandler
 
WSPasswordCallbackHandler - Class in org.mule.module.ws.security
Abstract implementation of CallbackHandler that only handles instances of WSPasswordCallback with a specific usage.
WSPasswordCallbackHandler(int) - Constructor for class org.mule.module.ws.security.WSPasswordCallbackHandler
 
WSProxy - Class in org.mule.module.ws.construct
This class is implemented to act as a Proxy for a Web Service.
WSProxy(String, MuleContext, MessageSource, OutboundEndpoint, List<MessageProcessor>, List<MessageProcessor>) - Constructor for class org.mule.module.ws.construct.WSProxy
 
WSProxy(String, MuleContext, MessageSource, OutboundEndpoint, List<MessageProcessor>, List<MessageProcessor>, String) - Constructor for class org.mule.module.ws.construct.WSProxy
 
WSProxy(String, MuleContext, MessageSource, OutboundEndpoint, List<MessageProcessor>, List<MessageProcessor>, URI) - Constructor for class org.mule.module.ws.construct.WSProxy
 
WSProxyBuilder - Class in org.mule.module.ws.construct.builder
 
WSProxyBuilder() - Constructor for class org.mule.module.ws.construct.builder.WSProxyBuilder
 
WSProxyDefinitionParser - Class in org.mule.module.ws.config.spring.parsers.specific
 
WSProxyDefinitionParser() - Constructor for class org.mule.module.ws.config.spring.parsers.specific.WSProxyDefinitionParser
 
WSProxyFactoryBean - Class in org.mule.module.ws.config.spring.factories
 
WSProxyFactoryBean() - Constructor for class org.mule.module.ws.config.spring.factories.WSProxyFactoryBean
 
WSProxyService - Class in org.mule.module.cxf
Deprecated.
WSProxyService only works for Services, to proxy web services in flows use CXF's proxy service and client message processors or the ws proxy pattern.
WSProxyService() - Constructor for class org.mule.module.cxf.WSProxyService
Deprecated.
 
WssDecryptSecurityStrategy - Class in org.mule.module.ws.security
Decrypts an encrypted SOAP response, using the private key of the key-store in the provided TLS context.
WssDecryptSecurityStrategy() - Constructor for class org.mule.module.ws.security.WssDecryptSecurityStrategy
 
WsSecurity - Class in org.mule.module.cxf.config
 
WsSecurity() - Constructor for class org.mule.module.cxf.config.WsSecurity
 
WSSecurity - Class in org.mule.module.ws.security
 
WSSecurity() - Constructor for class org.mule.module.ws.security.WSSecurity
 
WsSecurityDefinitionParser - Class in org.mule.module.cxf.config
 
WsSecurityDefinitionParser(Class) - Constructor for class org.mule.module.cxf.config.WsSecurityDefinitionParser
 
WssEncryptSecurityStrategy - Class in org.mule.module.ws.security
Verifies the signature of a SOAP response, using certificates of the trust-store in the provided TLS context.
WssEncryptSecurityStrategy() - Constructor for class org.mule.module.ws.security.WssEncryptSecurityStrategy
 
WssSignSecurityStrategy - Class in org.mule.module.ws.security
Signs the SOAP request that is being sent, using the private key of the key-store in the provided TLS context.
WssSignSecurityStrategy() - Constructor for class org.mule.module.ws.security.WssSignSecurityStrategy
 
WssTimestampSecurityStrategy - Class in org.mule.module.ws.security
 
WssTimestampSecurityStrategy() - Constructor for class org.mule.module.ws.security.WssTimestampSecurityStrategy
 
WssUsernameTokenSecurityStrategy - Class in org.mule.module.ws.security
 
WssUsernameTokenSecurityStrategy() - Constructor for class org.mule.module.ws.security.WssUsernameTokenSecurityStrategy
 
WssVerifySignatureSecurityStrategy - Class in org.mule.module.ws.security
Verifies the signature of a SOAP response, using certificates of the trust-store in the provided TLS context.
WssVerifySignatureSecurityStrategy() - Constructor for class org.mule.module.ws.security.WssVerifySignatureSecurityStrategy
 
WSTX_INPUT_FACTORY - Static variable in class org.mule.module.xml.util.XMLUtils
 
WWW_AUTHENTICATE - Static variable in class org.mule.module.http.api.HttpHeaders.Names

X

X_FORWARDED_FOR - Static variable in class org.mule.module.http.api.HttpHeaders.Names
X_PROPERTY_PREFIX - Static variable in class org.mule.transport.http.HttpConstants
 
X_RATE_LIMIT_LIMIT_HEADER - Static variable in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
X_RATE_LIMIT_LIMIT_HEADER - Static variable in class org.mule.transport.http.HttpMessageProcessTemplate
 
X_RATE_LIMIT_REMAINING_HEADER - Static variable in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
X_RATE_LIMIT_REMAINING_HEADER - Static variable in class org.mule.transport.http.HttpMessageProcessTemplate
 
X_RATE_LIMIT_RESET_HEADER - Static variable in class org.mule.module.http.internal.listener.HttpMessageProcessorTemplate
 
X_RATE_LIMIT_RESET_HEADER - Static variable in class org.mule.transport.http.HttpMessageProcessTemplate
 
XAConnectionFactoryWrapper - Interface in org.mule.transport.jms.xa
Wraps a XAConnectionFactory to support integration with XA transaction manager.
XaQueueTransactionContext - Interface in org.mule.util.queue
XA Transaction context for queues
XaQueueTxJournalEntry - Class in org.mule.util.journal.queue
Queue JournalEntry for XA transactions
XaQueueTxJournalEntry(Xid, byte, String, Serializable) - Constructor for class org.mule.util.journal.queue.XaQueueTxJournalEntry
 
XaQueueTxJournalEntry(Xid, byte) - Constructor for class org.mule.util.journal.queue.XaQueueTxJournalEntry
 
XaQueueTxJournalEntry(DataInputStream, MuleContext) - Constructor for class org.mule.util.journal.queue.XaQueueTxJournalEntry
 
XaQueueTypeTransactionContextAdapter - Class in org.mule.util.queue
 
XaQueueTypeTransactionContextAdapter(XaTxQueueTransactionJournal, QueueProvider, Xid) - Constructor for class org.mule.util.queue.XaQueueTypeTransactionContextAdapter
 
XAResourceFactory - Interface in org.mule.util.xa
Factory for XAResource implementations
XaResourceFactoryHolder - Interface in org.mule.util.xa
Implementations of this interface hold a reference to a factory of XAResource objects.
XAResourceWrapper - Class in org.mule.transport.jms.xa
 
XAResourceWrapper(XAResource, SessionInvocationHandler, Boolean) - Constructor for class org.mule.transport.jms.xa.XAResourceWrapper
 
XaTransactedJmsMessageReceiver - Class in org.mule.transport.jms
 
XaTransactedJmsMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.jms.XaTransactedJmsMessageReceiver
 
XaTransactedJmsMessageReceiver.JmsThreadContext - Class in org.mule.transport.jms
Holder receiving the session and consumer for this thread.
XaTransactedJmsMessageReceiver.JmsThreadContext() - Constructor for class org.mule.transport.jms.XaTransactedJmsMessageReceiver.JmsThreadContext
 
XaTransactedJmsMessageReceiver.ThreadContextLocal - Class in org.mule.transport.jms
Strongly typed ThreadLocal for ThreadContext.
XaTransactedJmsMessageReceiver.ThreadContextLocal() - Constructor for class org.mule.transport.jms.XaTransactedJmsMessageReceiver.ThreadContextLocal
 
XaTransaction - Class in org.mule.transaction
XaTransaction represents an XA transaction in Mule.
XaTransaction(MuleContext) - Constructor for class org.mule.transaction.XaTransaction
 
XaTransaction.MuleXaObject - Interface in org.mule.transaction
 
XaTransactionDefinitionParser - Class in org.mule.config.spring.parsers.specific
 
XaTransactionDefinitionParser(Class) - Constructor for class org.mule.config.spring.parsers.specific.XaTransactionDefinitionParser
 
XaTransactionFactory - Class in org.mule.transaction
XaTransactionFactory Is used to create/retrieve a Transaction from a transaction manager configured on the MuleManager.
XaTransactionFactory() - Constructor for class org.mule.transaction.XaTransactionFactory
 
XaTransactionRecoverer - Class in org.mule.util.xa
 
XaTransactionRecoverer(XaTxQueueTransactionJournal, QueueProvider) - Constructor for class org.mule.util.xa.XaTransactionRecoverer
 
XaTxQueueTransactionJournal - Class in org.mule.util.journal.queue
 
XaTxQueueTransactionJournal(String, MuleContext, Integer) - Constructor for class org.mule.util.journal.queue.XaTxQueueTransactionJournal
 
XaTxQueueTransactionJournal(String, MuleContext) - Constructor for class org.mule.util.journal.queue.XaTxQueueTransactionJournal
 
XML - Static variable in interface org.mule.transformer.types.MimeTypes
 
XML_INDENT_SIZE - Static variable in class org.mule.management.stats.printers.XMLPrinter
Indentation step for XML pretty-printing.
XML_INPUT_FACTORY - Static variable in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
XML_INPUT_PROPERTY - Static variable in class org.mule.util.xmlsecurity.DefaultXMLSecureFactories
 
XML_STRING - Static variable in class org.mule.transformer.types.DataTypeFactory
 
XMLEntityCodec - Class in org.mule.util
This encoder contains methods that convert characters to Character entities as defined by http://www.w3.org/TR/REC-html40/sgml/entities.html.
XMLEntityCodec() - Constructor for class org.mule.util.XMLEntityCodec
 
XmlEntityDecoder - Class in org.mule.transformer.codec
Decodes a String or byte[] containing XML entities
XmlEntityDecoder() - Constructor for class org.mule.transformer.codec.XmlEntityDecoder
 
XmlEntityEncoder - Class in org.mule.transformer.codec
Encodes a string with XML entities
XmlEntityEncoder() - Constructor for class org.mule.transformer.codec.XmlEntityEncoder
 
XMLExpressionLanguageExtension - Class in org.mule.module.xml.el
 
XMLExpressionLanguageExtension() - Constructor for class org.mule.module.xml.el.XMLExpressionLanguageExtension
 
XMLFactoryConfig - Class in org.mule.util.xmlsecurity
XMLFactoryConfig(DefaultXMLSecureFactories, String, String) - Constructor for class org.mule.util.xmlsecurity.XMLFactoryConfig
 
XmlInputFactoryInjectionProvider - Class in org.glassfish.jersey.message.internal
Thread-scoped injection provider of transformer factories.
XmlInputFactoryInjectionProvider(Configuration) - Constructor for class org.glassfish.jersey.message.internal.XmlInputFactoryInjectionProvider
Create new XML input factory provider.
XmlMessageEOFProtocol - Class in org.mule.transport.tcp.protocols
Extend XmlMessageProtocol to continue reading until either a new message or EOF is found.
XmlMessageEOFProtocol() - Constructor for class org.mule.transport.tcp.protocols.XmlMessageEOFProtocol
 
XmlMessageProtocol - Class in org.mule.transport.tcp.protocols
The XmlMessageProtocol is an application level tcp protocol that can be used to read streaming xml documents.
XmlMessageProtocol() - Constructor for class org.mule.transport.tcp.protocols.XmlMessageProtocol
 
XmlMessages - Class in org.mule.module.xml.i18n
 
XmlMessages() - Constructor for class org.mule.module.xml.i18n.XmlMessages
 
XmlMetadataAnnotations - Interface in org.mule.config.spring.parsers
Stores the metadata annotations from the XML parser so they are available when building the actual objects of the application.
XmlMetadataAnnotationsFactory - Interface in org.mule.config.spring
Factory object to get a fresh instance of a XmlMetadataAnnotations.
XmlNamespaceHandler - Class in org.mule.module.xml.config
 
XmlNamespaceHandler() - Constructor for class org.mule.module.xml.config.XmlNamespaceHandler
 
XmlPrettyPrinter - Class in org.mule.module.xml.transformer
 
XmlPrettyPrinter() - Constructor for class org.mule.module.xml.transformer.XmlPrettyPrinter
 
XMLPrinter - Class in org.mule.management.stats.printers
XMLPrinter prints event processing stats as a XML document
XMLPrinter(Writer) - Constructor for class org.mule.management.stats.printers.XMLPrinter
 
XMLPrinter(OutputStream) - Constructor for class org.mule.management.stats.printers.XMLPrinter
 
XMLSecureFactories - Class in org.mule.util.xmlsecurity
Provide XML parser factories configured to avoid XXE and BL attacks according to global configuration (safe by default)
XMLSecureFactoriesCache - Class in org.mule.util.xmlsecurity
Avoid configuring factories each time they are used.
XMLStreamCloser - Class in org.mule.module.xml.util
 
XMLStreamCloser() - Constructor for class org.mule.module.xml.util.XMLStreamCloser
 
XMLStreamReaderToByteArray - Class in org.mule.module.xml.transformer
Transforms an XMLStreamReader to a byte array.
XMLStreamReaderToByteArray() - Constructor for class org.mule.module.xml.transformer.XMLStreamReaderToByteArray
 
XMLStreamReaderToContentHandler - Class in org.mule.module.xml.stax
This is a simple utility class that adapts StAX events from an XMLStreamReader to SAX events on a ContentHandler, bridging between the two parser technologies.
XMLStreamReaderToContentHandler(XMLStreamReader, XMLFilterImplEx) - Constructor for class org.mule.module.xml.stax.XMLStreamReaderToContentHandler
Construct a new StAX to SAX adapter that will convert a StAX event stream into a SAX event stream.
XmlToDomDocument - Class in org.mule.module.xml.transformer
XmlToDomDocument transforms a XML String to org.w3c.dom.Document.
XmlToDomDocument() - Constructor for class org.mule.module.xml.transformer.XmlToDomDocument
 
XmlToJson - Class in org.mule.module.json.transformers
Convert XML to a JSON string
XmlToJson() - Constructor for class org.mule.module.json.transformers.XmlToJson
 
XmlToObject - Class in org.mule.module.xml.transformer
XmlToObject converts xml created by the ObjectToXml transformer in to a java object graph.
XmlToObject() - Constructor for class org.mule.module.xml.transformer.XmlToObject
 
XmlToOutputHandler - Class in org.mule.module.xml.transformer
 
XmlToOutputHandler() - Constructor for class org.mule.module.xml.transformer.XmlToOutputHandler
 
XmlToXMLStreamReader - Class in org.mule.module.xml.transformer
 
XmlToXMLStreamReader() - Constructor for class org.mule.module.xml.transformer.XmlToXMLStreamReader
 
XMLUtils - Class in org.mule.module.xml.util
General utility methods for working with XML.
XMLUtils() - Constructor for class org.mule.module.xml.util.XMLUtils
 
XMLUtils - Class in org.mule.util
These only depend on standard (JSE) XML classes and are used by Spring config code.
XMLUtils() - Constructor for class org.mule.util.XMLUtils
 
XMPP - Static variable in class org.mule.transport.xmpp.XmppConnector
 
XMPP_FROM - Static variable in class org.mule.transport.xmpp.XmppConnector
 
XMPP_GROUP_CHAT - Static variable in class org.mule.transport.xmpp.XmppConnector
 
XMPP_NICKNAME - Static variable in class org.mule.transport.xmpp.XmppConnector
 
XMPP_RECIPIENT - Static variable in class org.mule.transport.xmpp.XmppConnector
 
XMPP_RESOURCE - Static variable in class org.mule.transport.xmpp.XmppConnector
 
XMPP_SUBJECT - Static variable in class org.mule.transport.xmpp.XmppConnector
 
XMPP_THREAD - Static variable in class org.mule.transport.xmpp.XmppConnector
 
XMPP_TO - Static variable in class org.mule.transport.xmpp.XmppConnector
 
XMPP_TYPE - Static variable in class org.mule.transport.xmpp.XmppConnector
 
XmppAndFilter - Class in org.mule.transport.xmpp.filters
XmppAndFilter an Xmpp AND filter
XmppAndFilter() - Constructor for class org.mule.transport.xmpp.filters.XmppAndFilter
 
XmppAndFilter(PacketFilter, PacketFilter) - Constructor for class org.mule.transport.xmpp.filters.XmppAndFilter
 
XmppChatConversation - Class in org.mule.transport.xmpp
XmppConversation implementation that sends messages via Chat
XmppChatConversation(ImmutableEndpoint) - Constructor for class org.mule.transport.xmpp.XmppChatConversation
 
XmppConnector - Class in org.mule.transport.xmpp
XmppConnector represents a connection to a Jabber server.
XmppConnector(MuleContext) - Constructor for class org.mule.transport.xmpp.XmppConnector
 
XmppConversation - Interface in org.mule.transport.xmpp
Implementors of XmppConversation abstract from the XMPP conversation type (e.g.
XmppConversationFactory - Class in org.mule.transport.xmpp
A factory that creates XmppConversation instances based on the endpoint's configuration.
XmppConversationFactory() - Constructor for class org.mule.transport.xmpp.XmppConversationFactory
 
XmppEndpointURIBuilder - Class in org.mule.transport.xmpp
This endpoint builder ensures that a path is set on the URI as the path is the message type.
XmppEndpointURIBuilder() - Constructor for class org.mule.transport.xmpp.XmppEndpointURIBuilder
 
XmppFromContainsFilter - Class in org.mule.transport.xmpp.filters
XmppFromContainsFilter is an Xmpp FromContainsfilter adapter.
XmppFromContainsFilter() - Constructor for class org.mule.transport.xmpp.filters.XmppFromContainsFilter
 
XmppFromContainsFilter(String) - Constructor for class org.mule.transport.xmpp.filters.XmppFromContainsFilter
 
XmppMessageConversation - Class in org.mule.transport.xmpp
XmppConversation implementation for sending normal Jabber messages.
XmppMessageConversation(ImmutableEndpoint) - Constructor for class org.mule.transport.xmpp.XmppMessageConversation
 
XmppMessageDispatcher - Class in org.mule.transport.xmpp
Allows Mule events to be sent over Xmpp
XmppMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.xmpp.XmppMessageDispatcher
 
XmppMessageDispatcherFactory - Class in org.mule.transport.xmpp
Creates a dispatcher responsible for writing Xmpp packets to a an Jabber chat
XmppMessageDispatcherFactory() - Constructor for class org.mule.transport.xmpp.XmppMessageDispatcherFactory
 
XmppMessageReceiver - Class in org.mule.transport.xmpp
XmppMessageReceiver is responsible for receiving Mule events over XMPP.
XmppMessageReceiver(AbstractConnector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.xmpp.XmppMessageReceiver
 
XmppMessageRequester - Class in org.mule.transport.xmpp
Allows Mule messages to be received over XMPP
XmppMessageRequester(InboundEndpoint) - Constructor for class org.mule.transport.xmpp.XmppMessageRequester
 
XmppMessageRequesterFactory - Class in org.mule.transport.xmpp
Creates a dispatcher responsible for writing Xmpp packets to a an Jabber chat
XmppMessageRequesterFactory() - Constructor for class org.mule.transport.xmpp.XmppMessageRequesterFactory
 
XmppMessages - Class in org.mule.transport.xmpp.i18n
 
XmppMessages() - Constructor for class org.mule.transport.xmpp.i18n.XmppMessages
 
XmppMessageType - Enum in org.mule.transport.xmpp
This enum represents the XMPP message types that can be used in Mule.
XmppMessageTypeFilter - Class in org.mule.transport.xmpp.filters
XmppMessageTypeFilter is an Xmpp MessageTypeFilter adapter.
XmppMessageTypeFilter() - Constructor for class org.mule.transport.xmpp.filters.XmppMessageTypeFilter
 
XmppMessageTypeFilter(String) - Constructor for class org.mule.transport.xmpp.filters.XmppMessageTypeFilter
 
XmppMuleMessageFactory - Class in org.mule.transport.xmpp
 
XmppMuleMessageFactory() - Constructor for class org.mule.transport.xmpp.XmppMuleMessageFactory
 
XmppMultiUserChatConversation - Class in org.mule.transport.xmpp
 
XmppMultiUserChatConversation(ImmutableEndpoint) - Constructor for class org.mule.transport.xmpp.XmppMultiUserChatConversation
 
XmppNamespaceHandler - Class in org.mule.transport.xmpp.config
Registers a Bean Definition Parser for handling elements.
XmppNamespaceHandler() - Constructor for class org.mule.transport.xmpp.config.XmppNamespaceHandler
 
XmppNotFilter - Class in org.mule.transport.xmpp.filters
XmppNotFilter an Xmpp NOT filter
XmppNotFilter() - Constructor for class org.mule.transport.xmpp.filters.XmppNotFilter
 
XmppNotFilter(PacketFilter) - Constructor for class org.mule.transport.xmpp.filters.XmppNotFilter
 
XmppOrFilter - Class in org.mule.transport.xmpp.filters
XmppOrFilter an Xmpp OR filter
XmppOrFilter() - Constructor for class org.mule.transport.xmpp.filters.XmppOrFilter
 
XmppOrFilter(PacketFilter, PacketFilter) - Constructor for class org.mule.transport.xmpp.filters.XmppOrFilter
 
XmppPacketIDFilter - Class in org.mule.transport.xmpp.filters
XmppPacketIDFilter is an Xmpp PacketIDFilter adapter.
XmppPacketIDFilter() - Constructor for class org.mule.transport.xmpp.filters.XmppPacketIDFilter
 
XmppPacketIDFilter(String) - Constructor for class org.mule.transport.xmpp.filters.XmppPacketIDFilter
 
XmppPacketToObject - Class in org.mule.transport.xmpp.transformers
 
XmppPacketToObject() - Constructor for class org.mule.transport.xmpp.transformers.XmppPacketToObject
 
XmppPacketTypeFilter - Class in org.mule.transport.xmpp.filters
XmppPacketTypeFilter is an Xmpp PacketTypeFilter adapter.
XmppPacketTypeFilter() - Constructor for class org.mule.transport.xmpp.filters.XmppPacketTypeFilter
 
XmppPacketTypeFilter(Class<? extends Packet>) - Constructor for class org.mule.transport.xmpp.filters.XmppPacketTypeFilter
 
XmppPollingMessageReceiver - Class in org.mule.transport.xmpp
 
XmppPollingMessageReceiver(Connector, FlowConstruct, InboundEndpoint) - Constructor for class org.mule.transport.xmpp.XmppPollingMessageReceiver
 
XmppThreadFilter - Class in org.mule.transport.xmpp.filters
XmppThreadFilter is an Xmpp ThreadFilter adapter.
XmppThreadFilter() - Constructor for class org.mule.transport.xmpp.filters.XmppThreadFilter
 
XmppThreadFilter(String) - Constructor for class org.mule.transport.xmpp.filters.XmppThreadFilter
 
XmppToContainsFilter - Class in org.mule.transport.xmpp.filters
XmppToContainsFilter is an Xmpp ToContainsfilter adapter.
XmppToContainsFilter() - Constructor for class org.mule.transport.xmpp.filters.XmppToContainsFilter
 
XmppToContainsFilter(String) - Constructor for class org.mule.transport.xmpp.filters.XmppToContainsFilter
 
xor(boolean) - Method in class org.mule.util.concurrent.WaitableBoolean
 
XPath - Annotation Type in org.mule.api.annotations.expression
An expression annotation that allows developers to control how method parameter values are injected on a service component or transformer.
XPATH1_FALLBACK - Static variable in class org.mule.module.xml.util.XMLUtils
 
XPath3Function - Class in org.mule.module.xml.el
A MEL function capable of evaluation XPath expressions by delegating into an instance of XPathEvaluator

The function will now accept the following arguments (in order):

expression (required String) The Xpath expression to be evaluated.

XPathAnnotationParser - Class in org.mule.module.xml.config
Used to parse Bean parameter annotations.
XPathAnnotationParser() - Constructor for class org.mule.module.xml.config.XPathAnnotationParser
 
XPathBranchExpressionEvaluator - Class in org.mule.module.xml.expression
Deprecated.
This expression evaluator is deprecated and will be removed in Mule 4. Use XPath3Function instead
XPathBranchExpressionEvaluator() - Constructor for class org.mule.module.xml.expression.XPathBranchExpressionEvaluator
Deprecated.
 
XPathEvaluator - Interface in org.mule.module.xml.xpath
A simple component of evaluation XPath expressions in full conformance of the XPath 2.0 spec and basic conformance of the XPath 3.0 (everything except features which require schema awareness and high order functions).
XPathExpressionEvaluator - Class in org.mule.module.xml.expression
Deprecated.
This expression evaluator is deprecated and will be removed in Mule 4. Use XPath3Function instead
XPathExpressionEvaluator() - Constructor for class org.mule.module.xml.expression.XPathExpressionEvaluator
Deprecated.
 
XPathExtractor - Class in org.mule.module.xml.transformer
Simple transformer for using the JAXP XPath library to extract an XPath value from an XPath expression.
XPathExtractor() - Constructor for class org.mule.module.xml.transformer.XPathExtractor
 
XPathFilter - Class in org.mule.module.xml.filters
 
XPathFilter() - Constructor for class org.mule.module.xml.filters.XPathFilter
 
XPathFilter(String) - Constructor for class org.mule.module.xml.filters.XPathFilter
 
XPathFilter(String, String) - Constructor for class org.mule.module.xml.filters.XPathFilter
 
XPathFunction - Class in org.mule.module.xml.el
Deprecated.
this function is deprecated and will be removed in Mule 4.0. Use XPath3Function instead
XPathFunction(MuleContext) - Constructor for class org.mule.module.xml.el.XPathFunction
Deprecated.
 
XPathNodeExpressionEvaluator - Class in org.mule.module.xml.expression
Deprecated.
This expression evaluator is deprecated and will be removed in Mule 4. Use XPath3Function instead
XPathNodeExpressionEvaluator() - Constructor for class org.mule.module.xml.expression.XPathNodeExpressionEvaluator
Deprecated.
 
xpathResultTypeNotSupported(Class<?>) - Static method in class org.mule.module.xml.i18n.XmlMessages
 
XPathReturnType - Enum in org.mule.module.xml.xpath
An Enum listing the possible return types defined in the JAXP (JSR-206) without actually coupling to it.
XQueryTransformer - Class in org.mule.module.xml.transformer
The XQuery Module gives users the ability to perform XQuery transformations on XML messages in Mule
XQueryTransformer() - Constructor for class org.mule.module.xml.transformer.XQueryTransformer
 
XQueryTransformer(String) - Constructor for class org.mule.module.xml.transformer.XQueryTransformer
 
XQueryTransformer.PooledXQueryTransformerFactory - Class in org.mule.module.xml.transformer
 
XQueryTransformer.PooledXQueryTransformerFactory() - Constructor for class org.mule.module.xml.transformer.XQueryTransformer.PooledXQueryTransformerFactory
 
XSD_ANY - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_ANYSIMPLETYPE - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_ANYTYPE - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_ANYURI - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_BASE64 - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_BOOLEAN - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_BYTE - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_DATE - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_DATETIME - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_DAY - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_DECIMAL - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_DOUBLE - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_DURATION - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_ENTITIES - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_ENTITY - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_FLOAT - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_HEXBIN - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_ID - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_IDREF - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_IDREFS - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_INT - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_INTEGER - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_LANGUAGE - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_LONG - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_MONTH - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_MONTHDAY - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_NAME - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_NCNAME - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_NEGATIVEINTEGER - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_NMTOKEN - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_NMTOKENS - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_NONNEGATIVEINTEGER - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_NONPOSITIVEINTEGER - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_NORMALIZEDSTRING - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_NOTATION - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_PARAMETER_NAME - Static variable in class org.mule.module.cxf.support.ProxyWSDLQueryHandler
 
XSD_POSITIVEINTEGER - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_QNAME - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_SCHEMA - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_SHORT - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_STRING - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_TIME - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_TIMEINSTANT1999 - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_TIMEINSTANT2000 - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_TOKEN - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_UNSIGNEDBYTE - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_UNSIGNEDINT - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_UNSIGNEDLONG - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_UNSIGNEDSHORT - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_YEAR - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XSD_YEARMONTH - Static variable in class org.mule.transport.soap.axis.NamedParameter
 
XsltTextDefinitionParser - Class in org.mule.module.xml.config
TODO
XsltTextDefinitionParser(String) - Constructor for class org.mule.module.xml.config.XsltTextDefinitionParser
The class will be inferred from the class attribute
XsltTextDefinitionParser(String, Class) - Constructor for class org.mule.module.xml.config.XsltTextDefinitionParser
 
XsltTransformer - Class in org.mule.module.xml.transformer
XsltTransformer performs an XSLT transform on a DOM (or other XML-ish) object.
XsltTransformer() - Constructor for class org.mule.module.xml.transformer.XsltTransformer
 
XsltTransformer.DefaultErrorListener - Class in org.mule.module.xml.transformer
 
XsltTransformer.DefaultErrorListener(Transformer) - Constructor for class org.mule.module.xml.transformer.XsltTransformer.DefaultErrorListener
 
XsltTransformer.PooledXsltTransformerFactory - Class in org.mule.module.xml.transformer
 
XsltTransformer.PooledXsltTransformerFactory() - Constructor for class org.mule.module.xml.transformer.XsltTransformer.PooledXsltTransformerFactory
 
XsltTransformerDefinitionParser - Class in org.mule.module.xml.config
 
XsltTransformerDefinitionParser() - Constructor for class org.mule.module.xml.config.XsltTransformerDefinitionParser
 
XSTREAM_DOM4J_DRIVER - Static variable in class org.mule.module.xml.transformer.XStreamFactory
 
XSTREAM_DOM_DRIVER - Static variable in class org.mule.module.xml.transformer.XStreamFactory
 
XSTREAM_JDOM_DRIVER - Static variable in class org.mule.module.xml.transformer.XStreamFactory
 
XSTREAM_STAX_DRIVER - Static variable in class org.mule.module.xml.transformer.XStreamFactory
 
XSTREAM_XPP_DRIVER - Static variable in class org.mule.module.xml.transformer.XStreamFactory
 
XStreamFactory - Class in org.mule.module.xml.transformer
Initializes the XStream utility for converting Objects to XML and XML to Objects.
XStreamFactory() - Constructor for class org.mule.module.xml.transformer.XStreamFactory
 
XStreamFactory(String, Map<String, Class<?>>, Set<Class<? extends Converter>>) - Constructor for class org.mule.module.xml.transformer.XStreamFactory
 
XStreamWireFormat - Class in org.mule.module.xml.transformer.wire
Serializes objects using XStream.
XStreamWireFormat() - Constructor for class org.mule.module.xml.transformer.wire.XStreamWireFormat
 
XStreamWireFormat(String, Map, Set) - Constructor for class org.mule.module.xml.transformer.wire.XStreamWireFormat
 

Y

YourKitProfilerAgent - Class in org.mule.module.management.agent
 
YourKitProfilerAgent() - Constructor for class org.mule.module.management.agent.YourKitProfilerAgent
 
YourKitProfilerService - Class in org.mule.module.management.mbean
 
YourKitProfilerService() - Constructor for class org.mule.module.management.mbean.YourKitProfilerService
 
YourKitProfilerServiceMBean - Interface in org.mule.module.management.mbean
 

Z

ZIP - Static variable in class org.mule.module.ws.consumer.MuleWSDLLocator
 
ZIP_ARTIFACT_FILTER - Static variable in class org.mule.module.launcher.DeploymentDirectoryWatcher
 
ZIP_ARTIFACT_FILTER - Static variable in class org.mule.module.launcher.MuleDeploymentService
 
ZIP_FILE_SUFFIX - Static variable in class org.mule.module.launcher.DefaultArchiveDeployer
 

_

__DEFAULT_MULTIPART_CONFIG - Static variable in class org.mule.transport.http.multipart.MultiPartInputStream
 
_config - Variable in class org.mule.transport.http.multipart.MultiPartInputStream
 
_contentType - Variable in class org.mule.transport.http.multipart.MultiPartInputStream
 
_contentType - Variable in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
_file - Variable in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
_filename - Variable in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
_headers - Variable in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
_in - Variable in class org.mule.transport.http.multipart.MultiPartInputStream
 
_map - Variable in class org.mule.transport.http.multipart.MultiPartInputStream
 
_name - Variable in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
_out - Variable in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
_parts - Variable in class org.mule.transport.http.multipart.MultiPartInputStream
 
_size - Variable in class org.mule.transport.http.multipart.MultiPartInputStream.MultiPart
 
_tmpDir - Variable in class org.mule.transport.http.multipart.MultiPartInputStream
 
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 _ 

Copyright © 2003–2018 MuleSoft, Inc.. All rights reserved.