- AbstractAddVariablePropertyTransformer - Class in org.mule.transformer.simple
-
- AbstractAddVariablePropertyTransformer() - Constructor for class org.mule.transformer.simple.AbstractAddVariablePropertyTransformer
-
- AbstractAgent - Class in org.mule
-
Implements common methods for all Agents.
- AbstractAgent(String) - Constructor for class org.mule.AbstractAgent
-
- AbstractAggregator - Class in org.mule.routing
-
AbstractEventAggregator
will aggregate a set of messages into a
single message.
- AbstractAggregator() - Constructor for class org.mule.routing.AbstractAggregator
-
- AbstractAnnotatedObject - Class in org.mule
-
- AbstractAnnotatedObject() - Constructor for class org.mule.AbstractAnnotatedObject
-
- 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
-
- 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
-
- 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
-
- AbstractCatchAllStrategy - Class in org.mule.routing
-
Deprecated.
- AbstractCatchAllStrategy() - Constructor for class org.mule.routing.AbstractCatchAllStrategy
-
Deprecated.
- AbstractComponent - Class in org.mule.component
-
- 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
- AbstractConfigurationBuilder - Class in org.mule.config.builders
-
- AbstractConfigurationBuilder() - Constructor for class org.mule.config.builders.AbstractConfigurationBuilder
-
- AbstractConfigurationPattern - Class in org.mule.construct
-
A template class for configuration patterns, which takes care of setting common message processors and
optional transformers defined on the pattern.
- AbstractConfigurationPattern(String, MuleContext, List<MessageProcessor>, List<MessageProcessor>) - Constructor for class org.mule.construct.AbstractConfigurationPattern
-
- AbstractConnector - Class in org.mule.transport
-
AbstractConnector
provides base functionality for all connectors
provided with Mule.
- AbstractConnector(MuleContext) - Constructor for class org.mule.transport.AbstractConnector
-
- AbstractConsumer<T,P> - Class in org.mule.streaming
-
- 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
-
- AbstractDiscoverableTransformer - Class in org.mule.transformer
-
- AbstractDiscoverableTransformer() - Constructor for class org.mule.transformer.AbstractDiscoverableTransformer
-
- AbstractDynamicMessageProcessor - Class in org.mule.processor
-
- 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
-
- 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
-
- AbstractEndpointSecurityFilter - Class in org.mule.security
-
Deprecated.
- AbstractEndpointSecurityFilter() - Constructor for class org.mule.security.AbstractEndpointSecurityFilter
-
Deprecated.
- AbstractEndpointURIBuilder - Class in org.mule.endpoint
-
- 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
-
- 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
-
- AbstractExceptionStrategy(MuleContext) - Constructor for class org.mule.exception.AbstractExceptionStrategy
-
Deprecated.
- 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
-
- 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
-
- 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
-
- AbstractFilteringMessageProcessor() - Constructor for class org.mule.processor.AbstractFilteringMessageProcessor
-
- AbstractFlowConstruct - Class in org.mule.construct
-
- 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
-
- 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
-
- 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
-
- 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
-
- AbstractJCEEncryptionStrategy - Class in org.mule.security
-
A JCE based encryption strategy.
- AbstractJCEEncryptionStrategy() - Constructor for class org.mule.security.AbstractJCEEncryptionStrategy
-
- 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
-
- AbstractLifecycleManager<O> - Class in org.mule.lifecycle
-
- AbstractLifecycleManager(String, O) - Constructor for class org.mule.lifecycle.AbstractLifecycleManager
-
- AbstractMapContext<K,V> - Class in org.mule.el.context
-
- AbstractMapContext() - Constructor for class org.mule.el.context.AbstractMapContext
-
- AbstractMatchingRouter - Class in org.mule.routing
-
AbstractRouterCollection
provides common method implementations of router collections for in
and outbound routers.
- AbstractMatchingRouter() - Constructor for class org.mule.routing.AbstractMatchingRouter
-
- AbstractMessageAwareTransformer - Class in org.mule.transformer
-
Deprecated.
- AbstractMessageAwareTransformer() - Constructor for class org.mule.transformer.AbstractMessageAwareTransformer
-
Deprecated.
- AbstractMessageDispatcher - Class in org.mule.transport
-
Abstract implementation of an outbound channel adaptors.
- AbstractMessageDispatcher(OutboundEndpoint) - Constructor for class org.mule.transport.AbstractMessageDispatcher
-
- AbstractMessageDispatcherFactory - Class in org.mule.transport
-
AbstractMessageDispatcherFactory
is a base implementation of the
MessageDispatcherFactory
interface for managing the lifecycle of
message dispatchers.
- AbstractMessageDispatcherFactory() - Constructor for class org.mule.transport.AbstractMessageDispatcherFactory
-
- AbstractMessageProcessorChain - Class in org.mule.processor.chain
-
Builder needs to return a composite rather than the first MessageProcessor in the chain.
- AbstractMessageProcessorChain(String, List<MessageProcessor>) - Constructor for class org.mule.processor.chain.AbstractMessageProcessorChain
-
- AbstractMessageProcessorChainBuilder - Class in org.mule.processor.chain
-
Constructs a chain of
MessageProcessor
s 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
-
- AbstractMessageRequesterFactory() - Constructor for class org.mule.transport.AbstractMessageRequesterFactory
-
- AbstractMessageSequence<PayloadType> - Class in org.mule.routing
-
- AbstractMessageSequence() - Constructor for class org.mule.routing.AbstractMessageSequence
-
- AbstractMessageSequenceSplitter - Class in org.mule.routing.outbound
-
- 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
-
- 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.
- 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
-
- AbstractMuleObjectOwner<T> - Class in org.mule.processor
-
An object that owns Mule objects and delegates startup/shutdown events to them.
- AbstractMuleObjectOwner() - Constructor for class org.mule.processor.AbstractMuleObjectOwner
-
- AbstractNamedEncryptionStrategy - Class in org.mule.security
-
- AbstractNamedEncryptionStrategy() - Constructor for class org.mule.security.AbstractNamedEncryptionStrategy
-
- AbstractNonBlockingMessageProcessor - Class in org.mule.processor
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- AbstractQueueTransactionJournal<T,K extends JournalEntry<T>> - Class in org.mule.util.journal.queue
-
Base implementation for a queue transaction journal.
- AbstractQueueTransactionJournal(String, JournalEntrySerializer) - Constructor for class org.mule.util.journal.queue.AbstractQueueTransactionJournal
-
- AbstractQueueTxJournalEntry<T> - Class in org.mule.util.journal.queue
-
- 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
-
- AbstractReceiverWorker - Class in org.mule.transport
-
- 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
-
- 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
-
- AbstractRegistryBootstrap(RegistryBootstrapDiscoverer) - Constructor for class org.mule.config.bootstrap.AbstractRegistryBootstrap
-
- 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
-
- AbstractResourceManager() - Constructor for class org.mule.util.xa.AbstractResourceManager
-
- 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
-
- AbstractSecurityFilter - Class in org.mule.security
-
AbstractSecurityFilter
provides basic initialisation for
all security filters, namely configuring the SecurityManager for this instance
- AbstractSecurityFilter() - Constructor for class org.mule.security.AbstractSecurityFilter
-
- AbstractSecurityProvider - Class in org.mule.security
-
- AbstractSecurityProvider(String) - Constructor for class org.mule.security.AbstractSecurityProvider
-
- AbstractSelectiveRouter - Class in org.mule.routing
-
- AbstractSelectiveRouter() - Constructor for class org.mule.routing.AbstractSelectiveRouter
-
- 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
-
- AbstractService - Class in org.mule.service
-
Deprecated.
- AbstractService(MuleContext) - Constructor for class org.mule.service.AbstractService
-
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
-
- AbstractSingleResourceTransaction - Class in org.mule.transaction
-
This abstract class can be used as a base class for transactions that can enlist
only one resource (such as a JMS session or JDBC connection).
- AbstractSingleResourceTransaction(MuleContext) - Constructor for class org.mule.transaction.AbstractSingleResourceTransaction
-
- AbstractSplitter - Class in org.mule.routing
-
Splits a message invoking the next message processor one for each split part.
- AbstractSplitter() - Constructor for class org.mule.routing.AbstractSplitter
-
- AbstractSynchronizedVariable - Class in org.mule.util.concurrent
-
- AbstractSynchronizedVariable() - Constructor for class org.mule.util.concurrent.AbstractSynchronizedVariable
-
- AbstractSynchronizedVariable(Object) - Constructor for class org.mule.util.concurrent.AbstractSynchronizedVariable
-
- AbstractSystemExceptionStrategy - Class in org.mule.exception
-
Fire a notification, log exception, clean up transaction if any, and trigger reconnection strategy
if this is a ConnectException
.
- AbstractSystemExceptionStrategy(MuleContext) - Constructor for class org.mule.exception.AbstractSystemExceptionStrategy
-
- AbstractTablePrinter - Class in org.mule.management.stats.printers
-
HtmlTablePrinter
prints event processing stats as a HTML table
- AbstractTablePrinter(Writer) - Constructor for class org.mule.management.stats.printers.AbstractTablePrinter
-
- AbstractTablePrinter(OutputStream) - Constructor for class org.mule.management.stats.printers.AbstractTablePrinter
-
- AbstractThreadingProfileProcessingStrategy - Class in org.mule.processor.strategy
-
- AbstractThreadingProfileProcessingStrategy() - Constructor for class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
-
- 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
-
- AbstractVariableEnricherDataTypePropagator - Class in org.mule.el.mvel.datatype
-
- 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
-
- 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
-
- 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(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(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.
- 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
-
- 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
-
- ackExpression - Variable in class org.mule.construct.builder.ValidatorBuilder
-
- ackExpression(String) - Method in class org.mule.construct.builder.ValidatorBuilder
-
- acquireMessage() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
-
- action - Variable in class org.mule.api.context.notification.ServerNotification
-
- 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_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_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
-
- 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
-
- 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
-
- activate(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.AbstractMessageDispatcherFactory
-
- activate(InboundEndpoint, MessageRequester) - Method in class org.mule.transport.AbstractMessageRequesterFactory
-
- activate() - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- activate(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
-
- activate(InboundEndpoint, MessageRequester) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
-
- activateObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
-
- activateObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
-
- activeContexts - Variable in class org.mule.util.queue.objectstore.xa.AbstractXAResourceManager
-
Deprecated.
- activeContexts - Variable in class org.mule.util.xa.AbstractXAResourceManager
-
- add(FlowConstructStatistics) - Method in class org.mule.management.stats.AllStatistics
-
- 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.el.mvel.MVELExpressionLanguage
-
- addAlias(String, String) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
-
- 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
-
- 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.
- addArgument(ExpressionArgument) - Method in class org.mule.expression.transformers.AbstractExpressionTransformer
-
- addAttachment(String, DataHandler) - Method in interface org.mule.api.MuleMessage
-
- addAttachment(String, DataHandler) - Method in class org.mule.DefaultMuleMessage
-
Deprecated.
- addAttachments(DefaultMuleMessage, Object) - Method in class org.mule.transport.AbstractMuleMessageFactory
-
- AddAttachmentTransformer - Class in org.mule.transformer.simple
-
- AddAttachmentTransformer() - Constructor for class org.mule.transformer.simple.AddAttachmentTransformer
-
- addBody(String) - Method in class org.mule.util.SplashScreen
-
- 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
-
- addClassToSet(Class<T>, Set<Class<T>>, int) - Method in class org.mule.util.scan.ClasspathScanner
-
Deprecated.
- 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 branhc execution times
- addCompleteFlowExecutionTime(long) - Method in class org.mule.management.stats.FlowConstructStatistics
-
- addConverter(Converter) - Method in class org.mule.transformer.graph.TransformationGraph
-
- 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.
- addDirectTransition(String, String) - Method in class org.mule.lifecycle.AbstractLifecycleManager
-
- addEncryptionStrategy(EncryptionStrategy) - Method in interface org.mule.api.security.SecurityManager
-
- addEncryptionStrategy(EncryptionStrategy) - Method in class org.mule.security.MuleSecurityManager
-
- addEndpoint(MessageProcessor) - Method in class org.mule.exception.AbstractExceptionListener
-
- addEnrichExpressionPair(MessageEnricher.EnrichExpressionPair) - Method in class org.mule.enricher.MessageEnricher
-
- addEntryPointResolver(EntryPointResolver) - Method in interface org.mule.api.model.EntryPointResolverSet
-
Will add a resolver to the list of resolvers to invoke on a compoent.
- addEntryPointResolver(EntryPointResolver) - Method in class org.mule.model.resolvers.DefaultEntryPointResolverSet
-
- addEvent(MuleEvent) - Method in class org.mule.routing.EventGroup
-
Add the given event to this group.
- addEventGroup(EventGroup) - Method in class org.mule.routing.correlation.EventCorrelator
-
- addExceptionListener(AbstractFlowConstruct) - Method in class org.mule.construct.builder.AbstractFlowConstructBuilder
-
- addExecutionBranchTime(boolean, long, long) - Method in class org.mule.management.stats.ComponentStatistics
-
Add a new execution-time measurement for one branch of processing an event
- addExecutionTime(long) - Method in class org.mule.management.stats.ComponentStatistics
-
Add a new execution-time measurement for processing an event.
- addExpirable(long, TimeUnit, Expirable) - Method in class org.mule.util.monitor.ExpiryMonitor
-
Adds an expirable object to monitor.
- addFile(File) - Method in class org.mule.util.monitor.FileMonitor
-
Add file to listen for.
- 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
-
- addGlobalFunction(String, Function) - Method in class org.mule.el.mvel.MVELExpressionLanguage
-
- addIgnoredMethod(String) - Method in class org.mule.model.resolvers.ReflectionEntryPointResolver
-
- 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
-
- addLibrariesToClasspath(List) - Static method in class org.mule.util.ClassUtils
-
- 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(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
-
- 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
-
- 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.processor.AbstractInterceptingMessageProcessorBase
-
- addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.processor.AbstractMessageProcessorOwner
-
- addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.processor.AsyncDelegateMessageProcessor
-
- addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.processor.chain.AbstractMessageProcessorChain
-
- addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.processor.chain.SubflowInterceptingChainLifecycleWrapper
-
- addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.routing.AbstractSelectiveRouter
-
- addMessageProcessorPathElements(MessageProcessorPathElement) - Method in class org.mule.routing.Foreach
-
- addMessageProcessorPathElements(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
-
- 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
-
- 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
-
- addPart(Object, OutboundEndpoint) - Method in class org.mule.routing.outbound.SplitMessage
-
- addPrivateVariable(String, T) - Method in interface org.mule.api.el.ExpressionLanguageContext
-
Deprecated.
- addPrivateVariable(String, T) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
-
- 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(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
-
- AddPropertyTransformer - Class in org.mule.transformer.simple
-
- AddPropertyTransformer() - Constructor for class org.mule.transformer.simple.AddPropertyTransformer
-
- addProvider(SecurityProvider) - Method in interface org.mule.api.security.SecurityManager
-
- addProvider(SecurityProvider) - Method in class org.mule.security.MuleSecurityManager
-
- addQueueStore(QueueStore<Serializable>) - Method in class org.mule.config.QueueProfile
-
- 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.
- addResolver(String, VariableResolver) - Method in class org.mule.el.mvel.MuleBaseVariableResolverFactory
-
- 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
-
- 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
-
- AddSessionVariableTransformer - Class in org.mule.transformer.simple
-
- AddSessionVariableTransformer() - Constructor for class org.mule.transformer.simple.AddSessionVariableTransformer
-
- 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
-
- addStartupPropertiesConfigBuilder(List<ConfigurationBuilder>) - Method in class org.mule.MuleServer
-
- addToEnvironment(String, Object) - Method in class org.mule.jndi.SimpleContext
-
- 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
-
- 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
-
- addWork(Runnable) - Method in class org.mule.transport.ConcurrentWorkTracker
-
- addWork(Runnable) - Method in interface org.mule.transport.WorkTracker
-
Adds a work for tracking.
- ADMIN_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
-
- 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
-
- 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(MessagingException) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
-
- afterFailureProcessingFlow(MuleException) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
-
- afterRouteEvent(MuleEvent) - Method in interface org.mule.execution.FlowProcessingPhaseTemplate
-
- 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
-
- Agent - Interface in org.mule.api.agent
-
Agent
is a server plugin that can be initialised, started and
destroyed along with the MuleContext itself.
- agentsRunning() - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- Aggregator - Interface in org.mule.api.routing
-
- 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.endpoint.URIBuilder
-
- 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
-
- 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.QueuePersistenceObjectStore
-
Deprecated.
- allKeys() - Method in class org.mule.util.store.QueueStoreAdapter
-
Deprecated.
- allKeys() - Method in class org.mule.util.store.SimpleMemoryObjectStore
-
- 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
-
- 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
-
- 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
-
- AnnotatedObject - Interface in org.mule.api
-
- 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
- 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
-
- 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
-
- 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
-
- 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
-
- append(String, String) - Static method in class org.mule.transformer.simple.StringAppendTransformer
-
- appendJarFileEntries(File, LinkedHashMap) - Static method in class org.mule.util.JarUtils
-
- appendMessage(String) - Method in exception org.mule.api.MuleException
-
- APPLICATION - Static variable in class org.mule.api.transport.PropertyScope
-
This provides access to properties in the registry.
- APPLICATION_JSON - Static variable in interface org.mule.transformer.types.MimeTypes
-
- APPLICATION_NAME - Static variable in class org.mule.api.transport.PropertyScope
-
- APPLICATION_XML - Static variable in interface org.mule.transformer.types.MimeTypes
-
- applicationShutdownNormally(String, Date) - Static method in class org.mule.config.i18n.CoreMessages
-
- ApplicationShutdownSplashScreen - Class in org.mule.util
-
- ApplicationShutdownSplashScreen() - Constructor for class org.mule.util.ApplicationShutdownSplashScreen
-
- ApplicationStartupSplashScreen - Class in org.mule.util
-
- ApplicationStartupSplashScreen() - Constructor for class org.mule.util.ApplicationStartupSplashScreen
-
- ApplicationStatistics - Class in org.mule.management.stats
-
Aggregate statistics for all services and flows in an application.
- ApplicationStatistics(AllStatistics) - Constructor for class org.mule.management.stats.ApplicationStatistics
-
- applicationWasUpForDuration(long) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- 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.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
-
- 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
-
- 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
-
- 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
-
- ArrayEntryPointResolver - Class in org.mule.model.resolvers
-
Will resolver entry point methods on a service service that accept a single array.
- ArrayEntryPointResolver() - Constructor for class org.mule.model.resolvers.ArrayEntryPointResolver
-
- ArrayMessageSequence - Class in org.mule.routing.outbound
-
- ArrayMessageSequence(Object[]) - Constructor for class org.mule.routing.outbound.ArrayMessageSequence
-
- ArrayUtils - Class in org.mule.util
-
- ArrayUtils() - Constructor for class org.mule.util.ArrayUtils
-
- ArtifactType - Enum in org.mule.config.bootstrap
-
List the possible types of deployable artifacts
- 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.
- 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
-
- assertNonConsumableMessage(MuleEvent, MuleMessage) - Static method in class org.mule.routing.AbstractRoutingStrategy
-
- assertNotUsed() - Method in class org.mule.endpoint.URIBuilder
-
- assertProtocolConsistent() - Method in class org.mule.endpoint.URIBuilder
-
- assignValue(String, T, T) - Method in interface org.mule.api.el.VariableAssignmentCallback
-
- 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_REPLY_TIMEOUT - Static variable in class org.mule.context.notification.RoutingNotification
-
- AsyncDelegateMessageProcessor - Class in org.mule.processor
-
- AsyncDelegateMessageProcessor(MessageProcessor, ProcessingStrategy, String) - Constructor for class org.mule.processor.AsyncDelegateMessageProcessor
-
- asyncDoesNotSupportTransactions() - Static method in class org.mule.config.i18n.CoreMessages
-
- AsynchronousProcessingStrategy - Class in org.mule.processor.strategy
-
This strategy uses a WorkManager
to schedule the processing of the pipeline of message processors
in a single worker thread.
- AsynchronousProcessingStrategy() - Constructor for class org.mule.processor.strategy.AsynchronousProcessingStrategy
-
- AsynchronousRetryTemplate - Class in org.mule.retry.async
-
This class is a wrapper for a
RetryPolicyTemplate
and will execute any retry work within a separate thread.
- AsynchronousRetryTemplate(RetryPolicyTemplate) - Constructor for class org.mule.retry.async.AsynchronousRetryTemplate
-
- AsynchronousUntilSuccessfulProcessingStrategy - Class in org.mule.routing
-
Until successful asynchronous processing strategy.
- AsynchronousUntilSuccessfulProcessingStrategy() - Constructor for class org.mule.routing.AsynchronousUntilSuccessfulProcessingStrategy
-
- AsyncInterceptingMessageProcessor - Class in org.mule.processor
-
- AsyncInterceptingMessageProcessor(WorkManagerSource) - Constructor for class org.mule.processor.AsyncInterceptingMessageProcessor
-
- AsyncInterceptingMessageProcessor(ThreadingProfile, String, int) - Constructor for class org.mule.processor.AsyncInterceptingMessageProcessor
-
- 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
-
- 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
-
- AttachmentExpressionEnricher - Class in org.mule.expression
-
- AttachmentExpressionEnricher() - Constructor for class org.mule.expression.AttachmentExpressionEnricher
-
- ATTRIBUTE_OBJECT_CLASS - Static variable in class org.mule.object.AbstractObjectFactory
-
- ATTRIBUTE_OBJECT_CLASS_NAME - Static variable in class org.mule.object.AbstractObjectFactory
-
- 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
-
- attributeName(Attr) - Static method in class org.mule.util.XMLUtils
-
- 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) - 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.
- authenticateInbound(MuleEvent) - Method in class org.mule.security.AbstractEndpointSecurityFilter
-
Deprecated.
- authenticateInbound(MuleEvent) - Method in class org.mule.security.filters.MuleEncryptionEndpointSecurityFilter
-
- authenticateOutbound(MuleEvent) - Method in class org.mule.security.AbstractEndpointSecurityFilter
-
Deprecated.
- authenticateOutbound(MuleEvent) - Method in class org.mule.security.filters.MuleEncryptionEndpointSecurityFilter
-
- Authentication - Interface in org.mule.api.security
-
Authentication
represents an authentication request and contains
authentication information if the request was successful
- AuthenticationFilter - Interface in org.mule.api.security
-
AuthenticationFilter
is a base filter for authenticating messages.
- authFailedForUser(Object) - Static method in class org.mule.config.i18n.CoreMessages
-
- authNoCredentials() - Static method in class org.mule.config.i18n.CoreMessages
-
- authNoEncryptionStrategy(String) - Static method in class org.mule.config.i18n.CoreMessages
-
- authNoSecurityProvider(String) - Static method in class org.mule.config.i18n.CoreMessages
-
- authorizationAttemptFailed() - Static method in class org.mule.config.i18n.CoreMessages
-
- authorizationDeniedOnEndpoint(URI) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- 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
-
- 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() - 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
-
- CachingStrategy - Interface in org.mule.api.cache
-
Defines a way to process a
MuleEvent
using a cache.
- 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
-
- 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
-
- 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
-
- canClose(Class<?>) - Method in interface org.mule.api.util.StreamCloser
-
- 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
-
- cannotLoadFromClasspath(String) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- canTakeFromStore() - Method in class org.mule.util.queue.objectstore.QueueInfo
-
Deprecated.
- capacity - Variable in class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
-
Deprecated.
- capacity - Variable in class org.mule.util.queue.objectstore.QueueConfiguration
-
Deprecated.
- 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
-
- CaseInsensitiveHashMap - Class in org.mule.util
-
A case-insensitive Map
.
- CaseInsensitiveHashMap() - Constructor for class org.mule.util.CaseInsensitiveHashMap
-
Constructs a new empty map with default size and load factor.
- CaseInsensitiveHashMap(int) - Constructor for class org.mule.util.CaseInsensitiveHashMap
-
Constructs a new, empty map with the specified initial capacity.
- CaseInsensitiveHashMap(int, float) - Constructor for class org.mule.util.CaseInsensitiveHashMap
-
Constructs a new, empty map with the specified initial capacity and
load factor.
- CaseInsensitiveHashMap(Map) - Constructor for class org.mule.util.CaseInsensitiveHashMap
-
Constructor copying elements from another map.
- CaseInsensitiveMapWrapper<T> - Class in org.mule.util
-
Represents a Map from String to T
where the key's case is not taken into account when looking for it, but
remembered when the key set is retrieved from the map.
- CaseInsensitiveMapWrapper(Class<? extends Map>, Object...) - Constructor for class org.mule.util.CaseInsensitiveMapWrapper
-
- catchAll(MuleEvent) - Method in class org.mule.routing.outbound.DefaultOutboundRouterCollection
-
Deprecated.
- catchAllStrategy - Variable in class org.mule.service.ServiceCompositeMessageSource
-
Deprecated.
- CatchMessagingExceptionStrategy - Class in org.mule.exception
-
- CatchMessagingExceptionStrategy() - Constructor for class org.mule.exception.CatchMessagingExceptionStrategy
-
- category - Variable in class org.mule.api.processor.LoggerMessageProcessor
-
- causedBy(Class) - Method in exception org.mule.api.MessagingException
-
Evaluates if the exception was caused (instance of) by the provided exception
type
- causedExactlyBy(Class) - Method in exception org.mule.api.MessagingException
-
Evaluates if the exception was caused by the type and only the type provided
exception type i,e: if cause exception is NullPointerException will only
return true if provided exception type is NullPointerException
- causedRollback() - Method in exception org.mule.api.MessagingException
-
Signals if the exception cause rollback of any current transaction if any or
if the message source should rollback incoming message
- causeMatches(String) - Method in exception org.mule.api.MessagingException
-
Checks the cause exception type name matches the provided regex.
- 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
-
- 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.
- 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
-
- 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
-
- checkDisposed() - Method in class org.mule.registry.TransientRegistry
-
Deprecated.
- checkInboundExchangePattern() - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- checkKeyStoreContainsAlias(KeyStore) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- checkLifecycleForPropertySet(String, String) - Method in class org.mule.DefaultMuleContext
-
- 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
-
- checkReturnClass(Object, MuleEvent) - Method in class org.mule.transformer.AbstractMessageTransformer
-
Check if the return class is supported by this transformer
- checkState() - Method in class org.mule.retry.async.FutureRetryContext
-
- checkState(boolean, String) - Static method in class org.mule.util.Preconditions
-
- checkTransformerReturnClass(Transformer, Object) - Static method in class org.mule.transformer.TransformerUtils
-
Checks whether a given value is a valid output for a transformer.
- checkValidPayload() - Method in class org.mule.DefaultMessageCollection
-
- 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 single
MessageProcessor
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
-
- CLASS_PROPERTY - Static variable in class org.mule.transformer.simple.MapToBean
-
"className"
- 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_SPRING_CONFIG_BUILDER - Static variable in class org.mule.MuleServer
-
Required to support the '-config spring' shortcut.
- 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
-
- cleanDirectory(File) - Static method in class org.mule.util.FileUtils
-
Cleans a directory without deleting it.
- 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.el.context.InboundAttachmentMapContext
-
- clear() - Method in class org.mule.el.context.MessagePropertyMapContext
-
- clear() - Method in class org.mule.el.context.OutboundAttachmentMapContext
-
- clear() - Method in class org.mule.expression.InboundAttachmentsMap
-
- clear() - Method in class org.mule.expression.OutboundAttachmentsMap
-
- clear() - Method in class org.mule.expression.OutboundHeadersExpressionEvaluator.SendHeadersMap
-
- clear() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
-
- clear() - Method in class org.mule.management.stats.AllStatistics
-
- clear() - Method in class org.mule.management.stats.ComponentStatistics
-
- clear() - Method in class org.mule.management.stats.FlowConstructStatistics
-
- clear() - Method in class org.mule.management.stats.RouterStatistics
-
- clear() - Method in class org.mule.management.stats.SedaServiceStatistics
-
Deprecated.
- clear() - Method in class org.mule.management.stats.ServiceStatistics
-
Deprecated.
- 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.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.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.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.
- clearDispatchers() - Method in class org.mule.transport.AbstractConnector
-
- 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.
- 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
-
- 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
-
- clearSessionVariables() - Method in class org.mule.DefaultMuleEvent
-
- clearSessionVariables() - Method in class org.mule.VoidMuleEvent
-
- clearStoreCache() - Method in class org.mule.util.store.MuleObjectStoreManager
-
- CLI_OPTIONS - Static variable in class org.mule.MuleServer
-
- 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.endpoint.AbstractEndpointBuilder
-
- 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.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
-
- 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 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.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.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.QueueProducer
-
- close() - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
-
- close() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
-
- 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.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.
- 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
-
- closeQueueStore(QueueStore) - Method in class org.mule.util.queue.AbstractQueueManager
-
- closeQueueStore(QueueStore) - Method in interface org.mule.util.queue.QueueStoreCacheListener
-
- closeQuietly(Channel) - Static method in class org.mule.util.FileUtils
-
Unconditionally close a Channel
.
- closeResources() - Method in class org.mule.transaction.XaTransaction
-
- 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
-
- CollectAllAggregationStrategy - Class in org.mule.routing
-
- 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
-
- collectEventsWithoutExceptions() - Method in class org.mule.api.routing.AggregationContext
-
- CollectionCorrelatorCallback - Class in org.mule.routing.correlation
-
A Correlator that correlates messages based on Mule correlation settings
- CollectionCorrelatorCallback(MuleContext, boolean, String) - Constructor for class org.mule.routing.correlation.CollectionCorrelatorCallback
-
- CollectionDataType<T> - Class in org.mule.transformer.types
-
A data type that represents a generified collection.
- CollectionDataType(Class<? extends Collection>) - Constructor for class org.mule.transformer.types.CollectionDataType
-
Creates an untyped collection data type
- CollectionDataType(Class<? extends Collection>, String) - Constructor for class org.mule.transformer.types.CollectionDataType
-
- CollectionDataType(Class<? extends Collection>, Class, String) - Constructor for class org.mule.transformer.types.CollectionDataType
-
- CollectionDataType(Class<? extends Collection>, Class) - Constructor for class org.mule.transformer.types.CollectionDataType
-
- CollectionMessageSequence<T> - Class in org.mule.routing.outbound
-
- 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
-
- 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.
- 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
-
- COMMA - Static variable in class org.mule.transformer.TransformerUtils
-
- commit() - Method in interface org.mule.api.transaction.Transaction
-
Commit the transaction
- commit() - Method in class org.mule.exception.AbstractExceptionListener
-
- commit() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
-
- commit() - Method in class org.mule.transaction.AbstractTransaction
-
- 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
-
- 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
-
- 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
-
- 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
-
- ComparableWatermarkSelector() - Constructor for class org.mule.transport.polling.watermark.selector.ComparableWatermarkSelector
-
- 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(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
-
- complement() - Method in class org.mule.util.concurrent.WaitableBoolean
-
- completedPhases - Variable in class org.mule.lifecycle.AbstractLifecycleManager
-
- 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
-
- 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
- componentNotRegistered(String) - Static method in class org.mule.config.i18n.CoreMessages
-
- componentObject - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
-
- ComponentStatistics - Class in org.mule.management.stats
-
- ComponentStatistics() - Constructor for class org.mule.management.stats.ComponentStatistics
-
The constructor added to initialize the interval time in ms that stats
are measured for from the property statIntervalTime.
- composeName(String, String) - Method in class org.mule.jndi.SimpleContext
-
- composeName(Name, Name) - Method in class org.mule.jndi.SimpleContext
-
- 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
-
- CompositeMessageSource - Interface in org.mule.api.source
-
- 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
-
- CompositeRoutingException(MuleEvent, Map<Integer, Throwable>) - Constructor for exception org.mule.routing.CompositeRoutingException
-
- 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
-
- 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
-
- 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.
- configNotFoundUsage() - Static method in class org.mule.config.i18n.CoreMessages
-
- ConfigResource - Class in org.mule.config
-
A ConfigResource holds the url description (or location) and the url stream.
- ConfigResource(String) - Constructor for class org.mule.config.ConfigResource
-
- ConfigResource(URL) - Constructor for class org.mule.config.ConfigResource
-
- ConfigResource(String, InputStream) - Constructor for class org.mule.config.ConfigResource
-
- configResources - Variable in class org.mule.config.builders.AbstractResourceConfigurationBuilder
-
- ConfigurableKeyedObjectPool - Interface in org.mule.transport
-
A configurable KeyedObjectPool
.
- ConfigurableKeyedObjectPoolFactory - Interface in org.mule.transport
-
- 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
-
- 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
-
- 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.
- configureBinding(JavaComponent, Object) - Static method in class org.mule.component.BindingUtils
-
- configureComponentMessageProcessor(MuleContext, MessageProcessorChainBuilder, Component) - Method in enum org.mule.construct.SimpleService.Type
-
- configureContext(ExpressionLanguageContext) - Method in interface org.mule.api.el.ExpressionLanguageExtension
-
- configured - Variable in class org.mule.config.builders.AbstractConfigurationBuilder
-
- configureDefaultQueueSize(QueueProfile, ThreadingProfile) - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
-
- configureDispatcherPool() - Method in class org.mule.transport.AbstractConnector
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- connect() - Method in interface org.mule.api.transport.Connectable
-
Make the connection to the underlying transport.
- connect() - Method in class org.mule.transport.AbstractConnector
-
- connect() - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- Connectable - Interface in org.mule.api.transport
-
Interface for objects that should connect to a resource.
- ConnectableLifecycleManager<O> - Class in org.mule.transport
-
TODO
- ConnectableLifecycleManager(String, O) - Constructor for class org.mule.transport.ConnectableLifecycleManager
-
- connected - Variable in class org.mule.transport.AbstractTransportMessageHandler
-
- ConnectException - Exception in org.mule.transport
-
When this exception is thrown it will trigger a retry (reconnection) policy to go into effect if one is configured.
- ConnectException(Message, Connectable) - Constructor for exception org.mule.transport.ConnectException
-
- ConnectException(Message, Throwable, Connectable) - Constructor for exception org.mule.transport.ConnectException
-
- ConnectException(Throwable, Connectable) - Constructor for exception org.mule.transport.ConnectException
-
- connectHandler() - Method in class org.mule.transport.AbstractMessageReceiver
-
- connectHandler() - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- CONNECTION_CONNECTED - Static variable in class org.mule.context.notification.ConnectionNotification
-
- CONNECTION_DISCONNECTED - Static variable in class org.mule.context.notification.ConnectionNotification
-
- CONNECTION_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
-
- CONNECTION_FAILED - Static variable in class org.mule.context.notification.ConnectionNotification
-
- 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.
- ConnectNotifier - Class in org.mule.retry.notifiers
-
- 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.DefaultReplyToHandler
-
- 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_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_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
-
- 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
-
- 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
-
- 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.
- connectorSchemeIncompatibleWithEndpointScheme(Object, Object) - Static method in class org.mule.config.i18n.CoreMessages
-
- connectorWithProtocolNotRegistered(String) - Static method in class org.mule.config.i18n.CoreMessages
-
- ConstraintFilter - Class in org.mule.transaction.constraints
-
- ConstraintFilter() - Constructor for class org.mule.transaction.constraints.ConstraintFilter
-
- 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.
- ConsumerIterator<T> - Class in org.mule.streaming
-
- ConsumerIterator(Consumer<T>) - Constructor for class org.mule.streaming.ConsumerIterator
-
- containerAlreadyRegistered(String) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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.
- 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.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.QueueStoreAdapter
-
Deprecated.
- 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.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
-
- 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.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.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_TYPE_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
-
- 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.transaction.lookup.GenericTransactionManagerLookupFactory
-
- 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
-
- 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
-
- 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.
- 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.
- convertNumberToTargetClass(Number, Class<T>) - Static method in class org.mule.util.NumberUtils
-
- copy(MuleEvent) - Static method in class org.mule.DefaultMuleEvent
-
This method does a complete deep copy of the event.
- CopyAttachmentsTransformer - Class in org.mule.transformer.simple
-
- CopyAttachmentsTransformer() - Constructor for class org.mule.transformer.simple.CopyAttachmentsTransformer
-
- copyFile(File, File, boolean) - Static method in class org.mule.util.FileUtils
-
Copies a file to a new location.
- 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
-
- CopyPropertiesTransformer - Class in org.mule.transformer.simple
-
- CopyPropertiesTransformer() - Constructor for class org.mule.transformer.simple.CopyPropertiesTransformer
-
- 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
- CoreExtensionsAware - Interface in org.mule
-
- CoreMessages - Class in org.mule.config.i18n
-
- CoreMessages() - Constructor for class org.mule.config.i18n.CoreMessages
-
- 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
MuleEvent
s using their respective correlation sequences.
- CorrelationSequenceComparator() - Constructor for class org.mule.routing.correlation.CorrelationSequenceComparator
-
- correlationTimedOut(Object) - Static method in class org.mule.config.i18n.CoreMessages
-
- CorrelationTimeoutException - Exception in org.mule.routing.correlation
-
- CorrelationTimeoutException(Message, MuleEvent) - Constructor for exception org.mule.routing.correlation.CorrelationTimeoutException
-
- CorrelationTimeoutException(Message, MuleEvent, Throwable) - Constructor for exception org.mule.routing.correlation.CorrelationTimeoutException
-
- couldNotDetermineDestinationComponentFromEndpoint(String) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- count - Variable in class org.mule.retry.policies.SimpleRetryPolicyTemplate
-
- COUNT_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
-
- 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
-
- 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
-
- countRetry() - Method in class org.mule.retry.policies.SimpleRetryPolicy.RetryCounter
-
- 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(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.KeyedPoolMessageDispatcherFactoryAdapter
-
- create(InboundEndpoint) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
-
- create(Work, WorkListener) - Method in class org.mule.transport.TrackerWorkListenerWrapperFactory
-
- create(OutboundEndpoint) - Method in class org.mule.transport.UnsupportedMessageDispatcherFactory
-
- create(InboundEndpoint) - Method in class org.mule.transport.UnsupportedMessageRequesterFactory
-
- create(Work, WorkListener) - Method in interface org.mule.transport.WorkListenerWrapperFactory
-
- 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
-
- 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.
- createAndInitCiphers() - Method in class org.mule.security.AbstractJCEEncryptionStrategy
-
- createAndInitCiphers() - Method in class org.mule.security.SecretKeyEncryptionStrategy
-
Deprecated.
- createAntStyleParser() - Static method in class org.mule.util.TemplateParser
-
- 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.
- createBeginNotification(MuleEvent) - Method in class org.mule.endpoint.outbound.OutboundNotificationMessageProcessor
-
- createCheckpointJournalEntry(T, byte) - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
-
- createCheckpointJournalEntry(Integer, byte) - Method in class org.mule.util.journal.queue.LocalTxQueueTransactionJournal
-
- createCheckpointJournalEntry(Xid, byte) - Method in class org.mule.util.journal.queue.XaTxQueueTransactionJournal
-
- createConfigResourcesString() - Method in class org.mule.config.builders.AbstractResourceConfigurationBuilder
-
- createConfiguration() - Method in class org.mule.config.PropertiesMuleConfigurationFactory
-
- createConfigurationBuilder() - Method in class org.mule.MuleServer
-
- 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
-
- 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
-
- 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
-
- 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
-
- createDefaultProcessingStrategy() - Method in class org.mule.construct.Flow
-
- createDefaultRedeliveryPolicy(int) - Method in interface org.mule.api.endpoint.InboundEndpoint
-
- createDefaultRedeliveryPolicy(int) - Method in interface org.mule.api.transport.Connector
-
- createDefaultRedeliveryPolicy(int) - Method in class org.mule.endpoint.DefaultInboundEndpoint
-
- createDefaultRedeliveryPolicy(int) - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
-
- createDefaultRedeliveryPolicy(int) - Method in class org.mule.transport.AbstractConnector
-
- createDefaultUserObjectStore() - Method in interface org.mule.util.store.DefaultObjectStoreFactory
-
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(QueueInfo, MuleContext) - Method in interface org.mule.util.queue.objectstore.QueueInfo.QueueInfoDelegateFactory
-
Deprecated.
Create a delegate
- 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
-
- createEndpointBuilder(String) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
-
- createEndpointBuilder(EndpointURIEndpointBuilder) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
-
- createEndpointBuilder(Object[]) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
-
- createEndpointBuilder(String) - Method in interface org.mule.transport.service.TransportServiceDescriptor
-
- createEndpointBuilder(EndpointURIEndpointBuilder) - Method in interface org.mule.transport.service.TransportServiceDescriptor
-
- 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
-
- 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
-
- 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
-
- createExpressionLanguageContext() - Method in class org.mule.el.mvel.MVELExpressionLanguage
-
- createFile(String) - Static method in class org.mule.util.FileUtils
-
- createFileToStoreObject() - Method in class org.mule.util.store.PersistentObjectStorePartition
-
- 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
-
- createHeader(String, char[]) - Static method in class org.mule.security.MuleCredentials
-
- createHeader(String, String, String, EncryptionStrategy) - Static method in class org.mule.security.MuleCredentials
-
- 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
-
- createInnerChain(LinkedList<MessageProcessor>) - Method in class org.mule.processor.chain.DefaultMessageProcessorChainBuilder
-
- createInnerChain(LinkedList<MessageProcessor>) - Method in class org.mule.processor.chain.SimpleMessageProcessorChainBuilder
-
- createJarFileEntries(File, LinkedHashMap) - Static method in class org.mule.util.JarUtils
-
- createJdkVersionRanges(String) - Static method in class org.mule.util.JdkVersionUtils
-
- 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.
- 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.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
-
- 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
-
- 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.
- 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
.
- createMessageFromSource(Object) - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
-
- createMessageIdStore() - Method in class org.mule.routing.IdempotentMessageFilter
-
- 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
-
- createModel() - Method in interface org.mule.api.model.ModelServiceDescriptor
-
Deprecated.
- createModel() - Method in class org.mule.model.DefaultModelServiceDescriptor
-
Deprecated.
- createMuleConfiguration() - Method in class org.mule.context.DefaultMuleContextBuilder
-
- 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
-
- 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() - 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.
- createMuleContextBuilder() - Method in class org.mule.context.DefaultMuleContextFactory
-
- createMuleEvent(MuleMessage, OutboundEndpoint) - Method in class org.mule.client.DefaultLocalMuleClient
-
- createMuleEvent(MuleMessage, OutputStream) - Method in class org.mule.transport.AbstractMessageReceiver
-
- 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
-
- createMuleMessage(Object, String) - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- createMuleMessage(Object) - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- 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.service.DefaultTransportServiceDescriptor
-
- createMuleMessageFactory() - Method in interface org.mule.transport.service.TransportServiceDescriptor
-
- createMuleStyleParser() - Static method in class org.mule.util.TemplateParser
-
- createMuleWorkManager() - Method in class org.mule.context.DefaultMuleContextBuilder
-
- createMultipleTransactedReceivers - Variable in class org.mule.transport.AbstractConnector
-
- 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
-
- createNullMuleMessage() - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- 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
-
- createOrRetrievePartitionDescriptorFile() - Method in class org.mule.util.store.PersistentObjectStorePartition
-
- createOutboundEndpoint(EndpointURI, List<MessageProcessor>, List<MessageProcessor>, Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- 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
-
- createParserConfiguration(Map<String, Class<?>>) - Static method in class org.mule.el.mvel.MVELExpressionLanguage
-
- 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
-
- 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
-
- createProcessorExecutor(MuleEvent, List<MessageProcessor>, MessageProcessorExecutionTemplate, boolean) - Method in class org.mule.processor.chain.ProcessorExecutorFactory
-
- 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
-
- 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
- createRegistryBroker() - Method in class org.mule.DefaultMuleContext
-
- createRegistryHelper(DefaultRegistryBroker) - Method in class org.mule.DefaultMuleContext
-
- createReplyToHandler(MuleEvent) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
-
- 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
-
- 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
-
- 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
-
- 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
-
- createScheduler() - Method in class org.mule.transport.AbstractConnector
-
- createScopeExecutionTemplate(MuleContext, TransactionConfig, MessagingExceptionHandler) - Static method in class org.mule.execution.TransactionalErrorHandlingExecutionTemplate
-
Creates a TransactionalErrorHandlingExecutionTemplate for inner scopes within a flow
- 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
-
- 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
-
- createServiceDescriptor(ServiceType, String, Properties) - Method in class org.mule.registry.MuleRegistryHelper
-
- createSessionHandler() - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
-
- createSessionHandler() - Method in interface org.mule.transport.service.TransportServiceDescriptor
-
- 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, int) - Static method in class org.mule.util.TimedSocket
-
Creates a socket and waits until the given timeout is reached.
- createSquareBracesStyleParser() - Static method in class org.mule.util.TemplateParser
-
- 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.
- 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
-
- createSubcontext(Name) - Method in class org.mule.jndi.SimpleContext
-
- createSubcontext(String) - Method in class org.mule.jndi.SimpleContext
-
- createThreadingProfile(MuleContext) - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
-
- createTransactionalExecutionTemplate(MuleContext, TransactionConfig) - Static method in class org.mule.execution.TransactionalExecutionTemplate
-
Creates a ExecutionTemplate that will manage transactional context according to configured TransactionConfig
- 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
-
- 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
-
- createUnboundTransaction(MuleContext) - Method in interface org.mule.api.transaction.UnboundTransactionFactory
-
- 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.util.MuleUrlStreamHandlerFactory
-
- 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
-
- 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
-
- createWithEncoding(Class<T>, String) - Static method in class org.mule.transformer.types.DataTypeFactory
-
- createWork() - Method in class org.mule.transport.AbstractPollingMessageReceiver
-
- 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(FlowConstruct) - Method in class org.mule.processor.strategy.NonBlockingProcessingStrategy
-
- 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
- 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.
- cryptoFailure() - 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.
- currentlyProcessing - Variable in class org.mule.util.scan.annotations.AnnotationsScanner
-
Deprecated.
- currentPhase - Variable in class org.mule.lifecycle.AbstractLifecycleManager
-
- 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
-
- 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(..)
.
- 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
-
- 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
-
- 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
-
- Date - Interface in org.mule.api.el.datetime
-
- DATE_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
-
- 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
-
- deadLetterQueue - Variable in class org.mule.processor.AbstractRedeliveryPolicy
-
- debug(Object) - Method in class org.mule.util.MuleLogger
-
- debug(Object, Throwable) - Method in class org.mule.util.MuleLogger
-
- DebugUtils - Class in org.mule.util
-
Useful for enumerating debug information about the current Java environment
- declareFunction(String, ExpressionLanguageFunction) - Method in interface org.mule.api.el.ExpressionLanguageContext
-
- declareFunction(String, ExpressionLanguageFunction) - Method in class org.mule.el.mvel.MVELExpressionLanguageContext
-
- 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.
- 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.
- 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
- 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.security.AbstractJCEEncryptionStrategy
-
- decrypt(byte[], Object) - Method in class org.mule.security.AbstractJCEEncryptionStrategy
-
- decrypt(byte[], Object) - Method in class org.mule.security.AbstractNamedEncryptionStrategy
-
- 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
-
- DEFAULT - Static variable in class org.mule.util.ObjectNameHelper
-
- 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_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.util.compression.GZipCompression
-
- 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_DATE_FORMAT - Static variable in class org.mule.expression.FunctionExpressionEvaluator
-
- DEFAULT_DESCRIPTION_BUFFER_SIZE - Static variable in class org.mule.agent.Log4jNotificationLoggerAgent
-
- DEFAULT_DO_THREADING - Static variable in interface org.mule.api.config.ThreadingProfile
-
Default value for do threading
- 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_EXPRESSION_POSTFIX - Static variable in interface org.mule.api.expression.ExpressionManager
-
- DEFAULT_EXPRESSION_PREFIX - Static variable in interface org.mule.api.expression.ExpressionManager
-
- DEFAULT_FLAGS - Static variable in class org.mule.util.scan.ClasspathScanner
-
Deprecated.
- DEFAULT_FREQUENCY - Static variable in class org.mule.retry.policies.SimpleRetryPolicyTemplate
-
- DEFAULT_ITERATION_COUNT - Static variable in class org.mule.security.PasswordBasedEncryptionStrategy
-
- 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_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_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_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_MESSAGE_WIDTH - Static variable in class org.mule.util.StringMessageUtils
-
- DEFAULT_METHOD_NAME_TOKEN - Static variable in class org.mule.component.BindingInvocationHandler
-
- 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_MODEL_NAME - Static variable in class org.mule.model.AbstractModel
-
Deprecated.
- DEFAULT_NUM_CONCURRENT_TX_RECEIVERS - Static variable in class org.mule.transport.AbstractConnector
-
Default number of concurrent transactional receivers.
- DEFAULT_PARTITION - Static variable in class org.mule.util.store.AbstractPartitionedObjectStore
-
- DEFAULT_POLL_FREQUENCY - Static variable in class org.mule.transport.AbstractPollingMessageReceiver
-
- DEFAULT_POLL_TIMEUNIT - Static variable in class org.mule.transport.AbstractPollingMessageReceiver
-
- 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_PRIORITY_WEIGHTING - Static variable in interface org.mule.api.transformer.Converter
-
- 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_RELOAD_CONTROL - Static variable in class org.mule.config.i18n.MessageFactory
-
Default is ReloadControl.Always
.
- DEFAULT_RETRY_COUNT - Static variable in class org.mule.retry.policies.SimpleRetryPolicyTemplate
-
- 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_SLEEP_MILLIS - Static variable in class org.mule.transport.TrackingWorkManager
-
- 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_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_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
-
- 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
-
- DefaultConfigurableKeyedObjectPool() - Constructor for class org.mule.transport.DefaultConfigurableKeyedObjectPool
-
- DefaultConfigurableKeyedObjectPoolFactory - Class in org.mule.transport
-
- DefaultConfigurableKeyedObjectPoolFactory() - Constructor for class org.mule.transport.DefaultConfigurableKeyedObjectPoolFactory
-
- 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
-
- 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
-
- defaultHandler(Throwable) - Method in class org.mule.exception.AbstractMessagingExceptionStrategy
-
Deprecated.
Override doHandleException(Exception e, MuleEvent event) instead
- 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
-
- DefaultInterfaceBinding - Class in org.mule.component
-
- DefaultInterfaceBinding() - Constructor for class org.mule.component.DefaultInterfaceBinding
-
- DefaultJavaComponent - Class in org.mule.component
-
- 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
-
- DefaultLifecycleEnabledObjectPool - Class in org.mule.util.pool
-
- DefaultLifecycleEnabledObjectPool(ObjectFactory, PoolingProfile, MuleContext) - Constructor for class org.mule.util.pool.DefaultLifecycleEnabledObjectPool
-
- DefaultLifecycleManager<T extends Lifecycle> - Class in org.mule.lifecycle
-
- 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
- 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
-
- 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
- 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
MessageProcessor
s 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
-
- DefaultModelServiceDescriptor - Class in org.mule.model
-
- DefaultModelServiceDescriptor(String, Properties) - Constructor for class org.mule.model.DefaultModelServiceDescriptor
-
- 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
-
- 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
-
- DefaultMuleContextBuilder() - Constructor for class org.mule.context.DefaultMuleContextBuilder
-
- DefaultMuleContextFactory - Class in org.mule.context
-
- DefaultMuleContextFactory() - Constructor for class org.mule.context.DefaultMuleContextFactory
-
- 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
-
- 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) - 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.
- DefaultObjectSerializer - Annotation Type in org.mule.api.serialization
-
- 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.
- 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
-
- 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
-
- 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
-
- 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
-
- defaultResponseTransformers - Variable in class org.mule.transport.AbstractMessageDispatcher
-
- defaultResponseTransformers - Variable in class org.mule.transport.AbstractMessageReceiver
-
- 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
-
- 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
-
- 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
-
- DefaultServiceExceptionStrategy() - Constructor for class org.mule.exception.DefaultServiceExceptionStrategy
-
Deprecated.
- DefaultServiceExceptionStrategy(MuleContext) - Constructor for class org.mule.exception.DefaultServiceExceptionStrategy
-
Deprecated.
- 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
-
- DefaultThreadingProfileConfig - Class in org.mule.api.config
-
- 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
-
- 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
-
- 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
-
- delay(long) - Method in class org.mule.routing.EventProcessingThread
-
- delayTime - Variable in class org.mule.routing.EventProcessingThread
-
- delegate - Variable in class org.mule.el.mvel.DelegateVariableResolverFactory
-
- delegate - Variable in class org.mule.processor.AsyncDelegateMessageProcessor
-
- 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.
- DelegatingInputStream - Class in org.mule.model.streaming
-
- DelegatingInputStream(InputStream) - Constructor for class org.mule.model.streaming.DelegatingInputStream
-
- 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
-
- 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
-
- 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.expression.ExpressionConstants
-
- delist() - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
-
- 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
-
- 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
-
- dequeue() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
-
- 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.
- descriptorAlreadyExists(String) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- destroy(OutboundEndpoint, MessageDispatcher) - Method in interface org.mule.api.transport.MessageDispatcherFactory
-
- destroy(InboundEndpoint, MessageRequester) - Method in interface org.mule.api.transport.MessageRequesterFactory
-
- destroy(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.AbstractMessageDispatcherFactory
-
- destroy(InboundEndpoint, MessageRequester) - Method in class org.mule.transport.AbstractMessageRequesterFactory
-
- destroy(OutboundEndpoint, MessageDispatcher) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
-
- destroy(InboundEndpoint, MessageRequester) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
-
- destroyObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
-
- destroyObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
-
- destroyReceiver(MessageReceiver, ImmutableEndpoint) - Method in class org.mule.transport.AbstractConnector
-
- destroySubcontext(Name) - Method in class org.mule.jndi.SimpleContext
-
- destroySubcontext(String) - Method in class org.mule.jndi.SimpleContext
-
- directory - Variable in class org.mule.util.store.TextFileObjectStore
-
- dirty - Variable in class org.mule.util.queue.objectstore.xa.AbstractResourceManager
-
Deprecated.
- dirty - Variable in class org.mule.util.xa.AbstractResourceManager
-
- DISABLE_SYSTEM_PROPERTIES_MAPPING_PROPERTY - Static variable in class org.mule.api.security.tls.TlsConfiguration
-
- disableInterface(Class<? extends ServerNotificationListener>) - Method in class org.mule.context.notification.ServerNotificationManager
-
- disableNativeScheduling() - Method in class org.mule.transport.AbstractPollingMessageReceiver
-
- disableTransportTransformer - Variable in class org.mule.endpoint.AbstractEndpointBuilder
-
- disableType(Class<? extends ServerNotification>) - Method in class org.mule.context.notification.ServerNotificationManager
-
- discardInvalidMessage() - Method in interface org.mule.execution.ValidationPhaseTemplate
-
Discards the message because the validation failed
- discardInvalidMessage() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
-
- discardMessageOnThrottlingExceeded() - Method in interface org.mule.execution.ThrottlingPhaseTemplate
-
Discards the message due to ThrottlingPolicy configured for the
MessageSource
is exceeded
- disconnect() - Method in interface org.mule.api.transport.Connectable
-
Disconnect the from the underlying transport
- disconnect() - Method in class org.mule.transport.AbstractConnector
-
- disconnect() - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- 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.
- 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
-
- dispatch(String, Object, Map<String, Object>) - Method in interface org.mule.api.client.MuleClient
-
- 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
-
- 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
- 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
-
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 interface org.mule.api.MuleEventContext
-
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(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(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
-
- dispatchNotification(EndpointMessageNotification) - Method in class org.mule.endpoint.outbound.OutboundNotificationMessageProcessor
-
- 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.
- 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.construct.AbstractFlowConstruct
-
- dispose() - Method in class org.mule.context.notification.ServerNotificationManager
-
- dispose() - Method in class org.mule.DefaultMuleContext
-
- 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.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.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.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.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.polling.schedule.FixedFrequencyScheduler
-
- dispose() - Method in class org.mule.transport.TrackingWorkManager
-
- 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
-
- 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.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
-
- 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) - Static method in class org.mule.api.lifecycle.LifecycleUtils
-
- disposeIfNeeded(Object, Logger) - Static method in class org.mule.api.lifecycle.LifecycleUtils
-
- disposeMethod - Variable in class org.mule.component.DefaultComponentLifecycleAdapter
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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(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(String) - Method in class org.mule.util.SplashScreen
-
- doBuildInboundEndpoint() - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- doBuildOutboundEndpoint() - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- 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.
- 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 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.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
-
- 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
-
- 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.polling.MessageProcessorPollingConnector
-
- doConnect() - Method in class org.mule.transport.UnsupportedMessageDispatcher
-
- doConnect() - Method in class org.mule.transport.UnsupportedMessageRequester
-
- 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, T) - Method in class org.mule.transport.polling.schedule.FixedFrequencySchedulerFactory
-
- doCreateMuleContext(MuleContextBuilder, DefaultMuleContextFactory.ContextConfigurator) - Method in class org.mule.context.DefaultMuleContextFactory
-
- 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
.
- 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.polling.MessageProcessorPollingConnector
-
- doDisconnect() - Method in class org.mule.transport.UnsupportedMessageDispatcher
-
- doDisconnect() - Method in class org.mule.transport.UnsupportedMessageRequester
-
- doDispatch(MuleEvent) - Method in class org.mule.transport.AbstractMessageDispatcher
-
- doDispatch(MuleEvent) - Method in class org.mule.transport.UnsupportedMessageDispatcher
-
- 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.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.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.polling.MessageProcessorPollingConnector
-
- doDispose() - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
-
- doDispose() - Method in class org.mule.transport.UnsupportedMessageDispatcher
-
- doDispose() - Method in class org.mule.transport.UnsupportedMessageRequester
-
- 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(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
-
- doFilter(MuleEvent) - Method in interface org.mule.api.security.SecurityFilter
-
- 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.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.
- doHandleException(Exception, MuleEvent) - Method in class org.mule.exception.AbstractMessagingExceptionStrategy
-
- 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
-
- 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.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.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.transport.AbstractConnector
-
- doInitialise() - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- 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.UnsupportedMessageDispatcher
-
- doInitialise() - Method in class org.mule.transport.UnsupportedMessageRequester
-
- 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.
- doLoad(QueueInfo, Serializable) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
-
Deprecated.
- 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.
- DONT_BREAK_LINES - Static variable in class org.mule.util.Base64
-
Don't break lines when encoding (violates strict Base64 specification)
- 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.
- 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.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
-
- 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.
- 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, 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.
- 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.UnsupportedMessageRequester
-
- 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.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 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
-
- doRun() - Method in class org.mule.routing.EventProcessingThread
-
Detect and process events
- 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.UnsupportedMessageDispatcher
-
- 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.
- doShutdown() - Method in class org.mule.MuleServer
-
- 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.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.polling.MessageProcessorPollingConnector
-
- doStart() - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
-
- doStart() - Method in class org.mule.transport.TransactedPollingMessageReceiver
-
- doStart() - Method in class org.mule.transport.UnsupportedMessageDispatcher
-
- doStart() - Method in class org.mule.transport.UnsupportedMessageRequester
-
- 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.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.polling.MessageProcessorPollingConnector
-
- doStop() - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
-
- doStop() - Method in class org.mule.transport.UnsupportedMessageDispatcher
-
- doStop() - Method in class org.mule.transport.UnsupportedMessageRequester
-
- 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
-
- doThreading - Variable in class org.mule.processor.AsyncInterceptingMessageProcessor
-
- 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
-
- 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.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.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
-
- DualRandomAccessFileQueueStoreDelegate - Class in org.mule.util.queue
-
- DualRandomAccessFileQueueStoreDelegate(String, String, MuleContext, int) - Constructor for class org.mule.util.queue.DualRandomAccessFileQueueStoreDelegate
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- echo(String) - Method in interface org.mule.api.component.simple.EchoService
-
- echo(String) - Method in class org.mule.component.simple.EchoComponent
-
- 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
-
- elementToString(Element) - Static method in class org.mule.util.XMLUtils
-
- EMPTY_EVENTS_ARRAY - Static variable in class org.mule.routing.EventGroup
-
- EmptyLifecycleCallback<O> - Class in org.mule.lifecycle
-
A lifecycle callback that does nothing.
- EmptyLifecycleCallback() - Constructor for class org.mule.lifecycle.EmptyLifecycleCallback
-
- 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
-
- 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.
- 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.
- 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.
- encoding - Variable in class org.mule.endpoint.AbstractEndpointBuilder
-
- 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.security.AbstractJCEEncryptionStrategy
-
- encrypt(byte[], Object) - Method in class org.mule.security.AbstractJCEEncryptionStrategy
-
- encrypt(byte[], Object) - Method in class org.mule.security.AbstractNamedEncryptionStrategy
-
- encryptCipher - Variable in class org.mule.security.AbstractJCEEncryptionStrategy
-
- 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) - 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
-
- 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
-
- 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
-
- EndPhaseTemplate - Interface in org.mule.execution
-
- endpoint - Variable in exception org.mule.api.exception.MessageRedeliveredException
-
- 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.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_PREFIX - Static variable in class org.mule.util.ObjectNameHelper
-
- 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_REGISTRY_PREFIX - Static variable in class org.mule.endpoint.DefaultEndpointFactory
-
- 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.
- 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
-
- 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
-
- endpoints - Variable in class org.mule.service.ServiceCompositeMessageSource
-
Deprecated.
- 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.
- EndpointTransactionalInterceptingMessageProcessor - Class in org.mule.processor
-
- 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
-
- EndProcessPhase - Class in org.mule.execution
-
- EndProcessPhase() - Constructor for class org.mule.execution.EndProcessPhase
-
- enlist() - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
-
- 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
-
- 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
-
- 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.
- 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.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.registry.TransientRegistry.RegistryMap
-
Deprecated.
- 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.
- 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.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.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.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.NullPayload
-
- 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.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(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
- errorExpression - Variable in class org.mule.construct.builder.ValidatorBuilder
-
- errorExpression(String) - Method in class org.mule.construct.builder.ValidatorBuilder
-
- 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.
- errorInvokingMessageProcessorAsynchronously(MessageProcessor) - Static method in class org.mule.config.i18n.CoreMessages
-
- errorInvokingMessageProcessorWithinTransaction(MessageProcessor, TransactionConfig) - Static method in class org.mule.config.i18n.CoreMessages
-
- errorReadingStream() - Static method in class org.mule.config.i18n.CoreMessages
-
- errorSchedulingMessageProcessorForAsyncInvocation(MessageProcessor) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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(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.routing.correlation.CorrelationPropertiesExpressionEvaluator
-
- 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
-
- 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
-
- 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
-
- event - Variable in exception org.mule.api.MessagingException
-
The MuleEvent being processed when the error occurred
- event - Variable in class org.mule.processor.BlockingProcessorExecutor
-
- event - Variable in class org.mule.work.AbstractMuleEventWork
-
- EVENT_NAME - Variable in class org.mule.api.context.notification.ServerNotification
-
- 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, boolean, String) - 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
- 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, boolean, 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
-
- eventGroups - Variable in class org.mule.routing.correlation.EventCorrelator
-
A map of EventGroup objects.
- 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
-
- 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_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.
- 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
-
- 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.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.processor.TransactionalInterceptingMessageProcessor
-
- exceptionListener - Variable in class org.mule.service.AbstractService
-
Deprecated.
The exception strategy used by the service.
- 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.
- 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.
- exceptionStackIs() - Static method in class org.mule.config.i18n.CoreMessages
-
- exceptionStrategy(MessagingExceptionHandler) - Method in class org.mule.construct.builder.AbstractFlowConstructBuilder
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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() - 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(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
-
- executeNext() - Method in class org.mule.processor.BlockingProcessorExecutor
-
- executeNext() - Method in class org.mule.service.processor.ServiceProcessorExecutor
-
- executingPhase - Variable in class org.mule.lifecycle.AbstractLifecycleManager
-
- 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
-
- ExecutionContext() - Constructor for class org.mule.execution.ExecutionContext
-
- ExecutionTemplate<T> - Interface in org.mule.api.execution
-
ExecutionTemplate provides an execution context for message processing.
- expectedSize() - Method in class org.mule.routing.EventGroup
-
Returns the number of events that this EventGroup is expecting before
correlation can proceed.
- 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
-
- 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.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
-
- 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.
- expired() - Method in interface org.mule.util.monitor.Expirable
-
- 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
-
- expression - Variable in class org.mule.el.ExpressionLanguageComponent
-
- EXPRESSION_SEPARATOR - Static variable in class org.mule.expression.ExpressionConfig
-
- 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
-
- 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
-
- 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: org.mule.config.spring.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
-
- 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: org.mule.config.spring.SpringRegistry
)
- ExpressionEvaluatorProcessor(MuleContext) - Constructor for class org.mule.registry.ExpressionEvaluatorProcessor
-
Deprecated.
- expressionEvaluatorReturnedNull(String, String) - Static method in class org.mule.config.i18n.CoreMessages
-
- ExpressionExecutor<T extends ExpressionLanguageContext> - Interface in org.mule.api.el
-
Wraps an expression language engine.
- expressionExecutor - Variable in class org.mule.el.mvel.MVELExpressionLanguage
-
- expressionFile - Variable in class org.mule.el.ExpressionLanguageComponent
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- ExpressionUtils - Class in org.mule.expression
-
Used by the different header expression evaluators to read message properties, honuouring scope and return type
- 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
-
- 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
-
- extractCredentials(InboundEndpoint) - Method in class org.mule.DefaultMuleEvent
-
- extractMuleMessage(MuleEvent) - Method in exception org.mule.api.MessagingException
-
- extractPayload(Object, String) - Method in class org.mule.transport.AbstractMuleMessageFactory
-
- extractPayload(Object, String) - Method in class org.mule.transport.DefaultMuleMessageFactory
-
- 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
- generateEventId(MuleContext) - Method in class org.mule.DefaultMuleEvent
-
- 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
-
- 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
-
- 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() - 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(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(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
-
- getAcceptedTime() - Method in class org.mule.work.WorkerContext
-
System.currentTimeMillis() when the Work has been accepted.
- 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
-
- 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
-
- 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.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
-
- 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
-
- getAliases() - Method in class org.mule.el.mvel.MVELExpressionLanguage
-
- getAllAnnotations() - Method in class org.mule.util.scan.annotations.AnnotationsScanner
-
Deprecated.
- getAllFieldAnnotations(Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
-
- 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
-
- getAnnotation(QName) - Method in class org.mule.AbstractAnnotatedObject
-
- getAnnotation(QName) - Method in interface org.mule.api.AnnotatedObject
-
Gets the value of specified annotation.
- 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.processor.AbstractMessageProcessorOwner
-
- getApplicationName() - Method in class org.mule.context.notification.TransactionNotification
-
- getApplicationStatistics() - Method in class org.mule.management.stats.AllStatistics
-
- getArgs() - Method in class org.mule.config.i18n.Message
-
- getArguments() - Method in class org.mule.expression.transformers.AbstractExpressionTransformer
-
- getAsString() - Method in enum org.mule.config.bootstrap.ArtifactType
-
- getAsyncEventsReceived() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
-
- getAsyncEventsReceived() - Method in class org.mule.management.stats.ApplicationStatistics
-
- getAsyncEventsSent() - Method in class org.mule.management.stats.ServiceStatistics
-
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
-
- 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
-
- 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
-
- getAttachmentNames() - Method in interface org.mule.api.MuleMessage
-
- getAttachmentNames() - Method in class org.mule.DefaultMuleMessage
-
Deprecated.
- getAuthentication() - Method in interface org.mule.api.security.SecurityContext
-
- getAuthentication() - Method in class org.mule.security.DefaultSecurityContext
-
- getAuthenticationToken(MuleEvent) - Method in class org.mule.security.UsernamePasswordAuthenticationFilter
-
- getAuthority() - Method in interface org.mule.api.endpoint.EndpointURI
-
- getAuthority() - Method in class org.mule.endpoint.MuleEndpointURI
-
- getAverageExecutionTime() - Method in class org.mule.management.stats.ComponentStatistics
-
- getAverageExecutionTime() - Method in class org.mule.management.stats.ServiceStatistics
-
Deprecated.
- getAverageProcessingTime() - Method in class org.mule.management.stats.ApplicationStatistics
-
- getAverageProcessingTime() - Method in class org.mule.management.stats.FlowConstructStatistics
-
- getAverageQueueSize() - Method in class org.mule.management.stats.FlowConstructStatistics
-
- getAverageQueueSize() - Method in class org.mule.management.stats.ServiceStatistics
-
Deprecated.
- getBase() - Method in class org.mule.util.counters.impl.AggregateCounter
-
- getBaseStore() - Method in class org.mule.util.store.ObjectStorePartition
-
- getBaseStore() - Method in class org.mule.util.store.PartitionedObjectStoreWrapper
-
- 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.
- getBeanClass() - Method in class org.mule.expression.transformers.BeanBuilderTransformer
-
- getBeanFactory() - Method in class org.mule.expression.transformers.BeanBuilderTransformer
-
- 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
-
- 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(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
-
- getBranchQualifier() - Method in class org.mule.util.xa.MuleXid
-
- getBuildDate() - Static method in class org.mule.config.MuleManifest
-
- getBuildNumber() - Static method in class org.mule.config.MuleManifest
-
- 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
.
- 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
-
- getCacheKeyForPayload(Object, Object[]) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
-
- 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
- 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
-
- 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
-
- 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
-
- getCauseException() - Method in exception org.mule.api.MessagingException
-
- getChainsawHost() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
-
- getChainsawPort() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
-
- getChildren() - Method in class org.mule.api.processor.DefaultMessageProcessorPathElement
-
- getChildren() - Method in interface org.mule.api.processor.MessageProcessorPathElement
-
- getClass(String) - Method in class org.mule.config.bootstrap.AbstractRegistryBootstrap
-
- getClassAndMethodAnnotations(Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
-
- 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
-
- getClassAnnotationInHierarchy(Class<?>) - Static method in class org.mule.util.annotation.AnnotationUtils
-
- getClassAnnotations() - Method in class org.mule.util.scan.annotations.AnnotationsScanner
-
Deprecated.
- 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.
- 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.
- 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
-
- getClient() - Method in interface org.mule.api.MuleContext
-
- getClient() - Method in class org.mule.DefaultMuleContext
-
- getClientKeyStore() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getClientKeyStore() - Method in interface org.mule.api.security.TlsIndirectKeyStore
-
- getClientKeyStorePassword() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getClientKeyStorePassword() - Method in interface org.mule.api.security.TlsIndirectKeyStore
-
- getClientKeyStoreType() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getClientKeyStoreType() - Method in interface org.mule.api.security.TlsIndirectKeyStore
-
- 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 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
-
- getCompiledExpression(String) - Method in class org.mule.el.mvel.MVELExpressionExecutor
-
Compile an expression.
- 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.
- getComponentName() - Method in class org.mule.message.ExceptionMessage
-
- 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.
- getComponentStat() - Method in class org.mule.management.stats.ServiceStatistics
-
Deprecated.
- getComponentStatistics() - Method in class org.mule.management.stats.AllStatistics
-
Deprecated.
use #getServiceStatistics
- getConditionalMessageProcessors() - Method in class org.mule.routing.AbstractSelectiveRouter
-
- getConfigBuilderClassName() - Static method in class org.mule.MuleServer
-
Returns the class name of the configuration builder used to create this
MuleServer.
- getConfiguration() - Method in interface org.mule.api.MuleContext
-
- getConfiguration() - Method in class org.mule.DefaultMuleContext
-
- getConfigurationAnnotations() - Method in interface org.mule.api.MuleContext
-
Return all annotations seen in the configuration
- getConfigurationAnnotations() - Method in class org.mule.DefaultMuleContext
-
- getConfigurationResources() - Method in class org.mule.MuleServer
-
Getter for property messengerURL.
- 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
-
- 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
- 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.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.transport.AbstractTransportMessageHandler
-
- getConnector() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
-
- getConnector() - Method in class org.mule.transport.DefaultReplyToHandler
-
- getConnectorByProtocol(String) - Method in class org.mule.transport.service.TransportFactory
-
- getConnectorName() - Method in interface org.mule.api.endpoint.EndpointURI
-
- getConnectorName() - Method in class org.mule.endpoint.MuleEndpointURI
-
- getConnectorName(Connector) - Method in class org.mule.util.ObjectNameHelper
-
- getConnectors() - Method in interface org.mule.api.registry.MuleRegistry
-
Deprecated.
Use lookupConnector() instead
- getConnectors() - Method in class org.mule.registry.MuleRegistryHelper
- 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
-
- getContentType() - Method in class org.mule.message.ds.ByteArrayDataSource
-
- getContentType() - Method in class org.mule.message.ds.StringDataSource
-
- getContentType(DataType<?>) - Static method in class org.mule.util.DataTypeUtils
-
Generates a HTTP content type for a given data type
- getContext() - Method in class org.mule.object.JndiObjectFactory
-
- getContext() - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
-
- getContextClassLoader() - Method in class org.mule.util.concurrent.NamedThreadFactory
-
- getConverters() - Method in class org.mule.transformer.CompositeConverter
-
- 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(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
-
- 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
-
- 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
-
- 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.
- 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.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.security.AbstractAuthenticationFilter
-
- 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
-
- getData() - Method in class org.mule.component.simple.StaticComponent
-
- getDataFile() - Method in class org.mule.component.simple.StaticComponent
-
- 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
-
- getDate() - Method in class org.mule.el.datetime.DateTime
-
- getDateFromString(String, String) - Static method in class org.mule.util.DateUtils
-
- getDateTime() - Method in class org.mule.el.context.ServerContext
-
- 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
-
- getDeadLetterQueue() - Method in class org.mule.routing.UntilSuccessful
-
- getDeclaringClass() - Method in class org.mule.util.generics.MethodParameter
-
Return the class that declares the underlying Method or Constructor.
- 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.
- 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
-
- getDefaultCompressionStrategy() - Static method in class org.mule.util.compression.CompressionHelper
-
- 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
-
- 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
-
- 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
-
- getDefaultObjectSerializer() - Method in class org.mule.config.DefaultMuleConfiguration
-
- getDefaultOutboundTransformers(TransportServiceDescriptor, ImmutableEndpoint) - Static method in class org.mule.transformer.TransformerUtils
-
- getDefaultOutboundTransformers(ImmutableEndpoint) - Method in class org.mule.transport.AbstractConnector
-
- getDefaultProcessingStrategy() - Method in interface org.mule.api.config.MuleConfiguration
-
- getDefaultProcessingStrategy() - Method in class org.mule.config.DefaultMuleConfiguration
-
- 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
-
- 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.
- 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.
- getDelegate() - Method in class org.mule.retry.async.AsynchronousRetryTemplate
-
- getDeleteProperties() - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
-
- 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
-
- 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.retry.async.FutureRetryContext
-
- getDescription() - Method in class org.mule.retry.DefaultRetryContext
-
- getDetailedMessage() - Method in exception org.mule.api.MuleException
-
- getDevListEmail() - Static method in class org.mule.config.MuleManifest
-
- getDirectory() - Method in class org.mule.util.store.TextFileObjectStore
-
- 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
-
- getDispatcherThreadingProfile() - Method in class org.mule.transport.AbstractConnector
-
Getter for property 'dispatcherThreadingProfile'.
- 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
-
- getDocUrl(Class<?>) - Static method in class org.mule.config.ExceptionHelper
-
- getDomain() - Method in class org.mule.context.notification.MuleContextNotification
-
- getDomainId() - Method in interface org.mule.api.config.MuleConfiguration
-
- getDomainId() - Method in class org.mule.config.DefaultMuleConfiguration
-
- 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
-
- getEffectiveTime(long) - Static method in class org.mule.management.stats.ProcessingTime
-
Convert processing time to effective processing time.
- getElementName() - Method in class org.mule.util.annotation.AnnotationMetaData
-
- 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
-
- 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.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.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.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.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
-
- 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() - 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
-
- 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
-
- 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(EndpointURI) - Method in class org.mule.util.ObjectNameHelper
-
- getEndpointNameFor(EndpointURI) - Static method in class org.mule.util.ObjectNameHelper
-
- getEndpoints() - Method in interface org.mule.api.registry.MuleRegistry
-
- 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.transport.AbstractMessageReceiver
-
- 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.jndi.SimpleContext
-
- 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
-
- 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
-
- getEvent() - Method in exception org.mule.api.MessagingException
-
- getEvent() - Method in interface org.mule.api.security.Authentication
-
- getEvent() - Static method in class org.mule.RequestContext
-
Deprecated.
- getEvent() - Method in class org.mule.security.DefaultMuleAuthentication
-
- getEvent() - Method in class org.mule.work.AbstractMuleEventWork
-
- 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.
- getEventGroup() - Method in exception org.mule.routing.AggregationException
-
- getEventGroup(Serializable) - 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
-
- getEvents() - Method in class org.mule.api.routing.AggregationContext
-
- 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.retry.async.RetryWorker
-
- getExceptionCode() - Method in exception org.mule.api.MuleException
-
- 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
-
- getExceptionThrown() - Method in class org.mule.context.notification.MessageProcessorNotification
-
- 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
-
- 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.VoidMuleEvent
-
- getExecutedEvents() - Method in class org.mule.management.stats.ComponentStatistics
-
- getExecutedEvents() - Method in class org.mule.management.stats.ServiceStatistics
-
Deprecated.
- getExecutingPhase() - Method in interface org.mule.api.lifecycle.LifecycleManager
-
Returns the lifecycle phase being executed.
- getExecutingPhase() - Method in class org.mule.lifecycle.AbstractLifecycleManager
-
- 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.transport.TransportMessageProcessContext
-
- getExecutionErrors() - Method in class org.mule.management.stats.ApplicationStatistics
-
- getExecutionErrors() - Method in class org.mule.management.stats.FlowConstructStatistics
-
- getExhaustedAction() - Method in class org.mule.config.PoolingProfile
-
- getExpectedType() - Method in class org.mule.routing.filters.PayloadTypeFilter
-
- getExpirationInterval() - Method in class org.mule.util.store.AbstractMonitoredObjectStore
-
- getExpirationInterval() - Method in class org.mule.util.store.ManagedObjectStore
-
- 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.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
-
- 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
- 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
-
- getFactory() - Method in interface org.mule.api.transaction.TransactionConfig
-
- getFactory() - Method in class org.mule.transaction.MuleTransactionConfig
-
- 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
-
- getFatalErrors() - Method in class org.mule.management.stats.ApplicationStatistics
-
- getFatalErrors() - Method in class org.mule.management.stats.FlowConstructStatistics
-
- getFetchSize() - Method in class org.mule.streaming.PagingConfiguration
-
- getFieldAnnotations(Class<?>, Class<? extends Annotation>) - Static method in class org.mule.util.annotation.AnnotationUtils
-
- 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
-
- getFieldAnnotationsForHierarchy(Class<?>, Class<? extends Annotation>) - Static method in class org.mule.util.annotation.AnnotationUtils
-
- getFieldAnnotationsForInterfaces(Class<?>, Set<AnnotationMetaData>) - Static method in class org.mule.util.annotation.AnnotationUtils
-
- getFieldAnnotationsForInterfaces(Class<?>, Set<AnnotationMetaData>, Class<? extends Annotation>) - Static method in class org.mule.util.annotation.AnnotationUtils
-
- 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
-
- getFieldValue(Object, String, boolean) - Static method in class org.mule.util.ClassUtils
-
- getFile() - Method in class org.mule.util.queue.QueueFileProvider
-
- getFileSeparator() - Method in class org.mule.el.context.ServerContext
-
- 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.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
-
- 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
-
- 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
-
- 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
-
- 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.endpoint.DefaultInboundEndpoint
-
- getFlowConstruct() - Method in interface org.mule.execution.MessageProcessContext
-
- getFlowConstruct() - Method in class org.mule.processor.AbstractMuleObjectOwner
-
- getFlowConstruct() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
-
- getFlowConstruct() - Method in class org.mule.session.DefaultMuleSession
-
- 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
-
- 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.transport.TransportMessageProcessContext
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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 ExceptionUtils.getFullStackTrace(Throwable)
but removing the exception and causes
messages.
- 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
-
- 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
-
- getGlobalTransactionId() - Method in class org.mule.util.xa.MuleXid
-
- getGroupId() - Method in class org.mule.routing.EventGroup
-
Returns an identifier for this EventGroup.
- getHandler() - Method in class org.mule.DefaultMuleMessage.SerializedDataHandler
-
- getHeaders() - Method in class org.mule.management.stats.printers.AbstractTablePrinter
-
- getHeaders() - Method in class org.mule.management.stats.printers.XMLPrinter
-
- getHoldObject() - Method in interface org.mule.util.xa.XaResourceFactoryHolder
-
- getHome() - Method in class org.mule.el.context.MuleInstanceContext
-
- 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
-
- getHours() - Method in interface org.mule.api.el.datetime.Time
-
- getHours() - Method in class org.mule.el.datetime.DateTime
-
- getI18nMessage() - Method in exception org.mule.api.MuleException
-
- 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() - 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.util.store.InMemoryObjectStore.StoredObject
-
- getId() - Method in class org.mule.VoidMuleEvent
-
- 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
-
- getIgnoredMethods() - Method in class org.mule.model.resolvers.ReflectionEntryPointResolver
-
- 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
-
- 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() - Method in class org.mule.transport.AbstractTransportMessageProcessTemplate
-
- 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
-
- 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
-
- getIndexedVariableResolver(int) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
-
- getInfo(Throwable) - Method in interface org.mule.api.config.ExceptionReader
-
Returns a map of the non-stanard 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
-
- getInitialContext(Hashtable) - Method in class org.mule.jndi.MuleInitialContextFactory
-
- getInitialFactory() - Method in class org.mule.object.JndiObjectFactory
-
- getInitialisationPolicy() - Method in class org.mule.config.PoolingProfile
-
- 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.
- 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
-
- getInputStream() - Method in class org.mule.config.ConfigResource
-
- getInputStream() - Method in class org.mule.message.ds.ByteArrayDataSource
-
- getInputStream() - Method in class org.mule.message.ds.StringDataSource
-
- getInputWeighting() - Method in class org.mule.transformer.TransformerWeighting
-
- 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() - 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.NullPayload
-
- getInstance() - Static method in class org.mule.VoidMuleEvent
-
- getInstance() - Static method in class org.mule.VoidResult
-
- getInt(Object, Integer) - Static method in class org.mule.util.ObjectUtils
-
Gets a int from a value in a null-safe manner.
- 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
-
- getInterfaceClass() - Method in class org.mule.component.DefaultInterfaceBinding
-
- getInterfaceToTypes() - Method in class org.mule.context.notification.ServerNotificationManager
-
- 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
-
- 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
-
- 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
-
- getJavaDocUrl(Class<?>) - Static method in class org.mule.config.ExceptionHelper
-
- getJavaVendor() - Method in class org.mule.el.context.ServerContext
-
- getJavaVersion() - Method in class org.mule.el.context.ServerContext
-
- getJdkVersion() - Static method in class org.mule.util.JdkVersionUtils
-
- getJndiContext(String) - Method in class org.mule.transport.AbstractJndiConnector
-
- getJndiContext() - Method in class org.mule.transport.AbstractJndiConnector
-
- getJndiInitialFactory() - Method in class org.mule.transport.AbstractJndiConnector
-
- getJndiName() - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
-
- getJndiProviderProperties() - Method in class org.mule.transport.AbstractJndiConnector
-
- getJndiProviderUrl() - Method in class org.mule.transport.AbstractJndiConnector
-
- getJndiUrlPkgPrefixes() - Method in class org.mule.transport.AbstractJndiConnector
-
- getJournal() - Method in class org.mule.util.journal.queue.AbstractQueueTransactionJournal
-
- getKey() - Method in class org.mule.api.registry.AbstractServiceDescriptor.Key
-
- getKey() - Method in interface org.mule.security.SecretKeyFactory
-
- 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
-
- getKeyFactory() - Method in class org.mule.security.SecretKeyEncryptionStrategy
-
Deprecated.
- getKeyManagerAlgorithm() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getKeyManagerAlgorithm() - Method in interface org.mule.api.security.TlsDirectKeyStore
-
- getKeyManagerFactory() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getKeyManagerFactory() - Method in interface org.mule.api.security.TlsDirectKeyStore
-
- getKeyPassword() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getKeyPassword() - Method in interface org.mule.api.security.TlsDirectKeyStore
-
- getKeyStore() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getKeyStore() - Method in interface org.mule.api.security.TlsDirectKeyStore
-
- getKeyStorePassword() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getKeyStorePassword() - Method in interface org.mule.api.security.TlsDirectKeyStore
-
- getKeyStoreType() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getKeyStoreType() - Method in interface org.mule.api.security.TlsDirectKeyStore
-
- getKeyType() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
-
- getKnownVariables() - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
-
- 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
-
- getLength(Object) - Static method in class org.mule.util.ArrayUtils
-
- getLevelMappings() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
-
- 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
-
- 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.
- getListener() - Method in class org.mule.context.notification.ListenerSubscriptionPair
-
- getListener() - Method in class org.mule.processor.AbstractInterceptingMessageProcessorBase
-
- getListeners() - Method in class org.mule.context.notification.ServerNotificationManager
-
- getLocale() - Method in class org.mule.el.context.ServerContext
-
- 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.
- getLocalObjectStoreManager() - Method in class org.mule.DefaultMuleContext
-
- 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.
- 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
-
- getLogConfigFile() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
-
- 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.MuleServer
-
- getLogName() - Method in class org.mule.agent.Log4jNotificationLoggerAgent
-
- 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
-
- getLostObjects() - Method in class org.mule.registry.TransientRegistry.RegistryMap
-
Deprecated.
- getLowerVersion() - Method in class org.mule.util.VersionRange
-
- getMajor() - Method in class org.mule.util.JdkVersionUtils.JdkVersion
-
- getManifest() - Static method in class org.mule.config.MuleManifest
-
- getManifestProperty(String) - Static method in class org.mule.config.MuleManifest
-
- 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).
- 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
-
- 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
-
- 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
-
- 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
-
- getMaxExecutionTime() - Method in class org.mule.management.stats.ServiceStatistics
-
Deprecated.
- 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
-
- getMaxOutstandingMessages() - Method in class org.mule.config.QueueProfile
-
This specifies the number of messages that can be queued before it starts
blocking.
- getMaxProcessingTime() - Method in class org.mule.management.stats.ApplicationStatistics
-
- getMaxProcessingTime() - Method in class org.mule.management.stats.FlowConstructStatistics
-
- getMaxQueueSize() - Method in class org.mule.management.stats.ServiceStatistics
-
Deprecated.
- getMaxQueueSize() - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
-
- getMaxRedelivery() - Method in exception org.mule.api.exception.MessageRedeliveredException
-
- 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.
- 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.
- getMaxWait() - Method in class org.mule.config.PoolingProfile
-
- getMaxWait() - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
-
- getMaxWait() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
-
- getMember() - Method in class org.mule.util.annotation.AnnotationMetaData
-
- 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.transformer.simple.StringAppendTransformer
-
- 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
-
Returns the contents of the message as a byte array.
- 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
-
- getMessageDigestAlgorithm() - Method in class org.mule.processor.IdempotentRedeliveryPolicy
-
- getMessageDigestAlgorithm() - Method in class org.mule.routing.IdempotentSecureHashMessageFilter
-
- 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
-
- 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
-
- 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() - Method in class org.mule.routing.MessageProcessorFilterPair
-
- 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.
- 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.
- 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
-
- 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.TransactedPollingMessageReceiver
-
- getMessagesAsArray() - Method in interface org.mule.api.MuleMessageCollection
-
- getMessagesAsArray() - Method in class org.mule.DefaultMessageCollection
-
- 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.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
-
- getMessagingExceptionHandler() - Method in class org.mule.processor.AbstractMuleObjectOwner
-
- getMeta() - Method in class org.mule.endpoint.URIBuilder
-
- 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(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.
- 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
-
- 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
-
- getMethodMetaAnnotations(Class<?>, Class<? extends Annotation>) - Static method in class org.mule.util.annotation.AnnotationUtils
-
- getMethodProperty() - Method in class org.mule.model.resolvers.MethodHeaderPropertyEntryPointResolver
-
- getMethods() - Method in class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
-
- 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.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
-
- getMinEvictionMillis() - Method in class org.mule.config.PoolingProfile
-
- getMinExecutionTime() - Method in class org.mule.management.stats.ComponentStatistics
-
- getMinExecutionTime() - Method in class org.mule.management.stats.ServiceStatistics
-
Deprecated.
- getMinor() - Method in class org.mule.util.JdkVersionUtils.JdkVersion
-
- getMinProcessingTime() - Method in class org.mule.management.stats.ApplicationStatistics
-
- getMinProcessingTime() - Method in class org.mule.management.stats.FlowConstructStatistics
-
- 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
-
- 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.
- getModels() - Method in interface org.mule.api.registry.MuleRegistry
-
Deprecated.
Use lookupModel() instead
- getModels() - Method in class org.mule.registry.MuleRegistryHelper
-
Deprecated.
- getMonth() - Method in interface org.mule.api.el.datetime.Date
-
- getMonth() - Method in class org.mule.el.datetime.DateTime
-
- getMuleAppConfiguration(String) - Static method in class org.mule.config.PropertiesMuleConfigurationFactory
-
- getMuleConfiguration() - Method in class org.mule.context.DefaultMuleContextBuilder
-
- 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.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.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.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.service.AbstractService
-
Deprecated.
- 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.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
-
- 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.transport.AbstractTransportMessageProcessTemplate
-
- getMuleHomeDirectory() - Method in interface org.mule.api.config.MuleConfiguration
-
- getMuleHomeDirectory() - Method in class org.mule.config.DefaultMuleConfiguration
-
- getMuleHomeFile() - Static method in class org.mule.util.JarUtils
-
- getMuleLibDir() - Static method in class org.mule.util.JarUtils
-
- 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
-
- getName() - Method in class org.mule.AbstractAgent
-
- 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.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.StringDataSource
-
- getName() - Method in class org.mule.model.AbstractModel
-
Deprecated.
- 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.service.AbstractService
-
Deprecated.
- 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.polling.schedule.PollScheduler
-
- 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
-
- getNameInNamespace() - Method in class org.mule.jndi.SimpleContext
-
- 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
-
- 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.
- getNextFactory() - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
-
- getNextFactoryVariableResolver(String) - Method in class org.mule.el.mvel.MuleBaseVariableResolverFactory
-
- 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.
- getNodeId() - Method in class org.mule.el.context.MuleInstanceContext
-
- getNonMuleException(Throwable) - Static method in class org.mule.config.ExceptionHelper
-
- getNotificationManager() - Method in interface org.mule.api.MuleContext
-
- getNotificationManager() - Method in class org.mule.context.DefaultMuleContextBuilder
-
- getNotificationManager() - Method in class org.mule.DefaultMuleContext
-
- 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
-
- 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
-
- getNumberOfConcurrentTransactedReceivers() - Method in class org.mule.transport.AbstractConnector
-
- getNumberOfMessages() - Method in class org.mule.routing.outbound.MessageChunkingRouter
-
Deprecated.
- getNumIdle(Object) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
-
- getNumIdle() - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
-
- 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
-
- getObjectName() - Method in class org.mule.object.JndiObjectFactory
-
- getObjectSerializer() - Method in interface org.mule.api.MuleContext
-
- getObjectSerializer() - Method in class org.mule.DefaultMuleContext
-
- 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
-
- getOperation() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
-
- getOperationResourceFactory() - Method in class org.mule.transport.AbstractConnector
-
- getOppositeLifecyclePhase() - Method in interface org.mule.api.lifecycle.LifecyclePhase
-
- getOppositeLifecyclePhase() - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
-
- getOrBuildInboundEndpoint(MuleContext) - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundEndpointBuilder
-
- getOrBuildOutboundEndpoint(MuleContext) - Method in class org.mule.construct.builder.AbstractFlowConstructWithSingleInboundAndOutboundEndpointBuilder
-
- getOrCreateConnectorByProtocol(ImmutableEndpoint) - Method in class org.mule.transport.service.TransportFactory
-
- getOrCreateConnectorByProtocol(EndpointURI) - Method in class org.mule.transport.service.TransportFactory
-
Returns an initialized connector.
- 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.
- 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
-
- 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
-
- 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
-
- 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
-
- getOutputClass() - Method in class org.mule.transformer.TransformerWeighting
-
- 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.StringDataSource
-
- 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.VoidMuleEvent
-
- getOutputWeighting() - Method in class org.mule.transformer.TransformerWeighting
-
- 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
-
- 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
-
- 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.
- getParamAnnotations(Method) - Static method in class org.mule.util.annotation.AnnotationUtils
-
- 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
-
- 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.
- getParameterIndex() - Method in class org.mule.util.generics.MethodParameter
-
Return the index of the method/constructor parameter.
- getParameterName() - Method in class org.mule.util.generics.MethodParameter
-
Return the name of the method/constructor parameter.
- 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.
- getParameterType() - Method in class org.mule.util.generics.MethodParameter
-
Return the type of the method/constructor parameter.
- getParameterTypes(Object, String) - Static method in class org.mule.util.ClassUtils
-
- getParams() - Method in interface org.mule.api.endpoint.EndpointURI
-
- getParams() - Method in class org.mule.endpoint.MuleEndpointURI
-
- getParams() - Method in class org.mule.util.scan.annotations.AnnotationInfo
-
Deprecated.
- getParamsAsMap() - Method in class org.mule.util.scan.annotations.AnnotationInfo
-
Deprecated.
- getParent() - Method in class org.mule.api.processor.DefaultMessageProcessorPathElement
-
- getParent() - Method in interface org.mule.api.processor.MessageProcessorPathElement
-
- getParentName() - Method in class org.mule.config.support.InheritedModel
-
Deprecated.
- getParserConfiguration() - Method in class org.mule.el.mvel.MVELExpressionLanguage
-
- getPart(int) - Method in class org.mule.routing.outbound.SplitMessage
-
- getPart() - Method in class org.mule.routing.outbound.SplitMessage.MessagePart
-
- getPartitionName() - Method in class org.mule.util.store.ObjectStorePartition
-
- getPartitionName() - Method in class org.mule.util.store.PersistentObjectStorePartition
-
- getPassword() - Method in interface org.mule.api.endpoint.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.security.MuleCredentials
-
- getPassword() - Method in class org.mule.security.UsernamePasswordAuthenticationFilter
-
- 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
-
- 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 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
-
- 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
-
- 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
- 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.
- 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
-
- getPayloadList() - Method in class org.mule.DefaultMessageCollection
-
- getPayloadsAsArray() - Method in interface org.mule.api.MuleMessageCollection
-
- getPayloadsAsArray() - Method in class org.mule.DefaultMessageCollection
-
- 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
-
- getPolledMessageProcessor() - Method in class org.mule.endpoint.DefaultInboundEndpoint
-
- 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.
- 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
-
- 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
-
- getPrefix() - Method in class org.mule.component.simple.StaticComponent
-
- 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
-
- getPreNotification() - Method in class org.mule.lifecycle.LifecycleObject
-
- getPreNotificationName() - Method in class org.mule.lifecycle.NotificationLifecycleObject
-
- getPrincipal() - Method in interface org.mule.api.security.Authentication
-
- getPrincipal() - Method in class org.mule.security.DefaultMuleAuthentication
-
- 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.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
-
- getProcessedEvents() - Method in class org.mule.management.stats.ApplicationStatistics
-
- getProcessedEvents() - Method in class org.mule.management.stats.FlowConstructStatistics
-
- 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
-
- getProcessor() - Method in class org.mule.context.notification.MessageProcessorNotification
-
- getProcessorPath(MessageProcessor) - Method in interface org.mule.api.construct.MessageProcessorPathResolver
-
- getProcessorPath(MessageProcessor) - Method in class org.mule.construct.AbstractPipeline
-
- getProcessorPath() - Method in class org.mule.context.notification.MessageProcessorNotification
-
- getProcessorTimeWatcher() - Method in interface org.mule.api.MuleContext
-
- getProcessorTimeWatcher() - Method in class org.mule.DefaultMuleContext
-
- 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
-
- 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.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.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
-
- 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(Object) - Method in class org.mule.session.DefaultMuleSession
-
Will retrieve a session level property.
- getProperty(String) - Method in class org.mule.session.DefaultMuleSession
-
- getProperty(String) - Method in class org.mule.VoidMuleEvent
-
- getProperty(String, Object) - Method in class org.mule.VoidMuleEvent
-
- 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() - Method in class org.mule.transformer.simple.GetBeanProperty
-
- 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 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.transport.polling.MessageProcessorPollingConnector
-
- getProvider(String) - Method in interface org.mule.api.security.SecurityManager
-
- 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
-
- getQuery() - Method in interface org.mule.api.endpoint.EndpointURI
-
- getQuery() - Method in class org.mule.endpoint.MuleEndpointURI
-
- getQueryMap() - Method in class org.mule.endpoint.URIBuilder
-
- 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.
- 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
-
- 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.
- 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.
- getQueueSession() - Method in interface org.mule.util.queue.QueueManager
-
- getQueueSession() - Method in class org.mule.util.queue.TransactionalQueueManager
-
- getQueueSize() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
-
- getQueueStatistics() - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
-
- 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
-
- 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
-
- getReceiver(FlowConstruct, InboundEndpoint) - Method in class org.mule.transport.AbstractConnector
-
- getReceiver() - Method in class org.mule.transport.PollingReceiverWorker
-
- 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.polling.MessageProcessorPollingConnector
-
- getReceivers() - Method in class org.mule.transport.AbstractConnector
-
Getter for property 'receivers'.
- getReceivers(String) - Method in class org.mule.transport.AbstractConnector
-
- 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.
- 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
-
- 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
-
- getRegEx() - Method in class org.mule.util.TemplateParser.PatternInfo
-
- getRegistries() - Method in interface org.mule.api.registry.RegistryProvider
-
- getRegistries() - Method in class org.mule.registry.DefaultRegistryBroker
-
Deprecated.
- getRegistries() - Method in class org.mule.registry.MuleRegistryHelper
-
- getRegistry() - Method in interface org.mule.api.MuleContext
-
- 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
-
- getReloadControl() - Method in class org.mule.config.i18n.MessageFactory
-
Subclasses should override to customize the bundle reload control.
- getRenameProperties() - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
-
- 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.routing.outbound.AbstractOutboundRouter
-
- 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() - Method in class org.mule.VoidMuleEvent
-
- getReplyToEventsSent() - Method in class org.mule.management.stats.ServiceStatistics
-
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() - Method in class org.mule.VoidMuleEvent
-
- 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.
- getResource(Object) - Method in interface org.mule.api.transaction.Transaction
-
- 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(String, Class<?>) - Static method in class org.mule.util.ClassUtils
-
Load a given resource.
- 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, 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.
- 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
-
- getResourcePath(String, Class) - Static method in class org.mule.util.FileUtils
-
- getResourcePath(String, Class, String) - Static method in class org.mule.util.FileUtils
-
- getResources(String, Class<?>) - Static method in class org.mule.util.ClassUtils
-
- getResourceType() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
-
- 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
-
- 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
-
- 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
-
- 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
-
- getResponseTransformersFromUri(EndpointURI) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- getResult() - Method in class org.mule.api.model.InvocationResult
-
The result of this invocation
- 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.
- getResultsHandler() - Method in class org.mule.routing.outbound.AbstractOutboundRouter
-
- 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.transport.AbstractConnector
-
- getReturnClass() - Method in interface org.mule.api.transformer.Transformer
-
- 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
-
- 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
-
- 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
-
- getRouteIdentifier(MuleEvent) - Method in class org.mule.routing.DynamicRouteResolverAdapter
-
- getRouteIdentifier(MuleEvent) - Method in interface org.mule.routing.IdentifiableDynamicRouteResolver
-
- getRouter() - Method in class org.mule.routing.UntilSuccessful
-
- getRouter() - Method in interface org.mule.routing.UntilSuccessfulConfiguration
-
- 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
-
- 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.
- getSalt() - Method in class org.mule.security.PasswordBasedEncryptionStrategy
-
- 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
- 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
-
- 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
-
- getSchemeMetaInfo() - Method in interface org.mule.api.endpoint.EndpointURI
-
- getSchemeMetaInfo() - Method in class org.mule.endpoint.MuleEndpointURI
-
- 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.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
- getSeconds() - Method in interface org.mule.api.el.datetime.Time
-
- getSeconds() - Method in class org.mule.el.datetime.DateTime
-
- 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.
- 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
-
- 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.security.AbstractSecurityFilter
-
- getSecurityModel() - Static method in class org.mule.util.SecurityUtils
-
- getSecurityProviders() - Method in interface org.mule.api.security.SecurityFilter
-
- getSecurityProviders() - Method in class org.mule.security.AbstractSecurityFilter
-
- 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
-
- getServerId() - Method in class org.mule.api.context.notification.ServerNotification
-
- getServerSocketFactory() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getService() - Method in class org.mule.api.registry.AbstractServiceDescriptor
-
- getService() - Method in interface org.mule.api.registry.ServiceDescriptor
-
- getServiceDescriptor() - Method in class org.mule.transport.AbstractConnector
-
- getServiceName() - Method in class org.mule.context.notification.ComponentMessageNotification
-
- 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
-
- 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.VoidMuleEvent
-
- 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
-
- 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
-
Gets the data type for a given session variable
- getSessionVariableDataType(String) - Method in class org.mule.DefaultMuleEvent
-
- getSessionVariableDataType(String) - Method in class org.mule.VoidMuleEvent
-
- getSessionVariableNames() - Method in interface org.mule.api.MuleEvent
-
- getSessionVariableNames() - Method in class org.mule.DefaultMuleEvent
-
- getSessionVariableNames() - Method in class org.mule.VoidMuleEvent
-
- 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
-
- 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
-
- getSignature(Member, Class[]) - Static method in class org.mule.util.ClassReader
-
- 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).
- 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
- getSocket() - Method in class org.mule.ResponseOutputStream
-
- getSocketFactory() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- 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
-
- 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
-
- 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
-
- getSourceTypes() - Method in class org.mule.transformer.AbstractTransformer
-
Deprecated.
- getSourceTypes() - Method in class org.mule.transformer.CompositeConverter
-
- getSslContext() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getSslType() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- 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
- getStartTime() - Method in class org.mule.management.stats.AllStatistics
-
- 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.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
-
- getStaticEndpoint(MuleEvent) - Method in class org.mule.endpoint.DynamicOutboundEndpoint
-
- 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.service.AbstractService
-
Deprecated.
- getStatus() - Method in interface org.mule.api.transaction.Transaction
-
- getStatus() - Method in class org.mule.processor.DelegateTransaction
-
- getStatus() - Method in class org.mule.transaction.AbstractSingleResourceTransaction
-
- getStatus() - Method in class org.mule.transaction.XaTransaction
-
- 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
-
- 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
-
- getStreamCloserService() - Method in class org.mule.DefaultMuleContext
-
- 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, 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
-
- 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.util.TemplateParser
-
- getSubscription() - Method in class org.mule.context.notification.ListenerSubscriptionPair
-
- getSuffix() - Method in class org.mule.util.TemplateParser.PatternInfo
-
- 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
-
- 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
- getSupportedTransportMessageTypes() - Method in class org.mule.transport.AbstractMuleMessageFactory
-
- getSupportedTransportMessageTypes() - Method in class org.mule.transport.DefaultMuleMessageFactory
-
- getSyncEventsReceived() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
-
- getSyncEventsReceived() - Method in class org.mule.management.stats.ApplicationStatistics
-
- getSyncEventsSent() - Method in class org.mule.management.stats.ServiceStatistics
-
Deprecated.
- getSynchronous() - Method in class org.mule.routing.outbound.AbstractRecipientList
-
- getSystemModelType() - Method in interface org.mule.api.config.MuleConfiguration
-
- getSystemModelType() - Method in class org.mule.config.DefaultMuleConfiguration
-
- 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 class org.mule.enricher.MessageEnricher.EnrichExpressionPair
-
- getTargetObject() - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
-
Get XAConnection or XASession from wrapper / proxy
- getTargetObject() - Method in interface org.mule.util.proxy.TargetInvocationHandler
-
- getTargetType(MethodParameter) - Static method in class org.mule.util.generics.GenericTypeResolver
-
Determine the target type for the given parameter specification.
- getTextChild(Element) - Static method in class org.mule.util.XMLUtils
-
- getTheFailedMessageProcessor() - Method in class org.mule.processor.AbstractRedeliveryPolicy
-
- 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.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
-
- 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.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() - Method in class org.mule.transaction.AbstractTransaction
-
- getTimeout() - Method in class org.mule.transaction.MuleTransactionConfig
-
- 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
-
- 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
-
- getTmpDir() - Method in class org.mule.el.context.ServerContext
-
- getToken() - Method in class org.mule.security.MuleCredentials
-
- getTotalEventsReceived() - Method in class org.mule.management.stats.AbstractFlowConstructStatistics
-
- getTotalEventsReceived() - Method in class org.mule.management.stats.ApplicationStatistics
-
- getTotalEventsSent() - Method in class org.mule.management.stats.ServiceStatistics
-
Deprecated.
- getTotalExecutionTime() - Method in class org.mule.management.stats.ComponentStatistics
-
- getTotalExecutionTime() - Method in class org.mule.management.stats.ServiceStatistics
-
Deprecated.
- getTotalProcessingTime() - Method in class org.mule.management.stats.ApplicationStatistics
-
- getTotalProcessingTime() - Method in class org.mule.management.stats.FlowConstructStatistics
-
- getTotalReceived() - Method in class org.mule.management.stats.RouterStatistics
-
- 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.
- getTotalRouted() - Method in class org.mule.management.stats.RouterStatistics
-
- 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 class org.mule.transaction.TransactionCoordination
-
- getTransaction() - Method in class org.mule.transaction.XaTransaction
-
- 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.routing.outbound.AbstractOutboundRouter
-
- 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
-
- getTransactionFactoryFor(Class) - Method in class org.mule.api.SingleResourceTransactionFactoryManager
-
- getTransactionFactoryManager() - Method in interface org.mule.api.MuleContext
-
- getTransactionFactoryManager() - Method in class org.mule.DefaultMuleContext
-
- 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.util.queue.objectstore.xa.DefaultXASession
-
Deprecated.
- getTransactionTimeout() - Method in class org.mule.util.queue.TransactionalQueueSession
-
- getTransactionTimeout() - Method in class org.mule.util.xa.DefaultXASession
-
- getTransformer() - Method in exception org.mule.api.transformer.TransformerException
-
- getTransformer() - Method in exception org.mule.api.transformer.TransformerMessagingException
-
- getTransformer() - Method in class org.mule.routing.outbound.TransformerRouter
-
Deprecated.
- getTransformer() - Method in class org.mule.transformer.TransformerWeighting
-
- 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.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(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
-
- getTransportErrorMapping(String, Class, MuleContext) - Static method in class org.mule.config.ExceptionHelper
-
Maps an exception thrown for a certain protocol to an error.
- getTrustManagerAlgorithm() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getTrustManagerAlgorithm() - Method in interface org.mule.api.security.TlsDirectTrustStore
-
- getTrustManagerFactory() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getTrustManagerFactory() - Method in interface org.mule.api.security.TlsDirectTrustStore
-
- getTrustStore() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getTrustStore() - Method in interface org.mule.api.security.TlsIndirectTrustStore
-
- getTrustStorePassword() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getTrustStorePassword() - Method in interface org.mule.api.security.TlsIndirectTrustStore
-
- getTrustStoreType() - Method in class org.mule.api.security.tls.TlsConfiguration
-
- getTrustStoreType() - Method in interface org.mule.api.security.TlsDirectTrustStore
-
- 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 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.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() - Method in class org.mule.transformer.types.CollectionDataType
-
- getType() - Method in class org.mule.transformer.types.SimpleDataType
-
- 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
-
- 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.
- getUnacceptedMessageProcessor() - Method in class org.mule.processor.AbstractFilteringMessageProcessor
-
- 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(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
-
- getUpdatedValue(MuleEvent) - Method in class org.mule.transport.polling.watermark.UpdateExpressionWatermark
-
- 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
-
- getUriTemplate() - Method in class org.mule.endpoint.DynamicURIBuilder
-
- getUrl() - Method in class org.mule.config.ConfigResource
-
- getUrl() - Method in class org.mule.object.JndiObjectFactory
-
- getUser() - Method in interface org.mule.api.endpoint.EndpointURI
-
- getUser() - Method in class org.mule.endpoint.MuleEndpointURI
-
- getUser() - Method in class org.mule.endpoint.URIBuilder
-
- 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
-
- getUserInfo() - Method in class org.mule.endpoint.MuleEndpointURI
-
- getUsername() - Method in interface org.mule.api.security.Credentials
-
- getUserName() - Method in class org.mule.el.context.ServerContext
-
- getUsername() - Method in class org.mule.security.MuleCredentials
-
- getUsername() - Method in class org.mule.security.UsernamePasswordAuthenticationFilter
-
- 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
-
- getUUID() - Static method in class org.mule.util.UUID
-
- getValue(String, Map) - Method in class org.mule.expression.MapPayloadExpressionEvaluator
-
- getValue() - Method in class org.mule.transformer.types.TypedValue
-
- 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
-
- 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
-
- 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
-
- 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
-
- getVersion() - Method in class org.mule.el.context.MuleInstanceContext
-
- 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
-
- getWorkDescription() - Method in interface org.mule.api.retry.RetryCallback
-
- getWorkDir() - Method in class org.mule.el.context.AppContext
-
- getWorkException() - Method in class org.mule.work.WorkerContext
-
Gets the WorkException, if any, thrown during the execution.
- getWorkingDirectory() - Method in interface org.mule.api.config.MuleConfiguration
-
- getWorkingDirectory() - Method in class org.mule.config.DefaultMuleConfiguration
-
- 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
-
- getXAResource() - Method in class org.mule.util.queue.objectstore.xa.DefaultXASession
-
Deprecated.
- getXAResource() - Method in class org.mule.util.xa.DefaultXASession
-
- getXATerminator() - Method in class org.mule.work.MuleWorkManager
-
- getXaTxQueueTransactionJournal() - Method in class org.mule.util.xa.XaTransactionRecoverer
-
- getYear() - Method in interface org.mule.api.el.datetime.Date
-
- getYear() - Method in class org.mule.el.datetime.DateTime
-
- globalContext - Variable in class org.mule.el.mvel.MVELExpressionLanguage
-
- globalFunctions - Variable in class org.mule.el.mvel.MVELExpressionLanguage
-
- 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
- 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
-
- graphTransformerResolver - Variable in class org.mule.registry.TypeBasedTransformerResolver
-
- GraphTransformerResolver - Class in org.mule.transformer.graph
-
- GraphTransformerResolver() - Constructor for class org.mule.transformer.graph.GraphTransformerResolver
-
- groupsLock - Variable in class org.mule.routing.correlation.EventCorrelator
-
- groupTimeToLive - Variable in class org.mule.routing.correlation.EventCorrelator
-
- 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
-
- 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
-
- 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
-
- 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
- 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
-
- ignoredPropertyOverrides - Variable in class org.mule.DefaultMuleEvent
-
- 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
-
- 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
-
- ImmutableEndpoint - Interface in org.mule.api.endpoint
-
ImmutableEndpoint
describes a Message endpoint where data is
sent or received.
- 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
-
- 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
-
- INBOUND - Static variable in class org.mule.api.transport.PropertyScope
-
This scope holds all inbound headers when a message is received.
- INBOUND_NAME - Static variable in class org.mule.api.transport.PropertyScope
-
- 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
-
- 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
-
- 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
-
- InboundEndpointPropertyMessageProcessor(InboundEndpoint) - Constructor for class org.mule.endpoint.inbound.InboundEndpointPropertyMessageProcessor
-
- 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
-
- 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
-
- InboundNotificationMessageProcessor(InboundEndpoint) - Constructor for class org.mule.endpoint.inbound.InboundNotificationMessageProcessor
-
- inboundTransformer - Variable in class org.mule.transformer.wire.TransformerPairWireFormat
-
- 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.
- 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.
- INFINITY_CAPACTY - Static variable in class org.mule.util.queue.objectstore.QueueConfiguration
-
Deprecated.
- info(Object) - Method in class org.mule.util.MuleLogger
-
- info(Object, Throwable) - Method in class org.mule.util.MuleLogger
-
- InheritedModel - Class in org.mule.config.support
-
Deprecated.
- InheritedModel() - Constructor for class org.mule.config.support.InheritedModel
-
Deprecated.
- init(String[]) - Method in class org.mule.MuleServer
-
- init(Properties) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
-
- init() - Method in class org.mule.util.monitor.ExpiryMonitor
-
- init(Object, MuleContext) - Static method in class org.mule.util.store.DeserializationPostInitialisable.Implementation
-
- 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
-
- initExchangePatternFromConnectorDefault(TransportServiceDescriptor) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- initFromServiceDescriptor() - Method in class org.mule.transport.AbstractConnector
-
- 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
-
Method used to perform any initialisation work.
- initialise() - Method in class org.mule.connector.MuleConnectorOperationLocator
-
- initialise() - Method in class org.mule.construct.AbstractFlowConstruct
-
- initialise() - Method in class org.mule.DefaultMuleContext
-
- 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.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.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.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.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.polling.schedule.FixedFrequencyScheduler
-
- initialise() - Method in class org.mule.transport.polling.watermark.selector.SelectorWatermark
-
- initialise() - Method in class org.mule.transport.polling.watermark.UpdateExpressionWatermark
-
- 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
-
- 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
-
- initialiseIfNeeded(Object, MuleContext) - Static method in class org.mule.api.lifecycle.LifecycleUtils
-
- initialiseIfNeeded(Collection<? extends Object>) - Static method in class org.mule.api.lifecycle.LifecycleUtils
-
- initialiseProcessingStrategy() - Method in class org.mule.construct.AbstractPipeline
-
- 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.
- 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.
- initializeMessageProcessor(Object) - Method in class org.mule.endpoint.EndpointMessageProcessorChainBuilder
-
- initializeMessageProcessor(Object) - Method in class org.mule.processor.chain.AbstractMessageProcessorChainBuilder
-
- initializeRemoved() - Method in class org.mule.util.queue.objectstore.QueueTransactionContext
-
Deprecated.
- initializeRemoved() - Method in class org.mule.util.queue.TransientQueueTransactionContext
-
- initializeRetryPolicy() - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- 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
-
- initialValue() - Method in class org.mule.retry.policies.SimpleRetryPolicy.RetryCounter
-
- 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
-
- 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.
- initQueueStore(MuleContext) - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
-
- 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.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: org.mule.config.spring.SpringRegistry
)
- injectService() - Method in class org.mule.component.AbstractJavaComponent
-
- 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
-
- INPUT_STREAM - Static variable in class org.mule.transformer.types.DataTypeFactory
-
- installUrlStreamHandlerFactory() - Static method in class org.mule.util.MuleUrlStreamHandlerFactory
-
Install an instance of this class as UrlStreamHandlerFactory.
- INSTANCE - Static variable in class org.mule.routing.filters.AcceptAllFilter
-
- 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
- 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_ERROR - Static variable in class org.mule.util.NumberUtils
-
- INTEGER_SIZE_IN_BYTES - Static variable in class org.mule.util.queue.QueueControlDataFile
-
- 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
-
- InterceptingMessageProcessor - Interface in org.mule.api.processor
-
- Interceptor - Interface in org.mule.api.interceptor
-
Interceptor
is based on a similar concept of servlet filters and
works much the same way.
- 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
-
- interceptorChain - Variable in class org.mule.component.AbstractComponent
-
- 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
-
- 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.
- 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
-
- 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.
- internalRewriteEvent(MuleMessage, boolean) - Static method in class org.mule.RequestContext
-
Deprecated.
- internalSetEvent(MuleEvent) - Static method in class org.mule.RequestContext
-
Deprecated.
- 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.
- InvalidatableCachingStrategy - Interface in org.mule.api.cache
-
- 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.
- 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
-
- invalidateObject(Object, Object) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
-
- 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
-
- invalidJdk(String, String) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- invocationMap - Variable in class org.mule.MessagePropertiesContext
-
- InvocationResult - Class in org.mule.api.model
-
- 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.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.
- invokeComponentInstance(MuleEvent) - Method in class org.mule.component.AbstractJavaComponent
-
- invokeComponentInstance(MuleEvent) - Method in class org.mule.component.SimpleCallableJavaComponent
-
- invokeMethod(Object, Method, Object[]) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
-
- invokePhase(String, Object, LifecycleCallback) - Method in class org.mule.lifecycle.AbstractLifecycleManager
-
- invokePhase(String, Object, LifecycleCallback) - Method in class org.mule.lifecycle.MuleContextLifecycleManager
-
- invokePhase(String, Object, LifecycleCallback) - Method in class org.mule.lifecycle.RegistryLifecycleManager
-
- InvokerMessageProcessor - Class in org.mule.processor
-
InvokerMessageProcessor
invokes a specified method of an object.
- InvokerMessageProcessor() - Constructor for class org.mule.processor.InvokerMessageProcessor
-
- 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.transformer.simple.SerializableToByteArray
-
- isAcceptNull() - Method in interface org.mule.api.transformer.Transformer
-
Does this transformer allow null input?
- isAcceptNull() - Method in class org.mule.transformer.AbstractTransformer
-
- isAcceptNull() - Method in class org.mule.transformer.CompositeConverter
-
- isAcceptVoidMethods() - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
-
- isAdd() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
-
- isAddFirst() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
-
- isAfter(Instant) - Method in interface org.mule.api.el.datetime.Instant
-
- isAfter(Instant) - Method in class org.mule.el.datetime.AbstractInstant
-
- 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
-
- 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
- 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.
- isAssertMessageAccess() - Static method in class org.mule.api.ThreadSafeAccess.AccessControl
-
- isAuthenticate() - Method in class org.mule.security.AbstractAuthenticationFilter
-
- isAuthenticated() - Method in interface org.mule.api.security.Authentication
-
- isAuthenticated() - Method in class org.mule.security.DefaultMuleAuthentication
-
- 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.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
-
- isBase64Encoding() - Method in class org.mule.security.AbstractJCEEncryptionStrategy
-
- 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
-
- 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
-
- isCaseSensitive() - Method in class org.mule.routing.filters.MessagePropertyFilter
-
- isCaseSensitive() - Method in class org.mule.routing.filters.WildcardFilter
-
- isCheckpointOperation(byte) - Static method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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.transport.AbstractConnector
-
- isConnected() - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- isConnecting() - Method in class org.mule.transport.AbstractConnector
-
- isConsumable() - Method in class org.mule.DefaultMuleMessage
-
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
-
- isContainsTemplate(String) - Method in class org.mule.util.TemplateParser
-
- 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
-
- isCreateDispatcherPerRequest() - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
-
- isCreateMultipleTransactedReceivers() - Method in class org.mule.transport.AbstractConnector
-
- 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
-
- isCreateRequesterPerRequest() - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
-
- 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
-
- 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
-
- 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.
- 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
-
- isDisableRoundRobin() - Method in class org.mule.routing.outbound.AbstractRoundRobinMessageSplitter
-
The default behaviour for splitter routers is to round-robin across
targets.
- 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
-
- 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.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
-
- 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
-
- 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
-
- 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
-
- 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.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.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
-
- 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
-
- 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.util.PropertyChecker
-
- isEnableDiscovery() - Method in class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
-
- isEnableMessageEvents() - Method in class org.mule.transport.AbstractConnector
-
- isEnableNotifications() - Method in class org.mule.exception.AbstractExceptionListener
-
- isEnableStreaming() - Method in interface org.mule.api.config.MuleConfiguration
-
- isEnableStreaming() - Method in class org.mule.config.DefaultMuleConfiguration
-
- 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
-
Checks whether an enricher is registered with the manager
- 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
- isErrorEnabled() - Method in class org.mule.util.MuleLogger
-
- 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
-
- 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
-
- 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.
- 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.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.
- isFatalEnabled() - Method in class org.mule.util.MuleLogger
-
- 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
-
- isGroupAlreadyProcessed(Object) - Method in class org.mule.routing.correlation.EventCorrelator
-
- 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
-
- 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
-
- 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.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
-
- isInitialStateStopped() - Method in class org.mule.transport.AbstractConnector
-
- isInteractWithExternal() - Method in interface org.mule.api.transaction.TransactionConfig
-
- isInteractWithExternal() - Method in class org.mule.transaction.MuleTransactionConfig
-
- isInvalidatedPayload() - Method in class org.mule.DefaultMessageCollection
-
- 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
-
- isLocalName(Element, String) - Static method in class org.mule.util.XMLUtils
-
- isLookupOnEachCall() - Method in class org.mule.object.JndiObjectFactory
-
- isLowerBoundInclusive() - Method in class org.mule.util.VersionRange
-
- 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.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.
- isMuleUri(String) - Static method in class org.mule.endpoint.MuleEndpointURI
-
- isNewFile() - Method in class org.mule.util.queue.QueueFileProvider
-
- isNewMessage(MuleEvent) - Method in class org.mule.routing.IdempotentMessageFilter
-
- isNewMessage(MuleEvent) - Method in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
-
- isNonBlocking(MuleEvent) - Method in class org.mule.processor.AbstractNonBlockingMessageProcessor
-
- 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(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
-
- isNullReturnsTrue() - Method in class org.mule.routing.filters.ExpressionFilter
-
- isNullSubscription() - Method in class org.mule.context.notification.ListenerSubscriptionPair
-
- 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
-
- isOpaque() - Method in class org.mule.endpoint.MuleEndpointURI
-
- isOptional() - Method in class org.mule.expression.transformers.ExpressionArgument
-
- isOverwrite() - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
-
- isParamTypeACollection(Method, int) - Static method in class org.mule.transformer.types.CollectionDataType
-
- isParseExpression() - Method in class org.mule.util.AttributeEvaluator
-
- 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.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.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.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?
- 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
-
- isPrepare() - Method in class org.mule.util.journal.queue.AbstractQueueTxJournalEntry
-
- 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
-
- 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
-
- 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
-
- isProxyClass(Class<T>) - Static method in class org.mule.transformer.types.DataTypeFactory
-
Cache which classes are proxies.
- 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.
- isReadOnly() - Method in interface org.mule.api.endpoint.ImmutableEndpoint
-
- isReadOnly() - Method in interface org.mule.api.registry.Registry
-
- 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.registry.AbstractRegistryBroker
-
Deprecated.
- isReadOnly() - Method in class org.mule.registry.MuleRegistryHelper
- isReadOnly() - Method in class org.mule.registry.TransientRegistry
-
Deprecated.
- isReady() - Method in class org.mule.retry.async.FutureRetryContext
-
- isReceiveMessagesInTransaction() - Method in class org.mule.transport.TransactedPollingMessageReceiver
-
- isRecommendedJdkVersion() - Static method in class org.mule.util.JdkVersionUtils
-
- isRedeliveryPolicyConfigured() - Method in class org.mule.construct.AbstractPipeline
-
- isRegistered(Expirable) - Method in class org.mule.util.monitor.ExpiryMonitor
-
- isRemote() - Method in interface org.mule.api.registry.Registry
-
- 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
-
- 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.
- 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
-
- isResponseEnabled() - Method in interface org.mule.api.transport.Connector
-
- isResponseEnabled() - Method in class org.mule.transport.AbstractConnector
-
- isReturnSourceIfNull() - Method in class org.mule.expression.transformers.ExpressionTransformer
-
- isReturnTypeACollection(Method) - Static method in class org.mule.transformer.types.CollectionDataType
-
- isReuseObject() - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
-
- isRollback(Throwable) - Method in class org.mule.exception.AbstractExceptionListener
-
- 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.transport.PollingReceiverWorker
-
- 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
-
- isSendTransformed() - Method in class org.mule.routing.ForwardingCatchAllStrategy
-
Deprecated.
- isServerReachable(URL, int) - Static method in class org.mule.util.NetworkUtils
-
- isServerReachable(String, int, int) - Static method in class org.mule.util.NetworkUtils
-
- 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.object.AbstractObjectFactory
-
- isSingleton() - Method in class org.mule.object.JndiObjectFactory
-
- isSingleton() - Method in class org.mule.object.SingletonObjectFactory
-
- 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
-
- 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
-
- 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.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.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
-
- 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
-
- isStatsEnabled() - Method in class org.mule.processor.SedaStageInterceptingMessageProcessor
-
- 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
-
Determines whether the default processing for this event will be executed.
- 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.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.service.AbstractService
-
Deprecated.
- isStopping() - Method in class org.mule.transport.AbstractConnector
-
- isStopping() - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- isStreamOpen() - Method in class org.mule.config.ConfigResource
-
- 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
-
- 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 class org.mule.construct.AbstractPipeline
-
- isSynchronous() - Method in class org.mule.DefaultMuleEvent
-
- isSynchronous() - Method in class org.mule.VoidMuleEvent
-
- 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
-
- 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.
- isTraceEnabled() - Method in class org.mule.util.MuleLogger
-
- 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.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.VoidMuleEvent
-
- isTransactional() - Method in interface org.mule.util.queue.TransactionContextProvider
-
- isTransactionComplete(JournalEntry) - Method in interface org.mule.util.journal.TransactionCompletePredicate
-
- 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
-
- isUnder(JdkVersionUtils.JdkVersion) - Method in class org.mule.util.JdkVersionUtils.JdkVersionRange
-
- isUpperBoundInclusive() - Method in class org.mule.util.VersionRange
-
- isUseEventCopy(MuleEvent) - Method in class org.mule.processor.BlockingProcessorExecutor
-
- isUseMultipleTransactedReceivers() - Method in class org.mule.transport.TransactedPollingMessageReceiver
-
- isUseSecureHash() - Method in class org.mule.processor.IdempotentRedeliveryPolicy
-
- isUseTemplates() - Method in class org.mule.routing.outbound.FilteringOutboundRouter
-
- 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() - Method in class org.mule.session.DefaultMuleSession
-
- 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
-
- 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
-
- isWarnEnabled() - Method in class org.mule.util.MuleLogger
-
- 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
-
- 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() - Method in class org.mule.util.concurrent.ConcurrentHashSet
-
- IteratorMessageSequence<T> - Class in org.mule.routing.outbound
-
- IteratorMessageSequence(Iterator<T>) - Constructor for class org.mule.routing.outbound.IteratorMessageSequence
-
- 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
-
- LastItemWatermarkSelector - Class in org.mule.transport.polling.watermark.selector
-
- LastItemWatermarkSelector() - Constructor for class org.mule.transport.polling.watermark.selector.LastItemWatermarkSelector
-
- 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
-
- LaxSedaStageInterceptingMessageProcessor - Class in org.mule.processor
-
- LaxSedaStageInterceptingMessageProcessor(String, String, QueueProfile, int, ThreadingProfile, QueueStatistics, MuleContext) - Constructor for class org.mule.processor.LaxSedaStageInterceptingMessageProcessor
-
- LegacyEntryPointResolverSet - Class in org.mule.model.resolvers
-
- LegacyEntryPointResolverSet() - Constructor for class org.mule.model.resolvers.LegacyEntryPointResolverSet
-
- LegacySessionHandler - Class in org.mule.session
-
- 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.
- level - Variable in class org.mule.api.processor.LoggerMessageProcessor
-
- 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
-
- 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
-
- 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
-
- 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: org.mule.config.spring.SpringRegistry
)
- LifecycleStateInjectorProcessor(LifecycleState) - Constructor for class org.mule.registry.LifecycleStateInjectorProcessor
-
Deprecated.
- 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
-
- LifecycleUtils() - Constructor for class org.mule.api.lifecycle.LifecycleUtils
-
- 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.
- 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 - Static variable in class org.mule.util.MapCombiner
-
- list - Variable in class org.mule.util.queue.objectstore.DefaultQueueInfoDelegate
-
Deprecated.
- ListableObjectStore<T extends Serializable> - Interface in org.mule.api.store
-
- ListableObjectStoreProducer<T extends Serializable> - Class in org.mule.streaming
-
- ListableObjectStoreProducer(ListableObjectStore<T>) - Constructor for class org.mule.streaming.ListableObjectStoreProducer
-
- listBindings(Name) - Method in class org.mule.jndi.SimpleContext
-
- listBindings(String) - Method in class org.mule.jndi.SimpleContext
-
- ListConsumer<T> - Class in org.mule.streaming
-
- 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
-
- listener - Variable in class org.mule.source.StartableCompositeMessageSource
-
- listener - Variable in class org.mule.transport.AbstractMessageReceiver
-
- listenerAlreadyRegistered(EndpointURI) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- ListMessageSplitter - Class in org.mule.routing.outbound
-
Deprecated.
- ListMessageSplitter() - Constructor for class org.mule.routing.outbound.ListMessageSplitter
-
Deprecated.
- listSecurityServiceTypes() - Static method in class org.mule.util.DebugUtils
-
- listStoredFiles(File, List<Serializable>) - Method in class org.mule.util.store.QueuePersistenceObjectStore
-
Deprecated.
- 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.
- 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
-
- 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
-
- 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
-
- 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.
- 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
-
- 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
-
- LocalQueueTxJournalEntry - Class in org.mule.util.journal.queue
-
- 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
-
- LocalTxQueueTransactionContext - Class in org.mule.util.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) - 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
-
- 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
-
- lock - Variable in class org.mule.routing.EventProcessingThread
-
- 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(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 - Variable in class org.mule.processor.chain.AbstractMessageProcessorChain
-
- log - Static variable in class org.mule.source.StartableCompositeMessageSource
-
- log - Variable in class org.mule.util.scan.annotations.AnnotationsScanner
-
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
*****************************************************************************
- 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
-
- 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
-
- logException(Throwable) - 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.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.DefaultMuleConfiguration
-
- logger - Variable in class org.mule.config.dsl.ModelBuilder
-
Deprecated.
- logger - Static variable in class org.mule.config.ExceptionHelper
-
logger used by this class
- 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.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 - 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 - 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.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.polling.schedule.FixedFrequencyScheduler
-
- logger - Static variable in class org.mule.transport.service.TransportFactory
-
logger used by this class
- logger - Static variable in class org.mule.transport.TrackingWorkManager
-
- logger - Variable in class org.mule.transport.TransportMessageProcessContext
-
- 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
-
- 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
-
- logPrepare(Xid) - Method in class org.mule.util.journal.queue.XaTxQueueTransactionJournal
-
- 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.
- 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
-
- lookup(Name) - Method in class org.mule.jndi.SimpleContext
-
- lookup(String) - Method in class org.mule.jndi.SimpleContext
-
- 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
- lookupByType(Class<T>) - Method in interface org.mule.api.registry.Registry
-
- 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.
- 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.
- 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
-
- lookupEndpointFactory() - Method in class org.mule.registry.MuleRegistryHelper
- lookupFlowConstruct(String) - Method in interface org.mule.api.registry.MuleRegistry
-
- lookupFlowConstruct(String) - Method in class org.mule.registry.MuleRegistryHelper
- lookupFlowConstructs() - Method in interface org.mule.api.registry.MuleRegistry
-
- lookupFlowConstructs() - Method in class org.mule.registry.MuleRegistryHelper
- 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
-
- 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.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.
- 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(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.
- 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
-
- 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.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(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.
- 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.api.registry.SPIServiceRegistry
-
Searches for implementations of a particular service class
using the given class loader.
- lookupProviders(Class<T>) - Method in class org.mule.api.registry.SPIServiceRegistry
-
Searches for implementations of a particular service class
- lookupReceiver(String) - Method in class org.mule.transport.AbstractConnector
-
- 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
-
- 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
-
- 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
-
- magicProperties - Static variable in class org.mule.routing.AbstractRoutingStrategy
-
These properties are automatically propagated by Mule from inbound to outbound
- main(String[]) - Static method in class org.mule.MuleServer
-
Application entry point.
- makeObject(Object) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
-
- makeObject(Object) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
-
- 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
-
- ManagedObjectStore<T extends Serializable> - Class in org.mule.util.store
-
- ManagedObjectStore() - Constructor for class org.mule.util.store.ManagedObjectStore
-
- 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
-
- 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
- managerAlreadyStarted() - Static method in class org.mule.config.i18n.CoreMessages
-
- 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_ENTRY_KEY - Static variable in class org.mule.routing.MapSplitter
-
- 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
-
- 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
-
- 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
-
- 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
-
- MapToBean() - Constructor for class org.mule.transformer.simple.MapToBean
-
- 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
-
Mark the current transaction (if any) for rollback
- 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
-
- 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.
- MatchingRouter - Interface in org.mule.api.routing
-
Routes the message to zero or more MatchableMessageProcessor
s.
- 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_BUFFER_SIZE_PROPERTY - Static variable in class org.mule.api.config.DefaultThreadingProfileConfig
-
- MAX_ELEMENTS - Static variable in class org.mule.util.StringMessageUtils
-
- 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.correlation.EventCorrelator
-
- MAX_PROCESSED_GROUPS - Static variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
-
- 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_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
-
- 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
-
- MaxValueWatermarkSelector() - Constructor for class org.mule.transport.polling.watermark.selector.MaxValueWatermarkSelector
-
- MD5MuleEventKeyGenerator - Class in org.mule.keygenerator
-
Deprecated.
Use SHA256MuleEventKeyGenerator
instead.
- MD5MuleEventKeyGenerator() - Constructor for class org.mule.keygenerator.MD5MuleEventKeyGenerator
-
Deprecated.
- 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
-
- 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_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_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_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_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
-
- 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
-
- 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
-
- messageExchangePattern - Variable in class org.mule.endpoint.AbstractEndpointBuilder
-
- MessageExchangePattern - Enum in org.mule
-
- 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
-
- MessageFilter - Class in org.mule.routing
-
- 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
-
- 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
-
- messageNotSupportedByMuleMessageFactory(Object, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
-
- MessagePayloadExpressionEvaluator - Class in org.mule.expression
-
Returns the message payload.
- MessagePayloadExpressionEvaluator() - Constructor for class org.mule.expression.MessagePayloadExpressionEvaluator
-
- MessageProcessContext - Interface in org.mule.execution
-
- messageProcessingEnded() - Method in interface org.mule.execution.EndPhaseTemplate
-
template method call when the message processing ends
- MessageProcessingManager - Interface in org.mule.execution
-
In charge of processing messages through mule.
- MessageProcessor - Interface in org.mule.api.processor
-
- messageProcessor - Variable in class org.mule.context.notification.AsyncMessageNotification
-
- MessageProcessorBuilder - Interface in org.mule.api.processor
-
- MessageProcessorChain - Interface in org.mule.api.processor
-
- messageProcessorChain - Variable in class org.mule.service.AbstractService
-
Deprecated.
- MessageProcessorChainBuilder - Interface in org.mule.api.processor
-
- MessageProcessorContainer - Interface in org.mule.api.processor
-
Identifies Constructs that contain Message Processors configured by the user.
- 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
-
- 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
-
- 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.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
-
- MessageProcessPhase<Template extends MessageProcessTemplate> - Interface in org.mule.execution
-
- MessageProcessTemplate - Interface in org.mule.execution
-
- 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
-
- 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.
- MessageRedeliveredException - Exception in org.mule.api.exception
-
- MessageRedeliveredException(String, int, int, InboundEndpoint, MuleEvent, Message) - Constructor for exception org.mule.api.exception.MessageRedeliveredException
-
- MessageRedeliveredException(String, int, int, InboundEndpoint, MuleEvent) - Constructor for exception org.mule.api.exception.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
-
- MessageSequence<T> - Interface in org.mule.routing
-
A sequence of messages
- 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.
- 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
-
- MessagingExceptionStrategyAcceptorDelegate - Class in org.mule.exception
-
- MessagingExceptionStrategyAcceptorDelegate(MessagingExceptionHandler) - Constructor for class org.mule.exception.MessagingExceptionStrategyAcceptorDelegate
-
- 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.
- 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 - Variable in class org.mule.processor.InvokerMessageProcessor
-
- 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
-
- 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.
- 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
-
- 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_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
-
- 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.
- 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.
- 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.
- ModelServiceDescriptor - Interface in org.mule.api.model
-
Deprecated.
- 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
-
- 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.
- MULE_ARRIVAL_ORDER_PROPERTY - Static variable in class org.mule.routing.EventGroup
-
- 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_WORKMANAGER_MAXTHREADSACTIVE - Static variable in class org.mule.context.DefaultMuleContextBuilder
-
- 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_PROCESSING_STRATEGY - Static variable in class org.mule.api.config.MuleProperties
-
- MULE_DISABLE_TRANSPORT_TRANSFORMER_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
-
- 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_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_FORCE_CONSOLE_LOG - Static variable in class org.mule.api.config.MuleProperties
-
- MULE_FORCE_SYNC_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
-
- 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_JMS_SESSION - Static variable in class org.mule.api.config.MuleProperties
-
- 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_ORIGINATING_ENDPOINT_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
-
- 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_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_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_SOAP_METHOD - Static variable in class org.mule.api.config.MuleProperties
-
- MULE_STREAMING_BUFFER_SIZE - Static variable in class org.mule.api.config.MuleProperties
-
- MULE_USER_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
-
- MULE_WAIT_MILLIS - Static variable in class org.mule.transport.TrackingWorkManager
-
- MULE_WORKING_DIRECTORY_PROPERTY - Static variable in class org.mule.api.config.MuleProperties
-
- MuleBaseVariableResolverFactory - Class in org.mule.el.mvel
-
- MuleBaseVariableResolverFactory() - Constructor for class org.mule.el.mvel.MuleBaseVariableResolverFactory
-
- MuleClient - Interface in org.mule.api.client
-
Provides methods for performing send, dispatch and request operations
programatically.
- MuleConfiguration - Interface in org.mule.api.config
-
Configuration info.
- MuleConnectorOperationLocator - Class in org.mule.connector
-
- MuleConnectorOperationLocator() - Constructor for class org.mule.connector.MuleConnectorOperationLocator
-
- 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.ImmutableThreadingProfile.DefaultWorkManagerFactory
-
- muleContext - Variable in class org.mule.config.pool.ThreadPoolFactory
-
- 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.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 - 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.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.service.TransportFactory
-
- 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
.
- 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.
- 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: org.mule.config.spring.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
-
- 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.
- 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
-
- 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.
- 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.
- 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
-
- 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
-
- 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
-
- MuleLockFactory - Class in org.mule.util.lock
-
- MuleLockFactory() - Constructor for class org.mule.util.lock.MuleLockFactory
-
- 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
-
- 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.
- 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
-
- muleMessageFactory - Variable in class org.mule.transport.AbstractTransportMessageHandler
-
- MuleMessageInfoMapping - Class in org.mule.routing
-
- MuleMessageInfoMapping() - Constructor for class org.mule.routing.MuleMessageInfoMapping
-
- MuleMessageProcessingManager - Class in org.mule.execution
-
- MuleMessageProcessingManager() - Constructor for class org.mule.execution.MuleMessageProcessingManager
-
- MuleMessageToByteArray - Class in org.mule.transformer.simple
-
TODO
- MuleMessageToByteArray() - Constructor for class org.mule.transformer.simple.MuleMessageToByteArray
-
- MuleObjectStoreManager - Class in org.mule.util.store
-
- MuleObjectStoreManager() - Constructor for class org.mule.util.store.MuleObjectStoreManager
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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.
- 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.
- 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
-
- MuleUrlStreamHandlerFactory - Class in org.mule.util
-
A factory for loading URL protocol handlers.
- MuleUrlStreamHandlerFactory() - Constructor for class org.mule.util.MuleUrlStreamHandlerFactory
-
- 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
-
- MuleXid - Class in org.mule.util.xa
-
- MuleXid(int, byte[], byte[]) - Constructor for class org.mule.util.xa.MuleXid
-
- MuleXid(Xid) - Constructor for class org.mule.util.xa.MuleXid
-
- 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
-
- 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
-
- 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
-
- MULTIPLY - Static variable in class org.mule.util.counters.CounterFactory.Type
-
Counter represening the multiplication of two other counters
- mustSetMethodNamesOnBinding() - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- 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
-
- 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
-
- MVELExpressionLanguageWrapper(MuleContext) - Constructor for class org.mule.el.mvel.MVELExpressionLanguageWrapper
-
- 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_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_FOR_ENRICHMENT - Static variable in class org.mule.expression.DefaultExpressionManager
-
- 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
-
- 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
- objectFailedToInitialise(String) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- 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
-
- 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: org.mule.config.spring.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
byte
s.
- 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
-
- 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
-
- 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
-
- ObjectToOutputHandler - Class in org.mule.transformer.simple
-
ObjectToOutputHandler
converts a byte array into a String.
- ObjectToOutputHandler() - Constructor for class org.mule.transformer.simple.ObjectToOutputHandler
-
- ObjectToString - Class in org.mule.transformer.simple
-
ObjectToString
transformer is useful for debugging.
- ObjectToString() - Constructor for class org.mule.transformer.simple.ObjectToString
-
- objectType - Variable in class org.mule.processor.InvokerMessageProcessor
-
- ObjectUtils - Class in org.mule.util
-
- ObjectUtils() - Constructor for class org.mule.util.ObjectUtils
-
- 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
-
- 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
-
- onClose() - Method in interface org.mule.model.streaming.CallbackOutputStream.Callback
-
- 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.
- onCreation(MuleContext) - Method in interface org.mule.api.context.notification.MuleContextListener
-
Notifies the creation of a
MuleContext
instance right before
the initialization.
- 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
-
- onException(Object, Method, Object[], Throwable) - Method in interface org.mule.util.Multicaster.InvokeListener
-
- 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
-
- onInitialization(MuleContext) - Method in interface org.mule.api.context.notification.MuleContextListener
-
Notifies the initialization of a
MuleContext
instance right
before the configuration.
- onMessage(MuleMessage, Transaction, boolean, OutputStream) - Method in interface org.mule.api.transport.InternalMessageListener
-
- onNotification(T) - Method in interface org.mule.api.context.notification.ServerNotificationListener
-
- onNotification(ServerNotification) - Method in class org.mule.lifecycle.PrimaryNodeLifecycleNotificationListener
-
- 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
-
- onUnacceptedFlowConstruct - Variable in class org.mule.processor.AbstractFilteringMessageProcessor
-
- 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.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.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
-
- openDirectory(String) - Static method in class org.mule.util.FileUtils
-
- 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
-
- 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
-
- 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
-
- 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
-
- OPTIONAL_ARGUMENT - Static variable in class org.mule.expression.ExpressionConstants
-
- or(boolean) - Method in class org.mule.util.concurrent.WaitableBoolean
-
- 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.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.cache - package org.mule.api.cache
-
- 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.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.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.dsl - package org.mule.config.dsl
-
- org.mule.config.dsl.routers - package org.mule.config.dsl.routers
-
- 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.pool - package org.mule.config.pool
-
- org.mule.config.support - package org.mule.config.support
-
- 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.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.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.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.object - package org.mule.object
-
- 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
-
- 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.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.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.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.service - package org.mule.transport.service
-
Provides SPI support for building mule connectors and providers using service descriptors.
- 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.work - package org.mule.work
-
A javax.resource.spi.WorkManager implementation.
- OSGI_HEADER_TRANSPORT - Static variable in interface org.mule.transport.service.TransportServiceDescriptor
-
- out - Variable in class org.mule.transport.AbstractReceiverWorker
-
- OUTBOUND - Static variable in class org.mule.api.transport.PropertyScope
-
This is the default scope when writing properties to a message.
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- OutboundResponsePropertiesMessageProcessor(OutboundEndpoint) - Constructor for class org.mule.endpoint.outbound.OutboundResponsePropertiesMessageProcessor
-
- OutboundRootMessageIdPropertyMessageProcessor - Class in org.mule.endpoint.outbound
-
- 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
-
- 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.
- OutRouteBuilder - Class in org.mule.config.dsl
-
Deprecated.
- OutRouteBuilder(OutboundRouterCollection, MuleContext) - Constructor for class org.mule.config.dsl.OutRouteBuilder
-
Deprecated.
- override - Variable in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
-
- 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
-
- 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
-
- ParameterNameDiscoverer - Interface in org.mule.util.generics
-
Interface to discover parameter names for methods and constructors.
- 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.
- 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(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(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
-
- parseExchangePatterns(String) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
-
- parseNumber(String, Class<T>) - Static method in class org.mule.util.NumberUtils
-
- parsePropertyDefinitions(String) - Static method in class org.mule.util.SystemUtils
-
Returns a Map of all valid property definitions in -Dkey=value
format.
- 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
-
- parseServerAuthority() - Method in class org.mule.endpoint.MuleEndpointURI
-
- 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
-
- 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, Object) - Method in class org.mule.transport.KeyedPoolMessageDispatcherFactoryAdapter
-
- passivateObject(Object, Object) - Method in class org.mule.transport.KeyedPoolMessageRequesterFactoryAdapter
-
- 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
-
- PasswordBasedEncryptionStrategy - Class in org.mule.security
-
Provides password-based encryption using JCE.
- PasswordBasedEncryptionStrategy() - Constructor for class org.mule.security.PasswordBasedEncryptionStrategy
-
- PATH - Static variable in class org.mule.endpoint.URIBuilder
-
- PATH_ATTRIBUTES - Static variable in class org.mule.endpoint.URIBuilder
-
- pattern - Variable in class org.mule.routing.filters.WildcardFilter
-
- patternInfo - Variable in class org.mule.processor.InvokerMessageProcessor
-
- patterns - Variable in class org.mule.routing.filters.WildcardFilter
-
- 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.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 - Static variable in class org.mule.el.mvel.MessageVariableResolverFactory
-
- PAYLOAD - Static variable in class org.mule.expression.MessageExpressionEvaluator
-
- PAYLOAD_CLASS_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
-
- 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
-
- 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
-
- 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
-
- 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.
- performPoll() - Method in class org.mule.transport.AbstractPollingMessageReceiver
-
Check whether polling should take place on this instance.
- 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
-
- 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
-
- PersistentXaTransactionContext(XaTxQueueTransactionJournal, QueueProvider, Xid) - Constructor for class org.mule.util.queue.PersistentXaTransactionContext
-
- 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.
- PhaseExecutionEngine - Class in org.mule.execution
-
- 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
-
- 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
- Pipeline - Interface in org.mule.api.construct
-
- 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
-
- 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.polling.MessageProcessorPollingMessageReceiver
-
- poll() - Method in class org.mule.transport.PollingReceiverWorker
-
- poll() - Method in class org.mule.transport.TransactedPollingMessageReceiver
-
- 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_OVERRIDE_PROPERTY_NAME - Static variable in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
-
- 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
- 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
-
- 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.polling.MessageProcessorPollingMessageReceiver
-
- 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
-
- 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
- populate(Object, Map) - Static method in class org.mule.util.BeanUtils
-
This will overlay a map of properties on a bean.
- 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
-
- 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
-
- postProcessMessage(MuleMessage) - Method in class org.mule.transport.AbstractReceiverWorker
-
- 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
- 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.
- Preconditions - Class in org.mule.util
-
Utility class to validate Preconditions
- Preconditions() - Constructor for class org.mule.util.Preconditions
-
- Predicate<T> - Interface in org.mule.util
-
- Preferred - Annotation Type in org.mule.config
-
Provides a means to give preference to an SPI implementation over others.
- 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
-
- 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: org.mule.config.spring.SpringRegistry
)
- 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
-
- 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
- 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(MessageProcessor) - Method in class org.mule.processor.BlockingProcessorExecutor
-
- preProcess(MessageProcessor) - Method in class org.mule.processor.NonBlockingProcessorExecutor
-
- 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
- preprocessUri(String) - Method in class org.mule.endpoint.MuleEndpointURI
-
- 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
- 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(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() - Method in class org.mule.util.ExceptionHolder
-
- 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
-
- printProviderStatsXml(String, int) - Method in class org.mule.management.stats.printers.XMLPrinter
-
- 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
-
- process(MuleEvent, MessageProcessor) - Method in interface org.mule.api.cache.CachingStrategy
-
Processes a
MuleEvent
using a caching schema.
- 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
-
- process(String, MessageExchangePattern, MuleMessage) - Method in interface org.mule.api.client.MuleClient
-
- 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(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(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.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.OutboundResponsePropertiesMessageProcessor
-
- 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(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.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.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.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() - Method in class org.mule.transport.TransactedPollingMessageReceiver.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_END - Static variable in class org.mule.context.notification.ExceptionStrategyNotification
-
- PROCESS_END - Static variable in class org.mule.context.notification.PipelineMessageNotification
-
- PROCESS_START - Static variable in class org.mule.context.notification.ExceptionStrategyNotification
-
- PROCESS_START - Static variable in class org.mule.context.notification.PipelineMessageNotification
-
- processBlocking(MuleEvent) - Method in class org.mule.interceptor.AbstractEnvelopeInterceptor
-
- processBlocking(MuleEvent) - Method in class org.mule.processor.AbstractNonBlockingMessageProcessor
-
- processBlocking(MuleEvent) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
-
- 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
-
- processEvent(MuleEvent) - Method in class org.mule.routing.AbstractUntilSuccessfulProcessingStrategy
-
Process the event through the configured route in the until-successful configuration.
- 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
-
- 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.
- 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
-
- 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
-
- 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.construct.AbstractPipeline
-
- processingStrategy - Variable in class org.mule.processor.AsyncDelegateMessageProcessor
-
- ProcessingStrategy.StageNameSource - Interface in org.mule.api.processor
-
Deprecated.
- 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.
- 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.
- 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.TransactedPollingMessageReceiver
-
- processMessages() - Method in class org.mule.transport.AbstractReceiverWorker
-
The actual logic used to receive messages from the underlying transport.
- 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.processor.AbstractNonBlockingMessageProcessor
-
- processNonBlocking(MuleEvent) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
-
- processNow() - Method in class org.mule.routing.EventProcessingThread
-
- ProcessorExecutor - Interface in org.mule.api.processor
-
Iterates over a list of
MessageProcessor
s 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
-
- 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.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.
- processParts(MessageSequence<?>, MuleEvent) - Method in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
-
- 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.DefaultReplyToHandler
-
- processRequest(MuleEvent) - Method in class org.mule.processor.AbstractRequestResponseMessageProcessor
-
Processes the request phase before the next message processor is invoked.
- processResponse(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.ResponseMessageProcessorAdapter
-
- processResponseThroughAckResponseExpression(MuleEvent) - Method in class org.mule.routing.AbstractUntilSuccessfulProcessingStrategy
-
- processValues(Collection<String>, WildcardAttributeEvaluator.MatchCallback) - Method in class org.mule.util.WildcardAttributeEvaluator
-
- 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
-
- 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.
- 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
-
- 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 - Variable in class org.mule.endpoint.AbstractEndpointBuilder
-
- properties - Variable in class org.mule.message.ExceptionMessage
-
- properties - Variable in class org.mule.object.AbstractObjectFactory
-
- PROPERTIES_FILE_PATTERN - Static variable in class org.mule.api.security.tls.TlsConfiguration
-
- 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
-
- 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_CONNECTOR_NAME - Static variable in interface org.mule.api.endpoint.EndpointURI
-
- 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_NAME - Static variable in interface org.mule.api.AnnotatedObject
-
- PROPERTY_POLLING_FREQUENCY - Static variable in class org.mule.transport.AbstractConnector
-
- PROPERTY_PREFIX - Static variable in class org.mule.api.config.MuleProperties
-
The prefix for any Mule-specific properties set on an event
- PROPERTY_PROCESS_SYNCHRONOUSLY - Static variable in class org.mule.endpoint.AbstractEndpoint
-
- 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_TRANSFORMERS - Static variable in interface org.mule.api.endpoint.EndpointURI
-
- 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
-
- 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
-
- 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
-
- PropertyScope.ScopeComparator() - Constructor for class org.mule.api.transport.PropertyScope.ScopeComparator
-
- PROTOCOL - Static variable in class org.mule.endpoint.URIBuilder
-
- 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
-
- provideEndLatch() - Method in class org.mule.work.WorkerContext
-
Provides a latch, which can be used to wait the end of a work execution.
- 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
- proxyPoolTimedOut() - Static method in class org.mule.config.i18n.CoreMessages
-
- 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(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<? 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<String, Object>) - Method in class org.mule.registry.TransientRegistry.RegistryMap
-
Deprecated.
- 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.
- 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
- 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 - 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(InputStream) - Method in class org.mule.transformer.wire.TransformerPairWireFormat
-
- 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
-
- 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
-
- ReaderInputStream - Class in org.mule.config
-
- ReaderInputStream(Reader) - Constructor for class org.mule.config.ReaderInputStream
-
- 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
-
- 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
-
- readShort() - Method in class org.mule.util.ClassReader
-
- rebind(Name, Object) - Method in class org.mule.jndi.SimpleContext
-
- rebind(String, Object) - Method in class org.mule.jndi.SimpleContext
-
- 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
-
- receiveAsyncReply(MuleEvent) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
-
- 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
-
- 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
-
- receiverKey - Variable in class org.mule.transport.AbstractMessageReceiver
-
Stores the key to this receiver, as used by the Connector to store the
receiver.
- receivers - Variable in class org.mule.transport.AbstractConnector
-
The collection of listeners on this connector.
- 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
-
- 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.
- REDELIVERY_FAIL_ON_FIRST - Static variable in class org.mule.processor.AbstractRedeliveryPolicy
-
- RedeliveryExceeded - Class in org.mule.exception
-
- RedeliveryExceeded() - Constructor for class org.mule.exception.RedeliveryExceeded
-
- redeliveryPolicy - Variable in class org.mule.endpoint.AbstractEndpointBuilder
-
- 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
-
- 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
-
- register() - Method in class org.mule.lifecycle.PrimaryNodeLifecycleNotificationListener
-
- 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) - Method in class org.mule.registry.MuleRegistryHelper
- registerConnector(Connector) - Method in interface org.mule.api.registry.MuleRegistry
-
- registerConnector(Connector) - Method in class org.mule.registry.MuleRegistryHelper
- registerDelegateFactory(Class<? extends ObjectStore>, QueueInfo.QueueInfoDelegateFactory) - Static method in class org.mule.util.queue.objectstore.QueueInfo
-
Deprecated.
- 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
- 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
- registerFlowConstruct(FlowConstruct) - Method in interface org.mule.api.registry.MuleRegistry
-
- registerFlowConstruct(FlowConstruct) - Method in class org.mule.registry.MuleRegistryHelper
- registerHandler(String, URLStreamHandler) - Static method in class org.mule.util.MuleUrlStreamHandlerFactory
-
- 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
-
- registerMaskedPropertyName(String) - Static method in class org.mule.util.PropertiesUtils
-
Register a property name for masking.
- registerModel(Model) - Method in interface org.mule.api.registry.MuleRegistry
-
Deprecated.
- registerModel(Model) - Method in class org.mule.registry.MuleRegistryHelper
-
Deprecated.
- 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
-
- 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
- registerObjects(Map<String, Object>) - Method in interface org.mule.api.registry.Registry
-
Registers a Map of objects into the registry
- 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.
- 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.lifecycle.RegistryBrokerLifecycleManager
-
Deprecated.
- registerPhases() - Method in class org.mule.lifecycle.RegistryLifecycleManager
-
- 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
- registerShutdownHook() - Method in class org.mule.MuleServer
-
- 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.
- 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.
- 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.
- 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_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.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
-
- 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
-
- RegistryBrokerLifecycleManager(String, Registry, MuleContext) - Constructor for class org.mule.lifecycle.RegistryBrokerLifecycleManager
-
Deprecated.
- RegistryDelegatingInjector - Class in org.mule.registry
-
- 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
-
- 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
-
- 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
- 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.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.PollingReceiverWorker
-
- release() - Method in class org.mule.transport.TransactedPollingMessageReceiver.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
-
- reloadControl - 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
-
- 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.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(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(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.QueueStoreAdapter
-
Deprecated.
- removeAll(Collection) - Method in class org.mule.util.concurrent.ConcurrentHashSet
-
- removeAllListeners(Collection<ServerNotificationListener>) - Method in class org.mule.context.notification.ServerNotificationManager
-
- removeAllListeners() - Method in class org.mule.util.timer.EventTimerTask
-
- 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
-
- removeClassProperty(String, Properties) - Method in class org.mule.api.registry.AbstractServiceDescriptor
-
- removeConverter(Converter) - Method in class org.mule.transformer.graph.TransformationGraph
-
- removedMessage(MuleMessage) - Method in interface org.mule.api.MuleMessageCollection
-
- removedMessage(MuleMessage) - Method in class org.mule.DefaultMessageCollection
-
- 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.
- 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
-
- removeFromEnvironment(String) - Method in class org.mule.jndi.SimpleContext
-
- removeIgnoredMethod(String) - Method in class org.mule.model.resolvers.ReflectionEntryPointResolver
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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.
- 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
-
- 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
-
- removeType(Collection<?>, Class<?>) - Static method in class org.mule.util.CollectionUtils
-
- 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.jndi.SimpleContext
-
- rename(Attributes.Name, Attributes.Name) - Method in class org.mule.jndi.SimpleContext
-
- rename(String, String) - Method in class org.mule.jndi.SimpleContext
-
- renameFile(String, String) - Static method in class org.mule.util.FileUtils
-
- renameFile(File, File) - Static method in class org.mule.util.FileUtils
-
- 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.
- replaceObjectNameChars(String) - Static method in class org.mule.util.ObjectNameHelper
-
- 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
-
- 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
-
- 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(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_NO_WAIT - Static variable in interface org.mule.api.transport.MessageRequesting
-
- REQUEST_WAIT_INDEFINITELY - Static variable in interface org.mule.api.transport.MessageRequesting
-
- RequestContext - Class in org.mule
-
- 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
-
Requests a synchronous receive of an event on the service.
- 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
- requestMessageProcessor - Variable in class org.mule.routing.requestreply.SimpleAsyncRequestReplyRequester
-
- RequestReplyReplierMessageProcessor - Interface in org.mule.api.processor
-
- 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
-
- 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
-
- ResequenceCorrelatorCallback - Class in org.mule.routing.correlation
-
A Correlator that correlates messages based on Mule correlation settings.
- ResequenceCorrelatorCallback(Comparator<MuleEvent>, MuleContext, boolean, String) - Constructor for class org.mule.routing.correlation.ResequenceCorrelatorCallback
-
- ResequenceMessagesCorrelatorCallback - Class in org.mule.routing.correlation
-
- ResequenceMessagesCorrelatorCallback(Comparator, MuleContext, boolean, 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.lifecycle.AbstractLifecycleManager
-
- reset() - Method in class org.mule.model.streaming.DelegatingInputStream
-
- reset() - Method in class org.mule.retry.policies.SimpleRetryPolicy.RetryCounter
-
- 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
-
- resetExpirable(Expirable) - Method in class org.mule.util.monitor.ExpiryMonitor
-
- 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(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(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
-
- resolveClass(int) - Method in class org.mule.util.ClassReader
-
- resolveEventSynchronicity() - Method in class org.mule.DefaultMuleEvent
-
- resolveField(int) - Method in class org.mule.util.ClassReader
-
- resolveIntegerValue(MuleEvent) - Method in class org.mule.util.AttributeEvaluator
-
- 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.
- 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
-
- resolveRoutes(MuleEvent) - Method in class org.mule.routing.DynamicRouteResolverAdapter
-
- resolveStringValue(MuleEvent) - Method in class org.mule.util.AttributeEvaluator
-
- 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(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
-
- 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
-
- ResponseCompletionCallback - Interface in org.mule.execution
-
Callback to be used to notify of the result of an asynchronous response writing task.
- 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
-
- 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
-
- 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
-
- 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
- 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
-
- 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
-
- restoreIsolatedTransaction() - Method in class org.mule.transaction.TransactionCoordination
-
- 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
-
- 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.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.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.util.concurrent.ConcurrentHashSet
-
- 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.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.QueueStoreAdapter
-
Deprecated.
- 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
- 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.
- 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
-
- RetryForeverPolicyTemplate() - Constructor for class org.mule.retry.policies.RetryForeverPolicyTemplate
-
- RetryForeverPolicyTemplate(long) - Constructor for class org.mule.retry.policies.RetryForeverPolicyTemplate
-
- 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.
- 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.
- 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
-
- retryTemplate - Variable in class org.mule.transport.AbstractTransportMessageHandler
-
- RetryWorker - Class in org.mule.retry.async
-
- 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
-
- 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
-
- 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.
- returnType - Variable in class org.mule.transformer.AbstractTransformer
-
- rewriteURI(URI) - Method in class org.mule.endpoint.AbstractEndpointURIBuilder
-
- 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.transaction.AbstractSingleResourceTransaction
-
- rollback() - Method in class org.mule.transaction.AbstractTransaction
-
- 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
-
- 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
-
- 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.
- 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
-
- 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
-
- ROOT_MESSAGE_PROPERTY - Static variable in class org.mule.routing.Foreach
-
- 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.AsynchronousUntilSuccessfulProcessingStrategy
-
- 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
-
- route(MuleEvent) - Method in class org.mule.routing.SynchronousUntilSuccessfulProcessingStrategy
-
- route(MuleEvent) - Method in class org.mule.routing.UntilSuccessful
-
- route(MuleEvent) - Method in interface org.mule.routing.UntilSuccessfulProcessingStrategy
-
- 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.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
-
- 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
-
- 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
-
- 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
-
- routes - Variable in class org.mule.routing.outbound.AbstractOutboundRouter
-
- ROUTING_EVENT_ACTION_START_RANGE - Static variable in class org.mule.api.context.notification.ServerNotification
-
- 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
-
- RSS - Static variable in interface org.mule.transformer.types.MimeTypes
-
- RSS_STRING - Static variable in class org.mule.transformer.types.DataTypeFactory
-
- run() - Method in class org.mule.context.notification.ServerNotificationManager
-
- 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.transport.AbstractReceiverWorker
-
- run() - Method in class org.mule.transport.PollingReceiverWorker
-
- run() - Method in class org.mule.transport.PollingReceiverWorkerSchedule
-
- run() - Method in class org.mule.transport.TransactedPollingMessageReceiver.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
-
- 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
-
- 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.
- 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
-
- 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
-
- schedule() - Method in interface org.mule.api.schedule.Scheduler
-
Launches the action asynchronously.
- 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
-
- 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
-
- 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
-
- 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
- Schedulers - Class in org.mule.api.schedule
-
- Schedulers() - Constructor for class org.mule.api.schedule.Schedulers
-
- schedules - Variable in class org.mule.transport.AbstractPollingMessageReceiver
-
- 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
-
- schemeCannotChangeForRouter(String, String) - Static method in class org.mule.config.i18n.CoreMessages
-
- schemeNotCompatibleWithConnector(String, Class<?>) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- 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
-
- 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
-
- SecurityFilter - Interface in org.mule.api.security
-
SecurityFilter
is a base filter for secure filtering of
inbound and outbound event flow.
- SecurityFilterMessageProcessor - Class in org.mule.processor
-
- 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
-
- 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
-
- 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
-
- 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(Predicate) - Method in class org.mule.registry.TransientRegistry.RegistryMap
-
Deprecated.
- SelectiveRouter - Interface in org.mule.api.routing
-
Routes the event to
MessageProcessor
s using a
Filter
to
evaluate the event being processed and determine if a given route should be used.
- SelectorWatermark - Class in org.mule.transport.polling.watermark.selector
-
- 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
-
- SelectorWatermarkPollingInterceptor(Watermark, WatermarkSelector, String) - Constructor for class org.mule.transport.polling.watermark.selector.SelectorWatermarkPollingInterceptor
-
- selectProcessors(MuleEvent) - Method in class org.mule.routing.AbstractSelectiveRouter
-
- selectProcessors(MuleEvent) - Method in class org.mule.routing.ChoiceRouter
-
- send(String, Object, Map<String, Object>) - Method in interface org.mule.api.client.MuleClient
-
- 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
-
- send(String, MuleMessage, long) - Method in interface org.mule.api.client.MuleClient
-
- 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
-
- sendAsyncRequest(MuleEvent) - Method in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
-
- sendAsyncRequest(MuleEvent) - Method in class org.mule.routing.requestreply.SimpleAsyncRequestReplyRequester
-
- 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
-
sends an event request via the configured outbound router for this service.
- sendEventAsync(MuleMessage, String, int) - Method in interface org.mule.api.MuleEventContext
-
sends an event request via the configured outbound router for this service.
- 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
-
- 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.
- 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.
- 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 byte
s
- 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 byte
s
- 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
-
- 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
-
- 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
-
- 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
-
- serverNotificationManagerNotEnabled() - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- 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(String) - Method in class org.mule.config.dsl.ModelBuilder
-
Deprecated.
- 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_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_PAUSED - Static variable in class org.mule.context.notification.ServiceNotification
-
Deprecated.
- 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.
- ServiceCompositeMessageSource - Class in org.mule.service
-
Deprecated.
- ServiceCompositeMessageSource() - Constructor for class org.mule.service.ServiceCompositeMessageSource
-
Deprecated.
- 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
-
- 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
-
- ServiceInternalMessageProcessor - Class in org.mule.service.processor
-
Deprecated.
- ServiceInternalMessageProcessor(Service) - Constructor for class org.mule.service.processor.ServiceInternalMessageProcessor
-
Deprecated.
- 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
- ServiceProcessorExecutor - Class in org.mule.service.processor
-
- ServiceProcessorExecutor(MuleEvent, List<MessageProcessor>, MessageProcessorExecutionTemplate, boolean) - Constructor for class org.mule.service.processor.ServiceProcessorExecutor
-
- ServiceRegistry - Interface in org.mule.api.registry
-
API component to be used as standard SPI discovery mechanism.
- servicesDeprecated() - Static method in class org.mule.config.i18n.CoreMessages
-
- 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.
- ServiceType - Enum in org.mule.api.registry
-
TODO
- SESSION - Static variable in class org.mule.api.transport.PropertyScope
-
Defines the scope for any properties set on the session.
- SESSION_NAME - Static variable in class org.mule.api.transport.PropertyScope
-
- SESSION_VARS - Static variable in class org.mule.el.mvel.MessageVariableResolverFactory
-
- 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
- sessionMap - Variable in class org.mule.MessagePropertiesContext
-
- sessionPropertyNotSerializableWarning(String) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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(boolean) - Method in class org.mule.util.concurrent.WaitableBoolean
-
- set(T) - Method in class org.mule.util.ValueHolder
-
Updates the held value
- 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
-
- setAcceptMuleMessage(boolean) - Method in class org.mule.transformer.simple.SerializableToByteArray
-
- setAcceptVoidMethods(boolean) - Method in class org.mule.model.resolvers.AbstractEntryPointResolver
-
- setAckExpression(String) - Method in class org.mule.routing.UntilSuccessful
-
- setAction(byte) - Method in interface org.mule.api.transaction.TransactionConfig
-
- setAction(byte) - Method in class org.mule.transaction.MuleTransactionConfig
-
- setActionAsString(String) - Method in class org.mule.transaction.MuleTransactionConfig
-
- setAddProperties(Map<String, Object>) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
-
- setAddress(String) - Method in class org.mule.endpoint.URIBuilder
-
- setAddTypedProperties(Map<String, TypedValue>) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
-
- setAggregationStrategy(AggregationStrategy) - Method in class org.mule.routing.ScatterGatherRouter
-
- setAlgorithm(String) - Method in class org.mule.security.AbstractJCEEncryptionStrategy
-
- setAliases(Map<String, String>) - Method in class org.mule.el.mvel.MVELExpressionLanguage
-
- setAllListenerSubscriptionPairs(Collection<?>) - Method in class org.mule.context.notification.ServerNotificationManager
-
Deprecated.
Use addAllListenerSubscriptionPairs which better describes the "add" operation that occurs.
- setAllowNullReturn(boolean) - Method in class org.mule.transformer.AbstractTransformer
-
- 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.processor.AbstractMessageProcessorOwner
-
- 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
-
- setAssertMessageAccess(boolean) - Static method in class org.mule.api.ThreadSafeAccess.AccessControl
-
- 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
-
- 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.security.DefaultMuleAuthentication
-
- setAuthentication(Authentication) - Method in interface org.mule.api.security.SecurityContext
-
- setAuthentication(Authentication) - Method in class org.mule.security.DefaultSecurityContext
-
- setAutoResolveVariables(boolean) - Method in class org.mule.el.mvel.MVELExpressionLanguage
-
- setAutoWrapMessageAwareTransform(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setBase64Encoding(boolean) - Method in class org.mule.security.AbstractJCEEncryptionStrategy
-
- 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
-
- 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
-
- setBeanClass(Class<?>) - Method in class org.mule.expression.transformers.BeanBuilderTransformer
-
- setBeanFactory(ObjectFactory) - Method in class org.mule.expression.transformers.BeanBuilderTransformer
-
- setBooleanProperty(String, boolean) - Method in interface org.mule.api.MuleMessage
-
- setBooleanProperty(String, boolean) - Method in class org.mule.DefaultMuleMessage
-
Deprecated.
- setCacheMessageAsBytes(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setCacheMessageOriginalPayload(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setCaseSensitive(boolean) - Method in class org.mule.routing.filters.MessagePropertyFilter
-
- setCaseSensitive(boolean) - Method in class org.mule.routing.filters.WildcardFilter
-
- 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.
- 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
-
- setClassName(String) - Method in class org.mule.util.scan.annotations.AnnotationInfo
-
Deprecated.
- setClientKeyStore(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setClientKeyStore(String) - Method in interface org.mule.api.security.TlsIndirectKeyStore
-
- setClientKeyStorePassword(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setClientKeyStorePassword(String) - Method in interface org.mule.api.security.TlsIndirectKeyStore
-
- setClientKeyStoreType(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setClientKeyStoreType(String) - Method in interface org.mule.api.security.TlsIndirectKeyStore
-
- setClientMode(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setClusterId(String) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setCollectionExpression(String) - Method in class org.mule.routing.Foreach
-
- setCommitTxFilter(WildcardFilter) - Method in class org.mule.exception.AbstractExceptionListener
-
- 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.
- setComponentPoolSize(int) - Method in class org.mule.management.stats.SedaServiceStatistics
-
Deprecated.
- setComponentStat(ComponentStatistics) - Method in class org.mule.management.stats.ServiceStatistics
-
Deprecated.
- 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.
- 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
-
- setConnector(Connector) - Method in interface org.mule.api.endpoint.EndpointBuilder
-
- setConnector(Connector) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- setConstraint(ConstraintFilter) - Method in interface org.mule.api.transaction.TransactionConfig
-
- setConstraint(ConstraintFilter) - Method in class org.mule.transaction.MuleTransactionConfig
-
- setContainerMode(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
-
The setting is only editable before the context has been initialized, change requests ignored afterwards.
- setContentType(String) - Method in class org.mule.transformer.simple.AddAttachmentTransformer
-
- setContext(Context) - Method in class org.mule.object.JndiObjectFactory
-
- setContext(Context) - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
-
- setCoreExtensions(List<MuleCoreExtension>) - Method in interface org.mule.CoreExtensionsAware
-
- 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.
- 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)
- setCount(int) - Method in class org.mule.retry.policies.SimpleRetryPolicyTemplate
-
- setCounterVariableName(String) - Method in class org.mule.routing.Foreach
-
- setCounterVariableName(String) - Method in class org.mule.routing.outbound.AbstractMessageSequenceSplitter
-
- setCreateConnector(int) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- setCreateMultipleTransactedReceivers(boolean) - Method in class org.mule.transport.AbstractConnector
-
- setCredentials(MuleEvent, Object) - Method in interface org.mule.api.security.CredentialsAccessor
-
- 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.security.AbstractAuthenticationFilter
-
- setCurrentPhase(String) - Method in class org.mule.lifecycle.AbstractLifecycleManager
-
- 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
-
- setData(Object) - Method in class org.mule.component.simple.StaticComponent
-
- setDataFile(String) - Method in class org.mule.component.simple.StaticComponent
-
- 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
-
- setDeadLetterQueue(MessageProcessorFilterPair) - Method in class org.mule.processor.AbstractRedeliveryPolicy
-
- setDeadLetterQueue(Object) - Method in class org.mule.routing.UntilSuccessful
-
- 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
-
- setDefaultObjectSerializer(ObjectSerializer) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setDefaultProcessingStrategy(ProcessingStrategy) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setDefaultQueueConfiguration(QueueConfiguration) - Method in class org.mule.util.queue.AbstractQueueManager
-
- setDefaultQueueConfiguration(QueueConfiguration) - Method in class org.mule.util.queue.DelegateQueueManager
-
- setDefaultQueueConfiguration(QueueConfiguration) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
-
Deprecated.
- setDefaultQueueConfiguration(QueueConfiguration) - Method in interface org.mule.util.queue.QueueManager
-
- setDefaultQueueTimeout(int) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setDefaultResponseTimeout(int) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setDefaultRoute(MessageProcessor) - Method in interface org.mule.api.routing.SelectiveRouter
-
- 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
-
- setDefaultTransactionTimeout(int) - Method in class org.mule.config.DefaultMuleConfiguration
-
- 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.
- 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
-
- 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
-
- 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
-
- 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<Class<? extends ServerNotificationListener>>) - Method in class org.mule.context.notification.ServerNotificationManager
-
- setDisabledTypes(Collection<Class<? extends ServerNotificationListener>>) - Method in class org.mule.context.notification.ServerNotificationManager
-
- setDisableRoundRobin(boolean) - Method in class org.mule.routing.outbound.AbstractRoundRobinMessageSplitter
-
The default behaviour for splitter routers is to round-robin across
targets.
- setDisableTransportTransformer(boolean) - Method in interface org.mule.api.endpoint.EndpointBuilder
-
- setDisableTransportTransformer(boolean) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- 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
-
- 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'.
- setDomainContext(MuleContext) - Method in interface org.mule.api.config.DomainMuleContextAwareConfigurationBuilder
-
- setDomainContext(MuleContext) - Method in class org.mule.config.builders.AutoConfigurationBuilder
-
- 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.
- 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
-
- 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
-
- 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)
- setEnableDiscovery(boolean) - Method in class org.mule.model.resolvers.AbstractArgumentEntryPointResolver
-
- 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.VoidMuleEvent
-
- setEnableStreaming(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
-
- 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.DefaultMuleMessage
-
Sets the encoding for this message
- setEncoding(String) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- 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
-
- 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(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(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
-
- setEndpointURI(EndpointURI) - Method in class org.mule.endpoint.DynamicURIInboundEndpoint
-
- setEndpointURI(EndpointURI) - Method in class org.mule.endpoint.DynamicURIOutboundEndpoint
-
- setEnricherPropagatesSessionVariableChanges(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setEnrichExpressionPairs(List<MessageEnricher.EnrichExpressionPair>) - Method in class org.mule.enricher.MessageEnricher
-
- setEnrichmentMessageProcessor(MessageProcessor) - Method in class org.mule.enricher.MessageEnricher
-
- 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
-
- setErrorMessage(String) - Method in class org.mule.api.model.InvocationResult
-
- setErrorNoMatchingMethods(Object, Class<?>[]) - Method in class org.mule.api.model.InvocationResult
-
- setErrorNoMatchingMethodsCalled(Object, String) - Method in class org.mule.api.model.InvocationResult
-
- setErrorTooManyMatchingMethods(Object, Class<?>[], String) - Method in class org.mule.api.model.InvocationResult
-
- 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
-
- setEvent(MuleEvent) - Method in interface org.mule.api.security.Authentication
-
- 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
-
- setEventComparator(Comparator) - Method in class org.mule.routing.Resequencer
-
- 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.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(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
-
- 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
- setExchangePattern(MessageExchangePattern) - Method in interface org.mule.api.endpoint.EndpointBuilder
-
- setExchangePattern(MessageExchangePattern) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- 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
-
- setExecutor(Executor) - Method in class org.mule.api.FutureMessageResult
-
Set an ExecutorService to run this invocation.
- setExhaustedAction(int) - Method in class org.mule.config.PoolingProfile
-
- setExpectedType(Class) - Method in class org.mule.routing.filters.PayloadTypeFilter
-
- setExpirationInterval(int) - Method in class org.mule.util.store.AbstractMonitoredObjectStore
-
- setExpirationInterval(int) - Method in class org.mule.util.store.ManagedObjectStore
-
- 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.
- 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.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
-
- 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
-
- setFactory(TransactionFactory) - Method in interface org.mule.api.transaction.TransactionConfig
-
- setFactory(TransactionFactory) - Method in class org.mule.transaction.MuleTransactionConfig
-
- setFactory(KeyedPoolableObjectFactory) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
-
- 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.
- 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
-
- setFieldValue(Object, String, Object, boolean) - Static method in class org.mule.util.ClassUtils
-
- 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
-
- setFilters(List<Filter>) - Method in class org.mule.routing.filters.logic.AbstractFilterCollection
-
- setFlags(int) - Method in class org.mule.routing.filters.RegExFilter
-
- 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.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.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.session.DefaultMuleSession
-
- setFlowConstruct(FlowConstruct) - Method in class org.mule.source.ClusterizableMessageSourceWrapper
-
- setFlowConstruct(FlowConstruct) - Method in class org.mule.source.StartableCompositeMessageSource
-
- setFlowEndingWithOneWayEndpointReturnsNull(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
-
- 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
-
- setFooter(MuleContext) - Method in class org.mule.util.SplashScreen
-
- 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
-
- 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
-
- 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
-
- setHeader(MuleContext) - Method in class org.mule.util.SplashScreen
-
Setting the header clears body and footer assuming a new
splash-screen is built.
- setHost(String) - Method in class org.mule.endpoint.URIBuilder
-
- setId(String) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setId(String) - Method in class org.mule.retry.policies.AbstractPolicyTemplate
-
- setIdentifier(String) - Method in class org.mule.transformer.simple.AbstractAddVariablePropertyTransformer
-
- setIdentifier(String) - Method in class org.mule.transformer.simple.AbstractRemoveVariablePropertyTransformer
-
- 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
-
- 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
-
- 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
-
- setIndexedVariableResolver(int, VariableResolver) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
-
- setInitialFactory(String) - Method in class org.mule.object.JndiObjectFactory
-
- setInitialisationPolicy(int) - Method in class org.mule.config.PoolingProfile
-
- 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.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
-
- setInjector(Injector) - Method in class org.mule.DefaultMuleContext
-
- 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
-
- setInterfaceToTypes(Map<Class<? extends ServerNotificationListener>, Set<Class<? extends ServerNotification>>>) - Method in class org.mule.context.notification.ServerNotificationManager
-
- 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
-
- setIterationCount(int) - Method in class org.mule.security.PasswordBasedEncryptionStrategy
-
- setJndiContext(Context) - Method in class org.mule.transport.AbstractJndiConnector
-
- setJndiInitialFactory(String) - Method in class org.mule.transport.AbstractJndiConnector
-
- setJndiName(String) - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
-
- setJndiProviderProperties(Map) - Method in class org.mule.transport.AbstractJndiConnector
-
- setJndiProviderUrl(String) - Method in class org.mule.transport.AbstractJndiConnector
-
- setJndiUrlPkgPrefixes(String) - Method in class org.mule.transport.AbstractJndiConnector
-
- 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
-
- setKeyFactory(SecretKeyFactory) - Method in class org.mule.security.SecretKeyEncryptionStrategy
-
Deprecated.
- setKeyManagerAlgorithm(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setKeyManagerAlgorithm(String) - Method in interface org.mule.api.security.TlsDirectKeyStore
-
- setKeyPassword(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setKeyPassword(String) - Method in interface org.mule.api.security.TlsDirectKeyStore
-
- setKeyStore(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setKeyStore(String) - Method in interface org.mule.api.security.TlsDirectKeyStore
-
- setKeyStorePassword(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setKeyStorePassword(String) - Method in interface org.mule.api.security.TlsDirectKeyStore
-
- setKeyStoreType(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setKeyStoreType(String) - Method in interface org.mule.api.security.TlsDirectKeyStore
-
- 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
-
- 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
-
- setLifecycleState(LifecycleState) - Method in interface org.mule.api.lifecycle.LifecycleStateAware
-
- 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.processor.AbstractInterceptingMessageProcessorBase
-
- 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.transport.AbstractMessageReceiver
-
- setLocalMuleClient(DefaultLocalMuleClient) - Method in class org.mule.DefaultMuleContext
-
- setLocation(String) - Method in class org.mule.transformer.simple.ParseTemplateTransformer
-
- setLockProvider(LockProvider) - Method in class org.mule.util.lock.MuleLockFactory
-
- setLogConfigFile(String) - Method in class org.mule.agent.Log4jNotificationLoggerAgent
-
- setLogFile(String) - Method in class org.mule.agent.Log4jNotificationLoggerAgent
-
- setLogName(String) - Method in class org.mule.agent.Log4jNotificationLoggerAgent
-
- 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
-
- 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
-
- 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
-
- 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
- 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
-
- setMaxOutstandingMessages(int) - Method in class org.mule.config.QueueProfile
-
This specifies the number of messages that can be queued before it starts
blocking.
- setMaxQueueSize(Integer) - Method in class org.mule.processor.strategy.QueuedAsynchronousProcessingStrategy
-
- 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
-
- 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
-
- setMaxWait(long) - Method in class org.mule.config.PoolingProfile
-
- setMaxWait(long) - Method in interface org.mule.transport.ConfigurableKeyedObjectPool
-
- setMaxWait(long) - Method in class org.mule.transport.DefaultConfigurableKeyedObjectPool
-
- 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.transformer.simple.StringAppendTransformer
-
- setMessage(MuleMessage) - Method in class org.mule.VoidMuleEvent
-
- setMessageDigestAlgorithm(String) - Method in class org.mule.processor.IdempotentRedeliveryPolicy
-
- setMessageDigestAlgorithm(String) - Method in class org.mule.routing.IdempotentSecureHashMessageFilter
-
- 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.
- setMessageProcessor(MessageProcessor) - Method in class org.mule.enricher.MessageEnricher
-
For spring
- 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.service.AbstractService
-
Deprecated.
- setMessageProcessors(List<MessageProcessor>) - Method in interface org.mule.api.construct.Pipeline
-
- setMessageProcessors(List<MessageProcessor>) - Method in interface org.mule.api.endpoint.EndpointBuilder
-
- 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.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
-
- 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.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.service.ServiceCompositeMessageSource
-
Deprecated.
- setMessageSources(List<MessageSource>) - Method in class org.mule.source.StartableCompositeMessageSource
-
- 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
-
- 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.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
-
- setMinThreads(Integer) - Method in class org.mule.processor.strategy.AbstractThreadingProfileProcessingStrategy
-
- setModel(Model) - Method in interface org.mule.api.service.Service
-
Deprecated.
- setModel(Model) - Method in class org.mule.service.AbstractService
-
Deprecated.
- 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) - Method in class org.mule.config.ChainedThreadingProfile
-
- setMuleContext(MuleContext) - Method in class org.mule.config.DefaultMuleConfiguration
-
- 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.connector.MuleConnectorOperationLocator
-
- 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.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.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.lifecycle.MuleContextLifecycleManager
-
- setMuleContext(MuleContext) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
-
- 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.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.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.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.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.polling.watermark.selector.SelectorWatermark
-
- setMuleContext(MuleContext) - Method in class org.mule.transport.polling.watermark.UpdateExpressionWatermark
-
- setMuleContext(MuleContext) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
-
- 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
-
- setMuleRegistry(MuleRegistryHelper) - Method in class org.mule.DefaultMuleContext
-
- 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.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.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.service.AbstractService
-
Deprecated.
- 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.polling.schedule.PollScheduler
-
- setName(String) - Method in class org.mule.util.store.AbstractMonitoredObjectStore
-
- setNextFactory(VariableResolverFactory) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
-
- setNextMessage(Message) - Method in class org.mule.config.i18n.Message
-
- 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
-
- setNullReturnsTrue(boolean) - Method in class org.mule.routing.filters.ExpressionFilter
-
- setNumberOfConcurrentTransactedReceivers(int) - Method in class org.mule.transport.AbstractConnector
-
- setNumberOfMessages(int) - Method in class org.mule.routing.outbound.MessageChunkingRouter
-
Deprecated.
- 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
-
- setObjectStore(String, ListableObjectStore<Serializable>) - Method in interface org.mule.api.MuleContext
-
- setObjectStore(String, ListableObjectStore<Serializable>) - Method in class org.mule.DefaultMuleContext
-
- 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
-
- setOptional(boolean) - Method in class org.mule.expression.transformers.ExpressionArgument
-
- setOrderedLifecycleObjects(Set<LifecycleObject>) - Method in interface org.mule.api.lifecycle.LifecyclePhase
-
- setOrderedLifecycleObjects(Set<LifecycleObject>) - Method in class org.mule.lifecycle.phases.DefaultLifecyclePhase
-
- 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
-
- setOverride(Boolean) - Method in class org.mule.util.PropertyChecker
-
- setOverrides(Properties) - Method in class org.mule.transport.service.DefaultTransportServiceDescriptor
-
- setOverwrite(boolean) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
-
- 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
-
- setPassword(String) - Method in class org.mule.endpoint.URIBuilder
-
- setPassword(String) - Method in class org.mule.security.PasswordBasedEncryptionStrategy
-
- setPassword(String) - Method in class org.mule.security.UsernamePasswordAuthenticationFilter
-
- setPath(String) - Method in class org.mule.endpoint.URIBuilder
-
- 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
-
- 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) - 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
-
- 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
-
- 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
-
- setPersistentStores(boolean) - Method in class org.mule.routing.AbstractAggregator
-
- setPollingController(PollingController) - Method in class org.mule.DefaultMuleContext
-
- 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.
- 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
- 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
-
- 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
-
- 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.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
-
- setProcessedEvent(MuleEvent) - Method in exception org.mule.api.MessagingException
-
Sets the event that should be processed once this exception is caught
- setProcessingStrategy(ProcessingStrategy) - Method in interface org.mule.api.construct.Pipeline
-
- 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
-
- 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<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) - 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
-
- 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
-
- 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
-
- 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.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
-
- 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
-
- setProtocol(String) - Method in class org.mule.endpoint.URIBuilder
-
- setProviders(Collection<SecurityProvider>) - Method in interface org.mule.api.security.SecurityManager
-
- setProviders(Collection<SecurityProvider>) - Method in class org.mule.security.MuleSecurityManager
-
- setQueryMap(Map) - Method in class org.mule.endpoint.URIBuilder
-
- setQueueConfiguration(String, QueueConfiguration) - Method in class org.mule.util.queue.AbstractQueueManager
-
- setQueueConfiguration(String, QueueConfiguration) - Method in class org.mule.util.queue.DelegateQueueManager
-
- setQueueConfiguration(String, QueueConfiguration) - Method in class org.mule.util.queue.objectstore.TransactionalQueueManager
-
Deprecated.
- setQueueConfiguration(String, QueueConfiguration) - Method in interface org.mule.util.queue.QueueManager
-
- 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.
- 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.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
-
- 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
-
- setReceiveMessagesInTransaction(boolean) - Method in class org.mule.transport.TransactedPollingMessageReceiver
-
- setReceiverKey(String) - Method in interface org.mule.api.transport.MessageReceiver
-
- setReceiverKey(String) - Method in class org.mule.transport.AbstractMessageReceiver
-
- setReceiverThreadingProfile(ThreadingProfile) - Method in class org.mule.transport.AbstractConnector
-
Setter for property 'receiverThreadingProfile'.
- setRecipients(List<?>) - Method in class org.mule.routing.outbound.StaticRecipientList
-
Deprecated.
- setRedeliveryExceeded(RedeliveryExceeded) - Method in class org.mule.exception.RollbackMessagingExceptionStrategy
-
- setRedeliveryPolicy(AbstractRedeliveryPolicy) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- 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
-
- 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.routing.outbound.AbstractOutboundRouter
-
- 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'.
- 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.
- setResponseMessageProcessors(List<MessageProcessor>) - Method in interface org.mule.api.endpoint.EndpointBuilder
-
- setResponseMessageProcessors(List<MessageProcessor>) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- setResponseTimeout(int) - Method in interface org.mule.api.endpoint.EndpointBuilder
-
- setResponseTimeout(int) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- setResponseTransformers(List<Transformer>) - Method in interface org.mule.api.endpoint.EndpointBuilder
-
Deprecated.
Use setResponseMessageProcessors()
- setResponseTransformers(List<Transformer>) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
Deprecated.
Use setResponseMessageProcessors()
- setResultAggregator(RouterResultsHandler) - Method in class org.mule.routing.DynamicAll
-
- setResultsHandler(RouterResultsHandler) - Method in class org.mule.routing.outbound.AbstractOutboundRouter
-
- 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.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
-
- 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
-
- 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
-
- setReturnSourceIfNull(boolean) - Method in class org.mule.expression.transformers.ExpressionTransformer
-
- setReuseObject(boolean) - Method in interface org.mule.transaction.XaTransaction.MuleXaObject
-
- setRollbackOnly() - Method in interface org.mule.api.transaction.Transaction
-
- 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
-
- 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(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
-
- setSalt(byte[]) - Method in class org.mule.security.PasswordBasedEncryptionStrategy
-
- setScheduler(ScheduledThreadPoolExecutor) - Method in class org.mule.util.store.AbstractMonitoredObjectStore
-
- setScope(String) - Method in class org.mule.routing.filters.MessagePropertyFilter
-
- setScope(PropertyScope) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
-
- setScopeName(String) - Method in class org.mule.transformer.simple.MessagePropertiesTransformer
-
For XML-based config
- setSecondsBetweenRetries(long) - Method in class org.mule.routing.UntilSuccessful
-
- 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(SecurityManager) - Method in class org.mule.security.AbstractSecurityFilter
-
- setSecurityProviders(String) - Method in interface org.mule.api.security.SecurityFilter
-
- setSecurityProviders(String) - Method in class org.mule.security.AbstractSecurityFilter
-
- setSendTransformed(boolean) - Method in class org.mule.routing.ForwardingCatchAllStrategy
-
Deprecated.
- setService(Service) - Method in interface org.mule.api.service.ServiceAware
-
Deprecated.
- setServiceOverrides(Map) - Method in class org.mule.transport.AbstractConnector
-
Set the Service overrides on this connector.
- 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
-
Sets a session variable value with a default data type
- setSessionVariable(String, Serializable, DataType) - Method in interface org.mule.api.MuleEvent
-
Sets a session variable value with a given data type
- 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
-
- setShutdownScreen(SplashScreen) - Method in class org.mule.context.DefaultMuleContextBuilder
-
- setShutdownTimeout(int) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setSource(String) - Method in class org.mule.enricher.MessageEnricher.EnrichExpressionPair
-
- setSslType(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setStartDelay(long) - Method in class org.mule.transport.polling.schedule.FixedFrequencySchedulerFactory
-
- 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.MuleServer
-
- setStartupScreen(SplashScreen) - Method in class org.mule.context.DefaultMuleContextBuilder
-
- 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
-
- 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.transformer.encryption.AbstractEncryptionTransformer
-
- setStringProperty(String, String) - Method in interface org.mule.api.MuleMessage
-
- setStringProperty(String, String) - Method in class org.mule.DefaultMuleMessage
-
Deprecated.
- setSubscription(String) - Method in class org.mule.context.notification.ListenerSubscriptionPair
-
- 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
- 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
-
- setSystemModelType(String) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setTap(MessageProcessor) - Method in class org.mule.routing.WireTap
-
- setTarget(String) - Method in class org.mule.enricher.MessageEnricher.EnrichExpressionPair
-
- 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.model.seda.SedaService
-
Deprecated.
- setThreadingProfile(ThreadingProfile) - Method in class org.mule.routing.ScatterGatherRouter
-
- setThreadingProfile(ThreadingProfile) - Method in class org.mule.routing.UntilSuccessful
-
- 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.
- setThrowOnUnaccepted(boolean) - Method in class org.mule.processor.AbstractFilteringMessageProcessor
-
- setTiltFlag(boolean) - Method in class org.mule.el.mvel.DelegateVariableResolverFactory
-
- 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(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.VoidMuleEvent
-
- setTimeUnit(TimeUnit) - Method in class org.mule.transport.AbstractPollingMessageReceiver
-
- setTimeUnit(TimeUnit) - Method in class org.mule.transport.polling.schedule.FixedFrequencySchedulerFactory
-
- 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
-
- setTransactionManager(TransactionManager) - Method in interface org.mule.api.MuleContext
-
Sets the Jta Transaction Manager to use with this Mule server instance
- setTransactionManager(TransactionManager) - Method in class org.mule.DefaultMuleContext
-
Sets the JTA Transaction Manager to use with this Mule server instance
- 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.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(List<Transformer>) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
Deprecated.
Use setMessageProcessors()
- setTransformers(List<Transformer>) - Method in class org.mule.routing.outbound.FilteringOutboundRouter
-
- setTransientServiceName(Object) - Method in class org.mule.DefaultMuleEvent
-
- setTrustManagerAlgorithm(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setTrustManagerAlgorithm(String) - Method in interface org.mule.api.security.TlsDirectTrustStore
-
- setTrustManagerFactory(TrustManagerFactory) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setTrustManagerFactory(TrustManagerFactory) - Method in interface org.mule.api.security.TlsDirectTrustStore
-
- setTrustStore(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setTrustStore(String) - Method in interface org.mule.api.security.TlsIndirectTrustStore
-
- setTrustStorePassword(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setTrustStorePassword(String) - Method in interface org.mule.api.security.TlsIndirectTrustStore
-
- setTrustStoreType(String) - Method in class org.mule.api.security.tls.TlsConfiguration
-
- setTrustStoreType(String) - Method in interface org.mule.api.security.TlsDirectTrustStore
-
- setTxManager(TransactionManager) - Method in class org.mule.transaction.lookup.GenericTransactionManagerLookupFactory
-
- 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.
- setUnacceptedMessageProcessor(MessageProcessor) - Method in class org.mule.processor.AbstractFilteringMessageProcessor
-
- 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
-
- 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.
- setupObjectClassFromObjectClassName() - Method in class org.mule.object.AbstractObjectFactory
-
- setUpperCase(boolean) - Method in class org.mule.transformer.simple.ByteArrayToHexString
-
- 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.
- setURIBuilder(URIBuilder) - Method in interface org.mule.api.endpoint.EndpointBuilder
-
- setURIBuilder(URIBuilder) - Method in class org.mule.endpoint.AbstractEndpointBuilder
-
- setUrl(String) - Method in class org.mule.object.JndiObjectFactory
-
- setUseExtendedTransformations(boolean) - Method in class org.mule.config.DefaultMuleConfiguration
-
- setUseMultipleTransactedReceivers(boolean) - Method in class org.mule.transport.TransactedPollingMessageReceiver
-
- setUser(String) - Method in class org.mule.endpoint.URIBuilder
-
- setUsername(String) - Method in class org.mule.security.UsernamePasswordAuthenticationFilter
-
- setUseSecureHash(boolean) - Method in class org.mule.processor.IdempotentRedeliveryPolicy
-
- setUseTemplates(boolean) - Method in class org.mule.routing.outbound.FilteringOutboundRouter
-
- 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.
- 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
-
- 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
-
- 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
-
- 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
-
- setWorkTracker(WorkTracker) - Method in class org.mule.transport.TrackingWorkManager
-
- SHA256MuleEventKeyGenerator - Class in org.mule.keygenerator
-
- SHA256MuleEventKeyGenerator() - Constructor for class org.mule.keygenerator.SHA256MuleEventKeyGenerator
-
- SHORT_PAYLOAD_CLASS_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
-
- 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.
- shouldConsumeInEveryNode() - Method in class org.mule.transport.AbstractMessageReceiver
-
Determines whether to start or not the MessageSource base on the running node state.
- 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
-
- 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
- shutdownNormally(Date) - Static method in class org.mule.config.i18n.CoreMessages
-
- shutdownScheduler() - Method in class org.mule.transport.AbstractConnector
-
- shutdownScreen - Variable in class org.mule.context.DefaultMuleContextBuilder
-
- 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
-
- SimpleCollectionAggregator - Class in org.mule.routing
-
- SimpleCollectionAggregator() - Constructor for class org.mule.routing.SimpleCollectionAggregator
-
- SimpleConfigurationBuilder - Class in org.mule.config.builders
-
This simple ConfgurationBuilder implementation.
- SimpleConfigurationBuilder(Map) - Constructor for class org.mule.config.builders.SimpleConfigurationBuilder
-
- 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
-
- SimpleLifecycleManager<O> - Class in org.mule.lifecycle
-
- 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
-
- 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
-
- 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
-
- 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
-
- SimpleRegistry - Class in org.mule.registry
-
- 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 org.mule.config.spring.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
-
- 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
-
- 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
-
- SINGLE_TX - Static variable in class org.mule.config.bootstrap.AbstractRegistryBootstrap
-
- SingleResourceTransactionFactoryManager - Class in org.mule.api
-
- SingleResourceTransactionFactoryManager() - Constructor for class org.mule.api.SingleResourceTransactionFactoryManager
-
- 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
-
- 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.
- size() - Method in interface org.mule.api.MuleMessageCollection
-
- 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.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() - 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.
- SOCKET_ATTRIBUTES - Static variable in class org.mule.endpoint.URIBuilder
-
- SocketEndpointURIBuilder - Class in org.mule.endpoint
-
SocketEndpointBuilder
builds an endpointUri based on host and port
only
- SocketEndpointURIBuilder() - Constructor for class org.mule.endpoint.SocketEndpointURIBuilder
-
- 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_MESSAGE_PROCESSOR_PROPERTY_NAME - Static variable in class org.mule.transport.polling.MessageProcessorPollingMessageReceiver
-
The
InboundEndpoint
property for poll that contains the poll message source.
- 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.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.api.registry
-
- SPIServiceRegistry() - Constructor for class org.mule.api.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(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.
- 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
-
- SplittingStrategy<Input,Output> - Interface in org.mule.util.collection
-
- SQUARE_TEMPLATE_PATTERN - Static variable in class org.mule.util.TemplateParser
-
- SQUARE_TEMPLATE_STYLE - Static variable in class org.mule.util.TemplateParser
-
- stackTraceFilter - Static variable in class org.mule.config.DefaultMuleConfiguration
-
A comma-separated list of internal packages/classes which are removed from sanitized stacktraces.
- 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
- 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.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.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(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.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.transport.AbstractConnector
-
- start() - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- start() - Method in class org.mule.transport.polling.schedule.FixedFrequencyScheduler
-
Starts the Scheduling of a Task.
- 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
-
- StartableCompositeMessageSource() - Constructor for class org.mule.source.StartableCompositeMessageSource
-
- startAfterConnect() - Method in class org.mule.transport.AbstractConnector
-
- 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.util.pool.DefaultLifecycleEnabledObjectPool
-
- 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
-
- startIfNeeded(Collection<? extends Object>) - Static method in class org.mule.api.lifecycle.LifecycleUtils
-
- 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
-
- startOnConnect - Variable in class org.mule.transport.AbstractConnector
-
Indicates whether the connector should start upon connecting.
- 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
-
- startupScreen - Variable in class org.mule.context.DefaultMuleContextBuilder
-
- 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.
- 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
-
- staticContext - Variable in class org.mule.el.mvel.MVELExpressionLanguage
-
- StaticRecipientList - Class in org.mule.routing.outbound
-
Deprecated.
- StaticRecipientList() - Constructor for class org.mule.routing.outbound.StaticRecipientList
-
Deprecated.
- 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.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.
- stats - Variable in class org.mule.service.AbstractService
-
Deprecated.
- 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_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
-
- stop() - Method in class org.mule.agent.AbstractNotificationLoggerAgent
-
- 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.construct.AbstractFlowConstruct
-
- stop() - Method in class org.mule.DefaultMuleContext
-
Stops the MuleContext
which stops all sessions and
connectors
- 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() - 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.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.transport.AbstractConnector
-
- stop() - Method in class org.mule.transport.AbstractTransportMessageHandler
-
- stop() - Method in class org.mule.transport.polling.schedule.FixedFrequencyScheduler
-
Stops the Scheduling of a Task.
- 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
-
- 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
-
- 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
-
- stopIfNeeded(Object) - Static method in class org.mule.api.lifecycle.LifecycleUtils
-
- stopIfStoppable(Object) - Method in class org.mule.construct.AbstractFlowConstruct
-
- stopIfStoppable(Object) - Method in class org.mule.service.AbstractService
-
Deprecated.
- 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.
- stopRequested - Variable in class org.mule.routing.EventProcessingThread
-
- 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.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.QueueStoreAdapter
-
Deprecated.
- store(Serializable, String) - Method in class org.mule.util.store.TextFileObjectStore
-
- 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
-
- 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.
- 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
-
- STRING - Static variable in class org.mule.transformer.types.DataTypeFactory
-
- STRING_DATA_TYPE - Static variable in interface org.mule.api.transformer.DataType
-
- 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.
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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(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
-
- supportsAsynchronousProcessing() - Method in interface org.mule.execution.MessageProcessContext
-
- supportsAsynchronousProcessing() - Method in class org.mule.transport.TransportMessageProcessContext
-
- supportsInnerTransaction(Transaction) - Method in class org.mule.processor.DelegateTransaction
-
- 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
-
- 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 - 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
-
- synchronous - Variable in class org.mule.endpoint.AbstractEndpointBuilder
-
- SYNCHRONOUS_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.
- 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_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).
- SystemUtils - Class in org.mule.util
-
- SystemUtils() - Constructor for class org.mule.util.SystemUtils
-
- SYSTIME_FUNCTION - Static variable in class org.mule.expression.FunctionExpressionEvaluator
-
- 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.processor.AsyncWorkListener
-
- TargetInvocationHandler - Interface in org.mule.util.proxy
-
- 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
-
- TEXT - Static variable in interface org.mule.transformer.types.MimeTypes
-
- TEXT_STRING - Static variable in class org.mule.transformer.types.DataTypeFactory
-
- 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.
- 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
-
- 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
SPI discovery
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
- throwOnUnaccepted - Variable in class org.mule.processor.AbstractFilteringMessageProcessor
-
Throw a FilterUnacceptedException when a message is rejected by the filter?
- 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
- 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 - Variable in class org.mule.routing.requestreply.AbstractAsyncRequestReplyRequester
-
- timeout - Variable in class org.mule.service.ServiceAsyncReplyCompositeMessageSource
-
Deprecated.
- timeout - Variable in class org.mule.transaction.AbstractTransaction
-
- 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_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
-
- 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
- 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
-
- TlsPropertiesMapper(String) - Constructor for class org.mule.api.security.tls.TlsPropertiesMapper
-
- TlsPropertiesSocketFactory - Class in org.mule.api.security.tls
-
- 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.
- 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() - 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(InputStream) - Static method in class org.mule.util.IOUtils
-
- 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
-
- 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.
- 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
-
- toLong(Object) - Static method in class org.mule.util.NumberUtils
-
- toLong(String) - Static method in class org.mule.util.NumberUtils
-
- toMessageCollection() - Method in class org.mule.routing.EventGroup
-
- toMessageCollection(boolean) - Method in class org.mule.routing.EventGroup
-
- 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
-
- 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
-
- toPooledComponent(Class) - Method in class org.mule.config.dsl.ServiceBuilder
-
Deprecated.
- toQueueConfiguration(MuleContext) - Method in class org.mule.config.QueueProfile
-
- toString() - Method in class org.mule.api.context.notification.ServerNotification
-
- 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.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.ListenerSubscriptionPair
-
- toString(Object) - 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.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.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.service.AbstractService
-
Deprecated.
- toString() - Method in class org.mule.source.StartableCompositeMessageSource
-
- 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.NullPayload
-
- 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
-
- 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
-
- toXMLCalendar() - Method in interface org.mule.api.el.datetime.Instant
-
- toXMLCalendar() - Method in class org.mule.el.datetime.AbstractInstant
-
- trace(Object) - Method in class org.mule.util.MuleLogger
-
- trace(Object, Throwable) - Method in class org.mule.util.MuleLogger
-
- 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
-
- TrackingWorkManager(WorkManagerHolder, int) - Constructor for class org.mule.transport.TrackingWorkManager
-
- 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
-
- 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_ROLLEDBACK - Static variable in class org.mule.context.notification.TransactionNotification
-
- 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
- TransactionalInterceptingMessageProcessor - Class in org.mule.processor
-
- TransactionalInterceptingMessageProcessor() - Constructor for class org.mule.processor.TransactionalInterceptingMessageProcessor
-
- 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
-
- 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
-
- 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
-
- 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) - Constructor for class org.mule.util.journal.TransactionJournal
-
- transactionManagerAlreadySet() - Static method in class org.mule.config.i18n.CoreMessages
-
- TransactionManagerFactory - Interface in org.mule.api.transaction
-
TranactionManagerFactory
is a factory class for creating a
transaction manager for the MuleServer.
- 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
-
- 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
-
- 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
-
- 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, 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
-
- 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 - Interface in org.mule.api.transformer
-
Transformer
can be chained together to covert message payloads
from one object type to another.
- TRANSFORMER_KEY - Static variable in class org.mule.config.bootstrap.AbstractRegistryBootstrap
-
- 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.registry.TypeBasedTransformerResolver
-
- transformerChange(Transformer, TransformerResolver.RegistryAction) - Method in class org.mule.transformer.graph.GraphTransformerResolver
-
- 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
-
- transformerInvalidReturnType(Class<?>, String) - Static method in class org.mule.config.i18n.CoreMessages
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- transformHasMultipleMatches(Class<?>, Class<?>, Transformer, 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(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.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() - 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
-
- transformToAny(T, MuleContext, DataType<?>...) - Static method in class org.mule.transformer.TransformerUtils
-
- 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
-
- 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
-
- 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
-
- TransportMessageProcessContext - Class in org.mule.transport
-
- 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
-
- truncate(String, int, boolean) - Static method in class org.mule.util.StringMessageUtils
-
- 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
-
- 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.transformer.types.SimpleDataType
-
- TYPE_BINDING - Static variable in class org.mule.management.stats.RouterStatistics
-
- 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_INBOUND - Static variable in class org.mule.management.stats.RouterStatistics
-
- TYPE_INFO - Static variable in class org.mule.api.context.notification.ServerNotification
-
- 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
-
- 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
-