- Method in class org.apache.camel.model.
- PackageHelper - Class in org.apache.camel.util
-
Some helper methods for working with Java packages and versioning.
- PackageScanClassResolver - Interface in org.apache.camel.spi
-
A resolver that can find resources based on package scanning.
- PackageScanDefinition - Class in org.apache.camel.model
-
PackageScanDefinition
represents a <packageScan/> element.
- PackageScanDefinition() - Constructor for class org.apache.camel.model.PackageScanDefinition
-
- PackageScanFilter - Interface in org.apache.camel.spi
-
- parallelProcessing() - Method in class org.apache.camel.model.AggregateDefinition
-
Sending the aggregated output in parallel
- parallelProcessing() - Method in class org.apache.camel.model.MulticastDefinition
-
- parallelProcessing() - Method in class org.apache.camel.model.RecipientListDefinition
-
Doing the recipient list work in parallel
- parallelProcessing() - Method in class org.apache.camel.model.SplitDefinition
-
Doing the splitting work in parallel
- parameter(String, Object) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- ParameterBindingException - Exception in org.apache.camel.component.bean
-
- ParameterBindingException(Throwable, Method, int, Class<?>, Object) - Constructor for exception org.apache.camel.component.bean.ParameterBindingException
-
- ParameterConfiguration - Class in org.apache.camel.impl
-
Represents the configuration of a URI query parameter value to allow type conversion
and better validation of the configuration of URIs and Endpoints
- ParameterConfiguration(String, Class<?>) - Constructor for class org.apache.camel.impl.ParameterConfiguration
-
- ParameterInfo - Class in org.apache.camel.component.bean
-
Parameter information to be used for method invocation.
- ParameterInfo(int, Class<?>, Annotation[], Expression) - Constructor for class org.apache.camel.component.bean.ParameterInfo
-
- ParameterMappingStrategy - Interface in org.apache.camel.component.bean
-
A strategy for creating a default parameter expression for a given type
- PARENT_PROPERTY - Static variable in interface org.apache.camel.Route
-
- PARENT_UNIT_OF_WORK - Static variable in interface org.apache.camel.Exchange
-
- parse() - Method in class org.apache.camel.converter.jaxp.StaxSource
-
- parse(InputSource) - Method in class org.apache.camel.converter.jaxp.StaxSource
-
- parse(String) - Method in class org.apache.camel.converter.jaxp.StaxSource
-
- parseAndCreateAstModel() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
-
- parseArguments(String[]) - Method in class org.apache.camel.main.MainSupport
-
Parses the command line arguments.
- parseBoolean(CamelContext, String) - Static method in class org.apache.camel.util.CamelContextHelper
-
Parses the given text and converts it to an Boolean and handling property placeholders as well
- parseDouble(CamelContext, String) - Static method in class org.apache.camel.util.CamelContextHelper
-
Parses the given text and converts it to a Double and handling property placeholders as well
- parseExpression(String, boolean) - Static method in class org.apache.camel.language.simple.SimpleBackwardsCompatibleParser
-
Deprecated.
- parseExpression() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
-
- parseInteger(CamelContext, String) - Static method in class org.apache.camel.util.CamelContextHelper
-
Parses the given text and converts it to an Integer and handling property placeholders as well
- parseLong(CamelContext, String) - Static method in class org.apache.camel.util.CamelContextHelper
-
Parses the given text and converts it to an Long and handling property placeholders as well
- parseParameters(URI) - Static method in class org.apache.camel.util.URISupport
-
Parses the query parameters of the uri (eg the query part).
- parsePredicate(String, boolean) - Static method in class org.apache.camel.language.simple.SimpleBackwardsCompatibleParser
-
Deprecated.
- parsePredicate() - Method in class org.apache.camel.language.simple.SimplePredicateParser
-
- parseProperty(String, String, Properties) - Method in class org.apache.camel.component.properties.DefaultPropertiesParser
-
- parseProperty(String, String, Properties) - Method in interface org.apache.camel.component.properties.PropertiesParser
-
While parsing the uri using
parseUri
each
parsed property found invokes this callback.
- parsePropertyValue(String) - Method in class org.apache.camel.util.jsse.JsseParameters
-
Parses the value using the Camel Property Placeholder capabilities if
a context is provided.
- parsePropertyValues(List<String>) - Method in class org.apache.camel.util.jsse.JsseParameters
-
Parses the values using the Camel Property Placeholder capabilities if
a context is provided.
- parseQuery(String) - Static method in class org.apache.camel.util.URISupport
-
Parses the query part of the uri (eg the parameters).
- parseQuery(String, boolean) - Static method in class org.apache.camel.util.URISupport
-
Parses the query part of the uri (eg the parameters).
- parseText(CamelContext, String) - Static method in class org.apache.camel.util.CamelContextHelper
-
Parses the given text and handling property placeholders as well
- parseTokensAndCreateNodes() - Method in class org.apache.camel.language.simple.SimplePredicateParser
-
Parses the tokens and crates the AST nodes.
- parseUri(String, Properties, String, String, String, String, boolean) - Method in interface org.apache.camel.component.properties.AugmentedPropertyNameAwarePropertiesParser
-
Parses the string, applying the optional propertyPrefix
and
propertySuffix
to the parsed property names, and replaces the
property placeholders with values from the given properties.
- parseUri(String, Properties, String, String) - Method in class org.apache.camel.component.properties.DefaultPropertiesParser
-
- parseUri(String, Properties, String, String, String, String, boolean) - Method in class org.apache.camel.component.properties.DefaultPropertiesParser
-
- parseUri(String) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
- parseUri(String, String...) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
- parseUri(String, Properties, String, String) - Method in interface org.apache.camel.component.properties.PropertiesParser
-
Parses the string and replaces the property placeholders with values from the given properties.
- parseURI() - Method in class org.apache.camel.impl.DefaultEndpointConfiguration
-
- parseURI() - Method in class org.apache.camel.impl.MappedEndpointConfiguration
-
- password - Variable in class org.apache.camel.util.jsse.KeyStoreParameters
-
The optional password for reading/opening/verifying the key store.
- pattern(ExchangePattern) - Method in class org.apache.camel.model.SetExchangePatternDefinition
-
- pattern(ExchangePattern) - Method in class org.apache.camel.model.ToDefinition
-
- Pattern - Annotation Type in org.apache.camel
-
- pattern - Variable in class org.apache.camel.processor.SendProcessor
-
- pendingExchanges - Variable in class org.apache.camel.component.file.GenericFileConsumer
-
- pendingExchanges - Variable in class org.apache.camel.impl.ScheduledBatchPollingConsumer
-
- PerformanceCounter - Interface in org.apache.camel.api.management
-
A counter that gathers performance metrics when an
Exchange
is routed in Camel.
- performAssertions(Exchange, Exchange) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
-
- performAssertions(Exchange, Exchange) - Method in class org.apache.camel.component.mock.MockEndpoint
-
Performs the assertions on the incoming exchange.
- pgp(String, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the PGP data format
- pgp(String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the PGP data format
- pgp(String, String, String, boolean, boolean) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the PGP data format
- PGPDataFormat - Class in org.apache.camel.model.dataformat
-
- PGPDataFormat() - Constructor for class org.apache.camel.model.dataformat.PGPDataFormat
-
- php(String) - Method in class org.apache.camel.builder.ExpressionClause
-
- php(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
- PhpExpression - Class in org.apache.camel.model.language
-
For PHP expressions and predicates
- PhpExpression() - Constructor for class org.apache.camel.model.language.PhpExpression
-
- PhpExpression(String) - Constructor for class org.apache.camel.model.language.PhpExpression
-
- pick(Expression) - Method in class org.apache.camel.util.toolbox.FlexibleAggregationStrategy
-
Set an expression to extract the element to be aggregated from the incoming
Exchange
.
- pipeline() - Method in class org.apache.camel.model.ProcessorDefinition
-
Pipes and Filters EIP:
Creates a
Pipeline
so that the message
will get processed by each endpoint in turn and for request/response the
output of one endpoint will be the input of the next endpoint
- pipeline(String...) - Method in class org.apache.camel.model.ProcessorDefinition
-
Pipes and Filters EIP:
Creates a
Pipeline
of the list of endpoints so that the message
will get processed by each endpoint in turn and for request/response the
output of one endpoint will be the input of the next endpoint
- pipeline(Endpoint...) - Method in class org.apache.camel.model.ProcessorDefinition
-
Pipes and Filters EIP:
Creates a
Pipeline
of the list of endpoints so that the message
will get processed by each endpoint in turn and for request/response the
output of one endpoint will be the input of the next endpoint
- pipeline(Collection<Endpoint>) - Method in class org.apache.camel.model.ProcessorDefinition
-
Pipes and Filters EIP:
Creates a
Pipeline
of the list of endpoints so that the message
will get processed by each endpoint in turn and for request/response the
output of one endpoint will be the input of the next endpoint
- Pipeline - Class in org.apache.camel.processor
-
Creates a Pipeline pattern where the output of the previous step is sent as
input to the next step, reusing the same message exchanges
- Pipeline(CamelContext, Collection<Processor>) - Constructor for class org.apache.camel.processor.Pipeline
-
- pipelineBindingProcessor(Processor, Exchange, Processor) - Method in class org.apache.camel.component.binding.BindingEndpoint
-
Applies the
Binding
processor to the given exchange before passing it on to the delegateProcessor (either a producer or consumer)
- PipelineDefinition - Class in org.apache.camel.model
-
Represents an XML <pipeline/> element which can be used to define an explicit pipeline; or to define
a specific pipeline within a <multicast> block
- PipelineDefinition() - Constructor for class org.apache.camel.model.PipelineDefinition
-
- PipelineHelper - Class in org.apache.camel.processor
-
- placeholder(String, String) - Method in class org.apache.camel.model.ProcessorDefinition
-
- PLACEHOLDER_QNAME - Static variable in class org.apache.camel.model.Constants
-
- PlatformHelper - Class in org.apache.camel.util
-
Utility dedicated for resolving runtime information related to the platform on which Camel is currently running.
- PojoMessageInvocationHandler - Class in org.apache.camel.component.bean
-
- PojoMessageInvocationHandler(Endpoint, Producer) - Constructor for class org.apache.camel.component.bean.PojoMessageInvocationHandler
-
- PojoProxyHelper - Class in org.apache.camel.component.bean
-
Create a dynamic proxy for a given interface and endpoint that sends the parameter object to the endpoint and optionally
receives a reply.
- policy(Policy) - Method in class org.apache.camel.model.ProcessorDefinition
-
- policy(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
- Policy - Interface in org.apache.camel.spi
-
A strategy capable of applying interceptors to a processor
Its
strongly adviced to use an
AsyncProcessor
as the returned wrapped
Processor
which ensures the policy works well with the asynchronous routing engine.
- PolicyDefinition - Class in org.apache.camel.model
-
Represents an XML <policy/> element
- PolicyDefinition() - Constructor for class org.apache.camel.model.PolicyDefinition
-
- PolicyDefinition(Policy) - Constructor for class org.apache.camel.model.PolicyDefinition
-
- poll() - Method in class org.apache.camel.component.file.GenericFileConsumer
-
Poll for files
- poll() - Method in class org.apache.camel.impl.DefaultScheduledPollConsumer
-
- poll() - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
The polling method which is invoked periodically to poll this consumer
- poll() - Method in class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
-
- poll(long, TimeUnit) - Method in class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
-
- pollDirectory(String, List<GenericFile<File>>, int) - Method in class org.apache.camel.component.file.FileConsumer
-
- pollDirectory(String, List<GenericFile<T>>, int) - Method in class org.apache.camel.component.file.GenericFileConsumer
-
Polls the given directory for files to process
- pollEndpoint(Endpoint, Processor, long) - Static method in class org.apache.camel.util.EndpointHelper
-
Creates a
PollingConsumer
and polls all pending messages on the endpoint
and invokes the given
Processor
to process each
Exchange
and then closes
down the consumer and throws any exceptions thrown.
- pollEndpoint(Endpoint, Processor) - Static method in class org.apache.camel.util.EndpointHelper
-
Creates a
PollingConsumer
and polls all pending messages on the
endpoint and invokes the given
Processor
to process each
Exchange
and then closes down the consumer and throws any
exceptions thrown.
- pollEnrich(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
- pollEnrich(String, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
-
- pollEnrich(String, long, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
-
- pollEnrich(String, long) - Method in class org.apache.camel.model.ProcessorDefinition
-
- PollEnrichDefinition - Class in org.apache.camel.model
-
Represents an XML <pollEnrich/> element
- PollEnrichDefinition() - Constructor for class org.apache.camel.model.PollEnrichDefinition
-
- PollEnrichDefinition(AggregationStrategy, String, long) - Constructor for class org.apache.camel.model.PollEnrichDefinition
-
- PollEnricher - Class in org.apache.camel.processor
-
A content enricher that enriches input data by first obtaining additional
data from a resource represented by an endpoint producer
and second by aggregating input data and additional data.
- PollEnricher(PollingConsumer) - Constructor for class org.apache.camel.processor.PollEnricher
-
- PollEnricher(AggregationStrategy, PollingConsumer, long) - Constructor for class org.apache.camel.processor.PollEnricher
-
- pollEnrichRef(String, long, String) - Method in class org.apache.camel.model.ProcessorDefinition
-
- PollingConsumer - Interface in org.apache.camel
-
Represents a
Polling
Consumer where the caller polls for messages when it is ready.
- PollingConsumerPollingStrategy - Interface in org.apache.camel
-
- PollingConsumerPollStrategy - Interface in org.apache.camel.spi
-
- PollingConsumerSupport - Class in org.apache.camel.impl
-
- PollingConsumerSupport(Endpoint) - Constructor for class org.apache.camel.impl.PollingConsumerSupport
-
- pool - Variable in class org.apache.camel.impl.DefaultServicePool
-
- poolSize(int) - Method in class org.apache.camel.builder.ThreadPoolBuilder
-
- poolSize(Integer) - Method in class org.apache.camel.builder.ThreadPoolProfileBuilder
-
- poolSize(int) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- poolSize(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- poolSize(int) - Method in class org.apache.camel.model.ThreadsDefinition
-
- popBlock() - Method in class org.apache.camel.impl.DefaultTracedRouteNodes
-
- popBlock() - Method in interface org.apache.camel.spi.TracedRouteNodes
-
Pops the last block from tracing.
- popRouteContext() - Method in class org.apache.camel.impl.DefaultUnitOfWork
-
- popRouteContext() - Method in class org.apache.camel.impl.MDCUnitOfWork
-
- popRouteContext() - Method in interface org.apache.camel.spi.UnitOfWork
-
When finished being routed under the current
RouteContext
it should be removed.
- populateDefaultHeaders(Map<String, Object>) - Method in class org.apache.camel.component.dataset.DataSetSupport
-
Allows derived classes to customize a default set of properties
- populateDefaultNamespaces(DefaultNamespaceContext) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
Populate a number of standard prefixes if they are not already there
- populateFromURI(CamelContext, EndpointConfiguration, ConfigurationHelper.ParameterSetter) - Static method in class org.apache.camel.impl.ConfigurationHelper
-
- populateHeaders(GenericFileMessage<T>) - Method in class org.apache.camel.component.file.GenericFile
-
- populateInitialAttachments(Map<String, DataHandler>) - Method in class org.apache.camel.impl.DefaultMessage
-
A strategy method populate the initial set of attachments on an inbound
message from an underlying binding
- populateInitialHeaders(Map<String, Object>) - Method in class org.apache.camel.impl.DefaultMessage
-
A strategy method populate the initial set of headers on an inbound
message from an underlying binding
- populateMessage(Exchange, long) - Method in interface org.apache.camel.component.dataset.DataSet
-
Populates a message exchange when using the DataSet as a source of messages
- populateMessage(Exchange, long) - Method in class org.apache.camel.component.dataset.DataSetSupport
-
- populateParameterConfigurationMap(SortedMap<String, ParameterConfiguration>, Class<?>, String) - Static method in class org.apache.camel.impl.UriEndpointComponent
-
- populateRoutes() - Method in class org.apache.camel.builder.RouteBuilder
-
- populateVariableMap(Exchange, Map<String, Object>) - Static method in class org.apache.camel.util.ExchangeHelper
-
Populates the Map with the variables which are made available to a script or template
- postInitChannel(ProcessorDefinition<?>, RouteContext) - Method in interface org.apache.camel.model.ModelChannel
-
Post initializes the channel.
- postInitChannel(ProcessorDefinition<?>, RouteContext) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
-
- postPollCheck() - Method in class org.apache.camel.component.file.GenericFileConsumer
-
Override if required.
- postProcessAfterInitialization(Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
-
Apply this post processor to the given new bean instance after any bean
initialization callbacks (like afterPropertiesSet
or a custom init-method).
- postProcessBeforeInitialization(Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
-
Apply this post processor to the given new bean instance before any bean
initialization callbacks (like afterPropertiesSet
or a custom init-method).
- postProcessCamelContext(CamelContext) - Method in class org.apache.camel.main.MainSupport
-
- postProcessContext() - Method in class org.apache.camel.main.MainSupport
-
- postWriteCheck() - Method in class org.apache.camel.component.file.GenericFileProducer
-
Perform any actions that need to occur after we are done such as disconnecting.
- preCheckPoll(Exchange) - Method in class org.apache.camel.processor.PollEnricher
-
Strategy to pre check polling.
- preCreateProcessor() - Method in class org.apache.camel.model.ExpressionNode
-
- preCreateProcessor() - Method in class org.apache.camel.model.ProcessorDefinition
-
Strategy to execute any custom logic before the
Processor
is created.
- preCreateProcessor() - Method in class org.apache.camel.model.TryDefinition
-
- predecessor(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
-
- predecessor(E) - Method in class org.apache.camel.processor.resequencer.Sequence
-
Returns the immediate predecessor of the given element in this sequence
or null
if no predecessor exists.
- predecessor(E, E) - Method in interface org.apache.camel.processor.resequencer.SequenceElementComparator
-
Returns true
if o1
is an immediate predecessor
of o2
.
- predicate(Predicate) - Method in class org.apache.camel.component.mock.AssertionClause
-
Adds the given predicate to this assertion clause
- predicate() - Method in class org.apache.camel.component.mock.AssertionClause
-
Adds the given predicate to this assertion clause
- predicate(String) - Static method in class org.apache.camel.language.simple.SimpleLanguage
-
- Predicate - Interface in org.apache.camel
-
- PredicateAssertHelper - Class in org.apache.camel.util
-
- PredicateBuilder - Class in org.apache.camel.builder
-
A helper class for working with predicates
- PredicateToExpressionAdapter - Class in org.apache.camel.util
-
- PredicateToExpressionAdapter(Predicate) - Constructor for class org.apache.camel.util.PredicateToExpressionAdapter
-
- PredicateValidatingProcessor - Class in org.apache.camel.processor.validation
-
A processor which validates the content of the inbound message body against a
Predicate
.
- PredicateValidatingProcessor(Predicate) - Constructor for class org.apache.camel.processor.validation.PredicateValidatingProcessor
-
- PredicateValidationException - Exception in org.apache.camel.processor.validation
-
A predicate validation exception occurred
- PredicateValidationException(Exchange, Predicate) - Constructor for exception org.apache.camel.processor.validation.PredicateValidationException
-
- PREFIX_TOKEN - Static variable in class org.apache.camel.component.properties.PropertiesComponent
-
- preMove - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- prepare(ModelCamelContext) - Method in class org.apache.camel.model.RouteDefinition
-
Prepares the route definition to be ready to be added to
CamelContext
- prepareAggregation(Exchange, Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
-
Prepares the exchanges for aggregation.
- prepareBlocks() - Method in class org.apache.camel.language.simple.BaseSimpleParser
-
Prepares blocks, such as functions, single or double quoted texts.
- prepareCopy(Exchange, boolean) - Method in class org.apache.camel.component.seda.SedaProducer
-
- prepareExchange(Exchange) - Method in class org.apache.camel.component.directvm.DirectVmProcessor
-
Strategy to prepare exchange for being processed by this consumer
- prepareExchange(Exchange) - Method in class org.apache.camel.component.seda.SedaConsumer
-
Strategy to prepare exchange for being processed by this consumer
- prepareExchange(Exchange, int, Exchange) - Method in class org.apache.camel.processor.LoopProcessor
-
Prepares the exchange for the next iteration
- prepareExchange(Exchange) - Method in class org.apache.camel.processor.OnCompletionProcessor
-
Prepares the
Exchange
to send as onCompletion.
- prepareExchangeAfterFailure(Exchange, RedeliveryErrorHandler.RedeliveryData, boolean, boolean) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
-
- prepareExchangeForContinue(Exchange, RedeliveryErrorHandler.RedeliveryData) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
-
- prepareExchangeForFailover(Exchange) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
-
Prepares the exchange for failover
- prepareExchangeForRedelivery(Exchange, RedeliveryErrorHandler.RedeliveryData) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
-
- prepareExchangeForRoutingSlip(Exchange, Endpoint) - Method in class org.apache.camel.processor.RoutingSlip
-
- prepareLoadedProperties(Properties) - Method in class org.apache.camel.component.properties.DefaultPropertiesResolver
-
Strategy to prepare loaded properties before being used by Camel.
- prepareOnStartup - Variable in class org.apache.camel.component.file.GenericFileConsumer
-
- prepareOnStartup(GenericFileOperations<T>, GenericFileEndpoint<T>) - Method in interface org.apache.camel.component.file.GenericFileExclusiveReadLockStrategy
-
Allows custom logic to be run on startup preparing the strategy, such as removing old lock files etc.
- prepareOnStartup(GenericFileOperations<T>, GenericFileEndpoint<T>) - Method in interface org.apache.camel.component.file.GenericFileProcessStrategy
-
Allows custom logic to be run on first poll preparing the strategy,
such as removing old lock files etc.
- prepareOnStartup(GenericFileOperations<File>, GenericFileEndpoint<File>) - Method in class org.apache.camel.component.file.strategy.FileLockExclusiveReadLockStrategy
-
- prepareOnStartup(GenericFileOperations<T>, GenericFileEndpoint<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileProcessStrategySupport
-
- prepareOnStartup(GenericFileOperations<T>, GenericFileEndpoint<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameExclusiveReadLockStrategy
-
- prepareOnStartup(GenericFileOperations<File>, GenericFileEndpoint<File>) - Method in class org.apache.camel.component.file.strategy.MarkerFileExclusiveReadLockStrategy
-
- prepareOutToIn(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
-
Strategy to prepare results before next iterator or when we are complete,
which is done by copying OUT to IN, so there is only an IN as input
for the next iteration.
- prepareRoute(ModelCamelContext, RouteDefinition) - Static method in class org.apache.camel.model.RouteDefinitionHelper
-
Prepares the route.
- prepareRoute(ModelCamelContext, RouteDefinition, List<OnExceptionDefinition>, List<InterceptDefinition>, List<InterceptFromDefinition>, List<InterceptSendToEndpointDefinition>, List<OnCompletionDefinition>) - Static method in class org.apache.camel.model.RouteDefinitionHelper
-
Prepares the route which supports context scoped features such as onException, interceptors and onCompletions
This method does
not mark the route as prepared afterwards.
- prepareRouteForInit(RouteDefinition, List<ProcessorDefinition<?>>, List<ProcessorDefinition<?>>) - Static method in class org.apache.camel.model.RouteDefinitionHelper
-
- prepareSharedUnitOfWork(Exchange, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
-
Prepares the exchange for participating in a shared unit of work
This ensures a child exchange can access its parent
UnitOfWork
when it participate
in a shared unit of work.
- prepareShutdown(boolean) - Method in class org.apache.camel.component.direct.DirectConsumer
-
- prepareShutdown(boolean) - Method in class org.apache.camel.component.seda.SedaConsumer
-
- prepareShutdown(boolean) - Method in class org.apache.camel.impl.ScheduledBatchPollingConsumer
-
- prepareShutdown(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- prepareShutdown(boolean) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
-
- prepareShutdown(boolean) - Method in interface org.apache.camel.spi.ShutdownPrepared
-
Prepares for shutdown.
- prepareUnaryExpressions() - Method in class org.apache.camel.language.simple.BaseSimpleParser
-
Prepares unary expressions.
- preparingShutdown - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
-
- prepend(Expression, Expression) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Prepends the String evaluations of the two expressions together
- prepend(Object) - Method in class org.apache.camel.builder.ValueBuilder
-
Prepends the string evaluation of this expression with the given value
- prePollCheck() - Method in class org.apache.camel.component.file.GenericFileConsumer
-
Override if required.
- preProcessUri(String) - Method in class org.apache.camel.impl.DefaultComponent
-
Deprecated.
- prestartAllCoreThreads() - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- prestartCoreThread() - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- previousIndex - Variable in class org.apache.camel.language.simple.BaseSimpleParser
-
- preWriteCheck() - Method in class org.apache.camel.component.file.GenericFileProducer
-
Perform any actions that need to occur before we write such as connecting to an FTP server etc.
- printDuration(double) - Static method in class org.apache.camel.util.TimeUtils
-
Prints the duration in a human readable format as X days Y hours Z minutes etc.
- printNode(PrintWriter, NodeData, ProcessorDefinition<?>) - Method in class org.apache.camel.view.RouteDotGenerator
-
- printNode(PrintWriter, NodeData) - Method in class org.apache.camel.view.RouteDotGenerator
-
- printNode(PrintWriter, NodeData, ProcessorDefinition<?>) - Method in class org.apache.camel.view.XmlGraphGenerator
-
- printNode(PrintWriter, NodeData) - Method in class org.apache.camel.view.XmlGraphGenerator
-
- printRoute(PrintWriter, RouteDefinition, FromDefinition) - Method in class org.apache.camel.view.RouteDotGenerator
-
- printRoute(PrintWriter, RouteDefinition, NodeData) - Method in class org.apache.camel.view.XmlGraphGenerator
-
- printRoutes(PrintWriter, Map<String, List<RouteDefinition>>) - Method in class org.apache.camel.view.RouteDotGenerator
-
- printRoutes(PrintWriter, String, List<RouteDefinition>) - Method in class org.apache.camel.view.RouteDotGenerator
-
- printRoutes(PrintWriter, Map<String, List<RouteDefinition>>) - Method in class org.apache.camel.view.XmlGraphGenerator
-
- printRoutes(PrintWriter, String, List<RouteDefinition>) - Method in class org.apache.camel.view.XmlGraphGenerator
-
- printUnitFromBytes(long) - Static method in class org.apache.camel.util.UnitUtils
-
If having a size in bytes and wanting to print this in human friendly\
format with xx kB, xx MB, xx GB instead of a large byte number.
- PriorityBlockingQueueFactory<E> - Class in org.apache.camel.component.seda
-
- PriorityBlockingQueueFactory() - Constructor for class org.apache.camel.component.seda.PriorityBlockingQueueFactory
-
- proceed(AsyncCallback) - Method in interface org.apache.camel.component.bean.MethodInvocation
-
Proceed and invokes the method.
- process(Exchange, AsyncCallback) - Method in interface org.apache.camel.AsyncProcessor
-
Processes the message exchange.
- process(Exchange) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- process(Exchange) - Method in class org.apache.camel.component.bean.BeanProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.bean.BeanProcessor
-
- process(Exchange) - Method in class org.apache.camel.component.binding.BindingConsumerProcessor
-
- process(Exchange) - Method in class org.apache.camel.component.binding.BindingProducer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.controlbus.ControlBusProducer
-
- process(Exchange) - Method in class org.apache.camel.component.direct.DirectBlockingProducer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.direct.DirectBlockingProducer
-
- process(Exchange) - Method in class org.apache.camel.component.direct.DirectProducer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.direct.DirectProducer
-
- process(Exchange) - Method in class org.apache.camel.component.directvm.DirectVmBlockingProducer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.directvm.DirectVmBlockingProducer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.directvm.DirectVmProcessor
-
- process(Exchange) - Method in class org.apache.camel.component.directvm.DirectVmProducer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.directvm.DirectVmProducer
-
- process(Exchange) - Method in class org.apache.camel.component.file.GenericFileProducer
-
- process(Exchange) - Method in class org.apache.camel.component.language.LanguageProducer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.log.LogProducer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.seda.CollectionProducer
-
Deprecated.
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.seda.SedaProducer
-
- process(Exchange) - Method in class org.apache.camel.impl.DefaultAsyncProducer
-
- process(Exchange) - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
-
- process(Exchange) - Method in class org.apache.camel.impl.SynchronousDelegateProducer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.management.InstrumentationProcessor
-
- process(Exchange) - Method in class org.apache.camel.model.LoadBalancerDefinition
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.model.LoadBalancerDefinition
-
- process(Processor) - Method in class org.apache.camel.model.ProcessorDefinition
-
Message Translator EIP:
Adds the custom processor to this destination which could be a final
destination, or could be a transformation in a pipeline
- process(Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.BatchProcessor
-
Deprecated.
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.BatchProcessor
-
Deprecated.
Enqueues an exchange for later batch processing.
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.CamelInternalProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.CamelLogger
-
Deprecated.
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.CamelLogger
-
Deprecated.
- process(Exchange, Throwable) - Method in class org.apache.camel.processor.CamelLogger
-
Deprecated.
- process(Exchange, String) - Method in class org.apache.camel.processor.CamelLogger
-
Deprecated.
- process(Exchange) - Method in class org.apache.camel.processor.CamelLogProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.CamelLogProcessor
-
- process(Exchange, Throwable) - Method in class org.apache.camel.processor.CamelLogProcessor
-
- process(Exchange, String) - Method in class org.apache.camel.processor.CamelLogProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.CatchProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.ChoiceProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ChoiceProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.ConvertBodyProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ConvertBodyProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.DeadLetterChannel
-
- process(Exchange) - Method in class org.apache.camel.processor.DefaultErrorHandler
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.DelayProcessorSupport
-
- process(Exchange) - Method in class org.apache.camel.processor.DelegateAsyncProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.DelegateAsyncProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.DelegateProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.DelegateSyncProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.DelegateSyncProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.Enricher
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Enricher
-
Enriches the input data (exchange
) by first obtaining
additional data from an endpoint represented by an endpoint
producer
and second by aggregating input data and additional
data.
- process(Exchange) - Method in class org.apache.camel.processor.EvaluateExpressionProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.EvaluateExpressionProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.ExchangePatternProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ExchangePatternProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.FatalFallbackErrorHandler
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.FilterProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.FinallyProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.interceptor.HandleFaultInterceptor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.interceptor.StreamCachingInterceptor
-
Deprecated.
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
- process(Exchange) - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
-
Process invoked by the interceptor
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
-
- process(Exchange) - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.loadbalancer.QueueLoadBalancer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.loadbalancer.SimpleLoadBalancerSupport
-
- process(Exchange) - Method in class org.apache.camel.processor.loadbalancer.SimpleLoadBalancerSupport
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
-
- process(Exchange) - Method in class org.apache.camel.processor.LogProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.LogProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.LoopProcessor
-
- process(Exchange, AsyncCallback, AtomicInteger, AtomicInteger, Exchange) - Method in class org.apache.camel.processor.LoopProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.MarshalProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.MarshalProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.MulticastProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.OnCompletionProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.OnCompletionProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.Pipeline
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Pipeline
-
- process(Exchange) - Method in class org.apache.camel.processor.PollEnricher
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.PollEnricher
-
Enriches the input data (exchange
) by first obtaining
additional data from an endpoint represented by an endpoint
producer
and second by aggregating input data and additional
data.
- process(Exchange) - Method in interface org.apache.camel.Processor
-
Processes the message exchange
- process(Exchange) - Method in class org.apache.camel.processor.RecipientList
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RecipientList
-
- process(Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
-
Process the exchange using redelivery error handling.
- process(Exchange) - Method in class org.apache.camel.processor.RollbackProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RollbackProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.RoutingSlip
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RoutingSlip
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SamplingThrottler
-
- process(Exchange) - Method in class org.apache.camel.processor.SendProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SendProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.SetBodyProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SetBodyProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.SortProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SortProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Splitter
-
- process(Exchange) - Method in class org.apache.camel.processor.StopProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.StopProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.StreamResequencer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.StreamResequencer
-
- process(Exchange) - Method in class org.apache.camel.processor.ThreadsProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ThreadsProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.ThroughputLogger
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ThroughputLogger
-
- process(Exchange) - Method in class org.apache.camel.processor.ThrowExceptionProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ThrowExceptionProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.TransformProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.TransformProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.TryProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.TryProcessor
-
- process(Exchange, AsyncCallback, Iterator<Processor>, AsyncProcessor, Object) - Method in class org.apache.camel.processor.TryProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.UnitOfWorkProducer
-
- process(Exchange) - Method in class org.apache.camel.processor.UnmarshalProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.UnmarshalProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.validation.PredicateValidatingProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- process(Exchange) - Method in class org.apache.camel.processor.WireTapProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.WireTapProcessor
-
- process(AsyncProcessor, Exchange, AsyncCallback) - Static method in class org.apache.camel.util.AsyncProcessorHelper
-
Deprecated.
should no longer be needed, instead invoke the process method on the AsyncProcessor
directly,
instead of using this method.
- process(AsyncProcessor, Exchange) - Static method in class org.apache.camel.util.AsyncProcessorHelper
-
Calls the async version of the processor's process method and waits
for it to complete before returning.
- processAsyncErrorHandler(Exchange, AsyncCallback, RedeliveryErrorHandler.RedeliveryData) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
-
This logic is only executed if we have to retry redelivery asynchronously, which have to be done from the callback.
- processBatch(Queue<Object>) - Method in interface org.apache.camel.BatchConsumer
-
Processes the list of
Exchange
objects in a batch.
- processBatch(Queue<Object>) - Method in class org.apache.camel.component.file.GenericFileConsumer
-
- processByAction(Exchange) - Method in class org.apache.camel.component.controlbus.ControlBusProducer
-
- processByLanguage(Exchange, Language) - Method in class org.apache.camel.component.controlbus.ControlBusProducer
-
- ProcessDefinition - Class in org.apache.camel.model
-
Represents an XML <process/> element
- ProcessDefinition() - Constructor for class org.apache.camel.model.ProcessDefinition
-
- ProcessDefinition(Processor) - Constructor for class org.apache.camel.model.ProcessDefinition
-
- processEmptyMessage() - Method in class org.apache.camel.impl.ScheduledBatchPollingConsumer
-
- processEmptyMessage() - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
No messages to poll so send an empty message instead.
- processExchange(Exchange) - Method in class org.apache.camel.component.file.GenericFileConsumer
-
Processes the exchange
- processExchange(Exchange, String) - Method in class org.apache.camel.component.file.GenericFileProducer
-
Perform the work to process the fileExchange
- processExchange(Exchange) - Method in class org.apache.camel.processor.BatchProcessor
-
Deprecated.
Strategy Method to process an exchange in the batch.
- processExchange(Endpoint, Exchange, Exchange, AsyncCallback, RoutingSlip.RoutingSlipIterator) - Method in class org.apache.camel.processor.RoutingSlip
-
- processNext(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.DelegateAsyncProcessor
-
- processNext(Exchange) - Method in class org.apache.camel.processor.DelegateProcessor
-
- processOption(String, LinkedList<String>) - Method in class org.apache.camel.main.MainSupport.Option
-
- Processor - Interface in org.apache.camel
-
- processor - Variable in class org.apache.camel.processor.DelegateAsyncProcessor
-
- processor - Variable in class org.apache.camel.processor.DelegateProcessor
-
- processor - Variable in class org.apache.camel.processor.DelegateSyncProcessor
-
- ProcessorBuilder - Class in org.apache.camel.builder
-
A builder of a number of different
Processor
implementations
- ProcessorDefinition<Type extends ProcessorDefinition<Type>> - Class in org.apache.camel.model
-
Base class for processor types that most XML types extend.
- ProcessorDefinition() - Constructor for class org.apache.camel.model.ProcessorDefinition
-
- ProcessorDefinitionHelper - Class in org.apache.camel.model
-
Helper class for ProcessorDefinition and the other model classes.
- ProcessorEndpoint - Class in org.apache.camel.impl
-
An endpoint which allows exchanges to be sent into it which just invokes a
given
Processor
.
- ProcessorEndpoint() - Constructor for class org.apache.camel.impl.ProcessorEndpoint
-
- ProcessorEndpoint(String, CamelContext, Processor) - Constructor for class org.apache.camel.impl.ProcessorEndpoint
-
- ProcessorEndpoint(String, Component, Processor) - Constructor for class org.apache.camel.impl.ProcessorEndpoint
-
- ProcessorEndpoint(String, Component) - Constructor for class org.apache.camel.impl.ProcessorEndpoint
-
- ProcessorEndpoint(String, Processor) - Constructor for class org.apache.camel.impl.ProcessorEndpoint
-
Deprecated.
- ProcessorExchangePair - Interface in org.apache.camel.processor
-
- ProcessorFactory - Interface in org.apache.camel.spi
-
- ProcessorPollingConsumer - Class in org.apache.camel.impl
-
- ProcessorPollingConsumer(Endpoint, Processor) - Constructor for class org.apache.camel.impl.ProcessorPollingConsumer
-
- ProcessorStatDump - Class in org.apache.camel.util
-
- ProcessorStatDump() - Constructor for class org.apache.camel.util.ProcessorStatDump
-
- processRef(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Message Translator EIP:
Adds the custom processor reference to this destination which could be a final
destination, or could be a transformation in a pipeline
- processStrategy - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- processStrategyCommit(GenericFileProcessStrategy<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.GenericFileOnCompletion
-
Strategy when the file was processed and a commit should be executed.
- processStrategyRollback(GenericFileProcessStrategy<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.GenericFileOnCompletion
-
Strategy when the file was not processed and a rollback should be executed.
- Produce - Annotation Type in org.apache.camel
-
Marks a field or property as being a producer to an
Endpoint
either via its
URI or via the name of the endpoint reference
which is then resolved in a registry such as the Spring Application Context.
- producer - Variable in class org.apache.camel.component.bean.AbstractCamelInvocationHandler
-
- producer - Variable in class org.apache.camel.processor.SendProcessor
-
- Producer - Interface in org.apache.camel
-
Provides a channel on which clients can create and invoke message exchanges
on an
Endpoint
- ProducerCache - Class in org.apache.camel.impl
-
- ProducerCache(Object, CamelContext) - Constructor for class org.apache.camel.impl.ProducerCache
-
- ProducerCache(Object, CamelContext, int) - Constructor for class org.apache.camel.impl.ProducerCache
-
- ProducerCache(Object, CamelContext, Map<String, Producer>) - Constructor for class org.apache.camel.impl.ProducerCache
-
- ProducerCache(Object, CamelContext, ServicePool<Endpoint, Producer>, Map<String, Producer>) - Constructor for class org.apache.camel.impl.ProducerCache
-
- producerCache - Variable in class org.apache.camel.processor.RoutingSlip
-
- producerCache - Variable in class org.apache.camel.processor.SendProcessor
-
- ProducerCallback<T> - Interface in org.apache.camel
-
Callback for sending a exchange message to a endpoint using a producer.
- ProducerTemplate - Interface in org.apache.camel
-
- propagateException(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
-
- propagateFailure(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
-
- PROPAGATION_REQUIRED - Static variable in class org.apache.camel.model.TransactedDefinition
-
- properties() - Method in class org.apache.camel.builder.ExpressionClause
-
An expression of the exchange properties
- properties() - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
An expression of the exchange properties
- Properties - Annotation Type in org.apache.camel
-
Marks a parameter as being an injection point of the properties of an
Exchange
- PropertiesComponent - Class in org.apache.camel.component.properties
-
- PropertiesComponent() - Constructor for class org.apache.camel.component.properties.PropertiesComponent
-
- PropertiesComponent(String) - Constructor for class org.apache.camel.component.properties.PropertiesComponent
-
- PropertiesComponent(String...) - Constructor for class org.apache.camel.component.properties.PropertiesComponent
-
- propertiesComponentExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
- PropertiesDefinition - Class in org.apache.camel.model.config
-
Represents the XML type for <properties>.
- PropertiesDefinition() - Constructor for class org.apache.camel.model.config.PropertiesDefinition
-
- propertiesExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns an expression for the properties of exchange
- PropertiesParser - Interface in org.apache.camel.component.properties
-
A parser to parse properties for a given input
- PropertiesResolver - Interface in org.apache.camel.component.properties
-
A resolver to load properties from a given source such as a file from a classpath.
- property(String) - Static method in class org.apache.camel.builder.Builder
-
Returns a predicate and value builder for properties on an exchange
- property(String) - Method in class org.apache.camel.builder.BuilderSupport
-
Returns a value builder for the given property
- property(String) - Method in class org.apache.camel.builder.ExpressionClause
-
An expression of an exchange property of the given name
- property(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
An expression of an exchange property of the given name
- property(String) - Static method in class org.apache.camel.language.property.PropertyLanguage
-
- Property - Annotation Type in org.apache.camel
-
Marks a parameter as being an injection point of a property of an
Exchange
- PROPERTY_IDGENERATOR_PORT - Static variable in class org.apache.camel.impl.ActiveMQUuidGenerator
-
- PropertyDefinition - Class in org.apache.camel.model.config
-
Represents the XML type for <property>.
- PropertyDefinition() - Constructor for class org.apache.camel.model.config.PropertyDefinition
-
- PropertyEditorTypeConverter - Class in org.apache.camel.impl.converter
-
Deprecated.
should be removed as it can cause side-effects when using 3rd party property editors
- PropertyEditorTypeConverter() - Constructor for class org.apache.camel.impl.converter.PropertyEditorTypeConverter
-
Deprecated.
- propertyExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns an expression for the property value of exchange with the given name
- PropertyExpression - Class in org.apache.camel.model.language
-
An expression which extracts the named exchange property
- PropertyExpression() - Constructor for class org.apache.camel.model.language.PropertyExpression
-
- PropertyExpression(String) - Constructor for class org.apache.camel.model.language.PropertyExpression
-
- PropertyInject - Annotation Type in org.apache.camel
-
- PropertyLanguage - Class in org.apache.camel.language.property
-
A language for property expressions.
- PropertyLanguage() - Constructor for class org.apache.camel.language.property.PropertyLanguage
-
- propertyOgnlExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns an expression for the property value of exchange with the given name invoking methods defined
in a simple OGNL notation
- PropertyPlaceholderDelegateRegistry - Class in org.apache.camel.impl
-
A
Registry
which delegates to the real registry.
- PropertyPlaceholderDelegateRegistry(CamelContext, Registry) - Constructor for class org.apache.camel.impl.PropertyPlaceholderDelegateRegistry
-
- protobuf() - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the protobuf data format
- protobuf(Object) - Method in class org.apache.camel.builder.DataFormatClause
-
- protobuf(String) - Method in class org.apache.camel.builder.DataFormatClause
-
- ProtobufDataFormat - Class in org.apache.camel.model.dataformat
-
- ProtobufDataFormat() - Constructor for class org.apache.camel.model.dataformat.ProtobufDataFormat
-
- ProtobufDataFormat(String) - Constructor for class org.apache.camel.model.dataformat.ProtobufDataFormat
-
- provider - Variable in class org.apache.camel.util.jsse.KeyManagersParameters
-
- provider - Variable in class org.apache.camel.util.jsse.KeyStoreParameters
-
The optional provider identifier for instantiating the key store.
- provider - Variable in class org.apache.camel.util.jsse.SecureRandomParameters
-
The optional provider identifier for the
SecureRandom
factory
method used to create the
SecureRandom
represented by this
object's configuration.
- provider - Variable in class org.apache.camel.util.jsse.TrustManagersParameters
-
- ProxyBuilder - Class in org.apache.camel.builder
-
A build to create Camel proxies.
- ProxyBuilder(CamelContext) - Constructor for class org.apache.camel.builder.ProxyBuilder
-
- ProxyHelper - Class in org.apache.camel.component.bean
-
A helper class for creating proxies which delegate to Camel
- ProxyInstantiationException - Exception in org.apache.camel
-
Exception indicating a failure while trying to create a proxy of a given type and on a given endpoint
- ProxyInstantiationException(Class<?>, Endpoint, Throwable) - Constructor for exception org.apache.camel.ProxyInstantiationException
-
- PublishEventNotifier - Class in org.apache.camel.management
-
- PublishEventNotifier() - Constructor for class org.apache.camel.management.PublishEventNotifier
-
- purge() - Method in interface org.apache.camel.api.management.mbean.ManagedConsumerCacheMBean
-
- purge() - Method in interface org.apache.camel.api.management.mbean.ManagedEndpointRegistryMBean
-
- purge() - Method in interface org.apache.camel.api.management.mbean.ManagedProducerCacheMBean
-
- purge() - Method in interface org.apache.camel.api.management.mbean.ManagedThreadPoolMBean
-
- purge() - Method in class org.apache.camel.impl.ConsumerCache
-
Purges this cache
- purge() - Method in class org.apache.camel.impl.DefaultServicePool
-
- purge() - Method in class org.apache.camel.impl.EndpointRegistry
-
Purges the cache
- purge() - Method in class org.apache.camel.impl.ProducerCache
-
Purges this cache
- purge() - Method in class org.apache.camel.management.mbean.ManagedConsumerCache
-
- purge() - Method in class org.apache.camel.management.mbean.ManagedEndpointRegistry
-
- purge() - Method in class org.apache.camel.management.mbean.ManagedProducerCache
-
- purge() - Method in class org.apache.camel.management.mbean.ManagedThreadPool
-
- purge() - Method in interface org.apache.camel.spi.ServicePool
-
Purges the pool.
- purge() - Method in class org.apache.camel.support.DefaultTimeoutMap
-
- purge() - Method in interface org.apache.camel.TimeoutMap
-
Purges any old entries from the map
- purge() - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- purgeQueue() - Method in class org.apache.camel.component.seda.SedaEndpoint
-
Purges the queue
- pushBlock() - Method in class org.apache.camel.impl.DefaultTracedRouteNodes
-
- pushBlock() - Method in interface org.apache.camel.spi.TracedRouteNodes
-
Prepares a new block for tracing.
- pushRouteContext(RouteContext) - Method in class org.apache.camel.impl.DefaultUnitOfWork
-
- pushRouteContext(RouteContext) - Method in class org.apache.camel.impl.MDCUnitOfWork
-
- pushRouteContext(RouteContext) - Method in interface org.apache.camel.spi.UnitOfWork
-
- put(K, V, long) - Method in class org.apache.camel.support.DefaultTimeoutMap
-
- put(K, V, long) - Method in interface org.apache.camel.TimeoutMap
-
Adds the key value pair into the map such that some time after the given
timeout the entry will be evicted
- put(String, Object) - Method in class org.apache.camel.util.CaseInsensitiveMap
-
- put(K, V) - Method in class org.apache.camel.util.LRUCache
-
- put(K, V) - Method in class org.apache.camel.util.LRUSoftCache
-
- put(K, V) - Method in class org.apache.camel.util.LRUWeakCache
-
- putAll(Map<? extends String, ?>) - Method in class org.apache.camel.util.CaseInsensitiveMap
-
- putAll(Map<? extends K, ? extends V>) - Method in class org.apache.camel.util.LRUCache
-
- putAll(Map<? extends K, ? extends V>) - Method in class org.apache.camel.util.LRUSoftCache
-
- putAll(Map<? extends K, ? extends V>) - Method in class org.apache.camel.util.LRUWeakCache
-
- putIfAbsent(K, V, long) - Method in class org.apache.camel.support.DefaultTimeoutMap
-
- putIfAbsent(K, V, long) - Method in interface org.apache.camel.TimeoutMap
-
Adds the key value pair into the map if the specified key is not already associated with a value
such that some time after the given timeout the entry will be evicted
- python(String) - Method in class org.apache.camel.builder.ExpressionClause
-
- python(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
- PythonExpression - Class in org.apache.camel.model.language
-
For Python expressions and predicates
- PythonExpression() - Constructor for class org.apache.camel.model.language.PythonExpression
-
- PythonExpression(String) - Constructor for class org.apache.camel.model.language.PythonExpression
-
- random() - Method in class org.apache.camel.model.LoadBalanceDefinition
-
Uses random load balancer
- randomBackOff() - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
-
- randomBackOff(boolean) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
-
- randomBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
-
- RandomLoadBalancer - Class in org.apache.camel.processor.loadbalancer
-
Implements the random load balancing policy
- RandomLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
-
- RandomLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
-
Represents an XML <random/> element
- RandomLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.RandomLoadBalancerDefinition
-
- randomNumberGenerator - Static variable in class org.apache.camel.processor.RedeliveryPolicy
-
- RAW_TOKEN_END - Static variable in class org.apache.camel.util.URISupport
-
- RAW_TOKEN_START - Static variable in class org.apache.camel.util.URISupport
-
- read() - Method in class org.apache.camel.converter.stream.FileInputStreamCache
-
- ReaderCache - Class in org.apache.camel.converter.stream
-
- ReaderCache(String) - Constructor for class org.apache.camel.converter.stream.ReaderCache
-
- readExternal(ObjectInput) - Method in class org.apache.camel.component.bean.BeanInvocation
-
- readExternal(ObjectInput) - Method in class org.apache.camel.StringSource
-
- readLock - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- readLockCheckInterval - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- readLockLoggingLevel - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- readLockMinLength - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- readLockTimeout - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- reason(Exchange, String) - Static method in exception org.apache.camel.NoSuchHeaderException
-
- reason(Exchange, String) - Static method in exception org.apache.camel.NoSuchPropertyException
-
- rebind(Name, Object) - Method in class org.apache.camel.util.jndi.JndiContext
-
- rebind(String, Object) - Method in class org.apache.camel.util.jndi.JndiContext
-
- receive() - Method in class org.apache.camel.component.seda.SedaPollingConsumer
-
- receive(long) - Method in class org.apache.camel.component.seda.SedaPollingConsumer
-
- receive(String) - Method in interface org.apache.camel.ConsumerTemplate
-
- receive(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response.
- receive(String, long) - Method in interface org.apache.camel.ConsumerTemplate
-
- receive(Endpoint, long) - Method in interface org.apache.camel.ConsumerTemplate
-
- receive(Endpoint) - Method in class org.apache.camel.impl.ConsumerCache
-
- receive(Endpoint, long) - Method in class org.apache.camel.impl.ConsumerCache
-
- receive(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receive(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receive(String, long) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receive(Endpoint, long) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receive() - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
-
- receive(long) - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
-
- receive() - Method in class org.apache.camel.impl.ProcessorPollingConsumer
-
- receive(long) - Method in class org.apache.camel.impl.ProcessorPollingConsumer
-
- receive() - Method in interface org.apache.camel.PollingConsumer
-
Waits until a message is available and then returns it.
- receive(long) - Method in interface org.apache.camel.PollingConsumer
-
Attempts to receive a message exchange, waiting up to the given timeout
to expire if a message is not yet available.
- receiveBody(String) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
- receiveBody(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
- receiveBody(String, long) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
or the timeout occurs
- receiveBody(Endpoint, long) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
or the timeout occurs
- receiveBody(String, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
- receiveBody(Endpoint, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
- receiveBody(String, long, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
or the timeout occurs
- receiveBody(Endpoint, long, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, waiting until there is a response
or the timeout occurs
- receiveBody(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveBody(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveBody(String, long) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveBody(Endpoint, long) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveBody(String, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveBody(Endpoint, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveBody(String, long, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveBody(Endpoint, long, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveBodyNoWait(String) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, not waiting for a response if non exists.
- receiveBodyNoWait(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, not waiting for a response if non exists.
- receiveBodyNoWait(String, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, not waiting for a response if non exists.
- receiveBodyNoWait(Endpoint, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, not waiting for a response if non exists.
- receiveBodyNoWait(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveBodyNoWait(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveBodyNoWait(String, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveBodyNoWait(Endpoint, Class<T>) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- RECEIVED_TIMESTAMP - Static variable in interface org.apache.camel.Exchange
-
- receiveNoWait() - Method in class org.apache.camel.component.seda.SedaPollingConsumer
-
- receiveNoWait(String) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, not waiting for a response if non exists.
- receiveNoWait(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
-
Receives from the endpoint, not waiting for a response if non exists.
- receiveNoWait(Endpoint) - Method in class org.apache.camel.impl.ConsumerCache
-
- receiveNoWait(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveNoWait(Endpoint) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- receiveNoWait() - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
-
- receiveNoWait() - Method in class org.apache.camel.impl.ProcessorPollingConsumer
-
- receiveNoWait() - Method in interface org.apache.camel.PollingConsumer
-
Attempts to receive a message exchange immediately without waiting and
returning null if a message exchange is not available yet.
- RECIPIENT_LIST_ENDPOINT - Static variable in interface org.apache.camel.Exchange
-
- recipientList(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
Recipient List EIP:
Creates a dynamic recipient list allowing you to route messages to a number of dynamically specified recipients.
- recipientList(Expression, String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Recipient List EIP:
Creates a dynamic recipient list allowing you to route messages to a number of dynamically specified recipients
- recipientList(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Recipient List EIP:
Creates a dynamic recipient list allowing you to route messages to a number of dynamically specified recipients
- recipientList() - Method in class org.apache.camel.model.ProcessorDefinition
-
Recipient List EIP:
Creates a dynamic recipient list allowing you to route messages to a number of dynamically specified recipients
- RecipientList - Class in org.apache.camel.processor
-
Implements a dynamic
Recipient List
pattern where the list of actual endpoints to send a message exchange to are
dependent on some dynamic expression.
- RecipientList(CamelContext) - Constructor for class org.apache.camel.processor.RecipientList
-
- RecipientList(CamelContext, String) - Constructor for class org.apache.camel.processor.RecipientList
-
- RecipientList(CamelContext, Expression) - Constructor for class org.apache.camel.processor.RecipientList
-
- RecipientList(CamelContext, Expression, String) - Constructor for class org.apache.camel.processor.RecipientList
-
- RecipientList - Annotation Type in org.apache.camel
-
Indicates that this method is to be used as a
Dynamic Recipient List routing the incoming message
to one or more endpoints.
- RecipientListDefinition<Type extends ProcessorDefinition<Type>> - Class in org.apache.camel.model
-
Represents an XML <recipientList/> element
- RecipientListDefinition() - Constructor for class org.apache.camel.model.RecipientListDefinition
-
- RecipientListDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.RecipientListDefinition
-
- RecipientListDefinition(Expression) - Constructor for class org.apache.camel.model.RecipientListDefinition
-
- RecipientListProcessor - Class in org.apache.camel.processor
-
Implements a dynamic
Recipient List
pattern where the list of actual endpoints to send a message exchange to are
dependent on some dynamic expression.
- RecipientListProcessor(CamelContext, ProducerCache, Iterator<Object>) - Constructor for class org.apache.camel.processor.RecipientListProcessor
-
- RecipientListProcessor(CamelContext, ProducerCache, Iterator<Object>, AggregationStrategy) - Constructor for class org.apache.camel.processor.RecipientListProcessor
-
- RecipientListProcessor(CamelContext, ProducerCache, Iterator<Object>, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean) - Constructor for class org.apache.camel.processor.RecipientListProcessor
-
- recordTime(Exchange, long) - Method in class org.apache.camel.management.InstrumentationProcessor
-
- recordTime(Exchange, long) - Method in class org.apache.camel.processor.CamelInternalProcessor.InstrumentationAdvice
-
- recover(CamelContext, String) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Recovers the exchange with the given exchange id
- RecoverableAggregationRepository - Interface in org.apache.camel.spi
-
- recursive - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- redeliverDelay(long) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- redeliverDelay(long) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- redeliverDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
- REDELIVERED - Static variable in interface org.apache.camel.Exchange
-
- REDELIVERY_COUNTER - Static variable in interface org.apache.camel.Exchange
-
- REDELIVERY_DELAY - Static variable in interface org.apache.camel.Exchange
-
- REDELIVERY_EXHAUSTED - Static variable in interface org.apache.camel.Exchange
-
- REDELIVERY_MAX_COUNTER - Static variable in interface org.apache.camel.Exchange
-
- redeliveryDelay(long) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- redeliveryDelay(long) - Method in class org.apache.camel.model.OnExceptionDefinition
-
Sets the initial redelivery delay
- redeliveryDelay(String) - Method in class org.apache.camel.model.OnExceptionDefinition
-
Sets the initial redelivery delay (supports property placeholders)
- redeliveryDelay(long) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
Sets the initial redelivery delay
- redeliveryDelay(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
Sets the initial redelivery delay (supports property placeholders)
- redeliveryDelay - Variable in class org.apache.camel.processor.RedeliveryPolicy
-
- redeliveryDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets the initial redelivery delay in milliseconds
- redeliveryEnabled - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
-
- RedeliveryErrorHandler - Class in org.apache.camel.processor
-
Base redeliverable error handler that also supports a final dead letter queue in case
all redelivery attempts fail.
- RedeliveryErrorHandler(CamelContext, Processor, CamelLogger, Processor, RedeliveryPolicy, Processor, String, boolean, Predicate, ScheduledExecutorService) - Constructor for class org.apache.camel.processor.RedeliveryErrorHandler
-
- RedeliveryErrorHandler.RedeliveryData - Class in org.apache.camel.processor
-
Contains the current redelivery data
- RedeliveryErrorHandler.RedeliveryData() - Constructor for class org.apache.camel.processor.RedeliveryErrorHandler.RedeliveryData
-
- redeliveryPolicy - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- redeliveryPolicy - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
-
- RedeliveryPolicy - Class in org.apache.camel.processor
-
The policy used to decide how many times to redeliver and the time between
the redeliveries before being sent to a
Dead Letter
Channel
- RedeliveryPolicy() - Constructor for class org.apache.camel.processor.RedeliveryPolicy
-
- RedeliveryPolicyDefinition - Class in org.apache.camel.model
-
Represents an XML <redeliveryPolicy/> element
- RedeliveryPolicyDefinition() - Constructor for class org.apache.camel.model.RedeliveryPolicyDefinition
-
- redeliveryPolicyRef(String) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- redeliveryProcessor - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
-
- ref(String) - Method in class org.apache.camel.builder.ExpressionClause
-
- ref(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
- ref(Object) - Static method in class org.apache.camel.language.ref.RefLanguage
-
- ref(String) - Method in class org.apache.camel.model.BeanDefinition
-
Deprecated.
not in use, will be removed in next Camel release
- ref - Variable in class org.apache.camel.model.PolicyDefinition
-
- ref(String) - Method in class org.apache.camel.model.PolicyDefinition
-
Sets a reference to use for lookup the policy in the registry.
- ref - Variable in class org.apache.camel.model.SendDefinition
-
- ref - Variable in class org.apache.camel.model.TransactedDefinition
-
- ref(String) - Method in class org.apache.camel.model.TransactedDefinition
-
Sets a reference to use for lookup the policy in the registry.
- ref - Variable in class org.apache.camel.model.WireTapDefinition
-
- RefComponent - Class in org.apache.camel.component.ref
-
Component for lookup of existing endpoints bound in the
Registry
.
- RefComponent() - Constructor for class org.apache.camel.component.ref.RefComponent
-
- refExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns an expression for lookup a bean in the
Registry
- RefExpression - Class in org.apache.camel.model.language
-
- RefExpression() - Constructor for class org.apache.camel.model.language.RefExpression
-
- RefExpression(String) - Constructor for class org.apache.camel.model.language.RefExpression
-
- RefLanguage - Class in org.apache.camel.language.ref
-
A language for referred expressions.
- RefLanguage() - Constructor for class org.apache.camel.language.ref.RefLanguage
-
- ReflectionHelper - Class in org.apache.camel.util
-
Helper for working with reflection on classes.
- ReflectionHelper.FieldCallback - Interface in org.apache.camel.util
-
Callback interface invoked on each field in the hierarchy.
- ReflectionHelper.MethodCallback - Interface in org.apache.camel.util
-
Action to take on each method.
- ReflectionInjector - Class in org.apache.camel.util
-
A simple implementation of
Injector
which just uses reflection to
instantiate new objects using their zero argument constructor.
- ReflectionInjector() - Constructor for class org.apache.camel.util.ReflectionInjector
-
- regex(Expression, String) - Static method in class org.apache.camel.builder.PredicateBuilder
-
Returns a predicate which is true if the expression matches the given
regular expression
- regex(Expression, Pattern) - Static method in class org.apache.camel.builder.PredicateBuilder
-
Returns a predicate which is true if the expression matches the given
regular expression
- regex(String) - Method in class org.apache.camel.builder.ValueBuilder
-
Creates a predicate which is true if this expression matches the given
regular expression
- regexReplaceAll(Expression, String, String) - Static method in class org.apache.camel.builder.Builder
-
Returns an expression that replaces all occurrences of the regular
expression with the given replacement
- regexReplaceAll(Expression, String, Expression) - Static method in class org.apache.camel.builder.Builder
-
Returns an expression that replaces all occurrences of the regular
expression with the given replacement
- regexReplaceAll(Expression, String, String) - Method in class org.apache.camel.builder.BuilderSupport
-
Returns an expression value builder that replaces all occurrences of the
regular expression with the given replacement
- regexReplaceAll(Expression, String, Expression) - Method in class org.apache.camel.builder.BuilderSupport
-
Returns an expression value builder that replaces all occurrences of the
regular expression with the given replacement
- regexReplaceAll(Expression, String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Transforms the expression into a String then performs the regex
replaceAll to transform the String and return the result
- regexReplaceAll(Expression, String, Expression) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Transforms the expression into a String then performs the regex
replaceAll to transform the String and return the result
- regexReplaceAll(String, String) - Method in class org.apache.camel.builder.ValueBuilder
-
Replaces all occurrences of the regular expression with the given
replacement
- regexReplaceAll(String, Expression) - Method in class org.apache.camel.builder.ValueBuilder
-
Replaces all occurrences of the regular expression with the given
replacement
- regexTokenize(String) - Method in class org.apache.camel.builder.ValueBuilder
-
Tokenizes the string conversion of this expression using the given
regular expression
- regexTokenizeExpression(Expression, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns a tokenize expression which will tokenize the string with the
given regex
- register() - Method in class org.apache.camel.impl.osgi.Activator.BaseService
-
- register() - Method in class org.apache.camel.impl.osgi.Activator.BundleComponentResolver
-
- register() - Method in class org.apache.camel.impl.osgi.Activator.BundleDataFormatResolver
-
- register() - Method in class org.apache.camel.impl.osgi.Activator.BundleLanguageResolver
-
- register() - Method in class org.apache.camel.impl.osgi.Activator.BundleMetaLanguageResolver
-
- register() - Method in class org.apache.camel.impl.osgi.Activator.BundleTypeConverterLoader
-
- register(Object, ObjectName) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- register(Object, ObjectName, boolean) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- register(Object, ObjectName) - Method in interface org.apache.camel.spi.ManagementAgent
-
Registers object with management infrastructure with a specific name.
- register(Object, ObjectName, boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Registers object with management infrastructure with a specific name.
- REGISTER_ALWAYS - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
-
- REGISTER_NEW_ROUTES - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
-
- registerComponents(Bundle, List<Activator.BaseService>) - Method in class org.apache.camel.impl.osgi.Activator
-
- registerDataFormats(Bundle, List<Activator.BaseService>) - Method in class org.apache.camel.impl.osgi.Activator
-
- registerEndpoint(String, Endpoint) - Method in class org.apache.camel.impl.InterceptSendToMockEndpointStrategy
-
- registerEndpoint(String, Endpoint) - Method in interface org.apache.camel.spi.EndpointStrategy
-
Register the endpoint.
- registerFallbackTypeConverter(TypeConverterRegistry, TypeConverter, Method) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
-
- registerLanguages(Bundle, List<Activator.BaseService>) - Method in class org.apache.camel.impl.osgi.Activator
-
- registerProcessor(ProcessorDefinition<?>) - Method in class org.apache.camel.management.DefaultManagementLifecycleStrategy
-
Should the given processor be registered.
- registerQueue(SedaEndpoint, BlockingQueue<Exchange>) - Method in class org.apache.camel.component.seda.SedaComponent
-
- registerThreadPoolProfile(ThreadPoolProfile) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
-
- registerThreadPoolProfile(ThreadPoolProfile) - Method in class org.apache.camel.impl.DefaultExecutorServiceStrategy
-
Deprecated.
- registerThreadPoolProfile(ThreadPoolProfile) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Registers the given thread pool profile
- registerThreadPoolProfile(ThreadPoolProfile) - Method in interface org.apache.camel.spi.ExecutorServiceStrategy
-
Deprecated.
Registers the given thread pool profile
- registerTypeConverter(TypeConverterRegistry, Method, Class<?>, Class<?>, TypeConverter) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
-
- registerTypeConverterLoader(Bundle, List<Activator.BaseService>) - Method in class org.apache.camel.impl.osgi.Activator
-
- registry - Variable in class org.apache.camel.main.Main
-
- Registry - Interface in org.apache.camel.spi
-
Represents a service registry which may be implemented via a Spring ApplicationContext,
via JNDI, a simple Map or the OSGi Service Registry
- REGISTRY_PORT - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
-
- RegistryBean - Class in org.apache.camel.component.bean
-
An implementation of a
BeanHolder
which will look up a bean from the registry and act as a cache of its metadata
- RegistryBean(CamelContext, String) - Constructor for class org.apache.camel.component.bean.RegistryBean
-
- RegistryBean(Registry, CamelContext, String) - Constructor for class org.apache.camel.component.bean.RegistryBean
-
- registryExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
-
- reject() - Method in interface org.apache.camel.Rejectable
-
The task was rejected.
- reject() - Method in class org.apache.camel.util.concurrent.RejectableFutureTask
-
- Rejectable - Interface in org.apache.camel
-
Reject executing or processing some task.
- RejectableFutureTask<V> - Class in org.apache.camel.util.concurrent
-
- RejectableFutureTask(Callable<V>) - Constructor for class org.apache.camel.util.concurrent.RejectableFutureTask
-
- RejectableFutureTask(Runnable, V) - Constructor for class org.apache.camel.util.concurrent.RejectableFutureTask
-
- RejectableScheduledThreadPoolExecutor - Class in org.apache.camel.util.concurrent
-
- RejectableScheduledThreadPoolExecutor(int) - Constructor for class org.apache.camel.util.concurrent.RejectableScheduledThreadPoolExecutor
-
- RejectableScheduledThreadPoolExecutor(int, ThreadFactory) - Constructor for class org.apache.camel.util.concurrent.RejectableScheduledThreadPoolExecutor
-
- RejectableScheduledThreadPoolExecutor(int, RejectedExecutionHandler) - Constructor for class org.apache.camel.util.concurrent.RejectableScheduledThreadPoolExecutor
-
- RejectableScheduledThreadPoolExecutor(int, ThreadFactory, RejectedExecutionHandler) - Constructor for class org.apache.camel.util.concurrent.RejectableScheduledThreadPoolExecutor
-
- RejectableThreadPoolExecutor - Class in org.apache.camel.util.concurrent
-
- RejectableThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>) - Constructor for class org.apache.camel.util.concurrent.RejectableThreadPoolExecutor
-
- RejectableThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.camel.util.concurrent.RejectableThreadPoolExecutor
-
- RejectableThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, RejectedExecutionHandler) - Constructor for class org.apache.camel.util.concurrent.RejectableThreadPoolExecutor
-
- RejectableThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory, RejectedExecutionHandler) - Constructor for class org.apache.camel.util.concurrent.RejectableThreadPoolExecutor
-
- rejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.builder.ThreadPoolBuilder
-
- rejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.builder.ThreadPoolProfileBuilder
-
- rejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- rejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.model.ThreadsDefinition
-
Sets the handler for tasks which cannot be executed by the thread pool.
- rejectOld() - Method in class org.apache.camel.model.ResequenceDefinition
-
Sets the rejectOld flag to throw an error when a message older than the last delivered message is processed
- release(Key, Service) - Method in class org.apache.camel.impl.DefaultServicePool
-
- release(Key, Service) - Method in interface org.apache.camel.spi.ServicePool
-
Releases the service back to the pool
- releaseExclusiveReadLock(GenericFileOperations<T>, GenericFile<T>, Exchange) - Method in interface org.apache.camel.component.file.GenericFileExclusiveReadLockStrategy
-
Releases the exclusive read lock granted by the acquireExclusiveReadLock method.
- releaseExclusiveReadLock(GenericFileOperations<File>, GenericFile<File>, Exchange) - Method in class org.apache.camel.component.file.strategy.FileLockExclusiveReadLockStrategy
-
- releaseExclusiveReadLock(GenericFileOperations<File>, GenericFile<File>, Exchange) - Method in class org.apache.camel.component.file.strategy.FileRenameExclusiveReadLockStrategy
-
- releaseExclusiveReadLock(GenericFileOperations<T>, GenericFile<T>, Exchange) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameExclusiveReadLockStrategy
-
- releaseExclusiveReadLock(GenericFileOperations<File>, GenericFile<File>, Exchange) - Method in class org.apache.camel.component.file.strategy.MarkerFileExclusiveReadLockStrategy
-
- releaseProducer(Endpoint, Producer) - Method in class org.apache.camel.impl.EmptyProducerCache
-
- releaseProducer(Endpoint, Producer) - Method in class org.apache.camel.impl.ProducerCache
-
Releases an acquired producer back after usage.
- releaseRetreivedFileResources(Exchange) - Method in class org.apache.camel.component.file.FileOperations
-
- releaseRetreivedFileResources(Exchange) - Method in interface org.apache.camel.component.file.GenericFileOperations
-
Releases the resources consumed by a retrieved file
- remove() - Method in interface org.apache.camel.api.management.mbean.ManagedRouteMBean
-
- remove() - Method in class org.apache.camel.builder.AdviceWithBuilder
-
Removes the matched node(s)
- remove(Exchange) - Method in class org.apache.camel.impl.DefaultInflightRepository
-
- remove(Exchange, String) - Method in class org.apache.camel.impl.DefaultInflightRepository
-
- remove(Bundle) - Method in class org.apache.camel.impl.osgi.tracker.BundleTracker
-
Remove a bundle from this BundleTracker
.
- remove() - Method in class org.apache.camel.management.mbean.ManagedRoute
-
- remove(CamelContext, String, Exchange) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
-
- remove(String) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
-
- remove(String) - Method in class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
-
- remove(CamelContext, String, Exchange) - Method in interface org.apache.camel.spi.AggregationRepository
-
Removes the exchange with the given correlation key, which should happen
when an
Exchange
is completed
Important: This method is
not invoked if only one exchange was completed, and therefore
the exchange does not need to be added to a repository, as its completed immediately.
- remove(E) - Method in interface org.apache.camel.spi.IdempotentRepository
-
Removes the key from the repository.
- remove(Exchange) - Method in interface org.apache.camel.spi.InflightRepository
-
Removes the exchange from the inflight registry to the total counter
- remove(Exchange, String) - Method in interface org.apache.camel.spi.InflightRepository
-
Removes the exchange from the inflight registry removing association to the given route
- remove(CamelContext, String, Exchange) - Method in interface org.apache.camel.spi.OptimisticLockingAggregationRepository
-
Removes the given Exchange when both the supplied key and Exchange are present in the repository.
- remove(K) - Method in class org.apache.camel.support.DefaultTimeoutMap
-
- remove(K) - Method in interface org.apache.camel.TimeoutMap
-
Removes the object with the given key
- remove(Object) - Method in class org.apache.camel.util.CaseInsensitiveMap
-
- remove() - Method in class org.apache.camel.util.GroupIterator
-
- remove(Object) - Method in class org.apache.camel.util.LRUCache
-
- remove(Object) - Method in class org.apache.camel.util.LRUSoftCache
-
- remove(Object) - Method in class org.apache.camel.util.LRUWeakCache
-
- REMOVE_NAMESPACE_PREFIXES - Static variable in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- removeAggregationStrategyFromExchange(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
-
- removeAllBreakpoints() - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- removeAllBreakpoints() - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- removeAllBreakpoints() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- removeAllOnCompletionDefinition(ProcessorDefinition<?>) - Method in class org.apache.camel.model.OnCompletionDefinition
-
- removeAttachment(String) - Method in class org.apache.camel.impl.DefaultMessage
-
- removeAttachment(String) - Method in interface org.apache.camel.Message
-
Removes the attachment specified by the id
- removeBreakpoint(String) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- removeBreakpoint(Breakpoint) - Method in class org.apache.camel.impl.DefaultDebugger
-
- removeBreakpoint(String) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- removeBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- removeBreakpoint(Breakpoint) - Method in interface org.apache.camel.spi.Debugger
-
Removes the given breakpoint
- removeById(RouteDefinition, String, boolean, boolean, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
-
- removeByToString(RouteDefinition, String, boolean, boolean, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
-
- removeByType(RouteDefinition, Class<?>, boolean, boolean, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
-
- removeChildService(Object) - Method in class org.apache.camel.support.ChildServiceSupport
-
- removeComponent(String) - Method in interface org.apache.camel.CamelContext
-
Removes a previously added component.
- removeComponent(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- removeConsumer(DirectConsumer) - Method in class org.apache.camel.component.direct.DirectEndpoint
-
- removeConsumer(DirectVmEndpoint, DirectVmConsumer) - Method in class org.apache.camel.component.directvm.DirectVmComponent
-
- removedBundle(Bundle, BundleEvent, Object) - Method in class org.apache.camel.impl.osgi.Activator
-
- removedBundle(Bundle, BundleEvent, Object) - Method in class org.apache.camel.impl.osgi.tracker.BundleTracker
-
Default implementation of the
BundleTrackerCustomizer.removedBundle
method.
- removedBundle(Bundle, BundleEvent, Object) - Method in interface org.apache.camel.impl.osgi.tracker.BundleTrackerCustomizer
-
A bundle tracked by the BundleTracker
has been removed.
- removeDir(File) - Static method in class org.apache.camel.util.FileUtil
-
- removeEndpoints(String) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
Removes the endpoint by the given pattern
- removeEndpoints(String) - Method in interface org.apache.camel.CamelContext
-
Removes all endpoints with the given URI.
- removeEndpoints(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- removeEndpoints(String) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- removeEventNotifier(EventNotifier) - Method in class org.apache.camel.management.DefaultManagementStrategy
-
- removeEventNotifier(EventNotifier) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Removes the event notifier
- removeExcessiveInProgressFiles(Deque<Exchange>, int) - Method in class org.apache.camel.component.file.GenericFileConsumer
-
Drain any in progress files as we are done with this batch
- removeExcessiveInProgressFiles(List<GenericFile<T>>) - Method in class org.apache.camel.component.file.GenericFileConsumer
-
Drain any in progress files as we are done with the files
- removeFaultHeader(String) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
- removeFaultHeader(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
- removeFilter(PackageScanFilter) - Method in class org.apache.camel.impl.converter.CorePackageScanClassResolver
-
- removeFilter(PackageScanFilter) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
-
- removeFilter(PackageScanFilter) - Method in interface org.apache.camel.spi.PackageScanClassResolver
-
Removes the filter
- removeFromEnvironment(String) - Method in class org.apache.camel.util.jndi.JndiContext
-
- removeHeader(String) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
Removes the header on the message.
- removeHeader(String) - Method in class org.apache.camel.impl.DefaultMessage
-
- removeHeader(String) - Method in interface org.apache.camel.Message
-
Removes the named header from this message
- removeHeader(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Adds a processor which removes the header on the IN message
- RemoveHeaderDefinition - Class in org.apache.camel.model
-
Represents an XML <removeHeader/> element
- RemoveHeaderDefinition() - Constructor for class org.apache.camel.model.RemoveHeaderDefinition
-
- RemoveHeaderDefinition(String) - Constructor for class org.apache.camel.model.RemoveHeaderDefinition
-
- removeHeaders(String) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
Removes the headers on the message
- removeHeaders(String, String...) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
Removes all headers on the message, except for the ones provided in the names parameter
- removeHeaders(String) - Method in class org.apache.camel.impl.DefaultMessage
-
- removeHeaders(String, String...) - Method in class org.apache.camel.impl.DefaultMessage
-
- removeHeaders(String) - Method in interface org.apache.camel.Message
-
Removes the headers from this message
- removeHeaders(String, String...) - Method in interface org.apache.camel.Message
-
Removes the headers from this message that match the given pattern,
except for the ones matching one ore more excludePatterns
- removeHeaders(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Adds a processor which removes the headers on the IN message
- removeHeaders(String, String...) - Method in class org.apache.camel.model.ProcessorDefinition
-
Adds a processor which removes the headers on the IN message
- RemoveHeadersDefinition - Class in org.apache.camel.model
-
Represents an XML <removeHeaders/> element
- RemoveHeadersDefinition() - Constructor for class org.apache.camel.model.RemoveHeadersDefinition
-
- RemoveHeadersDefinition(String) - Constructor for class org.apache.camel.model.RemoveHeadersDefinition
-
- RemoveHeadersDefinition(String, String...) - Constructor for class org.apache.camel.model.RemoveHeadersDefinition
-
- removeLeadingAndEndingQuotes(String) - Static method in class org.apache.camel.util.StringHelper
-
- removeLeadingOperators(String) - Static method in class org.apache.camel.util.OgnlHelper
-
Removes any leading operators from the Camel OGNL expression.
- removeMessageBodyOnBreakpoint(String) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- removeMessageBodyOnBreakpoint(String) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- removeMessageBodyOnBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- removeMessageHeaderOnBreakpoint(String, String) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- removeMessageHeaderOnBreakpoint(String, String) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- removeMessageHeaderOnBreakpoint(String, String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- removeOnExceptionList(String) - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
-
- removeOnExceptionList(String) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
-
Remove the OnExceptionList by look up the route id from the ErrorHandlerBuilder internal map
- removeOnFailure(boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
-
Sets whether to remove or keep the key on failure.
- removeOperators(String) - Static method in class org.apache.camel.util.OgnlHelper
-
- removeProcessor(Processor) - Method in class org.apache.camel.model.LoadBalancerDefinition
-
- removeProcessor(Processor) - Method in interface org.apache.camel.processor.loadbalancer.LoadBalancer
-
Removes the given processor from the load balancer
- removeProcessor(Processor) - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
-
- removeProcessor(Processor) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
-
- removeProperty(String) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
Removes the property on the exchange
- removeProperty(String) - Method in interface org.apache.camel.Exchange
-
Removes the given property on the exchange
- removeProperty(String) - Method in class org.apache.camel.impl.DefaultExchange
-
- removeProperty(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Adds a processor which removes the exchange property
- RemovePropertyDefinition - Class in org.apache.camel.model
-
Represents an XML <removeProperty/> element
- RemovePropertyDefinition() - Constructor for class org.apache.camel.model.RemovePropertyDefinition
-
- RemovePropertyDefinition(String) - Constructor for class org.apache.camel.model.RemovePropertyDefinition
-
- removeQueryString(String) - Method in class org.apache.camel.view.NodeData
-
- removeQuotes(String) - Static method in class org.apache.camel.util.StringHelper
-
- removeRoute(String) - Method in interface org.apache.camel.CamelContext
-
Removes the given route (the route must be stopped before it can be removed).
- removeRoute(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- removeRoute(String) - Method in class org.apache.camel.impl.DefaultInflightRepository
-
- removeRoute(String) - Method in interface org.apache.camel.spi.InflightRepository
-
Removes the route from the in flight registry.
- removeRouteDefinition(RouteDefinition) - Method in interface org.apache.camel.CamelContext
-
- removeRouteDefinition(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
Removes the route definition with the given key.
- removeRouteDefinition(RouteDefinition) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- removeRouteDefinition(RouteDefinition) - Method in interface org.apache.camel.model.ModelCamelContext
-
Removes a route definition from the context - stopping any previously running
routes if any of them are actively running
- removeRouteDefinitions(Collection<RouteDefinition>) - Method in interface org.apache.camel.CamelContext
-
- removeRouteDefinitions(Collection<RouteDefinition>) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- removeRouteDefinitions(Collection<RouteDefinition>) - Method in interface org.apache.camel.model.ModelCamelContext
-
Removes a collection of route definitions from the context - stopping any previously running
routes if any of them are actively running
- removeService(Object) - Method in interface org.apache.camel.CamelContext
-
Removes a service from this context.
- removeService(Object) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- removeStartingCharacters(String, char) - Static method in class org.apache.camel.util.ObjectHelper
-
Removes any starting characters on the given text which match the given
character
- removeSynchronization(Synchronization) - Method in class org.apache.camel.impl.DefaultUnitOfWork
-
- removeSynchronization(Synchronization) - Method in interface org.apache.camel.spi.UnitOfWork
-
Removes a synchronization hook
- removeTimer(TimerConsumer) - Method in class org.apache.camel.component.timer.TimerComponent
-
- removeTimer(TimerConsumer) - Method in class org.apache.camel.component.timer.TimerEndpoint
-
- removeTimerListener(TimerListener) - Method in class org.apache.camel.support.TimerListenerManager
-
Removes the listener.
- removeTraceHandler(TraceEventHandler) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Remove the given tracehandler
- removeTrailingOperators(String) - Static method in class org.apache.camel.util.OgnlHelper
-
Removes any trailing operators from the Camel OGNL expression.
- removeTypeConverter(Class<?>, Class<?>) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
-
- removeTypeConverter(Class<?>, Class<?>) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Removes the type converter
- rename(Name, Name) - Method in class org.apache.camel.util.jndi.JndiContext
-
- rename(String, String) - Method in class org.apache.camel.util.jndi.JndiContext
-
- renameFile(String, String) - Method in class org.apache.camel.component.file.FileOperations
-
- renameFile(String, String) - Method in interface org.apache.camel.component.file.GenericFileOperations
-
Renames the file
- renameFile(Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileExpressionRenamer
-
- renameFile(GenericFileOperations<T>, GenericFile<T>, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileProcessStrategySupport
-
- renameFile(Exchange, GenericFile<T>) - Method in interface org.apache.camel.component.file.strategy.GenericFileRenamer
-
Renames the given file
- renameFile(File, File, boolean) - Static method in class org.apache.camel.util.FileUtil
-
Renames a file.
- renameFileUsingCopy(File, File) - Static method in class org.apache.camel.util.FileUtil
-
Rename file using copy and delete strategy.
- replace() - Method in class org.apache.camel.builder.AdviceWithBuilder
-
Replaces the matched node(s) with the following nodes.
- replaceAll(String, String, String) - Static method in class org.apache.camel.util.StringHelper
-
Replaces all the from tokens in the given input string.
- replaceById(RouteDefinition, String, ProcessorDefinition<?>, boolean, boolean, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
-
- replaceByToString(RouteDefinition, String, ProcessorDefinition<?>, boolean, boolean, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
-
- replaceByType(RouteDefinition, Class<?>, ProcessorDefinition<?>, boolean, boolean, int, int) - Static method in class org.apache.camel.builder.AdviceWithTasks
-
- replaceFrom(RouteDefinition, Endpoint) - Static method in class org.apache.camel.builder.AdviceWithTasks
-
- replaceFromWith(String) - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
-
Replaces the route from endpoint with a new uri
- replaceFromWith(Endpoint) - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
-
Replaces the route from endpoint with a new endpoint
- replaceFromWith(RouteDefinition, String) - Static method in class org.apache.camel.builder.AdviceWithTasks
-
- replaceMessage(Exchange, Message, boolean) - Static method in class org.apache.camel.util.ExchangeHelper
-
Replaces the existing message with the new message
- reporter - Variable in class org.apache.camel.component.mock.MockEndpoint
-
- request(Endpoint, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- request(String, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- request(Endpoint, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an endpoint using a supplied processor
Uses an
ExchangePattern.InOut
message exchange pattern.
- request(String, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an endpoint using a supplied processor
Uses an
ExchangePattern.InOut
message exchange pattern.
- requestBody(String, Object) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- requestBody(Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBody(Endpoint, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBody(String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBody(Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBody(Endpoint, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBody(String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBody(String, Object) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- requestBody(Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint and returns the result content
Uses an
ExchangePattern.InOut
message exchange pattern.
- requestBody(Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint and returns the result content
Uses an
ExchangePattern.InOut
message exchange pattern.
- requestBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBody(Endpoint, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBody(String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBodyAndHeader(Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBodyAndHeader(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBodyAndHeader(Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint and returns the result content
Uses an
ExchangePattern.InOut
message exchange pattern.
- requestBodyAndHeader(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBodyAndHeader(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body.
- requestBodyAndHeaders(String, Object, Map<String, Object>) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- requestBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBodyAndHeaders(Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBodyAndHeaders(String, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBodyAndHeaders(Endpoint, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- requestBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- requestBodyAndHeaders(String, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values.
- requestBodyAndHeaders(String, Object, Map<String, Object>, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values.
- requestBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values.
- requestBodyAndHeaders(Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint and returns the result content
Uses an
ExchangePattern.InOut
message exchange pattern.
- requestBodyAndHeaders(Endpoint, Object, Map<String, Object>, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values.
- requestStringBody(String, String) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- requestStringBody(String, String) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- Required - Annotation Type in org.apache.camel.spi
-
Used to denote fields which are required to be specified for validation purposes
particularly in tooling.
- resequence() - Method in class org.apache.camel.model.ProcessorDefinition
-
Resequencer EIP:
Creates a resequencer allowing you to reorganize messages based on some comparator.
- resequence(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
Resequencer EIP:
Creates a resequencer allowing you to reorganize messages based on some comparator.
- ResequenceDefinition - Class in org.apache.camel.model
-
Represents an XML <resequence/> element
- ResequenceDefinition() - Constructor for class org.apache.camel.model.ResequenceDefinition
-
- Resequencer - Class in org.apache.camel.processor
-
An implementation of the
Resequencer
which can reorder messages within a batch.
- Resequencer(CamelContext, Processor, Expression) - Constructor for class org.apache.camel.processor.Resequencer
-
- Resequencer(CamelContext, Processor, Expression, boolean, boolean) - Constructor for class org.apache.camel.processor.Resequencer
-
- Resequencer(CamelContext, Processor, Set<Exchange>, Expression) - Constructor for class org.apache.camel.processor.Resequencer
-
- ResequencerConfig - Class in org.apache.camel.model.config
-
- ResequencerConfig() - Constructor for class org.apache.camel.model.config.ResequencerConfig
-
- ResequencerEngine<E> - Class in org.apache.camel.processor.resequencer
-
- ResequencerEngine(SequenceElementComparator<E>) - Constructor for class org.apache.camel.processor.resequencer.ResequencerEngine
-
Creates a new resequencer instance with a default timeout of 2000
milliseconds.
- reset(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
Resets all the performance counters.
- reset() - Method in interface org.apache.camel.api.management.mbean.ManagedCounterMBean
-
- reset(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedRouteMBean
-
- reset() - Method in interface org.apache.camel.api.management.mbean.ManagedRuntimeEndpointRegistryMBean
-
- reset() - Method in class org.apache.camel.builder.NotifyBuilder
-
Resets the notifier.
- reset() - Method in class org.apache.camel.component.dataset.DataSetEndpoint
-
- reset() - Method in class org.apache.camel.component.mock.MockEndpoint
-
- reset() - Method in class org.apache.camel.converter.stream.ByteArrayInputStreamCache
-
- reset() - Method in class org.apache.camel.converter.stream.FileInputStreamCache
-
- reset() - Method in class org.apache.camel.converter.stream.ReaderCache
-
- reset() - Method in class org.apache.camel.converter.stream.SourceCache
-
- reset() - Method in class org.apache.camel.converter.stream.StreamSourceCache
-
- reset() - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
-
- reset(boolean) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- reset() - Method in class org.apache.camel.management.mbean.ManagedCounter
-
- reset() - Method in class org.apache.camel.management.mbean.ManagedPerformanceCounter
-
- reset(boolean) - Method in class org.apache.camel.management.mbean.ManagedRoute
-
- reset() - Method in class org.apache.camel.management.mbean.ManagedRuntimeEndpointRegistry
-
- reset() - Method in class org.apache.camel.management.mbean.ManagedThroughputLogger
-
- reset() - Method in class org.apache.camel.management.mbean.Statistic
-
- reset() - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
-
Reset and clears the store to force it to reload from file
- reset() - Method in class org.apache.camel.processor.ThroughputLogger
-
- reset() - Method in class org.apache.camel.processor.validation.DefaultValidationErrorHandler
-
- reset() - Method in interface org.apache.camel.processor.validation.ValidatorErrorHandler
-
Resets any state within this error handler
- reset() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Clears the runtime usage gathered
- reset() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
-
Reset the counters
- reset() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
-
Reset the counters
- reset() - Method in interface org.apache.camel.StreamCache
-
Resets the StreamCache for a new stream consumption.
- resetAllCounters() - Static method in class org.apache.camel.impl.DefaultNodeIdFactory
-
Helper method for test purposes that allows tests to start clean (made protected
to ensure that it is not called accidentally)
- resetCacheStatistics() - Method in class org.apache.camel.impl.ConsumerCache
-
Resets the cache statistics
- resetCacheStatistics() - Method in class org.apache.camel.impl.ProducerCache
-
Resets the cache statistics
- resetDebugCounter() - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- resetDebugCounter() - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- resetDebugCounter() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- resetDuplicateMessageCount() - Method in interface org.apache.camel.api.management.mbean.ManagedIdempotentConsumerMBean
-
- resetDuplicateMessageCount() - Method in class org.apache.camel.management.mbean.ManagedIdempotentConsumer
-
- resetDuplicateMessageCount() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
-
Resets the duplicate message counter to 0L
.
- resetMocks(CamelContext) - Static method in class org.apache.camel.component.mock.MockEndpoint
-
Reset all mock endpoints
- resetRuntimeRatios() - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
-
- resetStatistics() - Method in interface org.apache.camel.api.management.mbean.ManagedConsumerCacheMBean
-
- resetStatistics() - Method in interface org.apache.camel.api.management.mbean.ManagedProducerCacheMBean
-
- resetStatistics() - Method in interface org.apache.camel.api.management.mbean.ManagedStreamCachingStrategyMBean
-
- resetStatistics() - Method in class org.apache.camel.management.mbean.ManagedConsumerCache
-
- resetStatistics() - Method in class org.apache.camel.management.mbean.ManagedProducerCache
-
- resetStatistics() - Method in class org.apache.camel.management.mbean.ManagedStreamCachingStrategy
-
- resetStatistics() - Method in class org.apache.camel.util.LRUCache
-
Rest the cache statistics such as hits and misses.
- resetStreamCache(Message) - Static method in class org.apache.camel.util.MessageHelper
-
If the message body contains a
StreamCache
instance, reset the
cache to enable reading from it again.
- resetThroughputLogger() - Method in interface org.apache.camel.api.management.mbean.ManagedThroughputLoggerMBean
-
- resetThroughputLogger() - Method in class org.apache.camel.management.mbean.ManagedThroughputLogger
-
- resetTimestamp - Variable in class org.apache.camel.management.mbean.ManagedCounter
-
- resetTraceCounter() - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogTracerMBean
-
- resetTraceCounter() - Method in class org.apache.camel.management.mbean.ManagedBacklogTracer
-
- resetTraceCounter() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
-
- resetTypeConversionCounters() - Method in interface org.apache.camel.api.management.mbean.ManagedTypeConverterRegistryMBean
-
- resetTypeConversionCounters() - Method in class org.apache.camel.management.mbean.ManagedTypeConverterRegistry
-
- resolve(String, String) - Method in class org.apache.camel.builder.xml.XsltUriResolver
-
- resolve(CamelContext, String) - Static method in class org.apache.camel.component.mock.MockEndpoint
-
A helper method to resolve the mock endpoint of the given URI on the given context
- resolveAndRemoveReferenceListParameter(Map<String, Object>, String, Class<T>) - Method in class org.apache.camel.impl.DefaultComponent
-
Resolves a reference list parameter in the registry and removes it from
the map.
- resolveAndRemoveReferenceListParameter(Map<String, Object>, String, Class<T>, List<T>) - Method in class org.apache.camel.impl.DefaultComponent
-
Resolves a reference list parameter in the registry and removes it from
the map.
- resolveAndRemoveReferenceParameter(Map<String, Object>, String, Class<T>) - Method in class org.apache.camel.impl.DefaultComponent
-
Resolves a reference parameter in the registry and removes it from the map.
- resolveAndRemoveReferenceParameter(Map<String, Object>, String, Class<T>, T) - Method in class org.apache.camel.impl.DefaultComponent
-
Resolves a reference parameter in the registry and removes it from the map.
- resolveClass(String) - Method in class org.apache.camel.impl.DefaultClassResolver
-
- resolveClass(String, Class<T>) - Method in class org.apache.camel.impl.DefaultClassResolver
-
- resolveClass(String, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
-
- resolveClass(String, Class<T>, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
-
- resolveClass(String) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveClass(String, Class<T>) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveClass(String, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveClass(String, Class<T>, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveComponent(String, CamelContext) - Method in class org.apache.camel.impl.DefaultComponentResolver
-
- resolveComponent(String, CamelContext) - Method in class org.apache.camel.impl.osgi.Activator.BundleComponentResolver
-
- resolveComponent(String, CamelContext) - Method in interface org.apache.camel.spi.ComponentResolver
-
Attempts to resolve the component for the given URI
- resolveDataFormat(String) - Method in interface org.apache.camel.CamelContext
-
Resolve a data format given its name
- resolveDataFormat(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- resolveDataFormat(String, CamelContext) - Method in class org.apache.camel.impl.DefaultDataFormatResolver
-
- resolveDataFormat(String, CamelContext) - Method in class org.apache.camel.impl.osgi.Activator.BundleDataFormatResolver
-
- resolveDataFormat(String, CamelContext) - Method in interface org.apache.camel.spi.DataFormatResolver
-
Resolves the given data format given its name.
- resolveDataFormatDefinition(String) - Method in interface org.apache.camel.CamelContext
-
- resolveDataFormatDefinition(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- resolveDataFormatDefinition(String, CamelContext) - Method in class org.apache.camel.impl.osgi.Activator.BundleDataFormatResolver
-
- resolveDataFormatDefinition(String) - Method in interface org.apache.camel.model.ModelCamelContext
-
Resolve a data format definition given its name
- resolveDefaultFactoryFinder(ClassResolver) - Method in class org.apache.camel.impl.DefaultFactoryFinderResolver
-
- resolveDefaultFactoryFinder(ClassResolver) - Method in interface org.apache.camel.spi.FactoryFinderResolver
-
Creates a new default factory finder using a default resource path.
- resolveEndpoint(String) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- resolveEndpoint(String, String) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- resolveEndpoint(RouteContext) - Method in class org.apache.camel.model.FromDefinition
-
- resolveEndpoint(CamelContext, String) - Method in class org.apache.camel.model.RouteDefinition
-
- resolveEndpoint(RouteContext) - Method in class org.apache.camel.model.SendDefinition
-
- resolveEndpoint(RouteContext) - Method in class org.apache.camel.model.WireTapDefinition
-
- resolveEndpoint(Exchange, Object) - Method in class org.apache.camel.processor.RecipientList
-
- resolveEndpoint(Exchange, Object) - Static method in class org.apache.camel.processor.RecipientListProcessor
-
- resolveEndpoint(RoutingSlip.RoutingSlipIterator, Exchange) - Method in class org.apache.camel.processor.RoutingSlip
-
- resolveEndpoint(String) - Method in interface org.apache.camel.spi.RouteContext
-
Resolves an endpoint from the URI
- resolveEndpoint(String, String) - Method in interface org.apache.camel.spi.RouteContext
-
Resolves an endpoint from either a URI or a named reference
- resolveEndpoint(Exchange, Object) - Static method in class org.apache.camel.util.ExchangeHelper
-
Attempts to resolve the endpoint for the given value
- ResolveEndpointFailedException - Exception in org.apache.camel
-
A runtime exception thrown if an
Endpoint
cannot be resolved via URI
- ResolveEndpointFailedException(String, Throwable) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
-
- ResolveEndpointFailedException(String, String) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
-
- ResolveEndpointFailedException(String) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
-
- resolveFactoryFinder(ClassResolver, String) - Method in class org.apache.camel.impl.DefaultFactoryFinderResolver
-
- resolveFactoryFinder(ClassResolver, String) - Method in interface org.apache.camel.spi.FactoryFinderResolver
-
Creates a new factory finder.
- resolveKnownConstantFields(Object) - Method in class org.apache.camel.model.ProcessorDefinition
-
Inspects the given definition and resolves known fields
This implementation will check all the getter/setter pairs on this instance and for all the values
(which is a String type) will check if it refers to a known field (such as on Exchange).
- resolveLanguage(String) - Method in interface org.apache.camel.CamelContext
-
Resolves a language for creating expressions
- resolveLanguage(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- resolveLanguage(String, CamelContext) - Method in class org.apache.camel.impl.DefaultLanguageResolver
-
- resolveLanguage(String, CamelContext) - Method in class org.apache.camel.impl.osgi.Activator.BundleLanguageResolver
-
- resolveLanguage(String, CamelContext) - Method in class org.apache.camel.impl.osgi.Activator.BundleMetaLanguageResolver
-
- resolveLanguage(String, CamelContext) - Method in interface org.apache.camel.spi.LanguageResolver
-
Resolves the given language.
- resolveManagementName(String, String, boolean) - Method in class org.apache.camel.impl.DefaultManagementNameStrategy
-
Creates a new management name with the given pattern
- resolveManagementName(String, String, boolean) - Method in interface org.apache.camel.spi.ManagementNameStrategy
-
Creates a new management name with the given pattern.
- resolveMandatoryClass(String) - Method in class org.apache.camel.impl.DefaultClassResolver
-
- resolveMandatoryClass(String, Class<T>) - Method in class org.apache.camel.impl.DefaultClassResolver
-
- resolveMandatoryClass(String, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
-
- resolveMandatoryClass(String, Class<T>, ClassLoader) - Method in class org.apache.camel.impl.DefaultClassResolver
-
- resolveMandatoryClass(String) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveMandatoryClass(String, Class<T>) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveMandatoryClass(String, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveMandatoryClass(String, Class<T>, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
-
Resolves the given class by its name
- resolveMandatoryEndpoint(String) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- resolveMandatoryEndpoint(String) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- resolveMandatoryResourceAsInputStream(ClassResolver, String) - Static method in class org.apache.camel.util.ResourceHelper
-
Resolves the mandatory resource.
- resolveMandatoryResourceAsUrl(ClassResolver, String) - Static method in class org.apache.camel.util.ResourceHelper
-
Resolves the mandatory resource.
- resolveMessageIdRepository(RouteContext) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
-
- resolvePath(String) - Static method in class org.apache.camel.util.FilePathResolver
-
Resolves the path.
- resolvePolicy(RouteContext) - Method in class org.apache.camel.model.PolicyDefinition
-
- resolvePolicy(RouteContext) - Method in class org.apache.camel.model.TransactedDefinition
-
- resolveProperties(CamelContext, boolean, String...) - Method in class org.apache.camel.component.properties.DefaultPropertiesResolver
-
- resolveProperties(CamelContext, boolean, String...) - Method in interface org.apache.camel.component.properties.PropertiesResolver
-
Resolve properties from the given uri
- resolvePropertyPlaceholders(String) - Method in interface org.apache.camel.CamelContext
-
Parses the given text and resolve any property placeholders - using {{key}}.
- resolvePropertyPlaceholders(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- resolvePropertyPlaceholders(RouteContext, Object) - Method in class org.apache.camel.model.ProcessorDefinition
-
Inspects the given definition and resolves any property placeholders from its properties.
- resolver - Variable in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
-
- resolver - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
-
- resolveRawParameterValues(Map<String, Object>) - Static method in class org.apache.camel.util.URISupport
-
Traverses the given parameters, and resolve any parameter values which uses the RAW token
syntax: key=RAW(value).
- resolveReferenceListParameter(CamelContext, String, Class<T>) - Static method in class org.apache.camel.util.EndpointHelper
-
Resolves a reference list parameter by making lookups in the registry.
- resolveReferenceParameter(CamelContext, String, Class<T>) - Static method in class org.apache.camel.util.EndpointHelper
-
Resolves a reference parameter by making a lookup in the registry.
- resolveReferenceParameter(CamelContext, String, Class<T>, boolean) - Static method in class org.apache.camel.util.EndpointHelper
-
Resolves a reference parameter by making a lookup in the registry.
- resolveRejectedPolicy(RouteContext) - Method in class org.apache.camel.model.ThreadsDefinition
-
- resolveResource(String, String, String, String, String) - Method in class org.apache.camel.component.validator.DefaultLSResourceResolver
-
- resolveResource(String) - Method in class org.apache.camel.util.jsse.JsseParameters
-
Attempts to loads a resource using a number of different approaches.
- resolveResourceAsInputStream(ClassResolver, String) - Static method in class org.apache.camel.util.ResourceHelper
-
Resolves the resource.
- resolveResourceAsUrl(ClassResolver, String) - Static method in class org.apache.camel.util.ResourceHelper
-
Resolves the resource.
- resolveScript(String) - Method in class org.apache.camel.component.language.LanguageEndpoint
-
Resolves the script.
- resolveSpoolDirectory(String) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- resolveThreadName(String) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
-
- resolveThreadName(String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Creates a full thread name
- resolveThreadName(String, String) - Static method in class org.apache.camel.util.concurrent.ThreadHelper
-
- resolveVariable(QName) - Method in class org.apache.camel.builder.xml.MessageVariableResolver
-
- RESOURCE - Static variable in class org.apache.camel.component.language.LanguageComponent
-
- RESOURCE - Static variable in class org.apache.camel.support.LanguageSupport
-
- resource - Variable in class org.apache.camel.util.jsse.KeyStoreParameters
-
The optional file path, class path resource, or URL of the resource
used to load the key store.
- RESOURCE_PATH - Static variable in class org.apache.camel.impl.DefaultComponentResolver
-
- ResourceEndpoint - Class in org.apache.camel.component
-
A useful base class for endpoints which depend on a resource
such as things like Velocity or XQuery based components.
- ResourceEndpoint() - Constructor for class org.apache.camel.component.ResourceEndpoint
-
- ResourceEndpoint(String, Component, String) - Constructor for class org.apache.camel.component.ResourceEndpoint
-
- ResourceHelper - Class in org.apache.camel.util
-
Helper class for loading resources on the classpath or file system.
- restart() - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- restart() - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- restart() - Method in class org.apache.camel.util.StopWatch
-
Starts or restarts the stop watch
- restoreTimeoutMapFromAggregationRepository() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
Restores the timeout map with timeout values from the aggregation repository.
- ResultHandler - Interface in org.apache.camel.builder.xml
-
A strategy for handling XSLT results
- ResultHandlerFactory - Interface in org.apache.camel.builder.xml
-
- resultType(Class<?>) - Method in class org.apache.camel.builder.SimpleBuilder
-
- resultType(Class<?>) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
Sets the expression result type to the given resultType
- resume() - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- resume() - Method in interface org.apache.camel.api.management.mbean.ManagedServiceMBean
-
- resume() - Method in interface org.apache.camel.api.management.mbean.ManagedSuspendableRouteMBean
-
- resume() - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- resume() - Method in class org.apache.camel.management.mbean.ManagedService
-
- resume() - Method in class org.apache.camel.management.mbean.ManagedSuspendableRoute
-
- resume() - Method in class org.apache.camel.support.ServiceSupport
-
- resume() - Method in interface org.apache.camel.SuspendableService
-
Resumes the service.
- resumeAll() - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- resumeAll() - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- resumeAll() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- resumeBreakpoint(String) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- resumeBreakpoint(String) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- resumeBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- resumeRoute(String) - Method in interface org.apache.camel.CamelContext
-
Resumes the given route if it has been previously suspended
If the route does
not support suspension the route will be started instead
- resumeRoute(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- resumeRoute(Route) - Method in class org.apache.camel.impl.RoutePolicySupport
-
- resumeRouteService(RouteService) - Method in class org.apache.camel.impl.DefaultCamelContext
-
Resumes the given route service
- resumeService(Service) - Static method in class org.apache.camel.util.ServiceHelper
-
Resumes the given service
.
- resumeServices(Collection<?>) - Static method in class org.apache.camel.util.ServiceHelper
-
Resumes each element of the given services
if services
itself is
not null
, otherwise this method would return immediately.
- retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.OnExceptionDefinition
-
Sets the logging level to use when retries has exhausted
- retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
Sets the logging level to use when retries has exhausted
- retriesExhaustedLogLevel - Variable in class org.apache.camel.processor.RedeliveryPolicy
-
- retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets the logging level to use for log messages when retries have been exhausted.
- retrieveFile(String, Exchange) - Method in class org.apache.camel.component.file.FileOperations
-
- retrieveFile(String, Exchange) - Method in interface org.apache.camel.component.file.GenericFileOperations
-
Retrieves the file
- retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.OnExceptionDefinition
-
Sets the logging level to use for logging retry attempts
- retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
Sets the logging level to use for logging retry attempts
- retryAttemptedLogLevel - Variable in class org.apache.camel.processor.RedeliveryPolicy
-
- retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets the logging level to use for log messages when retries are attempted.
- retryDelay(long) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
-
- retryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
-
- retryWhile - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- retryWhile(Expression) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
Sets the retry while expression.
- retryWhile(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
-
Sets the retry while predicate.
- retryWhilePolicy - Variable in class org.apache.camel.processor.RedeliveryErrorHandler
-
- retryWhileRef - Variable in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- returnReplyBody(Expression) - Method in class org.apache.camel.component.mock.MockEndpoint
-
Set the expression which value will be set to the message body
- returnReplyHeader(String, Expression) - Method in class org.apache.camel.component.mock.MockEndpoint
-
Set the expression which value will be set to the message header
- reverse() - Method in class org.apache.camel.model.ResequenceDefinition
-
Enables reverse mode for the batch resequencer mode.
- rollback(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in interface org.apache.camel.component.file.GenericFileProcessStrategy
-
Releases any file locks and possibly deletes or moves the file after
unsuccessful processing
- rollback(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileDeleteProcessStrategy
-
- rollback(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileProcessStrategySupport
-
- rollback(GenericFileOperations<T>, GenericFileEndpoint<T>, Exchange, GenericFile<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
-
- rollback(Consumer, Endpoint, int, Exception) - Method in class org.apache.camel.impl.DefaultPollingConsumerPollStrategy
-
- rollback(Consumer, Endpoint, int, Exception) - Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
-
- rollback() - Method in class org.apache.camel.model.ProcessorDefinition
-
Marks the exchange for rollback only and sets an exception with a default message.
- rollback(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Marks the exchange for rollback and sets an exception with the provided message.
- rollback(Consumer, Endpoint, int, Exception) - Method in interface org.apache.camel.spi.PollingConsumerPollStrategy
-
Called when poll failed
- ROLLBACK_ONLY - Static variable in interface org.apache.camel.Exchange
-
- ROLLBACK_ONLY_LAST - Static variable in interface org.apache.camel.Exchange
-
- RollbackDefinition - Class in org.apache.camel.model
-
Represents an XML <rollback/> element
- RollbackDefinition() - Constructor for class org.apache.camel.model.RollbackDefinition
-
- RollbackDefinition(String) - Constructor for class org.apache.camel.model.RollbackDefinition
-
- RollbackExchangeException - Exception in org.apache.camel
-
Exception used for forcing an Exchange to be rolled back.
- RollbackExchangeException(Exchange) - Constructor for exception org.apache.camel.RollbackExchangeException
-
- RollbackExchangeException(Exchange, Throwable) - Constructor for exception org.apache.camel.RollbackExchangeException
-
- RollbackExchangeException(String, Exchange) - Constructor for exception org.apache.camel.RollbackExchangeException
-
- RollbackExchangeException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.RollbackExchangeException
-
- RollbackProcessor - Class in org.apache.camel.processor
-
Processor for marking an
Exchange
to rollback.
- RollbackProcessor() - Constructor for class org.apache.camel.processor.RollbackProcessor
-
- RollbackProcessor(String) - Constructor for class org.apache.camel.processor.RollbackProcessor
-
- ROOT_NAME - Static variable in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- ROOT_TAG - Static variable in interface org.apache.camel.api.management.mbean.BacklogTracerEventMessage
-
- roundRobin() - Method in class org.apache.camel.model.LoadBalanceDefinition
-
Uses round robin load balancer
- RoundRobinLoadBalancer - Class in org.apache.camel.processor.loadbalancer
-
Implements the round robin load balancing policy
- RoundRobinLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer
-
- RoundRobinLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
-
Represents an XML <roundRobin/> element
- RoundRobinLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.RoundRobinLoadBalancerDefinition
-
- route - Variable in class org.apache.camel.management.mbean.ManagedRoute
-
- route() - Method in class org.apache.camel.model.RoutesDefinition
-
Creates a new route
- route(RouteDefinition) - Method in class org.apache.camel.model.RoutesDefinition
-
Creates a new route using the given route
- Route - Interface in org.apache.camel
-
- ROUTE_STOP - Static variable in interface org.apache.camel.Exchange
-
- RouteAddedEvent - Class in org.apache.camel.management.event
-
- RouteAddedEvent(Route) - Constructor for class org.apache.camel.management.event.RouteAddedEvent
-
- RouteAware - Interface in org.apache.camel
-
An interface to represent an object which wishes to be injected with
a
Route
such as
Consumer
which is the consumer for a route.
- RouteBuilder - Class in org.apache.camel.builder
-
- RouteBuilder() - Constructor for class org.apache.camel.builder.RouteBuilder
-
- RouteBuilder(CamelContext) - Constructor for class org.apache.camel.builder.RouteBuilder
-
- routeBuilderClasses - Variable in class org.apache.camel.main.MainSupport
-
- RouteBuilderDefinition - Class in org.apache.camel.model
-
Represents an XML <routeBuilderRef/> element
- RouteBuilderDefinition() - Constructor for class org.apache.camel.model.RouteBuilderDefinition
-
- RouteBuilderDefinition(String) - Constructor for class org.apache.camel.model.RouteBuilderDefinition
-
- routeBuilders - Variable in class org.apache.camel.main.MainSupport
-
- RouteContainer - Interface in org.apache.camel.model
-
- RouteContext - Interface in org.apache.camel.spi
-
The context used to activate new routing rules
- RouteContextRefDefinition - Class in org.apache.camel.model
-
Represents an XML <routeContextRef/> element
- RouteContextRefDefinition() - Constructor for class org.apache.camel.model.RouteContextRefDefinition
-
- RouteContextRefDefinitionHelper - Class in org.apache.camel.model
-
- RouteDefinition - Class in org.apache.camel.model
-
Represents an XML <route/> element
- RouteDefinition() - Constructor for class org.apache.camel.model.RouteDefinition
-
- RouteDefinition(String) - Constructor for class org.apache.camel.model.RouteDefinition
-
- RouteDefinition(Endpoint) - Constructor for class org.apache.camel.model.RouteDefinition
-
- RouteDefinitionHelper - Class in org.apache.camel.model
-
- RouteDotGenerator - Class in org.apache.camel.view
-
A
DOT file creator plugin which
creates a DOT file showing the current routes
- RouteDotGenerator(String) - Constructor for class org.apache.camel.view.RouteDotGenerator
-
- routeId(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Set the route id for this route.
- routeId(String) - Method in class org.apache.camel.model.RouteDefinition
-
Set the route id for this route
- routeIdExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns an Expression for the route id
- RouteNode - Interface in org.apache.camel
-
Represents a model of a node in the runtime route path.
- routePolicy(RoutePolicy...) - Method in class org.apache.camel.model.RouteDefinition
-
Configures route policies for this route
- RoutePolicy - Interface in org.apache.camel.spi
-
Policy for a
Route
which allows controlling the route at runtime.
- routePolicyRef(String) - Method in class org.apache.camel.model.RouteDefinition
-
Configures a route policy for this route
- RoutePolicySupport - Class in org.apache.camel.impl
-
A base class for developing custom
RoutePolicy
implementations.
- RoutePolicySupport() - Constructor for class org.apache.camel.impl.RoutePolicySupport
-
- RouteRemovedEvent - Class in org.apache.camel.management.event
-
- RouteRemovedEvent(Route) - Constructor for class org.apache.camel.management.event.RouteRemovedEvent
-
- RoutesBuilder - Interface in org.apache.camel
-
A routes builder is capable of building routes using the builder and model classes.
- RoutesDefinition - Class in org.apache.camel.model
-
Represents a collection of routes
- RoutesDefinition() - Constructor for class org.apache.camel.model.RoutesDefinition
-
- RouteService - Class in org.apache.camel.impl
-
Represents the runtime objects for a given
RouteDefinition
so that it can be stopped independently
of other routes
- RouteService(DefaultCamelContext, RouteDefinition, List<RouteContext>, List<Route>) - Constructor for class org.apache.camel.impl.RouteService
-
- routesOutputFile - Variable in class org.apache.camel.main.MainSupport
-
- RouteStartedEvent - Class in org.apache.camel.management.event
-
- RouteStartedEvent(Route) - Constructor for class org.apache.camel.management.event.RouteStartedEvent
-
- RouteStartupOrder - Interface in org.apache.camel.spi
-
Information about a route to be started where we want to control the order
in which they are started by
CamelContext
.
- RouteStatDump - Class in org.apache.camel.util
-
- RouteStatDump() - Constructor for class org.apache.camel.util.RouteStatDump
-
- RouteStoppedEvent - Class in org.apache.camel.management.event
-
- RouteStoppedEvent(Route) - Constructor for class org.apache.camel.management.event.RouteStoppedEvent
-
- routeSupportsSuspension(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- routingSlip(String, String) - Method in class org.apache.camel.model.ProcessorDefinition
-
- routingSlip(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
- routingSlip(String, String, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
-
- routingSlip(String, boolean) - Method in class org.apache.camel.model.ProcessorDefinition
-
- routingSlip(Expression, String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Routing Slip EIP:
Creates a routing slip allowing you to route a message consecutively through a series of processing
steps where the sequence of steps is not known at design time and can vary for each message.
- routingSlip(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
Routing Slip EIP:
Creates a routing slip allowing you to route a message consecutively through a series of processing
steps where the sequence of steps is not known at design time and can vary for each message.
- routingSlip() - Method in class org.apache.camel.model.ProcessorDefinition
-
Routing Slip EIP:
Creates a routing slip allowing you to route a message consecutively through a series of processing
steps where the sequence of steps is not known at design time and can vary for each message.
- RoutingSlip - Class in org.apache.camel.processor
-
Implements a
Routing Slip
pattern where the list of actual endpoints to send a message exchange to are
dependent on the value of a message header.
- RoutingSlip(CamelContext) - Constructor for class org.apache.camel.processor.RoutingSlip
-
- RoutingSlip(CamelContext, Expression, String) - Constructor for class org.apache.camel.processor.RoutingSlip
-
- RoutingSlip - Annotation Type in org.apache.camel
-
Indicates that this method is to be used as a
Routing Slip routing the incoming message
through a series of processing steps.
- RoutingSlip.RoutingSlipIterator - Interface in org.apache.camel.processor
-
The iterator to be used for retrieving the next routing slip(s) to be used.
- RoutingSlipDefinition<Type extends ProcessorDefinition<Type>> - Class in org.apache.camel.model
-
Represents an XML <routingSlip/> element
- RoutingSlipDefinition() - Constructor for class org.apache.camel.model.RoutingSlipDefinition
-
- RoutingSlipDefinition(String) - Constructor for class org.apache.camel.model.RoutingSlipDefinition
-
- RoutingSlipDefinition(String, String) - Constructor for class org.apache.camel.model.RoutingSlipDefinition
-
- RoutingSlipDefinition(Expression, String) - Constructor for class org.apache.camel.model.RoutingSlipDefinition
-
- RoutingSlipDefinition(Expression) - Constructor for class org.apache.camel.model.RoutingSlipDefinition
-
- rss() - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the RSS data format
- RssDataFormat - Class in org.apache.camel.model.dataformat
-
- RssDataFormat() - Constructor for class org.apache.camel.model.dataformat.RssDataFormat
-
- ruby(String) - Method in class org.apache.camel.builder.ExpressionClause
-
- ruby(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
- RubyExpression - Class in org.apache.camel.model.language
-
For Ruby expressions and predicates
- RubyExpression() - Constructor for class org.apache.camel.model.language.RubyExpression
-
- RubyExpression(String) - Constructor for class org.apache.camel.model.language.RubyExpression
-
- run() - Method in class org.apache.camel.component.seda.SedaConsumer
-
- run() - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
Invoked whenever we should be polled
- run() - Method in class org.apache.camel.main.MainSupport
-
Runs this process with the given arguments, and will wait until completed, or the JVM terminates.
- run(String[]) - Method in class org.apache.camel.main.MainSupport
-
Parses the command line arguments then runs the program.
- run() - Method in class org.apache.camel.processor.resequencer.Timeout
-
Notifies the timeout handler about the scheduled timeout.
- run() - Method in class org.apache.camel.support.DefaultTimeoutMap
-
The timer task which purges old requests and schedules another poll
- run() - Method in class org.apache.camel.support.TimerListenerManager
-
- RuntimeBeanExpressionException - Exception in org.apache.camel.language.bean
-
Exception thrown if invocation of bean failed.
- RuntimeBeanExpressionException(Exchange, String, String, Throwable) - Constructor for exception org.apache.camel.language.bean.RuntimeBeanExpressionException
-
- RuntimeCamelException - Exception in org.apache.camel
-
Base class for all Camel unchecked exceptions.
- RuntimeCamelException() - Constructor for exception org.apache.camel.RuntimeCamelException
-
- RuntimeCamelException(String) - Constructor for exception org.apache.camel.RuntimeCamelException
-
- RuntimeCamelException(String, Throwable) - Constructor for exception org.apache.camel.RuntimeCamelException
-
- RuntimeCamelException(Throwable) - Constructor for exception org.apache.camel.RuntimeCamelException
-
- RuntimeConfiguration - Interface in org.apache.camel
-
Various runtime configuration options used by
CamelContext
and
RouteContext
for cross cutting functions such as tracing, delayer, stream cache and the like.
- RuntimeEndpointRegistry - Interface in org.apache.camel.spi
-
A registry which listen for runtime usage of
Endpoint
during routing in Camel.
- RuntimeExchangeException - Exception in org.apache.camel
-
A runtime exception caused by a specific message
Exchange
- RuntimeExchangeException(String, Exchange) - Constructor for exception org.apache.camel.RuntimeExchangeException
-
- RuntimeExchangeException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.RuntimeExchangeException
-
- RuntimeExpressionException - Exception in org.apache.camel
-
Thrown if an expression evaluation fails
- RuntimeExpressionException(String) - Constructor for exception org.apache.camel.RuntimeExpressionException
-
- RuntimeExpressionException(String, Throwable) - Constructor for exception org.apache.camel.RuntimeExpressionException
-
- RuntimeExpressionException(Throwable) - Constructor for exception org.apache.camel.RuntimeExpressionException
-
- RuntimeTransformException - Exception in org.apache.camel
-
Thrown if a message transformation fails
- RuntimeTransformException(String) - Constructor for exception org.apache.camel.RuntimeTransformException
-
- RuntimeTransformException(String, Throwable) - Constructor for exception org.apache.camel.RuntimeTransformException
-
- RuntimeTransformException(Throwable) - Constructor for exception org.apache.camel.RuntimeTransformException
-
- safelyStartRouteServices(boolean, boolean, boolean, boolean, Collection<RouteService>) - Method in class org.apache.camel.impl.DefaultCamelContext
-
Starts the routes services in a proper manner which ensures the routes will be started in correct order,
check for clash and that the routes will also be shutdown in correct order as well.
- safelyStartRouteServices(boolean, boolean, boolean, boolean, boolean, RouteService...) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- sample() - Method in class org.apache.camel.model.ProcessorDefinition
-
Sampling Throttler
Creates a sampling throttler allowing you to extract a sample of
exchanges from the traffic on a route.
- sample(long, TimeUnit) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sampling Throttler
Creates a sampling throttler allowing you to extract a sample of exchanges
from the traffic through a route.
- sample(long) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sampling Throttler
Creates a sampling throttler allowing you to extract a sample of exchanges
from the traffic through a route.
- sampleMessageFrequency(long) - Method in class org.apache.camel.model.SamplingDefinition
-
Sets the sample message count which only a single
Exchange
will pass through after this many received.
- samplePeriod(long) - Method in class org.apache.camel.model.SamplingDefinition
-
Sets the sample period during which only a single
Exchange
will pass through.
- SamplingDefinition - Class in org.apache.camel.model
-
Represents an XML <sample/> element
- SamplingDefinition() - Constructor for class org.apache.camel.model.SamplingDefinition
-
- SamplingDefinition(long, TimeUnit) - Constructor for class org.apache.camel.model.SamplingDefinition
-
- SamplingDefinition(long) - Constructor for class org.apache.camel.model.SamplingDefinition
-
- SamplingThrottler - Class in org.apache.camel.processor
-
A SamplingThrottler
is a special kind of throttler.
- SamplingThrottler(Processor, long) - Constructor for class org.apache.camel.processor.SamplingThrottler
-
- SamplingThrottler(Processor, long, TimeUnit) - Constructor for class org.apache.camel.processor.SamplingThrottler
-
- sanitize(String) - Static method in class org.apache.camel.util.StringHelper
-
Ensures that s
is friendly for a URL or file system.
- sanitizeHostName(String) - Static method in class org.apache.camel.impl.ActiveMQUuidGenerator
-
- sanitizePath(String) - Static method in class org.apache.camel.util.URISupport
-
Removes detected sensitive information (such as passwords) from the
path part of an URI (that is, the part without the query
parameters or component prefix) and returns the result.
- sanitizeUri(String) - Static method in class org.apache.camel.util.URISupport
-
Removes detected sensitive information (such as passwords) from the URI and returns the result.
- sanityCheckRoute(RouteDefinition) - Static method in class org.apache.camel.model.RouteDefinitionHelper
-
Sanity check the route, that it has input(s) and outputs.
- saxon() - Method in class org.apache.camel.builder.xml.XPathBuilder
-
Configures to use Saxon as the XPathFactory which allows you to use XPath 2.0 functions
which may not be part of the build in JDK XPath parser.
- scan(CamelContext) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Scans the repository for
Exchange
s to be recovered
- schedule() - Method in class org.apache.camel.processor.resequencer.Timeout
-
Schedules this timeout task.
- schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- schedule(Runnable, long, TimeUnit) - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- ScheduledBatchPollingConsumer - Class in org.apache.camel.impl
-
A useful base class for any consumer which is polling batch based
- ScheduledBatchPollingConsumer(Endpoint, Processor) - Constructor for class org.apache.camel.impl.ScheduledBatchPollingConsumer
-
- ScheduledBatchPollingConsumer(Endpoint, Processor, ScheduledExecutorService) - Constructor for class org.apache.camel.impl.ScheduledBatchPollingConsumer
-
- ScheduledPollConsumer - Class in org.apache.camel.impl
-
A useful base class for any consumer which is polling based
- ScheduledPollConsumer(Endpoint, Processor) - Constructor for class org.apache.camel.impl.ScheduledPollConsumer
-
- ScheduledPollConsumer(Endpoint, Processor, ScheduledExecutorService) - Constructor for class org.apache.camel.impl.ScheduledPollConsumer
-
- ScheduledPollConsumerScheduler - Interface in org.apache.camel.spi
-
- ScheduledPollEndpoint - Class in org.apache.camel.impl
-
- ScheduledPollEndpoint(String, Component) - Constructor for class org.apache.camel.impl.ScheduledPollEndpoint
-
- ScheduledPollEndpoint(String, CamelContext) - Constructor for class org.apache.camel.impl.ScheduledPollEndpoint
-
Deprecated.
- ScheduledPollEndpoint(String) - Constructor for class org.apache.camel.impl.ScheduledPollEndpoint
-
Deprecated.
- ScheduledPollEndpoint() - Constructor for class org.apache.camel.impl.ScheduledPollEndpoint
-
- schedulePoll() - Method in class org.apache.camel.support.DefaultTimeoutMap
-
lets schedule each time to allow folks to change the time at runtime
- scheduleTask(Runnable) - Method in class org.apache.camel.impl.DefaultScheduledPollConsumerScheduler
-
- scheduleTask(Runnable) - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
-
Schedules the task to run.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- SchemaValidationException - Exception in org.apache.camel.processor.validation
-
A Schema validation exception occurred
- SchemaValidationException(Exchange, Object, List<SAXParseException>, List<SAXParseException>, List<SAXParseException>) - Constructor for exception org.apache.camel.processor.validation.SchemaValidationException
-
- seconds() - Method in class org.apache.camel.component.mock.TimeClause.TimeClassUnit
-
- seconds(long) - Static method in class org.apache.camel.util.Time
-
- SecureRandomParameters - Class in org.apache.camel.util.jsse
-
- SecureRandomParameters() - Constructor for class org.apache.camel.util.jsse.SecureRandomParameters
-
- SecureSocketProtocolsParameters - Class in org.apache.camel.util.jsse
-
Represents a list of TLS/SSL cipher suite names.
- SecureSocketProtocolsParameters() - Constructor for class org.apache.camel.util.jsse.SecureSocketProtocolsParameters
-
- secureXML() - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, boolean) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, Map<String, String>, boolean) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, boolean, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, Map<String, String>, boolean, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, boolean, String, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, Map<String, String>, boolean, String, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, boolean, String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Deprecated.
Use {@link #secureXML(String, Map, boolean, String, String, String, String) instead.
Uses the XML Security data format
- secureXML(String, boolean, String, String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, boolean, String, String, String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, boolean, String, String, String, KeyStoreParameters) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, boolean, String, String, String, KeyStoreParameters, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, Map<String, String>, boolean, String, String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, Map<String, String>, boolean, String, String, String, String, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, Map<String, String>, boolean, String, String, String, KeyStoreParameters) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, Map<String, String>, boolean, String, String, String, KeyStoreParameters, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- secureXML(String, Map<String, String>, boolean, String, String, String, KeyStoreParameters, String, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the XML Security data format
- SedaComponent - Class in org.apache.camel.component.seda
-
- SedaComponent() - Constructor for class org.apache.camel.component.seda.SedaComponent
-
- SedaConsumer - Class in org.apache.camel.component.seda
-
A Consumer for the SEDA component.
- SedaConsumer(SedaEndpoint, Processor) - Constructor for class org.apache.camel.component.seda.SedaConsumer
-
- SedaConsumerNotAvailableException - Exception in org.apache.camel.component.seda
-
- SedaConsumerNotAvailableException(String, Exchange) - Constructor for exception org.apache.camel.component.seda.SedaConsumerNotAvailableException
-
- SedaEndpoint - Class in org.apache.camel.component.seda
-
- SedaEndpoint() - Constructor for class org.apache.camel.component.seda.SedaEndpoint
-
- SedaEndpoint(String, Component, BlockingQueue<Exchange>) - Constructor for class org.apache.camel.component.seda.SedaEndpoint
-
- SedaEndpoint(String, Component, BlockingQueue<Exchange>, int) - Constructor for class org.apache.camel.component.seda.SedaEndpoint
-
- SedaEndpoint(String, Component, BlockingQueueFactory<Exchange>, int) - Constructor for class org.apache.camel.component.seda.SedaEndpoint
-
- SedaPollingConsumer - Class in org.apache.camel.component.seda
-
- SedaPollingConsumer(Endpoint) - Constructor for class org.apache.camel.component.seda.SedaPollingConsumer
-
- SedaProducer - Class in org.apache.camel.component.seda
-
- SedaProducer(SedaEndpoint, BlockingQueue<Exchange>, WaitForTaskToComplete, long) - Constructor for class org.apache.camel.component.seda.SedaProducer
-
- SedaProducer(SedaEndpoint, BlockingQueue<Exchange>, WaitForTaskToComplete, long, boolean) - Constructor for class org.apache.camel.component.seda.SedaProducer
-
- SedaProducer(SedaEndpoint, WaitForTaskToComplete, long, boolean) - Constructor for class org.apache.camel.component.seda.SedaProducer
-
- selectFirst() - Method in class org.apache.camel.builder.AdviceWithBuilder
-
Will only apply the first node matched.
- selectIndex(int) - Method in class org.apache.camel.builder.AdviceWithBuilder
-
Will only apply the n'th node matched.
- selectLast() - Method in class org.apache.camel.builder.AdviceWithBuilder
-
Will only apply the last node matched.
- selectProcessIndex() - Method in class org.apache.camel.processor.loadbalancer.WeightedRandomLoadBalancer
-
- selectRange(int, int) - Method in class org.apache.camel.builder.AdviceWithBuilder
-
Will only apply the node in the index range matched.
- send(String, Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- send(String, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- send(String, ExchangePattern, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- send(Endpoint, Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- send(Endpoint, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- send(Endpoint, ExchangePattern, Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- send(Exchange) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- send(Processor) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- send(Endpoint, Exchange) - Method in class org.apache.camel.impl.ProducerCache
-
Sends the exchange to the given endpoint.
- send(Endpoint, Processor) - Method in class org.apache.camel.impl.ProducerCache
-
Sends an exchange to an endpoint using a supplied
Processor
to populate the exchange
- send(Endpoint, ExchangePattern, Processor) - Method in class org.apache.camel.impl.ProducerCache
-
Sends an exchange to an endpoint using a supplied
Processor
to populate the exchange
- send(Exchange) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the exchange to the default endpoint
Notice: that if the processing of the exchange failed with an Exception
it is
not thrown from this method, but you can access it from the returned exchange using
Exchange.getException()
.
- send(Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to the default endpoint using a supplied processor
Notice: that if the processing of the exchange failed with an Exception
it is
not thrown from this method, but you can access it from the returned exchange using
Exchange.getException()
.
- send(String, Exchange) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the exchange to the given endpoint
Notice: that if the processing of the exchange failed with an Exception
it is
not thrown from this method, but you can access it from the returned exchange using
Exchange.getException()
.
- send(String, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an endpoint using a supplied processor
Notice: that if the processing of the exchange failed with an Exception
it is
not thrown from this method, but you can access it from the returned exchange using
Exchange.getException()
.
- send(String, ExchangePattern, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an endpoint using a supplied processor
Notice: that if the processing of the exchange failed with an Exception
it is
not thrown from this method, but you can access it from the returned exchange using
Exchange.getException()
.
- send(Endpoint, Exchange) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the exchange to the given endpoint
Notice: that if the processing of the exchange failed with an Exception
it is
not thrown from this method, but you can access it from the returned exchange using
Exchange.getException()
.
- send(Endpoint, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an endpoint using a supplied processor
Notice: that if the processing of the exchange failed with an Exception
it is
not thrown from this method, but you can access it from the returned exchange using
Exchange.getException()
.
- send(Endpoint, ExchangePattern, Processor) - Method in interface org.apache.camel.ProducerTemplate
-
Sends an exchange to an endpoint using a supplied processor
Notice: that if the processing of the exchange failed with an Exception
it is
not thrown from this method, but you can access it from the returned exchange using
Exchange.getException()
.
- sendBody(String, Object) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- sendBody(Endpoint, ExchangePattern, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBody(Endpoint, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBody(String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBody(String, ExchangePattern, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBody(Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBody(String, Object) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- sendBody(Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBody(Endpoint, ExchangePattern, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint with the given
ExchangePattern
returning any result output body
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBody(String, ExchangePattern, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Send the body to an endpoint returning any result output body
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndHeader(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndHeader(Endpoint, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndHeader(String, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndHeader(Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndHeader(Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint with a specified header and header value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeader(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified header and header value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeader(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified header and header value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeader(Endpoint, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified header and header value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeader(String, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified header and header value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeaders(String, Object, Map<String, Object>) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- sendBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndHeaders(String, ExchangePattern, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndHeaders(Endpoint, ExchangePattern, Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndHeaders(Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- sendBodyAndHeaders(Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint with the specified headers and header values
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeaders(String, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeaders(String, ExchangePattern, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndHeaders(Endpoint, ExchangePattern, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with the specified headers and header values
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndProperty(String, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndProperty(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndProperty(Endpoint, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndProperty(String, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndProperty(Object, String, Object) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- sendBodyAndProperty(Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to the default endpoint with a specified property and property value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndProperty(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified property and property value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndProperty(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified property and property value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndProperty(Endpoint, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified property and property value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- sendBodyAndProperty(String, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
-
Sends the body to an endpoint with a specified property and property value
Notice: that if the processing of the exchange failed with an Exception
it is thrown from this method as a
CamelExecutionException
with
the caused exception wrapped.
- SendDefinition<Type extends ProcessorDefinition<Type>> - Class in org.apache.camel.model
-
- SendDefinition() - Constructor for class org.apache.camel.model.SendDefinition
-
- SendDefinition(String) - Constructor for class org.apache.camel.model.SendDefinition
-
- sendElement(E) - Method in interface org.apache.camel.processor.resequencer.SequenceSender
-
Sends the given element.
- sendElement(Exchange) - Method in class org.apache.camel.processor.StreamResequencer
-
Sends the exchange
to the next processor
.
- sendExchange(Endpoint, ExchangePattern, Processor, Exchange) - Method in class org.apache.camel.impl.ProducerCache
-
- sendMessages(long, long) - Method in class org.apache.camel.component.dataset.DataSetConsumer
-
- sendNotification(Notification) - Method in interface org.apache.camel.api.management.NotificationSender
-
Send notification
- sendNotification(Notification) - Method in class org.apache.camel.management.NotificationSenderAdapter
-
- SendProcessor - Class in org.apache.camel.processor
-
Processor for forwarding exchanges to an endpoint destination.
- SendProcessor(Endpoint) - Constructor for class org.apache.camel.processor.SendProcessor
-
- SendProcessor(Endpoint, ExchangePattern) - Constructor for class org.apache.camel.processor.SendProcessor
-
- sendStringBody(String, String) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- sendStringBody(String, String) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- sendTimerExchange(long) - Method in class org.apache.camel.component.timer.TimerConsumer
-
- sendTo(String) - Static method in class org.apache.camel.builder.Builder
-
Returns an expression processing the exchange to the given endpoint uri.
- sendTo(String) - Method in class org.apache.camel.builder.BuilderSupport
-
Returns an expression processing the exchange to the given endpoint uri
- sendToConsumers(Exchange) - Method in class org.apache.camel.component.seda.SedaConsumer
-
Send the given
Exchange
to the consumer(s).
- sendToRecipientList(Exchange, Object, AsyncCallback) - Method in class org.apache.camel.processor.RecipientList
-
Sends the given exchange to the recipient list
- SEPARATOR - Static variable in class org.apache.camel.util.jndi.JndiContext
-
- Sequence<E> - Class in org.apache.camel.processor.resequencer
-
A sorted set of elements with additional methods for obtaining immediate
successors and immediate predecessors of a given element in the sequence.
- Sequence(SequenceElementComparator<E>) - Constructor for class org.apache.camel.processor.resequencer.Sequence
-
- SequenceElementComparator<E> - Interface in org.apache.camel.processor.resequencer
-
A strategy for comparing elements of a sequence.
- SequenceSender<E> - Interface in org.apache.camel.processor.resequencer
-
- serialization() - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the Java Serialization data format
- SerializationDataFormat - Class in org.apache.camel.impl
-
- SerializationDataFormat() - Constructor for class org.apache.camel.impl.SerializationDataFormat
-
- SerializationDataFormat - Class in org.apache.camel.model.dataformat
-
- SerializationDataFormat() - Constructor for class org.apache.camel.model.dataformat.SerializationDataFormat
-
- Service - Interface in org.apache.camel
-
Represents the core lifecycle API for POJOs which can be started and stopped
- SERVICE_URL_PATH - Static variable in class org.apache.camel.management.JmxSystemPropertyKeys
-
- ServiceHelper - Class in org.apache.camel.util
-
A collection of helper methods for working with
Service
objects.
- ServicePool<Key,Service> - Interface in org.apache.camel.spi
-
A service pool is like a connection pool but can pool any kind of objects.
- ServicePoolAware - Interface in org.apache.camel
-
Marker interface to indicate this service can be pooled using a
ServicePool
.
- ServiceStartupFailureEvent - Class in org.apache.camel.management.event
-
- ServiceStartupFailureEvent(CamelContext, Object, Throwable) - Constructor for class org.apache.camel.management.event.ServiceStartupFailureEvent
-
- ServiceStatus - Enum in org.apache.camel
-
Represents the status of a
Service
instance
- ServiceStopFailureEvent - Class in org.apache.camel.management.event
-
- ServiceStopFailureEvent(CamelContext, Object, Throwable) - Constructor for class org.apache.camel.management.event.ServiceStopFailureEvent
-
- ServiceSupport - Class in org.apache.camel.impl
-
Deprecated.
use org.apache.camel.support.ServiceSupport instead
- ServiceSupport() - Constructor for class org.apache.camel.impl.ServiceSupport
-
Deprecated.
- ServiceSupport - Class in org.apache.camel.support
-
A useful base class which ensures that a service is only initialized once and
provides some helper methods for enquiring of its status.
- ServiceSupport() - Constructor for class org.apache.camel.support.ServiceSupport
-
- set(CamelContext, EndpointConfiguration, String, T) - Method in class org.apache.camel.impl.ConfigurationHelper.FieldParameterSetter
-
- set(CamelContext, EndpointConfiguration, String, T) - Method in interface org.apache.camel.impl.ConfigurationHelper.ParameterSetter
-
Sets the parameter on the configuration.
- set(Container) - Static method in class org.apache.camel.spi.Container.Instance
-
Register the Container.
- set(V) - Method in class org.apache.camel.util.ValueHolder
-
Deprecated.
should be immutable, will be removed in Camel 3.0
- setAbsolute(boolean) - Method in class org.apache.camel.component.file.GenericFile
-
- setAbsoluteFilePath(String) - Method in class org.apache.camel.component.file.GenericFile
-
- setAcceptableSchemes(String) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
-
- setAccumulatedProcessingTime(Long) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setAction(String) - Method in class org.apache.camel.component.controlbus.ControlBusEndpoint
-
- setAction(String) - Method in class org.apache.camel.processor.ThroughputLogger
-
- setAfterFinallyUri(String) - Method in class org.apache.camel.model.AOPDefinition
-
Deprecated.
- setAfterUri(String) - Method in class org.apache.camel.model.AOPDefinition
-
Deprecated.
- setAggregateDot(boolean) - Method in class org.apache.camel.main.MainSupport
-
- setAggregationRepository(AggregationRepository) - Method in class org.apache.camel.model.AggregateDefinition
-
- setAggregationRepository(AggregationRepository) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setAggregationRepositoryRef(String) - Method in class org.apache.camel.model.AggregateDefinition
-
- setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.AggregateDefinition
-
- setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.EnrichDefinition
-
- setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.MulticastDefinition
-
- setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.PollEnrichDefinition
-
- setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.model.SplitDefinition
-
- setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.Enricher
-
Sets the aggregation strategy for this enricher.
- setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.PollEnricher
-
Sets the aggregation strategy for this poll enricher.
- setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.RecipientList
-
- setAggregationStrategyMethodAllowNull(Boolean) - Method in class org.apache.camel.model.EnrichDefinition
-
- setAggregationStrategyMethodAllowNull(Boolean) - Method in class org.apache.camel.model.PollEnrichDefinition
-
- setAggregationStrategyMethodName(String) - Method in class org.apache.camel.model.AggregateDefinition
-
- setAggregationStrategyMethodName(String) - Method in class org.apache.camel.model.EnrichDefinition
-
- setAggregationStrategyMethodName(String) - Method in class org.apache.camel.model.PollEnrichDefinition
-
- setAggregationStrategyOnExchange(Exchange, AggregationStrategy) - Method in class org.apache.camel.processor.MulticastProcessor
-
- setAggregationStrategyRef(String) - Method in class org.apache.camel.model.AggregateDefinition
-
- setAggregationStrategyRef(String) - Method in class org.apache.camel.model.EnrichDefinition
-
- setAggregationStrategyRef(String) - Method in class org.apache.camel.model.PollEnrichDefinition
-
- setAlgorithm(String) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setAlgorithm(String) - Method in class org.apache.camel.util.jsse.KeyManagersParameters
-
- setAlgorithm(String) - Method in class org.apache.camel.util.jsse.SecureRandomParameters
-
Sets the Random Number Generator (RNG) algorithm identifier for the
SecureRandom
factory method used to create the
SecureRandom
represented by this object's configuration.
- setAlgorithm(String) - Method in class org.apache.camel.util.jsse.TrustManagersParameters
-
- setAlgorithmParameterRef(String) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setAliases(Map<String, String>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
-
- setAllowDuplicates(Boolean) - Method in class org.apache.camel.model.config.BatchResequencerConfig
-
- setAllowNullBody(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setAllowNullNewExchange(boolean) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
-
- setAllowNullOldExchange(boolean) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
-
- setAllowNullValues(boolean) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
-
- setAllowRedeliveryWhileStopping(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setAllowRedeliveryWhileStopping(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Controls whether to allow redelivery while stopping/shutting down a route that uses error handling.
- setAllowStAX(boolean) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- setAllowUseOriginalMessage(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setAllowUseOriginalMessage(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setAllowUseOriginalMessage(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
- setAntExclude(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setAntFilterCaseSensitive(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setAntInclude(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setAnySpoolRules(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedStreamCachingStrategyMBean
-
- setAnySpoolRules(boolean) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- setAnySpoolRules(boolean) - Method in class org.apache.camel.management.mbean.ManagedStreamCachingStrategy
-
- setAnySpoolRules(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
- setApplicationContextClassLoader(ClassLoader) - Method in interface org.apache.camel.CamelContext
-
Sets the application context class loader
- setApplicationContextClassLoader(ClassLoader) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setArgs(Object[]) - Method in class org.apache.camel.component.bean.BeanInvocation
-
- setArmored(Boolean) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
-
- setArrayName(String) - Method in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- setAssertPeriod(CamelContext, long) - Static method in class org.apache.camel.component.mock.MockEndpoint
-
Sets the assert period on all the expectations on any
MockEndpoint
instances registered
in the given context.
- setAssertPeriod(long) - Method in class org.apache.camel.component.mock.MockEndpoint
-
Sets a grace period after which the mock endpoint will re-assert
to ensure the preliminary assertion is still valid.
- setAsync(boolean) - Method in class org.apache.camel.component.controlbus.ControlBusEndpoint
-
- setAsyncDelayed(Boolean) - Method in class org.apache.camel.model.DelayDefinition
-
- setAsyncDelayed(Boolean) - Method in class org.apache.camel.model.ThrottleDefinition
-
- setAsyncDelayed(boolean) - Method in class org.apache.camel.processor.DelayProcessorSupport
-
- setAsyncDelayedRedelivery(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- setAsyncDelayedRedelivery(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setAsyncDelayedRedelivery(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets whether asynchronous delayed redelivery is allowed.
- setAttachments(Map<String, DataHandler>) - Method in class org.apache.camel.impl.DefaultMessage
-
- setAttachments(Map<String, DataHandler>) - Method in interface org.apache.camel.Message
-
Set all the attachments associated with this message
- setAutoCreate(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setAutoCreateComponents(boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setAutogenColumns(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
-
- setAutoStartup(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setAutoStartup(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setAutoStartup(String) - Method in class org.apache.camel.model.RouteDefinition
-
- setAutoStartup(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether the object should automatically start when Camel starts.
- setBacklogSize(int) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogTracerMBean
-
- setBacklogSize(int) - Method in class org.apache.camel.management.mbean.ManagedBacklogTracer
-
- setBacklogSize(int) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
-
- setBackoffErrorThreshold(int) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
- setBackoffIdleThreshold(int) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
- setBackOffMultiplier(Double) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setBackoffMultiplier(int) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
- setBackOffMultiplier(Double) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setBackOffMultiplier(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setBackOffMultiplier(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
- setBaseUri(String) - Method in interface org.apache.camel.ComponentConfiguration
-
Sets the base URI without any query parameters added
- setBaseUri(String) - Method in class org.apache.camel.impl.ComponentConfigurationSupport
-
- setBatchConfig(BatchResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
-
- setBatchConsumer(boolean) - Method in class org.apache.camel.processor.BatchProcessor
-
Deprecated.
- setBatchSize(int) - Method in class org.apache.camel.model.config.BatchResequencerConfig
-
- setBatchSize(int) - Method in class org.apache.camel.processor.BatchProcessor
-
Deprecated.
Sets the in batch size.
- setBatchTimeout(long) - Method in class org.apache.camel.model.config.BatchResequencerConfig
-
- setBatchTimeout(long) - Method in class org.apache.camel.processor.BatchProcessor
-
Deprecated.
- setBean(Object) - Method in class org.apache.camel.model.BeanDefinition
-
- setBean(String) - Method in class org.apache.camel.model.language.MethodCallExpression
-
- setBeanHolder(BeanHolder) - Method in class org.apache.camel.component.bean.BeanEndpoint
-
- setBeanName(String) - Method in class org.apache.camel.component.bean.BeanEndpoint
-
Sets the name of the bean to invoke
- setBeanType(String) - Method in class org.apache.camel.model.BeanDefinition
-
- setBeanType(Class<?>) - Method in class org.apache.camel.model.BeanDefinition
-
- setBeanType(Class<?>) - Method in class org.apache.camel.model.language.MethodCallExpression
-
- setBeanTypeName(String) - Method in class org.apache.camel.model.language.MethodCallExpression
-
- setBeforeUri(String) - Method in class org.apache.camel.model.AOPDefinition
-
Deprecated.
- setBeginRenamer(GenericFileRenamer<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileDeleteProcessStrategy
-
- setBeginRenamer(GenericFileRenamer<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
-
- setBinding(Binding) - Method in class org.apache.camel.component.binding.BindingComponent
-
- setBinding(GenericFileBinding<T>) - Method in class org.apache.camel.component.file.GenericFile
-
- setBindingName(String) - Method in class org.apache.camel.model.dataformat.JibxDataFormat
-
- setBlock(boolean) - Method in class org.apache.camel.component.direct.DirectComponent
-
- setBlock(boolean) - Method in class org.apache.camel.component.direct.DirectEndpoint
-
- setBlock(boolean) - Method in class org.apache.camel.component.directvm.DirectVmComponent
-
- setBlock(boolean) - Method in class org.apache.camel.component.directvm.DirectVmEndpoint
-
- setBlockWhenFull(boolean) - Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setBlockWhenFull(boolean) - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
-
- setBody(Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
Creates a processor which sets the body of the message to the value of the expression
- setBody(Message) - Method in class org.apache.camel.builder.xml.DomResultHandler
-
- setBody(Message) - Method in class org.apache.camel.builder.xml.FileResultHandler
-
- setBody(Message) - Method in interface org.apache.camel.builder.xml.ResultHandler
-
- setBody(Message) - Method in class org.apache.camel.builder.xml.StreamResultHandler
-
- setBody(Message) - Method in class org.apache.camel.builder.xml.StringResultHandler
-
- setBody(GenericFile<File>, Object) - Method in class org.apache.camel.component.file.FileBinding
-
- setBody(Object) - Method in class org.apache.camel.component.file.GenericFile
-
- setBody(GenericFile<T>, Object) - Method in interface org.apache.camel.component.file.GenericFileBinding
-
Sets the body from the given file
- setBody(GenericFile<T>, Object) - Method in class org.apache.camel.component.file.GenericFileDefaultBinding
-
- setBody(Object) - Method in class org.apache.camel.impl.MessageSupport
-
- setBody(Object, Class<T>) - Method in class org.apache.camel.impl.MessageSupport
-
- setBody(Object) - Method in interface org.apache.camel.Message
-
Sets the body of the message
- setBody(Object, Class<T>) - Method in interface org.apache.camel.Message
-
Sets the body of the message as a specific type
- setBody() - Method in class org.apache.camel.model.ProcessorDefinition
-
- setBody(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
- setBody(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setBody(MessageDump.Body) - Method in class org.apache.camel.util.MessageDump
-
- SetBodyDefinition - Class in org.apache.camel.model
-
Represents an XML <setBody/> element.
- SetBodyDefinition() - Constructor for class org.apache.camel.model.SetBodyDefinition
-
- SetBodyDefinition(Expression) - Constructor for class org.apache.camel.model.SetBodyDefinition
-
- setBodyFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setBodyIncludeFiles(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- setBodyIncludeFiles(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogTracerMBean
-
- setBodyIncludeFiles(boolean) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- setBodyIncludeFiles(boolean) - Method in class org.apache.camel.management.mbean.ManagedBacklogTracer
-
- setBodyIncludeFiles(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- setBodyIncludeFiles(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
-
- setBodyIncludeStreams(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- setBodyIncludeStreams(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogTracerMBean
-
- setBodyIncludeStreams(boolean) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- setBodyIncludeStreams(boolean) - Method in class org.apache.camel.management.mbean.ManagedBacklogTracer
-
- setBodyIncludeStreams(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- setBodyIncludeStreams(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
-
- setBodyMaxChars(int) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- setBodyMaxChars(int) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogTracerMBean
-
- setBodyMaxChars(int) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- setBodyMaxChars(int) - Method in class org.apache.camel.management.mbean.ManagedBacklogTracer
-
- setBodyMaxChars(int) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- setBodyMaxChars(int) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
-
- SetBodyProcessor - Class in org.apache.camel.processor
-
A processor which sets the body on the IN or OUT message with an
Expression
- SetBodyProcessor(Expression) - Constructor for class org.apache.camel.processor.SetBodyProcessor
-
- setBodyType(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setBreadCrumbLength(int) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setBufferSize(int) - Method in interface org.apache.camel.api.management.mbean.ManagedStreamCachingStrategyMBean
-
- setBufferSize(int) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setBufferSize(int) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- setBufferSize(int) - Method in class org.apache.camel.management.mbean.ManagedStreamCachingStrategy
-
- setBuffersize(Integer) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setBufferSize(int) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Sets the buffer size to use when allocating in-memory buffers used for in-memory stream caches.
- setCache(boolean) - Method in class org.apache.camel.component.bean.BeanEndpoint
-
- setCache(boolean) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
- setCache(Boolean) - Method in class org.apache.camel.model.BeanDefinition
-
- setCache(Map<String, Object>) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
-
- setCacheScript(boolean) - Method in class org.apache.camel.component.language.LanguageEndpoint
-
Whether to cache the compiled script and reuse
Notice reusing the script can cause side effects from processing one Camel
Exchange
to the next
Exchange
.
- setCacheSize(Integer) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setCacheSize(Integer) - Method in class org.apache.camel.model.RoutingSlipDefinition
-
- setCacheSize(int) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
-
Sets the cache size
- setCacheSize(int) - Method in class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
-
- setCacheSize(int) - Method in class org.apache.camel.processor.RecipientList
-
- setCacheSize(int) - Method in class org.apache.camel.processor.RoutingSlip
-
- setCallerRunsWhenRejected(Boolean) - Method in class org.apache.camel.model.DelayDefinition
-
- setCallerRunsWhenRejected(Boolean) - Method in class org.apache.camel.model.ThreadsDefinition
-
- setCallerRunsWhenRejected(Boolean) - Method in class org.apache.camel.model.ThrottleDefinition
-
- setCallerRunsWhenRejected(boolean) - Method in class org.apache.camel.processor.DelayProcessorSupport
-
- setCallerRunsWhenRejected(boolean) - Method in class org.apache.camel.processor.ThreadsProcessor
-
- setCamelContext(CamelContext) - Method in interface org.apache.camel.CamelContextAware
-
- setCamelContext(CamelContext) - Method in interface org.apache.camel.Endpoint
-
Sets the camel context.
- setCamelContext(CamelContext) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultComponent
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultDebugger
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultEndpoint
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultScheduledPollConsumerScheduler
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.impl.InterceptSendToEndpoint
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.impl.ThrottlingInflightRoutePolicy
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.management.DefaultManagementLifecycleStrategy
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.management.DefaultManagementStrategy
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.management.PublishEventNotifier
-
- setCamelContext(ModelCamelContext) - Method in class org.apache.camel.model.RoutesDefinition
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.processor.MarshalProcessor
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.processor.UnmarshalProcessor
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.LanguageSupport
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.TimerListenerManager
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.util.jsse.JsseParameters
-
Sets the optional
CamelContext
used for integration with core capabilities
such as Camel Property Placeholders and
ClassResolver
.
- setCapacity(int) - Method in class org.apache.camel.impl.DefaultServicePool
-
- setCapacity(int) - Method in class org.apache.camel.model.config.StreamResequencerConfig
-
- setCapacity(int) - Method in class org.apache.camel.processor.StreamResequencer
-
- setCapacity(int) - Method in interface org.apache.camel.spi.ServicePool
-
Sets the capacity, which is capacity per key.
- setCaseSensitive(boolean) - Method in class org.apache.camel.component.file.AntPathMatcherFileFilter
-
Sets Whether or not pattern matching should be case sensitive
Is by default turned on
true.
- setCaseSensitive(boolean) - Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
-
- setCausedByException(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setCertAlias(String) - Method in class org.apache.camel.util.jsse.SSLContextParameters
-
An optional certificate alias to use.
- setCharset(String) - Method in class org.apache.camel.component.file.GenericFile
-
- setCharset(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setCharset(String) - Method in class org.apache.camel.impl.StringDataFormat
-
- setCharset(String) - Method in class org.apache.camel.model.ConvertBodyDefinition
-
- setCharset(String) - Method in class org.apache.camel.model.dataformat.StringDataFormat
-
- setCheckInterval(long) - Method in interface org.apache.camel.component.file.GenericFileExclusiveReadLockStrategy
-
Sets the check interval period.
- setCheckInterval(long) - Method in class org.apache.camel.component.file.strategy.FileChangedExclusiveReadLockStrategy
-
- setCheckInterval(long) - Method in class org.apache.camel.component.file.strategy.FileLockExclusiveReadLockStrategy
-
- setCheckInterval(long) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameExclusiveReadLockStrategy
-
- setCheckInterval(long) - Method in class org.apache.camel.component.file.strategy.MarkerFileExclusiveReadLockStrategy
-
- setChildDefinition(ProcessorDefinition<?>) - Method in interface org.apache.camel.model.ModelChannel
-
If the initialized output definition contained outputs (children) then we need to
set the child so we can leverage fine grained tracing
- setChildDefinition(ProcessorDefinition<?>) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
-
- setCipherSuites(CipherSuitesParameters) - Method in class org.apache.camel.util.jsse.BaseSSLContextParameters
-
Sets the optional explicitly configured cipher suites for this configuration.
- setCipherSuitesFilter(FilterParameters) - Method in class org.apache.camel.util.jsse.BaseSSLContextParameters
-
Sets the optional cipher suite filter for this JSSE configuration.
- setClasses(String[]) - Method in class org.apache.camel.model.dataformat.CastorDataFormat
-
- setClassLoaders(Set<ClassLoader>) - Method in class org.apache.camel.impl.converter.CorePackageScanClassResolver
-
- setClassLoaders(Set<ClassLoader>) - Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
-
- setClassLoaders(Set<ClassLoader>) - Method in interface org.apache.camel.spi.PackageScanClassResolver
-
- setClassResolver(ClassResolver) - Method in interface org.apache.camel.CamelContext
-
Sets the class resolver to be use
- setClassResolver(ClassResolver) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setClassType(String) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
-
- setClassType(Class<?>) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
-
- setClientAuthentication(String) - Method in class org.apache.camel.util.jsse.SSLContextServerParameters
-
Sets the configuration options for server-side client-authentication requirements.
- setClientParameters(SSLContextClientParameters) - Method in class org.apache.camel.util.jsse.SSLContextParameters
-
The optional configuration options to be applied purely to the client side settings
of the
SSLContext
.
- setCloseCorrelationKeyOnCompletion(Integer) - Method in class org.apache.camel.model.AggregateDefinition
-
- setCloseCorrelationKeyOnCompletion(Integer) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setClsName(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasEntry
-
- setClsName(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ConverterEntry
-
- setClsName(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionEntry
-
- setClsName(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldEntry
-
- setCollisionAvoidanceFactor(Double) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setCollisionAvoidanceFactor(Double) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setCollisionAvoidanceFactor(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setCollisionAvoidanceFactor(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
- setCollisionAvoidancePercent(Double) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setCollisionAvoidancePercent(Double) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setCollisionAvoidancePercent(double) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
- setCommitRenamer(GenericFileRenamer<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
-
- setComparator(Comparator<E>) - Method in class org.apache.camel.component.seda.PriorityBlockingQueueFactory
-
- setComparator(ExpressionResultComparator) - Method in class org.apache.camel.model.config.StreamResequencerConfig
-
- setComparator(Comparator<T>) - Method in class org.apache.camel.model.SortDefinition
-
- setComparatorRef(String) - Method in class org.apache.camel.model.config.StreamResequencerConfig
-
- setComparatorRef(String) - Method in class org.apache.camel.model.SortDefinition
-
- setCompletionFromBatchConsumer(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
-
- setCompletionFromBatchConsumer(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setCompletionInterval(Long) - Method in class org.apache.camel.model.AggregateDefinition
-
- setCompletionInterval(long) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setCompletionPredicate(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.AggregateDefinition
-
- setCompletionPredicate(Predicate) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setCompletionPredicate(Predicate) - Method in class org.apache.camel.processor.BatchProcessor
-
Deprecated.
- setCompletionSize(Integer) - Method in class org.apache.camel.model.AggregateDefinition
-
- setCompletionSize(int) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setCompletionSizeExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.AggregateDefinition
-
- setCompletionSizeExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setCompletionTimeout(Long) - Method in class org.apache.camel.model.AggregateDefinition
-
- setCompletionTimeout(long) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setCompletionTimeoutExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.AggregateDefinition
-
- setCompletionTimeoutExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setComponentResolver(ComponentResolver) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setCompressionLevel(int) - Method in class org.apache.camel.impl.ZipDataFormat
-
- setCompressionLevel(Integer) - Method in class org.apache.camel.model.dataformat.ZipDataFormat
-
- setConcurrentConsumers(int) - Method in class org.apache.camel.component.seda.SedaComponent
-
- setConcurrentConsumers(int) - Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setConfigRef(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
-
- setConfiguration(GenericFileConfiguration) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setConfigurationField(CamelContext, EndpointConfiguration, String, T) - Static method in class org.apache.camel.impl.ConfigurationHelper
-
- setConnectorPort(Integer) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setConnectorPort(Integer) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets the port clients must use to connect
- setConsumeDelay(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
-
Allows a delay to be specified which causes consumers to pause - to simulate slow consumers
- setConsumerDataFormat(DataFormat) - Method in class org.apache.camel.processor.binding.DataFormatBinding
-
- setConsumerProperties(Map<String, Object>) - Method in class org.apache.camel.impl.DefaultEndpoint
-
- setContentCache(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedResourceEndpointMBean
-
- setContentCache(boolean) - Method in class org.apache.camel.component.ResourceEndpoint
-
Sets whether to use resource content cache or not - default is false.
- setContentCache(boolean) - Method in class org.apache.camel.component.xslt.XsltComponent
-
- setContentHandler(ContentHandler) - Method in class org.apache.camel.converter.jaxp.StaxSource
-
- setContentResolvedFromResource(boolean) - Method in class org.apache.camel.component.language.LanguageEndpoint
-
- setContext(CamelContext) - Method in class org.apache.camel.builder.BuilderSupport
-
Deprecated.
- setContext(ModelCamelContext) - Method in class org.apache.camel.builder.BuilderSupport
-
- setContext(Context) - Method in class org.apache.camel.impl.JndiRegistry
-
- setContextCounter(int) - Static method in class org.apache.camel.impl.DefaultCamelContext
-
Reset context counter to a preset value.
- setContextPath(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
-
- setContextPath(String) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
-
- setContinued(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setContinuedPolicy(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setConverter(XmlConverter) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- setConverters(List<String>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
-
- setCopy(Boolean) - Method in class org.apache.camel.model.LoopDefinition
-
- setCopy(Boolean) - Method in class org.apache.camel.model.WireTapDefinition
-
- setCopy(boolean) - Method in class org.apache.camel.processor.WireTapProcessor
-
- setCopyAndDeleteOnRenameFail(boolean) - Method in class org.apache.camel.component.file.FileEndpoint
-
- setCorePoolSize(int) - Method in interface org.apache.camel.api.management.mbean.ManagedThreadPoolMBean
-
- setCorePoolSize(int) - Method in class org.apache.camel.management.mbean.ManagedThreadPool
-
- setCorePoolSize(int) - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- setCorrelationExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.AggregateDefinition
-
- setCorrelationExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
-
- setCorrelationExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setCounter(int) - Static method in class org.apache.camel.impl.DefaultCamelContextNameStrategy
-
To reset the counter, should only be used for testing purposes.
- setCounter(int) - Static method in class org.apache.camel.impl.DefaultManagementNameStrategy
-
To reset the counter, should only be used for testing purposes.
- setCounter(PerformanceCounter) - Method in class org.apache.camel.management.DelegatePerformanceCounter
-
- setCounter(Object) - Method in class org.apache.camel.management.InstrumentationProcessor
-
- setCounter(Object) - Method in class org.apache.camel.processor.CamelInternalProcessor.InstrumentationAdvice
-
- setCreateConnector(Boolean) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setCreateConnector(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether connector should be created, allowing clients to connect remotely
- setCryptoProvider(String) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setCustomId(Boolean) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
-
- setCustomProcessor(Processor) - Method in class org.apache.camel.component.file.GenericFileConsumer
-
Use a custom processor to process the exchange.
- setDaemon(boolean) - Method in class org.apache.camel.component.timer.TimerEndpoint
-
- setDataFormat(DataFormat) - Method in class org.apache.camel.component.dataformat.DataFormatEndpoint
-
- setDataFormat(DataFormat) - Method in class org.apache.camel.model.DataFormatDefinition
-
- setDataFormat(DataFormat) - Method in class org.apache.camel.processor.binding.DataFormatBinding
-
Sets the data format for both producer and consumer sides
- setDataFormatName(String) - Method in class org.apache.camel.model.DataFormatDefinition
-
- setDataFormatResolver(DataFormatResolver) - Method in interface org.apache.camel.CamelContext
-
Sets a custom data format resolver
- setDataFormatResolver(DataFormatResolver) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setDataFormats(Map<String, DataFormatDefinition>) - Method in interface org.apache.camel.CamelContext
-
- setDataFormats(Map<String, DataFormatDefinition>) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setDataFormats(List<DataFormatDefinition>) - Method in class org.apache.camel.model.dataformat.DataFormatsDefinition
-
- setDataFormats(Map<String, DataFormatDefinition>) - Method in interface org.apache.camel.model.ModelCamelContext
-
Sets the data formats that can be referenced in the routes.
- setDataFormatType(DataFormatDefinition) - Method in class org.apache.camel.model.MarshalDefinition
-
- setDataFormatType(DataFormatDefinition) - Method in class org.apache.camel.model.UnmarshalDefinition
-
- setDataObjectType(Class<?>) - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
-
- setDataObjectTypeName(String) - Method in class org.apache.camel.model.dataformat.TidyMarkupDataFormat
-
- setDataSet(DataSet) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
-
- setDeadLetter(Endpoint) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- setDeadLetterUri(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- setDeadLetterUri(String) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Sets an optional dead letter channel which exhausted recovered
Exchange
should be send to.
- setDebugger(Debugger) - Method in interface org.apache.camel.CamelContext
-
- setDebugger(Debugger) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setDefaultAggregationStrategy() - Method in class org.apache.camel.processor.Enricher
-
Sets the default aggregation strategy for this enricher.
- setDefaultAggregationStrategy() - Method in class org.apache.camel.processor.PollEnricher
-
Sets the default aggregation strategy for this poll enricher.
- setDefaultBacklogDebugger(InterceptStrategy) - Method in interface org.apache.camel.CamelContext
-
Sets a custom backlog debugger to be used as the default backlog debugger.
- setDefaultBacklogDebugger(InterceptStrategy) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setDefaultBacklogTracer(InterceptStrategy) - Method in interface org.apache.camel.CamelContext
-
Sets a custom backlog tracer to be used as the default backlog tracer.
- setDefaultBacklogTracer(InterceptStrategy) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setDefaultBody(Object) - Method in class org.apache.camel.component.dataset.SimpleDataSet
-
- setDefaultCapacity(int) - Method in class org.apache.camel.component.seda.ArrayBlockingQueueFactory
-
- setDefaultEndpoint(Endpoint) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- setDefaultEndpoint(Endpoint) - Method in interface org.apache.camel.ProducerTemplate
-
Sets the default endpoint to use if none is specified
- setDefaultEndpointUri(String) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
Sets the default endpoint to use if none is specified
- setDefaultEndpointUri(String) - Method in interface org.apache.camel.ProducerTemplate
-
Sets the default endpoint uri to use if none is specified
- setDefaultHeaders(Map<String, Object>) - Method in class org.apache.camel.component.dataset.DataSetSupport
-
- setDefaultInstance(Object) - Method in class org.apache.camel.model.dataformat.ProtobufDataFormat
-
- setDefaultProfile(Boolean) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setDefaultProfile(Boolean) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets whether this profile is the default profile (there can only be one).
- setDefaultQueueFactory(BlockingQueueFactory<Exchange>) - Method in class org.apache.camel.component.seda.SedaComponent
-
- setDefaultThreadPoolProfile(ThreadPoolProfile) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
-
- setDefaultThreadPoolProfile(ThreadPoolProfile) - Method in class org.apache.camel.impl.DefaultExecutorServiceStrategy
-
Deprecated.
- setDefaultThreadPoolProfile(ThreadPoolProfile) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Sets the default thread pool profile
- setDefaultThreadPoolProfile(ThreadPoolProfile) - Method in interface org.apache.camel.spi.ExecutorServiceStrategy
-
Deprecated.
Sets the default thread pool profile
- setDefaultTracer(InterceptStrategy) - Method in interface org.apache.camel.CamelContext
-
Sets a custom tracer to be used as the default tracer.
- setDefaultTracer(InterceptStrategy) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setDelay(long) - Method in interface org.apache.camel.api.management.mbean.ManagedSchedulePollConsumerMBean
-
- setDelay(long) - Method in class org.apache.camel.component.timer.TimerEndpoint
-
- setDelay(long) - Method in class org.apache.camel.impl.DefaultScheduledPollConsumerScheduler
-
- setDelay(long) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
- setDelay(long) - Method in class org.apache.camel.management.mbean.ManagedScheduledPollConsumer
-
- setDelay(Expression) - Method in class org.apache.camel.processor.Delayer
-
- setDelayer(Long) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setDelayer(Long) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setDelayer(String) - Method in class org.apache.camel.model.RouteDefinition
-
- setDelayer(Long) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets a delay value in millis that a message is delayed at every step it takes in the route path,
slowing the process down to better observe what is occurring
Is disabled by default
- setDelayPattern(String) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setDelayPattern(String) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setDelayPattern(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setDelayPattern(String) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets an optional delay pattern to use instead of fixed delay.
- setDelete(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setDeleteOutputFile(boolean) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- setDelimiter(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
-
- setDelimiter(String) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setDelimiter(String) - Method in class org.apache.camel.processor.RoutingSlip
-
- setDeltaProcessingTime(Long) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setDeltaProcessingTime(Long) - Method in class org.apache.camel.util.RouteStatDump
-
- setDescription(DescriptionDefinition) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
-
- setDestination(String) - Method in interface org.apache.camel.api.management.mbean.ManagedSendProcessorMBean
-
Deprecated.
no longer in use. Will be removed in a future Camel release.
- setDestination(String) - Method in class org.apache.camel.management.mbean.ManagedSendProcessor
-
- setDestination(Endpoint) - Method in class org.apache.camel.processor.interceptor.Tracer
-
- setDestination(Endpoint) - Method in class org.apache.camel.processor.SendProcessor
-
Deprecated.
not longer supported.
- setDestinationUri(String) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setDestinationUri(String) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setDestinationUri(String) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Sets an optional destination to send the traced Exchange.
- setDetour(Processor) - Method in class org.apache.camel.impl.InterceptSendToEndpoint
-
- setDigestAlgorithm(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setDirectory(boolean) - Method in class org.apache.camel.component.file.GenericFile
-
- setDirectory(String) - Method in class org.apache.camel.component.file.GenericFileConfiguration
-
- setDirectoryMustExist(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setDisableRedelivery(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setDiscardOnCompletionTimeout(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
-
- setDiscardOnCompletionTimeout(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setDistributionRatio(String) - Method in class org.apache.camel.model.loadbalancer.WeightedLoadBalancerDefinition
-
- setDistributionRatioDelimiter(String) - Method in class org.apache.camel.model.loadbalancer.WeightedLoadBalancerDefinition
-
- setDistributionRatioList(List<Integer>) - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
-
- setDistributionWeight(int) - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
-
- setDocumentBuilderFactory(DocumentBuilderFactory) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- setDocumentType(Class<?>) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setDomainName(String) - Method in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- setDoneFileName(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
Sets the done file name.
- setDotOutputDir(String) - Method in class org.apache.camel.main.MainSupport
-
Sets the output directory of the generated DOT Files to show the visual
representation of the routes.
- setDriver(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
-
- setDriverRef(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
-
- setDTDHandler(DTDHandler) - Method in class org.apache.camel.converter.jaxp.StaxSource
-
- setDuration(long) - Method in class org.apache.camel.main.MainSupport
-
Sets the duration to run the application for in milliseconds until it
should be terminated.
- setEager(Boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
-
- setEagerCheckCompletion(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
-
- setEagerCheckCompletion(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setEagerDeleteTargetFile(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setEagerLimitMaxMessagesPerPoll(boolean) - Method in class org.apache.camel.component.file.GenericFileConsumer
-
- setEagerMaxMessagesPerPoll(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setElementName(String) - Method in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- setElementNameStrategy(Object) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
-
- setElementNameStrategyRef(String) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
-
- setEnabled(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogTracerMBean
-
- setEnabled(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedRuntimeEndpointRegistryMBean
-
- setEnabled(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setEnabled(boolean) - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
-
- setEnabled(boolean) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- setEnabled(boolean) - Method in class org.apache.camel.management.mbean.ManagedBacklogTracer
-
- setEnabled(boolean) - Method in class org.apache.camel.management.mbean.ManagedRuntimeEndpointRegistry
-
- setEnabled(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setEnabled(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
-
- setEnabled(boolean) - Method in class org.apache.camel.processor.interceptor.Delayer
-
Deprecated.
- setEnabled(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
-
- setEnabled(boolean) - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Sets whether gathering runtime usage is enabled or not.
- setEnabled(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Sets whether the stream caching is enabled.
- setEncoding(String) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
-
- setEncoding(String) - Method in class org.apache.camel.model.dataformat.CastorDataFormat
-
- setEncoding(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
-
- setEncoding(String) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
-
- setEncoding(String) - Method in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- setEncoding(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
-
- setEndpoint(GenericFileEndpoint<File>) - Method in class org.apache.camel.component.file.FileOperations
-
- setEndpoint(GenericFileEndpoint<T>) - Method in interface org.apache.camel.component.file.GenericFileOperations
-
Sets the endpoint as some implementations need access to the endpoint and how its configured.
- setEndpoint(Endpoint) - Method in class org.apache.camel.management.PublishEventNotifier
-
- setEndpoint(Endpoint) - Method in class org.apache.camel.model.FromDefinition
-
- setEndpoint(Endpoint) - Method in class org.apache.camel.model.SendDefinition
-
- setEndpoint(Endpoint) - Method in class org.apache.camel.model.WireTapDefinition
-
- setEndpointClass(Class<? extends Endpoint>) - Method in class org.apache.camel.impl.UriEndpointComponent
-
To use a specific endpoint class, instead of what has been provided by the constructors.
- setEndpointConfiguration(EndpointConfiguration) - Method in class org.apache.camel.impl.DefaultEndpoint
-
- setEndpointHeaderFilterStrategy(Endpoint) - Method in class org.apache.camel.impl.HeaderFilterStrategyComponent
-
- setEndpointParameter(Endpoint, String, Object) - Method in interface org.apache.camel.ComponentConfiguration
-
Sets the named URI query parameter value on the given endpoint
- setEndpointParameter(Endpoint, String, Object) - Method in class org.apache.camel.impl.DefaultComponentConfiguration
-
- setEndpointParameter(Endpoint, String, Object) - Method in class org.apache.camel.impl.UriComponentConfiguration
-
- setEndpointPath(String) - Method in class org.apache.camel.component.file.GenericFile
-
- setEndpointUri(String) - Method in class org.apache.camel.impl.DefaultEndpoint
-
Sets the URI that created this endpoint.
- setEndpointUri(String) - Method in class org.apache.camel.management.PublishEventNotifier
-
- setEndpointUriIfNotSpecified(String) - Method in class org.apache.camel.impl.DefaultEndpoint
-
Sets the endpointUri if it has not been specified yet via some kind of
dependency injection mechanism.
- setEndToken(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- setEndToken(String) - Method in class org.apache.camel.model.language.TokenizerExpression
-
- setEntityResolver(EntityResolver) - Method in class org.apache.camel.converter.jaxp.StaxSource
-
- setErrorHandler(Processor) - Method in interface org.apache.camel.Channel
-
- setErrorHandler(ErrorHandler) - Method in class org.apache.camel.converter.jaxp.StaxSource
-
- setErrorHandler(Processor) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
-
- setErrorHandler(ValidatorErrorHandler) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setErrorHandlerBuilder(ErrorHandlerBuilder) - Method in class org.apache.camel.builder.BuilderSupport
-
Sets the error handler to use with processors created by this builder
- setErrorHandlerBuilder(ErrorHandlerBuilder) - Method in class org.apache.camel.builder.RouteBuilder
-
- setErrorHandlerBuilder(ErrorHandlerFactory) - Method in interface org.apache.camel.CamelContext
-
Sets the default error handler builder which is inherited by the routes
- setErrorHandlerBuilder(ErrorHandlerFactory) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setErrorHandlerBuilder(ErrorHandlerFactory) - Method in class org.apache.camel.model.RouteDefinition
-
Sets the error handler to use with processors created by this builder
- setErrorHandlerBuilder(ErrorHandlerFactory) - Method in class org.apache.camel.model.RoutesDefinition
-
- setErrorHandlerBuilderIfNull(ErrorHandlerFactory) - Method in class org.apache.camel.model.RouteDefinition
-
Sets the error handler if one is not already set
- setErrorHandlerRef(String) - Method in class org.apache.camel.model.RouteDefinition
-
Sets the bean ref name of the error handler builder to use on this route
- setErrorHandlers(RouteContext, List<OnExceptionDefinition>) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
-
Adds the error handlers for the given list of exception types
- setErrorHandlers(RouteContext, List<OnExceptionDefinition>) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
-
- setErrorListener(ErrorListener) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- setEventFactory(EventFactory) - Method in class org.apache.camel.management.DefaultManagementStrategy
-
- setEventFactory(EventFactory) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Sets the event factory to use
- setEventNotifierEnabled(boolean) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- setEventNotifierEnabled(boolean) - Method in class org.apache.camel.impl.ProducerCache
-
- setEventNotifierEnabled(boolean) - Method in interface org.apache.camel.ProducerTemplate
-
- setEventNotifiers(List<EventNotifier>) - Method in class org.apache.camel.management.DefaultManagementStrategy
-
- setEventNotifiers(List<EventNotifier>) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Sets the list of event notifier to use.
- setException(Throwable) - Method in interface org.apache.camel.Exchange
-
- setException(Throwable) - Method in class org.apache.camel.impl.DefaultExchange
-
- setException(Exception) - Method in class org.apache.camel.model.ThrowExceptionDefinition
-
- setExceptionClasses(List<Class<? extends Throwable>>) - Method in class org.apache.camel.model.CatchDefinition
-
- setExceptionClasses(List<Class<? extends Throwable>>) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.component.file.GenericFileOnCompletion
-
- setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.component.seda.SedaConsumer
-
- setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.impl.DefaultConsumer
-
- setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.impl.PollingConsumerSupport
-
- setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.impl.RoutePolicySupport
-
- setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.processor.BatchProcessor
-
Deprecated.
- setExceptionPolicy(ExceptionPolicyStrategy) - Method in class org.apache.camel.processor.ErrorHandlerSupport
-
- setExceptionPolicyStrategy(ExceptionPolicyStrategy) - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
-
Sets the exception policy strategy to use for resolving the
OnExceptionDefinition
to use for a given thrown exception
- setExceptionPolicyStrategy(ExceptionPolicyStrategy) - Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
-
- setExceptions(List<String>) - Method in class org.apache.camel.model.CatchDefinition
-
- setExceptions(List<String>) - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
-
- setExceptions(List<String>) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setExchange(Exchange) - Method in class org.apache.camel.impl.MessageSupport
-
- setExchangeFormatter(ExchangeFormatter) - Method in class org.apache.camel.component.log.LogComponent
-
Sets a custom
ExchangeFormatter
to convert the Exchange to a String suitable for logging.
- setExchangeId(String) - Method in interface org.apache.camel.Exchange
-
Set the exchange id
- setExchangeId(String) - Method in class org.apache.camel.impl.DefaultExchange
-
- setExchangeId(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setExchangeId(String) - Method in class org.apache.camel.util.MessageDump
-
- setExchangePattern(ExchangePattern) - Method in class org.apache.camel.impl.DefaultEndpoint
-
- setExchangePattern(ExchangePattern) - Method in class org.apache.camel.model.ProcessorDefinition
-
- setExchangePattern(ExchangePattern) - Method in class org.apache.camel.processor.ExchangePatternProcessor
-
- setExchangePattern(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- SetExchangePatternDefinition - Class in org.apache.camel.model
-
Represents an XML <setExchangePattern/> element
- SetExchangePatternDefinition() - Constructor for class org.apache.camel.model.SetExchangePatternDefinition
-
- SetExchangePatternDefinition(ExchangePattern) - Constructor for class org.apache.camel.model.SetExchangePatternDefinition
-
- setExchangesCompleted(Long) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setExchangesCompleted(Long) - Method in class org.apache.camel.util.RouteStatDump
-
- setExchangesFailed(Long) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setExchangesFailed(Long) - Method in class org.apache.camel.util.RouteStatDump
-
- setExclude(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setExcludePattern(String) - Method in class org.apache.camel.model.RemoveHeadersDefinition
-
- setExcludePatterns(String[]) - Method in class org.apache.camel.model.RemoveHeadersDefinition
-
- setExcludes(String[]) - Method in class org.apache.camel.component.file.AntPathMatcherFileFilter
-
- setExcludes(String) - Method in class org.apache.camel.component.file.AntPathMatcherFileFilter
-
Sets excludes using a single string where each element can be separated with comma
- setExcludes(String[]) - Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
-
- setExcludes(String) - Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
-
Sets excludes using a single string where each element can be separated with comma
- setExcludes(List<String>) - Method in class org.apache.camel.model.ContextScanDefinition
-
- setExcludes(List<String>) - Method in class org.apache.camel.model.PackageScanDefinition
-
- setExclusiveReadLockStrategy(GenericFileExclusiveReadLockStrategy<T>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setExclusiveReadLockStrategy(GenericFileExclusiveReadLockStrategy<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileProcessStrategySupport
-
- setExecutorService(ExecutorService) - Method in interface org.apache.camel.ExecutorServiceAware
-
Sets the executor service to be used.
- setExecutorService(ExecutorService) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- setExecutorService(ExecutorService) - Method in class org.apache.camel.model.AggregateDefinition
-
- setExecutorService(ExecutorService) - Method in class org.apache.camel.model.DelayDefinition
-
- setExecutorService(ExecutorService) - Method in class org.apache.camel.model.MulticastDefinition
-
- setExecutorService(ExecutorService) - Method in class org.apache.camel.model.OnCompletionDefinition
-
- setExecutorService(ExecutorService) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setExecutorService(ExecutorService) - Method in class org.apache.camel.model.SplitDefinition
-
- setExecutorService(ExecutorService) - Method in class org.apache.camel.model.ThreadsDefinition
-
- setExecutorService(ExecutorService) - Method in class org.apache.camel.model.ThrottleDefinition
-
- setExecutorService(ExecutorService) - Method in class org.apache.camel.model.WireTapDefinition
-
- setExecutorService(ExecutorService) - Method in class org.apache.camel.processor.RecipientList
-
- setExecutorService(ExecutorService) - Method in interface org.apache.camel.ProducerTemplate
-
Sets a custom executor service to use for async messaging.
- setExecutorServiceManager(ExecutorServiceManager) - Method in interface org.apache.camel.CamelContext
-
- setExecutorServiceManager(ExecutorServiceManager) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setExecutorServiceRef(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- setExecutorServiceRef(String) - Method in interface org.apache.camel.ExecutorServiceAware
-
Sets a reference to lookup in the
Registry
for the executor service to be used.
- setExecutorServiceRef(String) - Method in class org.apache.camel.model.AggregateDefinition
-
- setExecutorServiceRef(String) - Method in class org.apache.camel.model.DelayDefinition
-
- setExecutorServiceRef(String) - Method in class org.apache.camel.model.MulticastDefinition
-
- setExecutorServiceRef(String) - Method in class org.apache.camel.model.OnCompletionDefinition
-
- setExecutorServiceRef(String) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setExecutorServiceRef(String) - Method in class org.apache.camel.model.SplitDefinition
-
- setExecutorServiceRef(String) - Method in class org.apache.camel.model.ThreadsDefinition
-
- setExecutorServiceRef(String) - Method in class org.apache.camel.model.ThrottleDefinition
-
- setExecutorServiceRef(String) - Method in class org.apache.camel.model.WireTapDefinition
-
- setExpandableProperties(List<String>) - Method in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- setExpectedMessageCount(int) - Method in class org.apache.camel.component.mock.MockEndpoint
-
Specifies the expected number of message exchanges that should be
received by this endpoint.
- setExpireTime(long) - Method in class org.apache.camel.support.TimeoutMapEntry
-
- setExponentialBackOff(Boolean) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
-
- setExponentialBackOff(boolean) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
-
- setExpression(Expression) - Method in class org.apache.camel.component.bean.ParameterInfo
-
- setExpression(Expression) - Method in class org.apache.camel.component.file.strategy.GenericFileExpressionRenamer
-
- setExpression(Expression) - Method in class org.apache.camel.component.language.LanguageEndpoint
-
- setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.AggregateDefinition
-
- setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.ExpressionNode
-
- setExpression(Expression) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
-
- setExpression(String) - Method in class org.apache.camel.model.language.ExpressionDefinition
-
- setExpression(Expression) - Method in class org.apache.camel.model.LoopDefinition
-
- setExpression(ExpressionDefinition) - Method in class org.apache.camel.model.ResequenceDefinition
-
- setExpression(Expression) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
-
- setExpression(Expression) - Method in interface org.apache.camel.processor.resequencer.ExpressionResultComparator
-
Set the expression sed for comparing
Exchange
s.
- setExpressionType(ExpressionDefinition) - Method in class org.apache.camel.builder.ExpressionClause
-
- setExpressionType(ExpressionDefinition) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
- setExpressionType(ExpressionDefinition) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
-
- setExpressionType(ExpressionDefinition) - Method in class org.apache.camel.model.language.ExpressionDefinition
-
Allows derived classes to set a lazily created expressionType instance
such as if using the
ExpressionClause
- setExpressionValue(Expression) - Method in class org.apache.camel.builder.ExpressionClause
-
- setExpressionValue(Expression) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
- setExpressionValue(Expression) - Method in class org.apache.camel.model.language.ExpressionDefinition
-
- setFactoryFinderResolver(FactoryFinderResolver) - Method in interface org.apache.camel.CamelContext
-
Sets the factory finder resolver to use.
- setFactoryFinderResolver(FactoryFinderResolver) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setFactoryRef(String) - Method in class org.apache.camel.model.language.XPathExpression
-
- setFailIfNoConsumers(boolean) - Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setFailOnNullBody(boolean) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- setFailOnNullBody(boolean) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setFailOnNullHeader(boolean) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setFailureHandled(Exchange) - Static method in class org.apache.camel.util.ExchangeHelper
-
Sets the exchange to be failure handled.
- setFailureProcessor(Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- setFailureRenamer(GenericFileRenamer<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileDeleteProcessStrategy
-
- setFailureRenamer(GenericFileRenamer<T>) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
-
- setFailuresHandled(Long) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setFailuresHandled(Long) - Method in class org.apache.camel.util.RouteStatDump
-
- setFair(boolean) - Method in class org.apache.camel.component.seda.ArrayBlockingQueueFactory
-
- setFallbackTimeout(long) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- setFallbackTimeout(long) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- setFallbackTimeout(long) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- setFallbackToUnaugmentedProperty(boolean) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
- setFault(boolean) - Method in class org.apache.camel.impl.DefaultMessage
-
- setFault(boolean) - Method in interface org.apache.camel.Message
-
Sets the fault flag on this message
- setFaultBody(Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
Creates a processor which sets the body of the FAULT message (FAULT must be OUT) to the value of the expression
- setFaultBody(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
Adds a processor which sets the body on the FAULT message
- SetFaultBodyDefinition - Class in org.apache.camel.model
-
Represents an XML <setFaultBody/> element.
- SetFaultBodyDefinition() - Constructor for class org.apache.camel.model.SetFaultBodyDefinition
-
- SetFaultBodyDefinition(Expression) - Constructor for class org.apache.camel.model.SetFaultBodyDefinition
-
- setFaultHeader(String, Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
Sets the header on the FAULT message (FAULT must be OUT)
- setFaultHeader(String, Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
- setFeature(String, boolean) - Method in class org.apache.camel.converter.jaxp.StaxSource
-
- setField(Field, Object, Object) - Static method in class org.apache.camel.util.ReflectionHelper
-
- setFields(String[]) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionEntry
-
- setFields(String[]) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldEntry
-
- setFile(File) - Method in class org.apache.camel.component.file.FileEndpoint
-
- setFile(T) - Method in class org.apache.camel.component.file.GenericFile
-
- setFileExist(GenericFileExist) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setFileLength(long) - Method in class org.apache.camel.component.file.GenericFile
-
- setFileName(String) - Method in class org.apache.camel.component.file.GenericFile
-
- setFileName(Expression) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setFileName(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setFileNameOnly(String) - Method in class org.apache.camel.component.file.GenericFile
-
- setFileStore(File) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
-
- setFilter(GenericFileFilter<T>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setFilterNonXmlChars(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
-
- setFirstExchangeCompletedExchangeId(String) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setFirstExchangeCompletedExchangeId(String) - Method in class org.apache.camel.util.RouteStatDump
-
- setFirstExchangeCompletedTimestamp(String) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setFirstExchangeCompletedTimestamp(String) - Method in class org.apache.camel.util.RouteStatDump
-
- setFirstExchangeFailureExchangeId(String) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setFirstExchangeFailureExchangeId(String) - Method in class org.apache.camel.util.RouteStatDump
-
- setFirstExchangeFailureTimestamp(String) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setFirstExchangeFailureTimestamp(String) - Method in class org.apache.camel.util.RouteStatDump
-
- setFixedRate(boolean) - Method in class org.apache.camel.component.timer.TimerEndpoint
-
- setFlatten(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setForceCompletionOnStop(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
-
- setForceCompletionOnStop(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setForceTopLevelObject(Boolean) - Method in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- setForceWrites(boolean) - Method in class org.apache.camel.component.file.FileEndpoint
-
- setFormatter(ExchangeFormatter) - Method in class org.apache.camel.processor.CamelLogger
-
Deprecated.
- setFormatter(TraceFormatter) - Method in class org.apache.camel.processor.interceptor.Tracer
-
- setFormatterBreadCrumbLength(int) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterBreadCrumbLength(int) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterMaxChars(int) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterMaxChars(int) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterNodeLength(int) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterNodeLength(int) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowBody(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowBody(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowBodyType(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowBodyType(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowBreadCrumb(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowBreadCrumb(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowException(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowException(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowExchangeId(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowExchangeId(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowExchangePattern(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowExchangePattern(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowHeaders(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowHeaders(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowNode(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowNode(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowOutBody(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowOutBody(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowOutBodyType(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowOutBodyType(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowOutHeaders(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowOutHeaders(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowProperties(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowProperties(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowRouteId(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowRouteId(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowShortExchangeId(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setFormatterShowShortExchangeId(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFragment(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
-
- setFromEndpoint(Endpoint) - Method in interface org.apache.camel.Exchange
-
Sets the endpoint which originated this message exchange.
- setFromEndpoint(Endpoint) - Method in class org.apache.camel.impl.DefaultExchange
-
- setFromEndpointUri(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setFromRouteId(String) - Method in interface org.apache.camel.Exchange
-
Sets the route id which originated this message exchange.
- setFromRouteId(String) - Method in class org.apache.camel.impl.DefaultExchange
-
- setFunctionEndToken(String) - Method in class org.apache.camel.language.simple.SimpleLanguage
-
Change the end token used for functions.
- setFunctionResolver(XPathFunctionResolver) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setFunctionStartToken(String) - Method in class org.apache.camel.language.simple.SimpleLanguage
-
Change the start token used for functions.
- setGenericFile(GenericFile<T>) - Method in class org.apache.camel.component.file.GenericFileMessage
-
- setGreedy(boolean) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
If greedy then a poll is executed immediate after a previous poll that polled 1 or more messages.
- setGroup(int) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- setGroup(Integer) - Method in class org.apache.camel.model.language.TokenizerExpression
-
- setGroup(String) - Method in class org.apache.camel.model.RouteDefinition
-
- setGroupActiveOnly(Boolean) - Method in class org.apache.camel.component.log.LogEndpoint
-
- setGroupDelay(Long) - Method in class org.apache.camel.component.log.LogEndpoint
-
- setGroupDelay(long) - Method in class org.apache.camel.processor.ThroughputLogger
-
- setGroupExchanges(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
-
- setGroupExchanges(boolean) - Method in class org.apache.camel.processor.BatchProcessor
-
Deprecated.
- setGroupInterval(Long) - Method in class org.apache.camel.component.log.LogEndpoint
-
- setGroupInterval(Long) - Method in class org.apache.camel.processor.ThroughputLogger
-
- setGroupSize(Integer) - Method in class org.apache.camel.component.log.LogEndpoint
-
- setGroupSize(Integer) - Method in class org.apache.camel.processor.ThroughputLogger
-
- setHandled(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.CatchDefinition
-
- setHandled(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setHandledPolicy(Predicate) - Method in class org.apache.camel.model.CatchDefinition
-
- setHandledPolicy(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setHandleFault(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setHandleFault(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setHandleFault(String) - Method in class org.apache.camel.model.RouteDefinition
-
- setHandleFault(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether fault handling is enabled or not (default is disabled).
- setHeader(String, Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
Sets the header on the message.
- setHeader(String, Object) - Method in class org.apache.camel.impl.DefaultMessage
-
- setHeader(String, Object) - Method in interface org.apache.camel.Message
-
Sets a header on the message
- setHeader(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Adds a processor which sets the header on the IN message
- setHeader(String, Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
Adds a processor which sets the header on the IN message
- SetHeaderDefinition - Class in org.apache.camel.model
-
Represents an XML <setHeader/> element
- SetHeaderDefinition() - Constructor for class org.apache.camel.model.SetHeaderDefinition
-
- SetHeaderDefinition(String, ExpressionDefinition) - Constructor for class org.apache.camel.model.SetHeaderDefinition
-
- SetHeaderDefinition(String, Expression) - Constructor for class org.apache.camel.model.SetHeaderDefinition
-
- SetHeaderDefinition(String, String) - Constructor for class org.apache.camel.model.SetHeaderDefinition
-
- setHeaderFilterStrategy(HeaderFilterStrategy) - Method in class org.apache.camel.impl.HeaderFilterStrategyComponent
-
- setHeaderFilterStrategy(HeaderFilterStrategy) - Method in interface org.apache.camel.spi.HeaderFilterStrategyAware
-
Sets the header filter strategy to use
- setHeaderFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setHeaderName(String) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setHeaderName(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- setHeaderName(String) - Method in class org.apache.camel.model.language.TokenizerExpression
-
- setHeaderName(String) - Method in class org.apache.camel.model.language.XPathExpression
-
- setHeaderName(String) - Method in class org.apache.camel.model.language.XQueryExpression
-
- setHeaderName(String) - Method in class org.apache.camel.model.RemoveHeaderDefinition
-
- setHeaderName(String) - Method in class org.apache.camel.model.SetHeaderDefinition
-
- setHeaderName(String) - Method in class org.apache.camel.model.SetOutHeaderDefinition
-
Deprecated.
- setHeaderName(String) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setHeaders(Map<String, Object>) - Method in class org.apache.camel.impl.DefaultMessage
-
- setHeaders(Map<String, Object>) - Method in interface org.apache.camel.Message
-
Set all the headers associated with this message
Important: If you want to copy headers from another
Message
to this
Message
, then
use
getHeaders().putAll(other) to copy the headers, where
other is the other headers.
- setHeaders(List<SetHeaderDefinition>) - Method in class org.apache.camel.model.WireTapDefinition
-
- setHeaders(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setHeaders(List<MessageDump.Header>) - Method in class org.apache.camel.util.MessageDump
-
- setHostName(String) - Method in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- setId(String) - Method in class org.apache.camel.model.ChoiceDefinition
-
- setId(String) - Method in class org.apache.camel.model.IdentifiedType
-
Sets the value of the id property.
- setId(String) - Method in class org.apache.camel.model.language.ExpressionDefinition
-
Sets the value of the id property.
- setId(String) - Method in class org.apache.camel.model.OptionalIdentifiedDefinition
-
Sets the value of the id property.
- setId(String) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the id of this profile
- setId(String) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setId(String) - Method in class org.apache.camel.util.RouteStatDump
-
- setIdempotent(Boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setIdempotentKey(Expression) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setIdempotentKey(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setIdempotentRepository(IdempotentRepository<String>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setIgnoreCamelContextEvents(boolean) - Method in class org.apache.camel.management.mbean.ManagedEventNotifier
-
- setIgnoreCamelContextEvents(boolean) - Method in interface org.apache.camel.management.mbean.ManagedEventNotifierMBean
-
- setIgnoreCamelContextEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
-
- setIgnoreCamelContextEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeCompletedEvent(boolean) - Method in class org.apache.camel.management.mbean.ManagedEventNotifier
-
- setIgnoreExchangeCompletedEvent(boolean) - Method in interface org.apache.camel.management.mbean.ManagedEventNotifierMBean
-
- setIgnoreExchangeCompletedEvent(boolean) - Method in interface org.apache.camel.spi.EventNotifier
-
- setIgnoreExchangeCompletedEvent(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeCreatedEvent(boolean) - Method in class org.apache.camel.management.mbean.ManagedEventNotifier
-
- setIgnoreExchangeCreatedEvent(boolean) - Method in interface org.apache.camel.management.mbean.ManagedEventNotifierMBean
-
- setIgnoreExchangeCreatedEvent(boolean) - Method in interface org.apache.camel.spi.EventNotifier
-
- setIgnoreExchangeCreatedEvent(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeEvents(boolean) - Method in class org.apache.camel.management.mbean.ManagedEventNotifier
-
- setIgnoreExchangeEvents(boolean) - Method in interface org.apache.camel.management.mbean.ManagedEventNotifierMBean
-
- setIgnoreExchangeEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
-
- setIgnoreExchangeEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeFailedEvents(boolean) - Method in class org.apache.camel.management.mbean.ManagedEventNotifier
-
- setIgnoreExchangeFailedEvents(boolean) - Method in interface org.apache.camel.management.mbean.ManagedEventNotifierMBean
-
- setIgnoreExchangeFailedEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
-
- setIgnoreExchangeFailedEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeRedeliveryEvents(boolean) - Method in class org.apache.camel.management.mbean.ManagedEventNotifier
-
- setIgnoreExchangeRedeliveryEvents(boolean) - Method in interface org.apache.camel.management.mbean.ManagedEventNotifierMBean
-
- setIgnoreExchangeRedeliveryEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
-
- setIgnoreExchangeRedeliveryEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeSendingEvents(boolean) - Method in class org.apache.camel.management.mbean.ManagedEventNotifier
-
- setIgnoreExchangeSendingEvents(boolean) - Method in interface org.apache.camel.management.mbean.ManagedEventNotifierMBean
-
- setIgnoreExchangeSendingEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
-
- setIgnoreExchangeSendingEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeSentEvents(boolean) - Method in class org.apache.camel.management.mbean.ManagedEventNotifier
-
- setIgnoreExchangeSentEvents(boolean) - Method in interface org.apache.camel.management.mbean.ManagedEventNotifierMBean
-
- setIgnoreExchangeSentEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
-
- setIgnoreExchangeSentEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreInvalidCorrelationKeys(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
-
- setIgnoreInvalidCorrelationKeys(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setIgnoreInvalidEndpoints(Boolean) - Method in class org.apache.camel.model.DynamicRouterDefinition
-
- setIgnoreInvalidEndpoints(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setIgnoreInvalidEndpoints(Boolean) - Method in class org.apache.camel.model.RoutingSlipDefinition
-
- setIgnoreInvalidEndpoints(boolean) - Method in class org.apache.camel.processor.RecipientList
-
- setIgnoreInvalidEndpoints(boolean) - Method in class org.apache.camel.processor.RecipientListProcessor
-
- setIgnoreInvalidEndpoints(boolean) - Method in class org.apache.camel.processor.RoutingSlip
-
- setIgnoreInvalidExchanges(Boolean) - Method in class org.apache.camel.model.config.BatchResequencerConfig
-
- setIgnoreInvalidExchanges(Boolean) - Method in class org.apache.camel.model.config.StreamResequencerConfig
-
- setIgnoreInvalidExchanges(boolean) - Method in class org.apache.camel.processor.BatchProcessor
-
Deprecated.
- setIgnoreInvalidExchanges(boolean) - Method in class org.apache.camel.processor.StreamResequencer
-
Sets whether to ignore invalid exchanges which cannot be used by this stream resequencer.
- setIgnoreInvalidRecords(Boolean) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
-
- setIgnoreJAXBElement(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
-
- setIgnoreMissingLocation(boolean) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
- setIgnoreRouteEvents(boolean) - Method in class org.apache.camel.management.mbean.ManagedEventNotifier
-
- setIgnoreRouteEvents(boolean) - Method in interface org.apache.camel.management.mbean.ManagedEventNotifierMBean
-
- setIgnoreRouteEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
-
- setIgnoreRouteEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreServiceEvents(boolean) - Method in class org.apache.camel.management.mbean.ManagedEventNotifier
-
- setIgnoreServiceEvents(boolean) - Method in interface org.apache.camel.management.mbean.ManagedEventNotifierMBean
-
- setIgnoreServiceEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
-
- setIgnoreServiceEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreUnexpectedRecords(Boolean) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
-
- setIgnoreUnidentifiedRecords(Boolean) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
-
- setImagePrefix(String) - Method in class org.apache.camel.view.GraphSupport
-
- setImplicitCollections(Map<String, String[]>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
-
- setIn(Message) - Method in interface org.apache.camel.Exchange
-
Sets the inbound message instance
- setIn(Message) - Method in class org.apache.camel.impl.DefaultExchange
-
- setInclude(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setInclude(String) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
-
- setIncludeHostName(Boolean) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setIncludeHostName(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
- setIncludes(String[]) - Method in class org.apache.camel.component.file.AntPathMatcherFileFilter
-
- setIncludes(String) - Method in class org.apache.camel.component.file.AntPathMatcherFileFilter
-
Sets includes using a single string where each element can be separated with comma
- setIncludes(String[]) - Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
-
- setIncludes(String) - Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
-
Sets includes using a single string where each element can be separated with comma
- setIncludes(List<String>) - Method in class org.apache.camel.model.ContextScanDefinition
-
- setIncludes(List<String>) - Method in class org.apache.camel.model.PackageScanDefinition
-
- setIncludeTokens(boolean) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- setIncludeTokens(Boolean) - Method in class org.apache.camel.model.language.TokenizerExpression
-
- setIndex(Integer) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setInFilter(Set<String>) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
-
Sets the "in" direction filter set.
- setInFilterPattern(String) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
-
Sets the "in" direction filter regular expression
Pattern
.
- setInflightRepository(InflightRepository) - Method in interface org.apache.camel.CamelContext
-
Sets a custom inflight repository to use
- setInflightRepository(InflightRepository) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setInheritErrorHandler(Boolean) - Method in class org.apache.camel.model.ProcessorDefinition
-
- setInheritNamespaceTagName(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- setInheritNamespaceTagName(String) - Method in class org.apache.camel.model.language.TokenizerExpression
-
- setInitialDelay(long) - Method in interface org.apache.camel.api.management.mbean.ManagedSchedulePollConsumerMBean
-
- setInitialDelay(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
-
- setInitialDelay(long) - Method in class org.apache.camel.impl.DefaultScheduledPollConsumerScheduler
-
- setInitialDelay(long) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
- setInitialDelay(long) - Method in class org.apache.camel.management.mbean.ManagedScheduledPollConsumer
-
- setInitialProperties(Properties) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
Sets initial properties which will be used before any locations are resolved.
- setInitVectorRef(String) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setInjector(Injector) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
-
- setInjector(Injector) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setInjector(Injector) - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Sets the injector to be used for creating new instances during type conversions.
- setInline(Boolean) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setInProgressRepository(IdempotentRepository<String>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setInputFactory(XMLInputFactory) - Method in class org.apache.camel.converter.jaxp.StaxConverter
-
- setInputs(List<FromDefinition>) - Method in class org.apache.camel.model.RouteDefinition
-
- setInputStream(InputStream) - Method in class org.apache.camel.converter.stream.StreamSourceCache
-
- setInstance(Object) - Method in class org.apache.camel.model.language.MethodCallExpression
-
- setInstanceClass(String) - Method in class org.apache.camel.model.dataformat.ProtobufDataFormat
-
- setInstanceClassName(String) - Method in class org.apache.camel.model.dataformat.AvroDataFormat
-
- setIntegrity(Boolean) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
-
- setInterceptFroms(List<InterceptFromDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
-
- setIntercepts(List<InterceptDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
-
- setInterceptSendTos(List<InterceptSendToEndpointDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
-
- setInterceptStrategies(List<InterceptStrategy>) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setInterceptStrategies(List<InterceptStrategy>) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setInterceptStrategies(List<InterceptStrategy>) - Method in interface org.apache.camel.spi.RouteContext
-
This method sets the InterceptStrategy instances on this route context.
- setInterruptedExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.impl.EventDrivenPollingConsumer
-
- setInterval(long) - Method in class org.apache.camel.support.TimerListenerManager
-
Sets the interval in millis.
- setIsRouteAdded(boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setIsRouteAdded(boolean) - Method in interface org.apache.camel.spi.RouteContext
-
- setJmxTraceNotifications(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setJmxTraceNotifications(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setJmxTraceNotifications(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
-
- setJndiContext(Context) - Method in class org.apache.camel.impl.DefaultCamelContext
-
Sets the registry to the given JNDI context
- setJpaTraceEventMessageClassName(String) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Set the fully qualified name of the class to be used by the JPA event tracing.
- setJsonView(Class<?>) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
-
- setKeepAliveTime(long) - Method in interface org.apache.camel.api.management.mbean.ManagedThreadPoolMBean
-
- setKeepAliveTime(long) - Method in class org.apache.camel.management.mbean.ManagedThreadPool
-
- setKeepAliveTime(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setKeepAliveTime(Long) - Method in class org.apache.camel.model.ThreadsDefinition
-
- setKeepAliveTime(Long) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the keep alive time for inactive threads
- setKeepAliveTime(long, TimeUnit) - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- setKeepLastModified(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setKey(String) - Method in class org.apache.camel.model.config.PropertyDefinition
-
- setKey(String) - Method in class org.apache.camel.util.MessageDump.Header
-
- setKeyCipherAlgorithm(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setKeyFileName(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
-
- setKeyManagers(KeyManagersParameters) - Method in class org.apache.camel.util.jsse.SSLContextParameters
-
Sets the optional key manager configuration for creating the
KeyManager
s used in constructing an
SSLContext
.
- setKeyOrTrustStoreParametersId(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setKeyPassword(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setKeyPassword(String) - Method in class org.apache.camel.util.jsse.KeyManagersParameters
-
Sets the optional password for recovering keys in the key store.
- setKeyRef(String) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setKeyStore(KeyStoreParameters) - Method in class org.apache.camel.util.jsse.KeyManagersParameters
-
Sets the key store configuration used to create the
KeyStore
that the
KeyManager
s produced by this object's configuration expose.
- setKeyStore(KeyStoreParameters) - Method in class org.apache.camel.util.jsse.TrustManagersParameters
-
- setKeyUserid(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
-
- setLang(String) - Method in class org.apache.camel.model.DescriptionDefinition
-
- setLanguage(Language) - Method in class org.apache.camel.component.controlbus.ControlBusEndpoint
-
- setLanguage(String) - Method in class org.apache.camel.model.language.LanguageExpression
-
- setLanguageName(String) - Method in class org.apache.camel.component.language.LanguageEndpoint
-
Sets the name of the language to use
- setLanguageResolver(LanguageResolver) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setLastExchangeCompletedExchangeId(String) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setLastExchangeCompletedExchangeId(String) - Method in class org.apache.camel.util.RouteStatDump
-
- setLastExchangeCompletedTimestamp(String) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setLastExchangeCompletedTimestamp(String) - Method in class org.apache.camel.util.RouteStatDump
-
- setLastExchangeFailureExchangeId(String) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setLastExchangeFailureExchangeId(String) - Method in class org.apache.camel.util.RouteStatDump
-
- setLastExchangeFailureTimestamp(String) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setLastExchangeFailureTimestamp(String) - Method in class org.apache.camel.util.RouteStatDump
-
- setLastModified(long) - Method in class org.apache.camel.component.file.GenericFile
-
- setLastProcessingTime(Long) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setLastProcessingTime(Long) - Method in class org.apache.camel.util.RouteStatDump
-
- setLayoutHeight(Double) - Method in class org.apache.camel.model.DescriptionDefinition
-
- setLayoutWidth(Double) - Method in class org.apache.camel.model.DescriptionDefinition
-
- setLayoutX(Double) - Method in class org.apache.camel.model.DescriptionDefinition
-
- setLayoutY(Double) - Method in class org.apache.camel.model.DescriptionDefinition
-
- setLazyLoad(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
-
- setLazyLoadTypeConverters(Boolean) - Method in interface org.apache.camel.CamelContext
-
Deprecated.
this option is no longer supported, will be removed in a future Camel release.
- setLazyLoadTypeConverters(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
Deprecated.
- setLenient(Boolean) - Method in class org.apache.camel.model.language.JXPathExpression
-
- setLevel(LoggingLevel) - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
-
- setLevel(String) - Method in class org.apache.camel.component.log.LogEndpoint
-
- setLevel(LoggingLevel) - Method in class org.apache.camel.processor.CamelLogger
-
Deprecated.
- setLevel(LoggingLevel) - Method in class org.apache.camel.processor.CamelLogProcessor
-
- setLevel(LoggingLevel) - Method in class org.apache.camel.util.CamelLogger
-
- setLibrary(JsonLibrary) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
-
- setLifecycleStrategies(List<LifecycleStrategy>) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setLimit(int) - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
-
- setLimit(int) - Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
-
Sets the limit for how many straight rollbacks causes this strategy to suspend the fault consumer.
- setLimit(int) - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Sets the maximum number of endpoints to keep in the cache per route.
- setLineLength(Integer) - Method in class org.apache.camel.model.dataformat.Base64DataFormat
-
- setLineSeparator(String) - Method in class org.apache.camel.model.dataformat.Base64DataFormat
-
- setList(List<XStreamDataFormat.AliasEntry>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasList
-
- setList(List<XStreamDataFormat.ConverterEntry>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ConverterList
-
- setList(List<XStreamDataFormat.ImplicitCollectionEntry>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionList
-
- setList(List<XStreamDataFormat.OmitFieldEntry>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldList
-
- setLoadBalancerType(LoadBalancerDefinition) - Method in class org.apache.camel.model.LoadBalanceDefinition
-
- setLoadStatisticsEnabled(boolean) - Method in class org.apache.camel.management.DefaultManagementStrategy
-
- setLoadStatisticsEnabled(boolean) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Sets whether load statistics is enabled.
- setLocale(String) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
-
- setLocalWorkDirectory(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setLocation(String) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
- setLocations(String[]) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
- setLog(Logger) - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
-
- setLog(Logger) - Method in class org.apache.camel.processor.CamelLogger
-
Deprecated.
- setLog(Logger) - Method in class org.apache.camel.util.CamelLogger
-
- setLogContinued(Boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setLogContinued(Boolean) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setLogContinued(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setLogContinued(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets whether errors should be logged even if its continued
- setLogExhausted(Boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setLogExhausted(Boolean) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setLogExhausted(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setLogExhausted(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets whether exhausted exceptions should be logged or not
- setLogExhaustedMessageHistory(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setLogExhaustedMessageHistory(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets whether exhausted exceptions should be logged with message history included.
- setLogger(CamelLogger) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- setLogger(Processor) - Method in class org.apache.camel.component.log.LogEndpoint
-
- setLogger(CamelLogger) - Method in class org.apache.camel.impl.ThrottlingInflightRoutePolicy
-
Sets the logger to use for logging throttling activity.
- setLogger(Logger) - Method in class org.apache.camel.model.LogDefinition
-
- setLoggerRef(String) - Method in class org.apache.camel.model.LogDefinition
-
- setLoggingLevel(String) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- setLoggingLevel(String) - Method in interface org.apache.camel.api.management.mbean.ManagedThrottlingInflightRoutePolicyMBean
-
- setLoggingLevel(LoggingLevel) - Method in class org.apache.camel.component.controlbus.ControlBusEndpoint
-
- setLoggingLevel(LoggingLevel) - Method in class org.apache.camel.impl.ThrottlingInflightRoutePolicy
-
Sets the logging level to report the throttling activity.
- setLoggingLevel(String) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- setLoggingLevel(String) - Method in class org.apache.camel.management.mbean.ManagedThrottlingInflightRoutePolicy
-
- setLoggingLevel(LoggingLevel) - Method in class org.apache.camel.model.LogDefinition
-
- setLoggingLevel(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- setLogHandled(Boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setLogHandled(Boolean) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setLogHandled(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setLogHandled(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets whether errors should be logged even if its handled
- setLogLevel(String) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setLogLevel(String) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Sets the logging level to output tracing.
- setLogName(String) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setLogName(String) - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
-
- setLogName(String) - Method in class org.apache.camel.management.LoggingEventNotifier
-
Sets the log name to use.
- setLogName(String) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setLogName(String) - Method in class org.apache.camel.model.LogDefinition
-
- setLogName(String) - Method in class org.apache.camel.processor.CamelLogger
-
Deprecated.
- setLogName(String) - Method in class org.apache.camel.processor.CamelLogProcessor
-
- setLogName(String) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Sets the logging name to use.
- setLogName(String) - Method in class org.apache.camel.util.CamelLogger
-
- setLogNamespaces(boolean) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setLogNamespaces(Boolean) - Method in class org.apache.camel.model.language.XPathExpression
-
- setLogRetryAttempted(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setLogRetryAttempted(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets whether retry attempts should be logged or not
- setLogRetryStackTrace(Boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setLogRetryStackTrace(Boolean) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setLogRetryStackTrace(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setLogRetryStackTrace(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets whether stack traces should be logged or not
- setLogStackTrace(Boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setLogStackTrace(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setLogStackTrace(Boolean) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setLogStackTrace(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setLogStackTrace(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setLogStackTrace(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Sets whether thrown exception stacktrace should be traced, if disabled then only the exception message is logged
- setLogStackTrace(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets whether stack traces should be logged or not
- setLowerCase(boolean) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
-
Sets the isLowercase property which is a boolean to determine
whether header names should be converted to lowercase before
checking it the filter Set.
- setMacAlgorithm(String) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setManagedInterceptStrategy(InterceptStrategy) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setManagedInterceptStrategy(InterceptStrategy) - Method in interface org.apache.camel.spi.RouteContext
-
Sets a special intercept strategy for management.
- setManagementAgent(ManagementAgent) - Method in class org.apache.camel.management.DefaultManagementStrategy
-
- setManagementAgent(ManagementAgent) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Sets the management agent to use
- setManagementMBeanAssembler(ManagementMBeanAssembler) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setManagementName(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setManagementNameStrategy(ManagementNameStrategy) - Method in interface org.apache.camel.CamelContext
-
Sets a custom management name strategy
- setManagementNameStrategy(ManagementNameStrategy) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setManagementNamingStrategy(ManagementNamingStrategy) - Method in class org.apache.camel.management.DefaultManagementStrategy
-
- setManagementNamingStrategy(ManagementNamingStrategy) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Sets the naming strategy to use
- setManagementObjectStrategy(ManagementObjectStrategy) - Method in class org.apache.camel.management.DefaultManagementStrategy
-
- setManagementObjectStrategy(ManagementObjectStrategy) - Method in interface org.apache.camel.spi.ManagementStrategy
-
Sets the object strategy to use
- setManagementStrategy(ManagementStrategy) - Method in interface org.apache.camel.CamelContext
-
Sets the management strategy to use
- setManagementStrategy(ManagementStrategy) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setMapping(String) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
-
- setMappingFile(String) - Method in class org.apache.camel.model.dataformat.CastorDataFormat
-
- setMarker(String) - Method in class org.apache.camel.component.log.LogEndpoint
-
- setMarker(String) - Method in class org.apache.camel.model.LogDefinition
-
- setMarker(String) - Method in class org.apache.camel.processor.CamelLogProcessor
-
- setMarker(Marker) - Method in class org.apache.camel.util.CamelLogger
-
- setMarker(String) - Method in class org.apache.camel.util.CamelLogger
-
- setMarkRollbackOnly(Boolean) - Method in class org.apache.camel.model.RollbackDefinition
-
- setMarkRollbackOnly(boolean) - Method in class org.apache.camel.processor.RollbackProcessor
-
- setMarkRollbackOnlyLast(Boolean) - Method in class org.apache.camel.model.RollbackDefinition
-
- setMarkRollbackOnlyLast(boolean) - Method in class org.apache.camel.processor.RollbackProcessor
-
- setMask(Boolean) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setMask(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to remove detected sensitive information (such as passwords) from MBean names and attributes.
- setMaxChars(int) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setMaxChars(int) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setMaxDepth(int) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setMaxFileStoreSize(long) - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
-
Sets the maximum file size for the file store in bytes.
- setMaximumCacheSize(int) - Method in interface org.apache.camel.ConsumerTemplate
-
Sets a custom maximum cache size.
- setMaximumCacheSize(int) - Method in class org.apache.camel.impl.DefaultConsumerTemplate
-
- setMaximumCacheSize(int) - Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- setMaximumCacheSize(int) - Method in interface org.apache.camel.ProducerTemplate
-
Sets a custom maximum cache size to use in the backing cache pools.
- setMaximumFailoverAttempts(Integer) - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
-
- setMaximumFailoverAttempts(int) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
-
- setMaximumPoolSize(int) - Method in interface org.apache.camel.api.management.mbean.ManagedThreadPoolMBean
-
- setMaximumPoolSize(int) - Method in class org.apache.camel.management.mbean.ManagedThreadPool
-
- setMaximumPoolSize(int) - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- setMaximumRedeliveries(Integer) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setMaximumRedeliveries(Integer) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setMaximumRedeliveries(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setMaximumRedeliveries(int) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets the maximum number of times a message exchange will be redelivered.
- setMaximumRedeliveries(int) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Sets an optional limit of the number of redelivery attempt of recovered
Exchange
should be attempted, before its exhausted.
- setMaximumRedeliveryDelay(Long) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setMaximumRedeliveryDelay(Long) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setMaximumRedeliveryDelay(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setMaximumRedeliveryDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets the maximum redelivery delay.
- setMaximumRequestsPerPeriod(long) - Method in interface org.apache.camel.api.management.mbean.ManagedThrottlerMBean
-
- setMaximumRequestsPerPeriod(long) - Method in class org.apache.camel.management.mbean.ManagedThrottler
-
- setMaximumRequestsPerPeriodExpression(Expression) - Method in class org.apache.camel.processor.Throttler
-
Sets the maximum number of requests per time period expression
- setMaximumRetries(Integer) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
-
- setMaximumRetries(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
-
- setMaximumRetryDelay(Long) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
-
- setMaximumRetryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
-
- setMaxInflightExchanges(int) - Method in interface org.apache.camel.api.management.mbean.ManagedThrottlingInflightRoutePolicyMBean
-
- setMaxInflightExchanges(int) - Method in class org.apache.camel.impl.ThrottlingInflightRoutePolicy
-
Sets the upper limit of number of concurrent inflight exchanges at which point reached
the throttler should suspend the route.
- setMaxInflightExchanges(int) - Method in class org.apache.camel.management.mbean.ManagedThrottlingInflightRoutePolicy
-
- setMaxMessagesPerPoll(int) - Method in interface org.apache.camel.BatchConsumer
-
Sets a maximum number of messages as a limit to poll at each polling.
- setMaxMessagesPerPoll(int) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setMaxMessagesPerPoll(int) - Method in class org.apache.camel.impl.ScheduledBatchPollingConsumer
-
- setMaxPoolSize(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setMaxPoolSize(Integer) - Method in class org.apache.camel.model.ThreadsDefinition
-
- setMaxPoolSize(Integer) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the maximum pool size
- setMaxProcessingTime(Long) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setMaxProcessingTime(Long) - Method in class org.apache.camel.util.RouteStatDump
-
- setMaxQueueSize(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setMaxQueueSize(Integer) - Method in class org.apache.camel.model.ThreadsDefinition
-
- setMaxQueueSize(Integer) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the maximum number of tasks in the work queue.
- setMBeanObjectDomainName(String) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setMBeanObjectDomainName(String) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets the object domain name
- setMBeanServer(MBeanServer) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setMBeanServer(MBeanServer) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets a custom mbean server to use
- setMBeanServerDefaultDomain(String) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setMBeanServerDefaultDomain(String) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets the default domain on the MBean server
- setMeanProcessingTime(Long) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setMeanProcessingTime(Long) - Method in class org.apache.camel.util.RouteStatDump
-
- setMessage(String) - Method in class org.apache.camel.model.LogDefinition
-
- setMessage(String) - Method in class org.apache.camel.model.RollbackDefinition
-
- setMessageBodyOnBreakpoint(String, Object) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- setMessageBodyOnBreakpoint(String, Object, String) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- setMessageBodyOnBreakpoint(String, Object) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- setMessageBodyOnBreakpoint(String, Object, String) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- setMessageBodyOnBreakpoint(String, Object) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- setMessageBodyOnBreakpoint(String, Object, Class) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- setMessageFrequency(Long) - Method in class org.apache.camel.model.SamplingDefinition
-
- setMessageHeaderOnBreakpoint(String, String, Object) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- setMessageHeaderOnBreakpoint(String, String, Object, String) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- setMessageHeaderOnBreakpoint(String, String, Object) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- setMessageHeaderOnBreakpoint(String, String, Object, String) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- setMessageHeaderOnBreakpoint(String, String, Object) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- setMessageHeaderOnBreakpoint(String, String, Object, Class) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- setMessageHistory(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setMessageHistory(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setMessageHistory(String) - Method in class org.apache.camel.model.RouteDefinition
-
- setMessageHistory(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether message history is enabled or not (default is enabled).
- setMessageId(String) - Method in class org.apache.camel.impl.MessageSupport
-
- setMessageId(String) - Method in interface org.apache.camel.Message
-
Sets the id of the message
- setMessageIdRepository(IdempotentRepository<?>) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
-
- setMessageIdRepositoryRef(String) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
-
- setMethod(String) - Method in class org.apache.camel.component.bean.BeanEndpoint
-
Sets the name of the method to invoke on the bean
- setMethod(Method) - Method in class org.apache.camel.component.bean.BeanInvocation
-
- setMethod(String) - Method in class org.apache.camel.component.bean.BeanProcessor
-
Sets the method name to use
- setMethod(String) - Method in class org.apache.camel.model.BeanDefinition
-
- setMethod(String) - Method in class org.apache.camel.model.language.MethodCallExpression
-
- setMethodName(String) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
-
- setMgfAlgorithm(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setMinDepth(int) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setMinimumExpectedMessageCount(int) - Method in class org.apache.camel.component.mock.MockEndpoint
-
Specifies the minimum number of expected message exchanges that should be
received by this endpoint
- setMinimumResultWaitTime(long) - Method in class org.apache.camel.component.mock.MockEndpoint
-
- setMinLength(long) - Method in class org.apache.camel.component.file.strategy.FileChangedExclusiveReadLockStrategy
-
- setMinProcessingTime(Long) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setMinProcessingTime(Long) - Method in class org.apache.camel.util.RouteStatDump
-
- setMinRate(int) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
-
- setMove(Expression) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setMove(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setMoveExisting(Expression) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setMoveExisting(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setMoveFailed(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setMoveFailed(Expression) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setMultiline(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
If enabled then each information is outputted on a newline.
- setMultiParameterArray(boolean) - Method in class org.apache.camel.component.bean.BeanEndpoint
-
- setMultiParameterArray(boolean) - Method in class org.apache.camel.component.bean.BeanProcessor
-
- setMultipleConsumers(boolean) - Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setName(String) - Method in class org.apache.camel.component.bean.MethodBean
-
- setName(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
Sets the name of the this context.
- setName(String) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasEntry
-
- setNamePattern(String) - Method in class org.apache.camel.impl.DefaultManagementNameStrategy
-
- setNamePattern(String) - Method in interface org.apache.camel.spi.ManagementNameStrategy
-
Sets a custom name pattern, which will be used instead of any default patterns.
- setNamespaceContext(DefaultNamespaceContext) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setNamespaceIfNotPresent(DefaultNamespaceContext, String, String) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setNamespaceLenient(Boolean) - Method in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- setNamespacePrefixRef(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
-
- setNamespacePrefixRef(String) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
-
- setNamespaces(Map<String, String>) - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
-
- setNamespaces(Map<String, String>) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setNamespaces(Map<String, String>) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setNamespaces(Map<String, String>) - Method in class org.apache.camel.model.language.NamespaceAwareExpression
-
Injects the XML Namespaces of prefix -> uri mappings
- setNamespaces(Map<String, String>) - Method in interface org.apache.camel.spi.NamespaceAware
-
Injects the XML Namespaces of prefix -> uri mappings
- setNameStrategy(CamelContextNameStrategy) - Method in interface org.apache.camel.CamelContext
-
Sets a custom name strategy
- setNameStrategy(CamelContextNameStrategy) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setNewExchangeExpression(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.WireTapDefinition
-
- setNewExchangeExpression(Expression) - Method in class org.apache.camel.model.WireTapDefinition
-
- setNewExchangeExpression(Expression) - Method in class org.apache.camel.processor.WireTapProcessor
-
- setNewExchangeProcessor(Processor) - Method in class org.apache.camel.model.WireTapDefinition
-
- setNewExchangeProcessorRef(String) - Method in class org.apache.camel.model.WireTapDefinition
-
- setNewExchangeProcessors(List<Processor>) - Method in class org.apache.camel.processor.WireTapProcessor
-
- setNextProcessor(Processor) - Method in interface org.apache.camel.Channel
-
Sets the processor that the channel should route the
Exchange
to.
- setNextProcessor(Processor) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
-
- setNodeIdFactory(NodeIdFactory) - Method in interface org.apache.camel.CamelContext
-
Uses a custom node id factory when generating auto assigned ids to the nodes in the route definitions
- setNodeIdFactory(NodeIdFactory) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setNodeLength(int) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setNoop(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setNotificationBroadcaster(NotificationBroadcasterSupport) - Method in interface org.apache.camel.api.management.JmxNotificationBroadcasterAware
-
Sets to use a custom broadcaster
- setNotificationBroadcaster(NotificationBroadcasterSupport) - Method in class org.apache.camel.management.JmxNotificationEventNotifier
-
- setNotificationSender(NotificationSender) - Method in interface org.apache.camel.api.management.NotificationSenderAware
-
- setNotificationSender(NotificationSender) - Method in class org.apache.camel.management.mbean.JMXNotificationTraceEventHandler
-
- setNotificationSender(NotificationSender) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setNumberFormat(NumberFormat) - Method in class org.apache.camel.processor.ThroughputLogger
-
- setNumberOfHashGroups(int) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
-
- setObjectModel(String) - Method in class org.apache.camel.model.language.XPathExpression
-
- setObjectModelUri(String) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setObjectModelUri(String) - Method in class org.apache.camel.language.xpath.XPathLanguage
-
- setOmitFields(Map<String, String[]>) - Method in class org.apache.camel.model.dataformat.XStreamDataFormat
-
- setOnCompleteOnly(Boolean) - Method in class org.apache.camel.model.OnCompletionDefinition
-
- setOnCompletions(List<OnCompletionDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
-
- setOnExceptions(List<OnExceptionDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
-
- setOnFailureOnly(Boolean) - Method in class org.apache.camel.model.OnCompletionDefinition
-
- setOnlyRegisterProcessorWithCustomId(Boolean) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setOnlyRegisterProcessorWithCustomId(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to only register processors which has a custom id assigned.
- setOnPrepare(Processor) - Method in class org.apache.camel.model.MulticastDefinition
-
- setOnPrepare(Processor) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setOnPrepare(Processor) - Method in class org.apache.camel.model.SplitDefinition
-
- setOnPrepare(Processor) - Method in class org.apache.camel.model.WireTapDefinition
-
- setOnPrepare(Processor) - Method in class org.apache.camel.processor.RecipientList
-
- setOnPrepare(Processor) - Method in class org.apache.camel.processor.WireTapProcessor
-
- setOnPrepareRef(String) - Method in class org.apache.camel.model.MulticastDefinition
-
- setOnPrepareRef(String) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setOnPrepareRef(String) - Method in class org.apache.camel.model.SplitDefinition
-
- setOnPrepareRef(String) - Method in class org.apache.camel.model.WireTapDefinition
-
- setOnRedelivery(Processor) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- setOnRedelivery(Processor) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setOnRedeliveryRef(String) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setOnWhen(WhenDefinition) - Method in class org.apache.camel.model.CatchDefinition
-
- setOnWhen(WhenDefinition) - Method in class org.apache.camel.model.OnCompletionDefinition
-
- setOnWhen(WhenDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setOperation(String) - Method in class org.apache.camel.component.dataformat.DataFormatEndpoint
-
- setOperations(GenericFileOperations<T>) - Method in class org.apache.camel.component.file.GenericFileConsumer
-
Sets the operations to be used.
- setOperations(GenericFileOperations<T>) - Method in class org.apache.camel.component.file.GenericFileProducer
-
Sets the operations to be used.
- setOptimisticLocking(boolean) - Method in class org.apache.camel.model.AggregateDefinition
-
- setOptimisticLocking(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setOptimisticLockRetryPolicy(OptimisticLockRetryPolicy) - Method in class org.apache.camel.model.AggregateDefinition
-
- setOptimisticLockRetryPolicy(OptimisticLockRetryPolicy) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setOptimisticLockRetryPolicyDefinition(OptimisticLockRetryPolicyDefinition) - Method in class org.apache.camel.model.AggregateDefinition
-
- setOriginalRoute(RouteDefinition) - Method in class org.apache.camel.builder.AdviceWithRouteBuilder
-
Sets the original route which we advice.
- setOtherAttributes(Map<QName, Object>) - Method in class org.apache.camel.model.ProcessorDefinition
-
- setOtherwise(OtherwiseDefinition) - Method in class org.apache.camel.model.ChoiceDefinition
-
- setOut(Message) - Method in interface org.apache.camel.Exchange
-
Sets the outbound message
- setOut(Message) - Method in class org.apache.camel.impl.DefaultExchange
-
- setOutBatchSize(int) - Method in class org.apache.camel.processor.BatchProcessor
-
Deprecated.
Sets the out batch size.
- setOutBody(Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
- setOutBody(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setOutBodyFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setOutBodyType(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setOutFilter(Set<String>) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
-
Sets the "out" direction filter set.
- setOutFilterPattern(String) - Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
-
Sets the "out" direction filter regular expression
Pattern
.
- setOutHeader(String, Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
- setOutHeader(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
- setOutHeader(String, Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
- SetOutHeaderDefinition - Class in org.apache.camel.model
-
Deprecated.
not really needed, will be removed in the future
- SetOutHeaderDefinition() - Constructor for class org.apache.camel.model.SetOutHeaderDefinition
-
Deprecated.
- SetOutHeaderDefinition(String, ExpressionDefinition) - Constructor for class org.apache.camel.model.SetOutHeaderDefinition
-
Deprecated.
- SetOutHeaderDefinition(String, Expression) - Constructor for class org.apache.camel.model.SetOutHeaderDefinition
-
Deprecated.
- setOutHeaderFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setOutHeaders(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setOutput(Processor) - Method in interface org.apache.camel.Channel
-
Sets the wrapped output that at runtime should be delegated to.
- setOutput(Processor) - Method in class org.apache.camel.processor.interceptor.DefaultChannel
-
- setOutputFactory(XMLOutputFactory) - Method in class org.apache.camel.converter.jaxp.StaxConverter
-
- setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.AggregateDefinition
-
- setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.CatchDefinition
-
- setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.ExpressionNode
-
- setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.LoadBalanceDefinition
-
- setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.OnCompletionDefinition
-
- setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.OutputDefinition
-
- setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.ResequenceDefinition
-
- setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.RouteDefinition
-
- setOutputs(List<ProcessorDefinition<?>>) - Method in class org.apache.camel.model.TryDefinition
-
- setOutputTransformer(Processor) - Method in class org.apache.camel.component.dataset.DataSetSupport
-
- setOverrideProperties(Properties) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
Sets a special list of override properties that take precedence
and will use first, if a property exist.
- setPackages(String[]) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
-
- setPackages(String[]) - Method in class org.apache.camel.model.dataformat.CastorDataFormat
-
- setPackages(List<String>) - Method in class org.apache.camel.model.PackageScanDefinition
-
- setPackageScanClassResolver(PackageScanClassResolver) - Method in interface org.apache.camel.CamelContext
-
Sets the package scanning class resolver to use
- setPackageScanClassResolver(PackageScanClassResolver) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setParallelProcessing(boolean) - Method in class org.apache.camel.model.AggregateDefinition
-
- setParallelProcessing(Boolean) - Method in class org.apache.camel.model.MulticastDefinition
-
- setParallelProcessing(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setParallelProcessing(Boolean) - Method in class org.apache.camel.model.SplitDefinition
-
- setParallelProcessing(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setParallelProcessing(boolean) - Method in class org.apache.camel.processor.RecipientList
-
- setParameter(String, Object) - Method in interface org.apache.camel.ComponentConfiguration
-
Sets the parameter value of the given name
- setParameter(String, T) - Method in interface org.apache.camel.EndpointConfiguration
-
Sets the value of a particular parameter.
- setParameter(String, Object) - Method in class org.apache.camel.impl.ComponentConfigurationSupport
-
- setParameter(String, T) - Method in class org.apache.camel.impl.DefaultEndpointConfiguration
-
- setParameter(String, T) - Method in class org.apache.camel.impl.MappedEndpointConfiguration
-
- setParameter(String, T) - Method in class org.apache.camel.impl.UriEndpointConfiguration
-
- setParameterMappingStrategy(ParameterMappingStrategy) - Method in class org.apache.camel.component.bean.RegistryBean
-
- setParameters(Map<String, Object>) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- setParameters(Map<String, Object>) - Method in interface org.apache.camel.ComponentConfiguration
-
Sets the parameter values of this configuration
- setParameters(Map<String, Object>) - Method in class org.apache.camel.impl.ComponentConfigurationSupport
-
- setParameterTypes(Class<?>[]) - Method in class org.apache.camel.component.bean.MethodBean
-
- setParent(ProcessorDefinition<?>) - Method in class org.apache.camel.model.ProcessorDefinition
-
- setParentUnitOfWork(UnitOfWork) - Method in class org.apache.camel.impl.DefaultUnitOfWork
-
- setParentUnitOfWork(UnitOfWork) - Method in interface org.apache.camel.spi.UnitOfWork
-
Sets the parent unit of work.
- setParser(Object) - Method in class org.apache.camel.model.dataformat.HL7DataFormat
-
- setPartClass(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
-
- setPartNamespace(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
-
- setPassPhrase(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setPassword(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
-
- setPassword(String) - Method in class org.apache.camel.util.jsse.KeyStoreParameters
-
Set the optional password for reading/opening/verifying the key store.
- setPathSeparator(String) - Method in class org.apache.camel.util.AntPathMatcher
-
Set the path separator to use for pattern parsing.
- setPattern(ExchangePattern) - Method in interface org.apache.camel.Exchange
-
- setPattern(ExchangePattern) - Method in class org.apache.camel.impl.DefaultExchange
-
- setPattern(String) - Method in class org.apache.camel.model.RemoveHeadersDefinition
-
- setPattern(ExchangePattern) - Method in class org.apache.camel.model.SetExchangePatternDefinition
-
- setPattern(ExchangePattern) - Method in class org.apache.camel.model.ToDefinition
-
- setPeriod(long) - Method in class org.apache.camel.component.timer.TimerEndpoint
-
- setPollingConsumerBlockWhenFull(boolean) - Method in class org.apache.camel.impl.DefaultEndpoint
-
- setPollingConsumerQueueSize(int) - Method in class org.apache.camel.impl.DefaultEndpoint
-
- setPollStrategy(PollingConsumerPollStrategy) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
- setPollTimeout(int) - Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setPoolSize(String) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setPoolSize(Integer) - Method in class org.apache.camel.model.ThreadsDefinition
-
- setPoolSize(Integer) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the core pool size (threads to keep minimum in pool)
- setPredicate(Predicate) - Method in class org.apache.camel.model.ExpressionSubElementDefinition
-
- setPrefixToken(String) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
Sets the value of the prefix token used to identify properties to replace.
- setPreloadSize(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
-
Sets how many messages should be preloaded (sent) before the route completes its initialization
- setPreMove(Expression) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setPreMove(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
-
- setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
-
- setPrettyPrint(Boolean) - Method in class org.apache.camel.model.dataformat.XMLBeansDataFormat
-
- setPreviousNode(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setProcessor(Processor) - Method in class org.apache.camel.impl.ProcessorEndpoint
-
- setProcessor(AsyncProcessor) - Method in class org.apache.camel.processor.DelegateAsyncProcessor
-
- setProcessor(Processor) - Method in class org.apache.camel.processor.DelegateAsyncProcessor
-
- setProcessor(Processor) - Method in class org.apache.camel.processor.DelegateProcessor
-
- setProcessorFactory(ProcessorFactory) - Method in interface org.apache.camel.CamelContext
-
- setProcessorFactory(ProcessorFactory) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setProcessorPosition(int) - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
-
- setProcessorStats(List<ProcessorStatDump>) - Method in class org.apache.camel.util.RouteStatDump
-
- setProcessStrategy(GenericFileProcessStrategy<T>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setProduceDelay(long) - Method in class org.apache.camel.component.dataset.DataSetEndpoint
-
Allows a delay to be specified which causes producers to pause - to simulate slow producers
- setProducerDataFormat(DataFormat) - Method in class org.apache.camel.processor.binding.DataFormatBinding
-
- setProducerServicePool(ServicePool<Endpoint, Producer>) - Method in interface org.apache.camel.CamelContext
-
Sets a pluggable service pool to use for
Producer
pooling.
- setProducerServicePool(ServicePool<Endpoint, Producer>) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setProperties(Map<String, String>) - Method in interface org.apache.camel.CamelContext
-
Sets the properties that can be referenced in the camel context
- setProperties(Map<String, String>) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setProperties(Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultComponent
-
Sets the bean properties on the given bean
- setProperties(Object, Map<String, Object>) - Method in class org.apache.camel.impl.DefaultEndpoint
-
Sets the bean properties on the given bean.
- setProperties(Map<String, Object>) - Method in class org.apache.camel.impl.DefaultExchange
-
- setProperties(List<PropertyDefinition>) - Method in class org.apache.camel.model.config.PropertiesDefinition
-
- setProperties(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setProperties(CamelContext, Object, Map<String, Object>) - Static method in class org.apache.camel.util.EndpointHelper
-
Sets the regular properties on the given bean
- setProperties(Object, Map<String, Object>, String, boolean) - Static method in class org.apache.camel.util.IntrospectionSupport
-
- setProperties(Object, Map<String, Object>, String) - Static method in class org.apache.camel.util.IntrospectionSupport
-
- setProperties(TypeConverter, Object, Map<String, Object>) - Static method in class org.apache.camel.util.IntrospectionSupport
-
- setProperties(Object, Map<String, Object>) - Static method in class org.apache.camel.util.IntrospectionSupport
-
- setPropertiesFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setPropertiesParser(PropertiesParser) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
- setPropertiesResolver(PropertiesResolver) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
- setProperty(String, String) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
Sets the value of a CamelContext property name
- setProperty(String, Expression) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
Sets the property on the exchange
- setProperty(String, Object) - Method in class org.apache.camel.converter.jaxp.StaxSource
-
- setProperty(String, Object) - Method in interface org.apache.camel.Exchange
-
Sets a property on the exchange
- setProperty(String, Object) - Method in class org.apache.camel.impl.DefaultExchange
-
- setProperty(String, String) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- setProperty(Object, String, Object) - Method in class org.apache.camel.model.DataFormatDefinition
-
- setProperty(CamelContext, Object, String, Object) - Method in class org.apache.camel.model.DataFormatDefinition
-
Sets a named property on the data format instance using introspection
- setProperty(Object, String, Object) - Method in class org.apache.camel.model.language.ExpressionDefinition
-
Sets a named property on the object instance using introspection
- setProperty(Object, String, Object) - Method in class org.apache.camel.model.LoadBalancerDefinition
-
Sets a named property on the data format instance using introspection
- setProperty(String, Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
Adds a processor which sets the exchange property
- setProperty(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Adds a processor which sets the exchange property
- setProperty(CamelContext, TypeConverter, Object, String, Object, String, boolean) - Static method in class org.apache.camel.util.IntrospectionSupport
-
This method supports two modes to set a property:
1.
- setProperty(TypeConverter, Object, String, Object) - Static method in class org.apache.camel.util.IntrospectionSupport
-
- setProperty(Object, String, Object, boolean) - Static method in class org.apache.camel.util.IntrospectionSupport
-
- setProperty(Object, String, Object) - Static method in class org.apache.camel.util.IntrospectionSupport
-
- SetPropertyDefinition - Class in org.apache.camel.model
-
Represents an XML <setProperty/> element
- SetPropertyDefinition() - Constructor for class org.apache.camel.model.SetPropertyDefinition
-
- SetPropertyDefinition(String, ExpressionDefinition) - Constructor for class org.apache.camel.model.SetPropertyDefinition
-
- SetPropertyDefinition(String, Expression) - Constructor for class org.apache.camel.model.SetPropertyDefinition
-
- SetPropertyDefinition(String, String) - Constructor for class org.apache.camel.model.SetPropertyDefinition
-
- setPropertyName(String) - Method in class org.apache.camel.model.RemovePropertyDefinition
-
- setPropertyName(String) - Method in class org.apache.camel.model.SetPropertyDefinition
-
- setPropertyPrefix(String) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
- setPropertySuffix(String) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
- setProvider(String) - Method in class org.apache.camel.model.dataformat.PGPDataFormat
-
- setProvider(String) - Method in class org.apache.camel.util.jsse.KeyManagersParameters
-
Sets the optional provider identifier for the
KeyManagerFactory
used to create
the
KeyManager
s represented by this object's configuration.
- setProvider(String) - Method in class org.apache.camel.util.jsse.KeyStoreParameters
-
Sets the optional provider identifier for instantiating the key store.
- setProvider(String) - Method in class org.apache.camel.util.jsse.SecureRandomParameters
-
Sets the optional provider identifier for the
SecureRandom
factory method used to create the
SecureRandom
represented by
this object's configuration.
- setProvider(String) - Method in class org.apache.camel.util.jsse.SSLContextParameters
-
Sets the optional provider identifier to use when constructing an
SSLContext
.
- setProvider(String) - Method in class org.apache.camel.util.jsse.TrustManagersParameters
-
- setPurgeWhenStopping(boolean) - Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setQueue(BlockingQueue<Exchange>) - Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setQueueSize(int) - Method in class org.apache.camel.component.seda.SedaComponent
-
- setRandomBackOff(Boolean) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
-
- setRandomBackOff(boolean) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
-
- setReadLock(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setReadLockCheckInterval(long) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setReadLockLoggingLevel(LoggingLevel) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setReadLockLoggingLevel(LoggingLevel) - Method in interface org.apache.camel.component.file.GenericFileExclusiveReadLockStrategy
-
Sets logging level used when a read lock could not be acquired.
- setReadLockLoggingLevel(LoggingLevel) - Method in class org.apache.camel.component.file.strategy.FileChangedExclusiveReadLockStrategy
-
- setReadLockLoggingLevel(LoggingLevel) - Method in class org.apache.camel.component.file.strategy.FileLockExclusiveReadLockStrategy
-
- setReadLockLoggingLevel(LoggingLevel) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameExclusiveReadLockStrategy
-
- setReadLockLoggingLevel(LoggingLevel) - Method in class org.apache.camel.component.file.strategy.MarkerFileExclusiveReadLockStrategy
-
- setReadLockMinLength(long) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setReadLockTimeout(long) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setRecipientKeyAlias(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setRecoveryInterval(long, TimeUnit) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Sets the interval between recovery scans
- setRecoveryInterval(long) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Sets the interval between recovery scans
- setRecursive(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setRedeliverDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
- setRedeliveries(Long) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setRedeliveries(Long) - Method in class org.apache.camel.util.RouteStatDump
-
- setRedeliveryDelay(Long) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setRedeliveryDelay(Long) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setRedeliveryDelay(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setRedeliveryDelay(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets the initial redelivery delay in milliseconds
- setRedeliveryPolicy(RedeliveryPolicy) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
Sets the redelivery policy
- setRedeliveryPolicy(RedeliveryPolicyDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setRedeliveryPolicyRef(String) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setRef(String) - Method in class org.apache.camel.model.BeanDefinition
-
- setRef(String) - Method in class org.apache.camel.model.dataformat.CustomDataFormat
-
- setRef(String) - Method in class org.apache.camel.model.FromDefinition
-
Sets the name of the endpoint within the registry (such as the Spring
ApplicationContext or JNDI) to use
- setRef(String) - Method in class org.apache.camel.model.language.MethodCallExpression
-
- setRef(String) - Method in class org.apache.camel.model.LoadBalanceDefinition
-
- setRef(String) - Method in class org.apache.camel.model.loadbalancer.CustomLoadBalancerDefinition
-
- setRef(String) - Method in class org.apache.camel.model.MarshalDefinition
-
- setRef(String) - Method in class org.apache.camel.model.PolicyDefinition
-
- setRef(String) - Method in class org.apache.camel.model.ProcessDefinition
-
- setRef(String) - Method in class org.apache.camel.model.RouteBuilderDefinition
-
- setRef(String) - Method in class org.apache.camel.model.RouteContextRefDefinition
-
- setRef(String) - Method in class org.apache.camel.model.SendDefinition
-
- setRef(String) - Method in class org.apache.camel.model.ThrowExceptionDefinition
-
- setRef(String) - Method in class org.apache.camel.model.TransactedDefinition
-
- setRef(String) - Method in class org.apache.camel.model.UnmarshalDefinition
-
- setRef(String) - Method in class org.apache.camel.model.WireTapDefinition
-
- setReferenceProperties(CamelContext, Object, Map<String, Object>) - Static method in class org.apache.camel.util.EndpointHelper
-
Sets the reference properties on the given bean
This is convention over configuration, setting all reference parameters (using
EndpointHelper.isReferenceParameter(String)
by looking it up in registry and setting it on the bean if possible.
- setRegex(boolean) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- setRegex(boolean) - Method in class org.apache.camel.model.language.TokenizerExpression
-
- setRegisterAlways(Boolean) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setRegisterAlways(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to always register mbeans.
- setRegisterNewRoutes(Boolean) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setRegisterNewRoutes(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to register mbeans when starting a new route
This option is default
true.
- setRegistry(Registry) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setRegistryPort(Integer) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setRegistryPort(Integer) - Method in interface org.apache.camel.spi.ManagementAgent
-
- setRejectedExecutionHandler(RejectedExecutionHandler) - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- setRejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setRejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.model.ThreadsDefinition
-
- setRejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.processor.ThreadsProcessor
-
- setRejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the handler for tasks which cannot be executed by the thread pool.
- setRejectOld(boolean) - Method in class org.apache.camel.model.config.StreamResequencerConfig
-
- setRejectOld(Boolean) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
-
- setRejectOld(Boolean) - Method in class org.apache.camel.processor.StreamResequencer
-
- setRelativeFilePath(String) - Method in class org.apache.camel.component.file.GenericFile
-
- setRemoveNamespacePrefixes(Boolean) - Method in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- setRemoveOnDump(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogTracerMBean
-
- setRemoveOnDump(boolean) - Method in class org.apache.camel.management.mbean.ManagedBacklogTracer
-
- setRemoveOnDump(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
-
- setRemoveOnFailure(Boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
-
- setRemoveSpoolDirectoryWhenStopping(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedStreamCachingStrategyMBean
-
- setRemoveSpoolDirectoryWhenStopping(boolean) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- setRemoveSpoolDirectoryWhenStopping(boolean) - Method in class org.apache.camel.management.mbean.ManagedStreamCachingStrategy
-
- setRemoveSpoolDirectoryWhenStopping(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Whether to remove the temporary directory when stopping.
- setRemovingRoutes(boolean) - Method in class org.apache.camel.impl.RouteService
-
- setRenameUsingCopy(boolean) - Method in class org.apache.camel.component.file.FileEndpoint
-
- setRepeatCount(long) - Method in class org.apache.camel.component.timer.TimerEndpoint
-
- setReportCount(long) - Method in class org.apache.camel.component.dataset.DataSetSupport
-
Sets the number of messages in a group on which we will report that messages have been received.
- setReporter(Processor) - Method in class org.apache.camel.component.mock.MockEndpoint
-
Allows a processor to added to the endpoint to report on progress of the test
- setRequest(Boolean) - Method in class org.apache.camel.model.dataformat.XmlRpcDataFormat
-
- setResequencerConfig(ResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
-
- setResetTimestamp(String) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setResetTimestamp(String) - Method in class org.apache.camel.util.RouteStatDump
-
- setResource(String) - Method in class org.apache.camel.util.jsse.KeyStoreParameters
-
Sets the optional file path, class path resource, or URL of the resource
used to load the key store.
- setResourceRef(String) - Method in class org.apache.camel.model.EnrichDefinition
-
- setResourceRef(String) - Method in class org.apache.camel.model.PollEnrichDefinition
-
- setResourceResolver(LSResourceResolver) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setResourceUri(String) - Method in class org.apache.camel.component.ResourceEndpoint
-
- setResourceUri(String) - Method in class org.apache.camel.model.EnrichDefinition
-
- setResourceUri(String) - Method in class org.apache.camel.model.PollEnrichDefinition
-
- setResultHandlerFactory(ResultHandlerFactory) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- setResultQName(QName) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setResultType(Class<?>) - Method in class org.apache.camel.builder.SimpleBuilder
-
- setResultType(Class<?>) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setResultType(QName) - Method in class org.apache.camel.language.xpath.XPathLanguage
-
- setResultType(Class<?>) - Method in class org.apache.camel.model.language.JsonPathExpression
-
- setResultType(Class<?>) - Method in class org.apache.camel.model.language.SimpleExpression
-
- setResultType(Class<?>) - Method in class org.apache.camel.model.language.XPathExpression
-
- setResultType(Class<?>) - Method in class org.apache.camel.model.language.XQueryExpression
-
- setResultTypeName(String) - Method in class org.apache.camel.model.language.JsonPathExpression
-
- setResultTypeName(String) - Method in class org.apache.camel.model.language.SimpleExpression
-
- setResultTypeName(String) - Method in class org.apache.camel.model.language.XPathExpression
-
- setResultWaitTime(long) - Method in class org.apache.camel.component.mock.MockEndpoint
-
- setResumePercentOfMax(int) - Method in interface org.apache.camel.api.management.mbean.ManagedThrottlingInflightRoutePolicyMBean
-
- setResumePercentOfMax(int) - Method in class org.apache.camel.impl.ThrottlingInflightRoutePolicy
-
Sets at which percentage of the max the throttler should start resuming the route.
- setResumePercentOfMax(int) - Method in class org.apache.camel.management.mbean.ManagedThrottlingInflightRoutePolicy
-
- setRetainFirst(int) - Method in class org.apache.camel.component.mock.MockEndpoint
-
Specifies to only retain the first n'th number of received
Exchange
s.
- setRetainLast(int) - Method in class org.apache.camel.component.mock.MockEndpoint
-
Specifies to only retain the last n'th number of received
Exchange
s.
- setRetriesExhaustedLogLevel(String) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setRetriesExhaustedLogLevel(String) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setRetriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setRetriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets the logging level to use for log messages when retries have been exhausted.
- setRetryAttemptedLogLevel(String) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setRetryAttemptedLogLevel(String) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setRetryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setRetryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sets the logging level to use for log messages when retries are attempted.
- setRetryDelay(Long) - Method in class org.apache.camel.model.OptimisticLockRetryPolicyDefinition
-
- setRetryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
-
- setRetryWhile(Predicate) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- setRetryWhile(ExpressionSubElementDefinition) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setRetryWhilePolicy(Predicate) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setRetryWhileRef(String) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- setReverse(Boolean) - Method in class org.apache.camel.model.config.BatchResequencerConfig
-
- setRootName(String) - Method in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- setRoundRobin(Boolean) - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
-
- setRoundRobin(Boolean) - Method in class org.apache.camel.model.loadbalancer.WeightedLoadBalancerDefinition
-
- setRoundRobin(boolean) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
-
- setRoute(Route) - Method in class org.apache.camel.impl.DefaultConsumer
-
- setRoute(Route) - Method in class org.apache.camel.management.mbean.ManagedProcessor
-
- setRoute(Route) - Method in class org.apache.camel.management.mbean.ManagedService
-
- setRoute(Route) - Method in class org.apache.camel.processor.CamelInternalProcessor.RoutePolicyAdvice
-
- setRoute(Route) - Method in interface org.apache.camel.RouteAware
-
- setRouteBuilderClasses(String) - Method in class org.apache.camel.main.MainSupport
-
- setRouteBuilders(List<RouteBuilder>) - Method in class org.apache.camel.main.MainSupport
-
- setRouteCollection(RoutesDefinition) - Method in class org.apache.camel.builder.RouteBuilder
-
- setRouteContext(RouteContext) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
- setRouteId(String) - Method in class org.apache.camel.component.controlbus.ControlBusEndpoint
-
- setRouteId(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setRoutePolicies(List<RoutePolicy>) - Method in class org.apache.camel.model.RouteDefinition
-
- setRoutePolicyList(List<RoutePolicy>) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setRoutePolicyList(List<RoutePolicy>) - Method in interface org.apache.camel.spi.RouteContext
-
Sets a custom route policy List
- setRoutePolicyRef(String) - Method in class org.apache.camel.model.RouteDefinition
-
- setRoutes(List<Route>) - Method in class org.apache.camel.impl.DefaultCamelContext
-
Deprecated.
- setRoutes(List<RouteDefinition>) - Method in interface org.apache.camel.model.RouteContainer
-
Sets the routes to use
- setRoutes(List<RouteDefinition>) - Method in class org.apache.camel.model.RoutesDefinition
-
- setRouteScoped(boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setRoutesOutputFile(String) - Method in class org.apache.camel.main.MainSupport
-
- setRunLoggingLevel(LoggingLevel) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
- setRuntimeEndpointRegistry(RuntimeEndpointRegistry) - Method in interface org.apache.camel.CamelContext
-
- setRuntimeEndpointRegistry(RuntimeEndpointRegistry) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setRuntimeRatios(ArrayList<DistributionRatio>) - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
-
- setRuntimeWeight(int) - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
-
- setSamplePeriod(Long) - Method in class org.apache.camel.model.SamplingDefinition
-
- setSaxon(boolean) - Method in class org.apache.camel.component.xslt.XsltComponent
-
- setSaxon(Boolean) - Method in class org.apache.camel.model.language.XPathExpression
-
- setScheduledExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.impl.DefaultScheduledPollConsumerScheduler
-
- setScheduledExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
Sets a custom shared
ScheduledExecutorService
to use as thread pool
Notice: When using a custom thread pool, then the lifecycle of this thread
pool is not controlled by this consumer (eg this consumer will not start/stop the thread pool
when the consumer is started/stopped etc.)
- setScheduler(ScheduledPollConsumerScheduler) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
Sets a custom scheduler to use for scheduling running this task (poll).
- setSchedulerProperties(Map<String, Object>) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
Additional properties to configure on the custom scheduler.
- setSchema(Object) - Method in class org.apache.camel.model.dataformat.AvroDataFormat
-
- setSchema(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
-
- setSchema(Schema) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setSchemaAsByteArray(byte[]) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setSchemaFactory(SchemaFactory) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setSchemaFile(File) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setSchemaLanguage(String) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setSchemaSource(Source) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setSchemaUrl(URL) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setScope(String) - Method in interface org.apache.camel.api.management.mbean.ManagedThrottlingInflightRoutePolicyMBean
-
- setScope(ThrottlingInflightRoutePolicy.ThrottlingScope) - Method in class org.apache.camel.impl.ThrottlingInflightRoutePolicy
-
Sets which scope the throttling should be based upon, either route or total scoped.
- setScope(String) - Method in class org.apache.camel.management.mbean.ManagedThrottlingInflightRoutePolicy
-
- setScript(String) - Method in class org.apache.camel.component.language.LanguageEndpoint
-
Sets the script to execute
- setSecureRandom(SecureRandomParameters) - Method in class org.apache.camel.util.jsse.SSLContextParameters
-
Sets the optional secure random configuration options to use for
constructing the
SecureRandom
used in the creation of an
SSLContext
.
- setSecureSocketProtocol(String) - Method in class org.apache.camel.util.jsse.SSLContextParameters
-
Sets the optional protocol for the secure sockets created by the
SSLContext
represented by this instance's configuration.
- setSecureSocketProtocols(SecureSocketProtocolsParameters) - Method in class org.apache.camel.util.jsse.BaseSSLContextParameters
-
Sets the explicitly configured secure socket protocol names for this configuration.
- setSecureSocketProtocolsFilter(FilterParameters) - Method in class org.apache.camel.util.jsse.BaseSSLContextParameters
-
Sets the optional secure socket protocol filter for this JSSE configuration.
- setSecureTag(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setSecureTagContents(Boolean) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setSelfProcessingTime(Long) - Method in class org.apache.camel.util.RouteStatDump
-
- setSendEmptyMessageWhenIdle(boolean) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
- setSeparator(String) - Method in class org.apache.camel.util.CollectionStringBuffer
-
- setSequenceSender(SequenceSender<E>) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
-
Sets the sequence sender.
- setServerParameters(SSLContextServerParameters) - Method in class org.apache.camel.util.jsse.SSLContextParameters
-
The optional configuration options to be applied purely to the server side settings
of the
SSLContext
.
- setServiceUrlPath(String) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setServiceUrlPath(String) - Method in interface org.apache.camel.spi.ManagementAgent
-
Sets the service url
- setSessionTimeout(String) - Method in class org.apache.camel.util.jsse.BaseSSLContextParameters
-
- setShareUnitOfWork(Boolean) - Method in class org.apache.camel.model.MulticastDefinition
-
- setShareUnitOfWork(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setShareUnitOfWork(Boolean) - Method in class org.apache.camel.model.SplitDefinition
-
- setShareUnitOfWork(boolean) - Method in class org.apache.camel.processor.RecipientList
-
- setShortExchangeId(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setShorthandMethod(boolean) - Method in class org.apache.camel.component.bean.BeanProcessor
-
Sets whether to support getter style method name, so you can
say the method is called 'name' but it will invoke the 'getName' method.
- setShouldAppendHMAC(Boolean) - Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setShowAll(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setShowBody(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setShowBody(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowBodyType(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setShowBodyType(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowBreadCrumb(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowCaughtException(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setShowException(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setShowException(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowExchangeId(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setShowExchangeId(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowExchangePattern(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setShowExchangePattern(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowFiles(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
If enabled Camel will output files
Is default disabled.
- setShowFuture(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
If enabled Camel will on Future objects wait for it to complete to obtain the payload to be logged.
- setShowHeaders(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setShowHeaders(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowNode(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowOut(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setShowOutBody(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowOutBodyType(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowOutHeaders(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowProperties(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setShowProperties(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowRouteId(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowShortExchangeId(boolean) - Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowStackTrace(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setShowStreams(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
If enabled Camel will output stream objects
Is default disabled.
- setShutdownAwaitTermination(long) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
-
- setShutdownAwaitTermination(long) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
- setShutdownExecutorService(boolean) - Method in class org.apache.camel.processor.RecipientList
-
- setShutdownNowOnTimeout(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- setShutdownNowOnTimeout(boolean) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
- setShutdownNowOnTimeout(boolean) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- setShutdownNowOnTimeout(boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Sets whether to force shutdown of all consumers when a timeout occurred and thus
not all consumers was shutdown within that period.
- setShutdownRoute(ShutdownRoute) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setShutdownRoute(ShutdownRoute) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setShutdownRoute(ShutdownRoute) - Method in class org.apache.camel.model.RouteDefinition
-
- setShutdownRoute(ShutdownRoute) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets the ShutdownRoute option for routes.
- setShutdownRoutesInReverseOrder(boolean) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
- setShutdownRoutesInReverseOrder(boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Sets whether routes should be shutdown in reverse or the same order as they where started.
- setShutdownRunningTask(ShutdownRunningTask) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setShutdownRunningTask(ShutdownRunningTask) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setShutdownRunningTask(ShutdownRunningTask) - Method in class org.apache.camel.model.RouteDefinition
-
- setShutdownRunningTask(ShutdownRunningTask) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets the ShutdownRunningTask option to use when shutting down a route.
- setShutdownStrategy(ShutdownStrategy) - Method in interface org.apache.camel.CamelContext
-
Sets a custom shutdown strategy
- setShutdownStrategy(ShutdownStrategy) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setShutdownTimeoutCheckerExecutorService(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setSimpleFunction(XPathFunction) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setSize(long) - Method in class org.apache.camel.component.dataset.DataSetSupport
-
- setSize(int) - Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setSkipBodyLineSeparator(boolean) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
- setSkipDuplicate(Boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
-
- setSkipFirstLine(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
-
- setSkipNamespaces(Boolean) - Method in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- setSkipSendToOriginalEndpoint(Boolean) - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
-
- setSkipWhitespace(Boolean) - Method in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- setSleepForEmptyTest(long) - Method in class org.apache.camel.component.mock.MockEndpoint
-
- setSortBy(Comparator<Exchange>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setSortBy(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setSortBy(String, boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setSorter(Comparator<GenericFile<T>>) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setSource(String) - Method in class org.apache.camel.management.JmxNotificationEventNotifier
-
Sets the source to be used when broadcasting events.
- setSpoolChiper(String) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- setSpoolChiper(String) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Sets a chiper name to use when spooling to disk to write with encryption.
- setSpoolDirectory(String) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- setSpoolDirectory(File) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- setSpoolDirectory(File) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Sets the spool (temporary) directory to use for overflow and spooling to disk.
- setSpoolDirectory(String) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
- setSpoolThreshold(long) - Method in interface org.apache.camel.api.management.mbean.ManagedStreamCachingStrategyMBean
-
- setSpoolThreshold(long) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- setSpoolThreshold(long) - Method in class org.apache.camel.management.mbean.ManagedStreamCachingStrategy
-
- setSpoolThreshold(long) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Threshold in bytes when overflow to disk is activated.
- setSpoolUsedHeapMemoryLimit(StreamCachingStrategy.SpoolUsedHeapMemoryLimit) - Method in interface org.apache.camel.api.management.mbean.ManagedStreamCachingStrategyMBean
-
- setSpoolUsedHeapMemoryLimit(StreamCachingStrategy.SpoolUsedHeapMemoryLimit) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- setSpoolUsedHeapMemoryLimit(StreamCachingStrategy.SpoolUsedHeapMemoryLimit) - Method in class org.apache.camel.management.mbean.ManagedStreamCachingStrategy
-
- setSpoolUsedHeapMemoryLimit(StreamCachingStrategy.SpoolUsedHeapMemoryLimit) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
- setSpoolUsedHeapMemoryThreshold(int) - Method in interface org.apache.camel.api.management.mbean.ManagedStreamCachingStrategyMBean
-
- setSpoolUsedHeapMemoryThreshold(int) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- setSpoolUsedHeapMemoryThreshold(int) - Method in class org.apache.camel.management.mbean.ManagedStreamCachingStrategy
-
- setSpoolUsedHeapMemoryThreshold(int) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Sets a percentage (1-99) of used heap memory threshold to activate spooling to disk.
- setStartingDirectoryMustExist(boolean) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setStartScheduler(boolean) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
Sets whether the scheduler should be started when this consumer starts.
- setStartupOrder(Integer) - Method in class org.apache.camel.model.RouteDefinition
-
- setStatisticsEnabled(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedPerformanceCounterMBean
-
- setStatisticsEnabled(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedStreamCachingStrategyMBean
-
- setStatisticsEnabled(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTypeConverterRegistryMBean
-
- setStatisticsEnabled(boolean) - Method in interface org.apache.camel.api.management.PerformanceCounter
-
Sets whether statistics are enabled.
- setStatisticsEnabled(boolean) - Method in class org.apache.camel.management.CompositePerformanceCounter
-
- setStatisticsEnabled(boolean) - Method in class org.apache.camel.management.DelegatePerformanceCounter
-
- setStatisticsEnabled(boolean) - Method in class org.apache.camel.management.mbean.ManagedPerformanceCounter
-
- setStatisticsEnabled(boolean) - Method in class org.apache.camel.management.mbean.ManagedStreamCachingStrategy
-
- setStatisticsEnabled(boolean) - Method in class org.apache.camel.management.mbean.ManagedTypeConverterRegistry
-
- setStatisticsEnabled(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
-
Sets whether statistics is enabled.
- setStatisticsEnabled(boolean) - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
-
Sets whether statistics is enabled.
- setStatisticsLevel(ManagementStatisticsLevel) - Method in class org.apache.camel.management.DefaultManagementStrategy
-
- setStatisticsLevel(ManagementStatisticsLevel) - Method in interface org.apache.camel.spi.ManagementStrategy
-
- setStopOnException(Boolean) - Method in class org.apache.camel.model.MulticastDefinition
-
- setStopOnException(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setStopOnException(Boolean) - Method in class org.apache.camel.model.SplitDefinition
-
- setStopOnException(boolean) - Method in class org.apache.camel.processor.RecipientList
-
- setStrategyMethodAllowNull(Boolean) - Method in class org.apache.camel.model.AggregateDefinition
-
- setStrategyMethodAllowNull(Boolean) - Method in class org.apache.camel.model.MulticastDefinition
-
- setStrategyMethodAllowNull(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setStrategyMethodAllowNull(Boolean) - Method in class org.apache.camel.model.SplitDefinition
-
- setStrategyMethodName(String) - Method in class org.apache.camel.model.AggregateDefinition
-
- setStrategyMethodName(String) - Method in class org.apache.camel.model.MulticastDefinition
-
- setStrategyMethodName(String) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setStrategyMethodName(String) - Method in class org.apache.camel.model.SplitDefinition
-
- setStrategyRef(String) - Method in class org.apache.camel.model.AggregateDefinition
-
- setStrategyRef(String) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
-
- setStrategyRef(String) - Method in class org.apache.camel.model.MulticastDefinition
-
- setStrategyRef(String) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setStrategyRef(String) - Method in class org.apache.camel.model.SplitDefinition
-
- setStreamCache(String) - Method in class org.apache.camel.model.RouteDefinition
-
- setStreamCaching(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setStreamCaching(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setStreamCaching(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether stream caching is enabled or not (default is disabled).
- setStreamCachingStrategy(StreamCachingStrategy) - Method in interface org.apache.camel.CamelContext
-
- setStreamCachingStrategy(StreamCachingStrategy) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setStreamConfig(StreamResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
-
- setStreaming(Boolean) - Method in class org.apache.camel.model.MulticastDefinition
-
- setStreaming(Boolean) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setStreaming(Boolean) - Method in class org.apache.camel.model.SplitDefinition
-
- setStreaming(boolean) - Method in class org.apache.camel.processor.RecipientList
-
- setStreamName(String) - Method in class org.apache.camel.model.dataformat.BeanioDataFormat
-
- setStrictOnParameterNames(boolean) - Method in class org.apache.camel.impl.UriComponentConfiguration
-
Strict mode is enabled by default but if disabled then invalid parameter names
will not result in exceptions but we will just log warnings about their use
- setStyle(DefaultExchangeFormatter.OutputStyle) - Method in class org.apache.camel.processor.DefaultExchangeFormatter
-
Sets the outputs style to use.
- setSuffixToken(String) - Method in class org.apache.camel.component.properties.PropertiesComponent
-
Sets the value of the suffix token used to identify properties to replace.
- setSuppressLoggingOnTimeout(boolean) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
- setSuppressLoggingOnTimeout(boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Whether Camel should try to suppress logging during shutdown and timeout was triggered,
meaning forced shutdown is happening.
- setSynchronous(boolean) - Method in class org.apache.camel.impl.DefaultEndpoint
-
Sets whether synchronous processing should be strictly used, or Camel is
allowed to use asynchronous processing (if supported).
- setTarget(Processor) - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
-
- setTempFileName(Expression) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setTempFileName(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setTemplate(Templates) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- setTempPrefix(String) - Method in class org.apache.camel.component.file.GenericFileEndpoint
-
Enables and uses temporary prefix when writing files, after write it will
be renamed to the correct name.
- setterBeanInjection(Method, String, Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
-
- setterInjection(Method, Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
-
- setterInjection(Method, Object, String, String, String, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
-
- setterPropertyInjection(Method, String, String, Object, String) - Method in class org.apache.camel.impl.DefaultCamelBeanPostProcessor
-
- setText(String) - Method in class org.apache.camel.model.DescriptionDefinition
-
- setThreadFactory(ThreadFactory) - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- setThreadName(String) - Method in class org.apache.camel.model.ThreadsDefinition
-
- setThreadNamePattern(String) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
-
- setThreadNamePattern(String) - Method in class org.apache.camel.impl.DefaultExecutorServiceStrategy
-
Deprecated.
- setThreadNamePattern(String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Sets the thread name pattern used for creating the full thread name.
- setThreadNamePattern(String) - Method in interface org.apache.camel.spi.ExecutorServiceStrategy
-
Deprecated.
Sets the thread name pattern used for creating the full thread name.
- setThreadPoolFactory(ThreadPoolFactory) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
-
- setThreadPoolFactory(ThreadPoolFactory) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
- setTime(Date) - Method in class org.apache.camel.component.timer.TimerEndpoint
-
- setTimeout(long) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- setTimeout(long) - Method in class org.apache.camel.component.direct.DirectComponent
-
- setTimeout(long) - Method in class org.apache.camel.component.direct.DirectEndpoint
-
- setTimeout(long) - Method in class org.apache.camel.component.directvm.DirectVmComponent
-
- setTimeout(long) - Method in class org.apache.camel.component.directvm.DirectVmEndpoint
-
- setTimeout(long) - Method in interface org.apache.camel.component.file.GenericFileExclusiveReadLockStrategy
-
Sets an optional timeout period.
- setTimeout(long) - Method in class org.apache.camel.component.file.strategy.FileChangedExclusiveReadLockStrategy
-
- setTimeout(long) - Method in class org.apache.camel.component.file.strategy.FileLockExclusiveReadLockStrategy
-
- setTimeout(long) - Method in class org.apache.camel.component.file.strategy.GenericFileRenameExclusiveReadLockStrategy
-
- setTimeout(long) - Method in class org.apache.camel.component.file.strategy.MarkerFileExclusiveReadLockStrategy
-
- setTimeout(long) - Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setTimeout(long) - Method in class org.apache.camel.component.test.TestEndpoint
-
- setTimeout(long) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
- setTimeout(long) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- setTimeout(long) - Method in class org.apache.camel.model.config.StreamResequencerConfig
-
- setTimeout(Long) - Method in class org.apache.camel.model.MulticastDefinition
-
- setTimeout(Long) - Method in class org.apache.camel.model.PollEnrichDefinition
-
- setTimeout(Long) - Method in class org.apache.camel.model.RecipientListDefinition
-
- setTimeout(Long) - Method in class org.apache.camel.model.SplitDefinition
-
- setTimeout(long) - Method in class org.apache.camel.processor.PollEnricher
-
Sets the timeout to use when polling.
- setTimeout(long) - Method in class org.apache.camel.processor.RecipientList
-
- setTimeout(long) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
-
Sets this sequencer's timeout value.
- setTimeout(long) - Method in class org.apache.camel.processor.StreamResequencer
-
- setTimeout(long) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Set an timeout to wait for the shutdown to complete.
- setTimeout(long) - Method in class org.apache.camel.support.TimeoutMapEntry
-
- setTimeoutCheckerExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.model.AggregateDefinition
-
- setTimeoutCheckerExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- setTimeoutCheckerExecutorServiceRef(String) - Method in class org.apache.camel.model.AggregateDefinition
-
- setTimeoutHandler(TimeoutHandler) - Method in class org.apache.camel.processor.resequencer.Timeout
-
Sets a timeout handler for receiving timeout notifications.
- setTimePeriodMillis(long) - Method in interface org.apache.camel.api.management.mbean.ManagedThrottlerMBean
-
- setTimePeriodMillis(long) - Method in class org.apache.camel.management.mbean.ManagedThrottler
-
- setTimePeriodMillis(Long) - Method in class org.apache.camel.model.ThrottleDefinition
-
- setTimePeriodMillis(long) - Method in class org.apache.camel.processor.Throttler
-
Sets the time period during which the maximum number of requests apply
- setTimer(Timer) - Method in class org.apache.camel.component.timer.TimerEndpoint
-
- setTimerName(String) - Method in class org.apache.camel.component.timer.TimerEndpoint
-
- setTimestamp(Date) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setTimeUnit(TimeUnit) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- setTimeUnit(String) - Method in interface org.apache.camel.api.management.mbean.ManagedSchedulePollConsumerMBean
-
- setTimeUnit(TimeUnit) - Method in class org.apache.camel.impl.DefaultScheduledPollConsumerScheduler
-
- setTimeUnit(TimeUnit) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
- setTimeUnit(TimeUnit) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
Sets the time unit to use.
- setTimeUnit(TimeUnit) - Method in class org.apache.camel.main.MainSupport
-
Sets the time unit duration.
- setTimeUnit(TimeUnit) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- setTimeUnit(String) - Method in class org.apache.camel.management.mbean.ManagedScheduledPollConsumer
-
- setTimeUnit(TimeUnit) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setTimeUnit(TimeUnit) - Method in class org.apache.camel.model.ThreadsDefinition
-
- setTimeUnit(TimeUnit) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Set the time unit to use
- setTimeUnit(TimeUnit) - Method in class org.apache.camel.spi.ThreadPoolProfile
-
Sets the time unit used for keep alive time
- setToEndpoint(Exchange, Processor) - Static method in class org.apache.camel.processor.MulticastProcessor
-
- setToken(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- setToken(String) - Method in class org.apache.camel.model.language.TokenizerExpression
-
- setToNode(String) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setTotalProcessingTime(Long) - Method in class org.apache.camel.util.ProcessorStatDump
-
- setTotalProcessingTime(Long) - Method in class org.apache.camel.util.RouteStatDump
-
- setTrace(String) - Method in class org.apache.camel.model.RouteDefinition
-
- setTraceBodySize(int) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setTraceBodySize(int) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setTraceBodySize(int) - Method in class org.apache.camel.processor.interceptor.Tracer
-
- setTraceExceptions(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setTraceExceptions(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setTraceExceptions(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Sets whether thrown exceptions should be traced
- setTraceFilter(String) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogTracerMBean
-
- setTraceFilter(String) - Method in class org.apache.camel.management.mbean.ManagedBacklogTracer
-
- setTraceFilter(String) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
-
- setTraceFilter(Predicate) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Sets a predicate to be used as filter when tracing
- setTraceHandler(TraceEventHandler) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
Deprecated.
- setTraceHandler(TraceEventHandler) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Deprecated.
- setTraceInterceptorFactory(TraceInterceptorFactory) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Set the factory to be used to create the trace interceptor.
- setTraceInterceptors(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setTraceInterceptors(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setTraceInterceptors(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Sets whether interceptors should be traced or not
- setTraceOutExchanges(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedTracerMBean
-
- setTraceOutExchanges(boolean) - Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setTraceOutExchanges(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Sets whether exchanges coming out of processors should be traced
- setTracePattern(String) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogTracerMBean
-
- setTracePattern(String) - Method in class org.apache.camel.management.mbean.ManagedBacklogTracer
-
- setTracePattern(String) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
-
- setTracing(Boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- setTracing(Boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedRouteMBean
-
- setTracing(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setTracing(Boolean) - Method in class org.apache.camel.impl.DefaultRouteContext
-
- setTracing(Boolean) - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- setTracing(Boolean) - Method in class org.apache.camel.management.mbean.ManagedRoute
-
- setTracing(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
-
Sets whether tracing is enabled or not (default is disabled).
- setTransform(boolean) - Method in class org.apache.camel.component.language.LanguageEndpoint
-
Whether or not the result of the script should be used as message body.
- setTransformerFactory(TransformerFactory) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- setTransformerFile(File) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
Sets the XSLT transformer from a File
- setTransformerInputStream(InputStream) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
Sets the XSLT transformer from the given input stream
- setTransformerSource(Source) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
Sets the XSLT transformer from a Source
- setTransformerURL(URL) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
Sets the XSLT transformer from a URL
- setTrim(Boolean) - Method in class org.apache.camel.model.language.ExpressionDefinition
-
- setTrimSpaces(Boolean) - Method in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- setTrustManagers(TrustManagersParameters) - Method in class org.apache.camel.util.jsse.SSLContextParameters
-
Sets the optional trust manager configuration for creating the
TrustManager
s used in constructing an
SSLContext
.
- setType(Class<?>) - Method in class org.apache.camel.component.bean.MethodBean
-
- setType(String) - Method in class org.apache.camel.management.InstrumentationProcessor
-
- setType(String) - Method in class org.apache.camel.model.ConvertBodyDefinition
-
- setType(BindyType) - Method in class org.apache.camel.model.dataformat.BindyDataFormat
-
- setType(String) - Method in class org.apache.camel.model.language.XQueryExpression
-
- setType(Class<? extends Policy>) - Method in class org.apache.camel.model.PolicyDefinition
-
Sets a policy type that this definition should scope within.
- setType(Class<? extends Policy>) - Method in class org.apache.camel.model.TransactedDefinition
-
Sets a policy type that this definition should scope within.
- setType(String) - Method in class org.apache.camel.processor.CamelInternalProcessor.InstrumentationAdvice
-
- setType(String) - Method in class org.apache.camel.util.jsse.KeyStoreParameters
-
Sets the type of the key store to create and load.
- setType(String) - Method in class org.apache.camel.util.MessageDump.Body
-
- setType(String) - Method in class org.apache.camel.util.MessageDump.Header
-
- setTypeClass(Class<?>) - Method in class org.apache.camel.model.ConvertBodyDefinition
-
- setTypeConverter(TypeConverter) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setTypeConverter(TypeConverter) - Method in interface org.apache.camel.spi.TypeConverterAware
-
Injects the root type converter.
- setTypeConverterRegistry(TypeConverterRegistry) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setTypeConverterStatisticsEnabled(Boolean) - Method in interface org.apache.camel.CamelContext
-
Sets whether or not type converter statistics is enabled.
- setTypeConverterStatisticsEnabled(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setTypeHints(String) - Method in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- setUnitOfWork(UnitOfWork) - Method in interface org.apache.camel.Exchange
-
Sets the unit of work that this exchange belongs to; which may map to
zero, one or more physical transactions
- setUnitOfWork(UnitOfWork) - Method in class org.apache.camel.impl.DefaultExchange
-
- setUnitOfWorkFactory(UnitOfWorkFactory) - Method in interface org.apache.camel.CamelContext
-
- setUnitOfWorkFactory(UnitOfWorkFactory) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setUnits(String) - Method in class org.apache.camel.model.SamplingDefinition
-
- setUnits(TimeUnit) - Method in class org.apache.camel.model.SamplingDefinition
-
- setUnmarshallClass(Class<?>) - Method in class org.apache.camel.model.dataformat.JibxDataFormat
-
- setUnmarshallTypeName(String) - Method in class org.apache.camel.model.dataformat.JibxDataFormat
-
- setUnmarshalType(Class<?>) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
-
- setUnmarshalTypeName(String) - Method in class org.apache.camel.model.dataformat.JsonDataFormat
-
- setupFeatures(DocumentBuilderFactory) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- setupRoutes(boolean) - Method in interface org.apache.camel.CamelContext
-
Method to signal to
CamelContext
that the process to initialize setup routes is in progress.
- setupRoutes(boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setURI(URI) - Method in class org.apache.camel.impl.DefaultEndpointConfiguration
-
- setURI(String) - Method in class org.apache.camel.impl.DefaultEndpointConfiguration
-
- setURI(URI) - Method in class org.apache.camel.impl.UriEndpointConfiguration
-
- setUri(String) - Method in class org.apache.camel.model.FromDefinition
-
Sets the URI of the endpoint to use
- setUri(String) - Method in class org.apache.camel.model.InterceptFromDefinition
-
- setUri(String) - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
-
- setUri(String) - Method in class org.apache.camel.model.SendDefinition
-
- setUri(String) - Method in class org.apache.camel.model.WireTapDefinition
-
- setUriDelimiter(String) - Method in class org.apache.camel.model.DynamicRouterDefinition
-
- setUriDelimiter(String) - Method in class org.apache.camel.model.RoutingSlipDefinition
-
- setUriPostfix(String) - Method in class org.apache.camel.component.binding.BindingComponent
-
- setUriPrefix(String) - Method in class org.apache.camel.component.binding.BindingComponent
-
- setUriResolver(URIResolver) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- setUriResolver(URIResolver) - Method in class org.apache.camel.component.xslt.XsltComponent
-
- setUriString(String) - Method in interface org.apache.camel.ComponentConfiguration
-
- setUriString(String) - Method in class org.apache.camel.impl.ComponentConfigurationSupport
-
- setUrlSafe(Boolean) - Method in class org.apache.camel.model.dataformat.Base64DataFormat
-
- setUseBreadcrumb(Boolean) - Method in interface org.apache.camel.CamelContext
-
Set whether breadcrumb is enabled.
- setUseBreadcrumb(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setUseCollisionAvoidance(Boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setUseCollisionAvoidance(Boolean) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setUseCollisionAvoidance(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setUseCollisionAvoidance(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Enables/disables collision avoidance which adds some randomization to the
backoff timings to reduce contention probability
- setUseDom(boolean) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
Deprecated.
- setUseExponentialBackOff(Boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedErrorHandlerMBean
-
- setUseExponentialBackOff(Boolean) - Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setUseExponentialBackOff(String) - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setUseExponentialBackOff(boolean) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
- setUseFixedDelay(boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedSchedulePollConsumerMBean
-
- setUseFixedDelay(boolean) - Method in class org.apache.camel.impl.DefaultScheduledPollConsumerScheduler
-
- setUseFixedDelay(boolean) - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
- setUseFixedDelay(boolean) - Method in class org.apache.camel.management.mbean.ManagedScheduledPollConsumer
-
- setUseJpa(boolean) - Method in class org.apache.camel.processor.interceptor.Tracer
-
Sets whether we should use a JpaTraceEventMessage instead of
an ordinary
DefaultTraceEventMessage
Use this to allow persistence of trace events into a database using JPA.
- setUseMaps(Boolean) - Method in class org.apache.camel.model.dataformat.CsvDataFormat
-
- setUseMDCLogging(Boolean) - Method in interface org.apache.camel.CamelContext
-
Set whether
MDC is enabled.
- setUseMDCLogging(Boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setUseOriginalMessage(boolean) - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- setUseOriginalMessagePolicy(Boolean) - Method in class org.apache.camel.model.OnCompletionDefinition
-
- setUseOriginalMessagePolicy(Boolean) - Method in class org.apache.camel.model.OnExceptionDefinition
-
- setUsePlatformMBeanServer(Boolean) - Method in class org.apache.camel.management.DefaultManagementAgent
-
- setUsePlatformMBeanServer(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
-
Whether to use the platform MBean Server.
- setUseRecovery(boolean) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
-
Sets whether or not recovery is enabled
- setUseSaxon(Boolean) - Method in class org.apache.camel.language.xpath.XPathLanguage
-
- setUseSharedSchema(boolean) - Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setUseTracer(boolean) - Method in class org.apache.camel.impl.DefaultDebugger
-
- setUsingIterator(Boolean) - Method in class org.apache.camel.model.dataformat.ZipFileDataFormat
-
- setUuidGenerator(UuidGenerator) - Method in interface org.apache.camel.CamelContext
-
- setUuidGenerator(UuidGenerator) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- setValidate(Boolean) - Method in class org.apache.camel.model.dataformat.HL7DataFormat
-
- setValidation(Boolean) - Method in class org.apache.camel.model.dataformat.CastorDataFormat
-
- setValue(String) - Method in class org.apache.camel.model.config.PropertyDefinition
-
- setValue(V) - Method in class org.apache.camel.support.TimeoutMapEntry
-
- setValue(String) - Method in class org.apache.camel.util.MessageDump.Body
-
- setValue(String) - Method in class org.apache.camel.util.MessageDump.Header
-
- setVersion(String) - Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
-
- setWaitForTaskToComplete(WaitForTaskToComplete) - Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setWhenClauses(List<WhenDefinition>) - Method in class org.apache.camel.model.ChoiceDefinition
-
- setXml(boolean) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- setXml(Boolean) - Method in class org.apache.camel.model.language.TokenizerExpression
-
- setXmlCipherAlgorithm(String) - Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setXmlConverter(XmlConverter) - Method in class org.apache.camel.component.xslt.XsltComponent
-
- setXmlStreamWriterWrapper(String) - Method in class org.apache.camel.model.dataformat.JaxbDataFormat
-
- setXPathFactory(XPathFactory) - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setXpathFactory(XPathFactory) - Method in class org.apache.camel.language.xpath.XPathLanguage
-
- shape - Variable in class org.apache.camel.view.NodeData
-
- SharedProducerServicePool - Class in org.apache.camel.impl
-
- SharedProducerServicePool() - Constructor for class org.apache.camel.impl.SharedProducerServicePool
-
- SharedProducerServicePool(int) - Constructor for class org.apache.camel.impl.SharedProducerServicePool
-
- shareUnitOfWork() - Method in class org.apache.camel.model.MulticastDefinition
-
Shares the
UnitOfWork
with the parent and each of the sub messages.
- shareUnitOfWork() - Method in class org.apache.camel.model.RecipientListDefinition
-
Shares the
UnitOfWork
with the parent and each of the sub messages.
- shareUnitOfWork() - Method in class org.apache.camel.model.SplitDefinition
-
Shares the
UnitOfWork
with the parent and each of the sub messages.
- shouldFailOver(Exchange) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
-
Should the given failed Exchange failover?
- shouldHandleException(Exchange) - Method in class org.apache.camel.processor.RedeliveryErrorHandler
-
Strategy whether the exchange has an exception that we should try to handle.
- shouldLog() - Method in class org.apache.camel.util.CamelLogger
-
- shouldLog(Logger, LoggingLevel) - Static method in class org.apache.camel.util.CamelLogger
-
- shouldLogException(Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
Returns true if the given exchange should be logged when an exception was thrown
- shouldLogExchange(Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
Returns true if the given exchange should be logged in the trace list
- shouldLogNode(ProcessorDefinition<?>) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
Returns true if the given node should be logged in the trace list
- shouldRedeliver(Exchange, int, Predicate) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Returns true if the policy decides that the message exchange should be
redelivered.
- shouldRegister(Object, Route) - Method in class org.apache.camel.management.DefaultManagementLifecycleStrategy
-
Whether or not to register the mbean.
- shouldRetry(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
-
- shouldSpoolCache(long) - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- shouldSpoolCache(long) - Method in interface org.apache.camel.spi.StreamCachingStrategy
-
Determines if the stream should be spooled or not.
- shouldSpoolCache(long) - Method in interface org.apache.camel.spi.StreamCachingStrategy.SpoolRule
-
Determines if the stream should be spooled or not.
- shouldStartRoutes() - Method in class org.apache.camel.impl.DefaultCamelContext
-
Should we start newly added routes?
- shouldTrace(ProcessorDefinition<?>, Exchange) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
-
Whether or not to trace the given processor definition.
- shouldTraceOutExchanges() - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
Returns whether exchanges coming out of processors should be traced
- showOptions() - Method in class org.apache.camel.main.MainSupport
-
Displays the command line options.
- showOptionsHeader() - Method in class org.apache.camel.main.MainSupport
-
Displays the header message for the command line options.
- shutdown() - Method in interface org.apache.camel.api.management.mbean.ManagedRouteMBean
-
Deprecated.
will be removed in the near future. Use stop and remove instead
- shutdown(long) - Method in interface org.apache.camel.api.management.mbean.ManagedRouteMBean
-
Deprecated.
will be removed in the near future. Use stop and remove instead
- shutdown() - Method in class org.apache.camel.component.seda.SedaEndpoint
-
- shutdown(ExecutorService) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
-
- shutdown(ExecutorService) - Method in class org.apache.camel.impl.DefaultExecutorServiceStrategy
-
Deprecated.
- shutdown(CamelContext, List<RouteStartupOrder>) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
- shutdown(CamelContext, List<RouteStartupOrder>, long, TimeUnit) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
- shutdown(CamelContext, RouteStartupOrder, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
- shutdown() - Method in class org.apache.camel.management.mbean.ManagedRoute
-
- shutdown(long) - Method in class org.apache.camel.management.mbean.ManagedRoute
-
- shutdown() - Method in interface org.apache.camel.ShutdownableService
-
Shutdown the service, which means it cannot be started again.
- shutdown(ExecutorService) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Shutdown the given executor service (not graceful).
- shutdown(ExecutorService) - Method in interface org.apache.camel.spi.ExecutorServiceStrategy
-
Deprecated.
Shutdown the given executor service.
- shutdown(CamelContext, List<RouteStartupOrder>) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Shutdown the routes
- shutdown(CamelContext, List<RouteStartupOrder>, long, TimeUnit) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Shutdown the routes using a specified timeout instead of the default timeout values
- shutdown(CamelContext, RouteStartupOrder, long, TimeUnit, boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Shutdown the route using a specified timeout instead of the default timeout values and supports abortAfterTimeout mode
- shutdown() - Method in class org.apache.camel.support.ChildServiceSupport
-
- shutdown - Variable in class org.apache.camel.support.ServiceSupport
-
- shutdown() - Method in class org.apache.camel.support.ServiceSupport
-
- shutdown() - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- shutdown() - Method in class org.apache.camel.util.concurrent.SynchronousExecutorService
-
- shutdown() - Static method in class org.apache.camel.util.FileUtil
-
Deprecated.
- ShutdownableService - Interface in org.apache.camel
-
A
Service
which is capable of being shut down.
- ShutdownAware - Interface in org.apache.camel.spi
-
Allows
Consumer
to fine grained control on shutdown which mostly
have to cater for in-memory based components.
- shutdownForced(CamelContext, List<RouteStartupOrder>) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
- shutdownForced(CamelContext, List<RouteStartupOrder>) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Shutdown the routes, forcing shutdown being more aggressive, if timeout occurred.
- shutdownGraceful(ExecutorService) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
-
- shutdownGraceful(ExecutorService, long) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
-
- shutdownGraceful(ExecutorService) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Shutdown the given executor service graceful at first, and then aggressively
if the await termination timeout was hit.
- shutdownGraceful(ExecutorService, long) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Shutdown the given executor service graceful at first, and then aggressively
if the await termination timeout was hit.
- shutdownNow(ExecutorService) - Method in class org.apache.camel.impl.DefaultExecutorServiceManager
-
- shutdownNow(ExecutorService) - Method in class org.apache.camel.impl.DefaultExecutorServiceStrategy
-
Deprecated.
- shutdownNow(List<Consumer>) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
Shutdown all the consumers immediately.
- shutdownNow(Consumer) - Static method in class org.apache.camel.impl.DefaultShutdownStrategy
-
Shutdown the consumer immediately.
- shutdownNow(ExecutorService) - Method in interface org.apache.camel.spi.ExecutorServiceManager
-
Shutdown now the given executor service aggressively.
- shutdownNow(ExecutorService) - Method in interface org.apache.camel.spi.ExecutorServiceStrategy
-
Deprecated.
Shutdown now the given executor service.
- shutdownNow() - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- shutdownNow() - Method in class org.apache.camel.util.concurrent.SynchronousExecutorService
-
- ShutdownPrepared - Interface in org.apache.camel.spi
-
Allows a
Service
to prepare for shutdown.
- shutdownRoute(String) - Method in interface org.apache.camel.CamelContext
-
- shutdownRoute(String, long, TimeUnit) - Method in interface org.apache.camel.CamelContext
-
- shutdownRoute(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- shutdownRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- shutdownRoute(ShutdownRoute) - Method in class org.apache.camel.model.RouteDefinition
-
Configures a shutdown route option.
- ShutdownRoute - Enum in org.apache.camel
-
Represents the options available when shutting down routes.
- shutdownRouteService(RouteService) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- shutdownRoutesNow(List<RouteStartupOrder>) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
Shutdown all the consumers immediately.
- shutdownRunningTask - Variable in class org.apache.camel.component.file.GenericFileConsumer
-
- shutdownRunningTask - Variable in class org.apache.camel.impl.ScheduledBatchPollingConsumer
-
- shutdownRunningTask(ShutdownRunningTask) - Method in class org.apache.camel.model.RouteDefinition
-
Configures a shutdown running task option.
- ShutdownRunningTask - Enum in org.apache.camel
-
Represents the kind of options for what to do with the current task when shutting down.
- ShutdownStrategy - Interface in org.apache.camel.spi
-
Pluggable shutdown strategy executed during shutdown of routes.
- shuttingdown - Variable in class org.apache.camel.support.ServiceSupport
-
- simple(String) - Static method in class org.apache.camel.builder.Builder
-
Returns a simple expression
- simple(String, Class<?>) - Static method in class org.apache.camel.builder.Builder
-
Returns a simple expression
- simple(String) - Method in class org.apache.camel.builder.BuilderSupport
-
Returns a simple expression value builder
- simple(String, Class<?>) - Method in class org.apache.camel.builder.BuilderSupport
-
Returns a simple expression value builder
- simple(String) - Method in class org.apache.camel.builder.ExpressionClause
-
- simple(String, Class<?>) - Method in class org.apache.camel.builder.ExpressionClause
-
- simple(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
- simple(String, Class<?>) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
- simple(String) - Static method in class org.apache.camel.builder.SimpleBuilder
-
- simple(String, Class<?>) - Static method in class org.apache.camel.builder.SimpleBuilder
-
- Simple - Annotation Type in org.apache.camel.language
-
Used to inject a simple expression into a field, property, method or parameter when using
Bean Integration.
- simple(String) - Static method in class org.apache.camel.language.simple.SimpleLanguage
-
- simple(String, Class<?>) - Static method in class org.apache.camel.language.simple.SimpleLanguage
-
- SimpleBackwardsCompatibleParser - Class in org.apache.camel.language.simple
-
Deprecated.
will be removed in Camel 3.0
- SimpleBuilder - Class in org.apache.camel.builder
-
Creates an
Simple
language builder.
- SimpleBuilder(String) - Constructor for class org.apache.camel.builder.SimpleBuilder
-
- SimpleDataSet - Class in org.apache.camel.component.dataset
-
A simple DataSet that allows a static payload to be used to create each message exchange
along with using a pluggable transformer to randomize the message.
- SimpleDataSet() - Constructor for class org.apache.camel.component.dataset.SimpleDataSet
-
- SimpleDataSet(int) - Constructor for class org.apache.camel.component.dataset.SimpleDataSet
-
- simpleExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
- SimpleExpression - Class in org.apache.camel.model.language
-
- SimpleExpression() - Constructor for class org.apache.camel.model.language.SimpleExpression
-
- SimpleExpression(String) - Constructor for class org.apache.camel.model.language.SimpleExpression
-
- SimpleExpression(Expression) - Constructor for class org.apache.camel.model.language.SimpleExpression
-
- SimpleExpressionParser - Class in org.apache.camel.language.simple
-
A parser to parse simple language as a Camel
Expression
- SimpleExpressionParser(String) - Constructor for class org.apache.camel.language.simple.SimpleExpressionParser
-
Deprecated.
- SimpleExpressionParser(String, boolean) - Constructor for class org.apache.camel.language.simple.SimpleExpressionParser
-
- SimpleFunctionEnd - Class in org.apache.camel.language.simple.ast
-
Ends a function
- SimpleFunctionEnd(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.SimpleFunctionEnd
-
- SimpleFunctionExpression - Class in org.apache.camel.language.simple.ast
-
- SimpleFunctionExpression(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.SimpleFunctionExpression
-
- SimpleFunctionStart - Class in org.apache.camel.language.simple.ast
-
Starts a function
- SimpleFunctionStart(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.SimpleFunctionStart
-
- SimpleIllegalSyntaxException - Exception in org.apache.camel.language.simple.types
-
Syntax error in the simple language expression.
- SimpleIllegalSyntaxException(String, int, String) - Constructor for exception org.apache.camel.language.simple.types.SimpleIllegalSyntaxException
-
- SimpleIllegalSyntaxException(String, int, String, Throwable) - Constructor for exception org.apache.camel.language.simple.types.SimpleIllegalSyntaxException
-
- SimpleLanguage - Class in org.apache.camel.language.simple
-
A
simple language
which maps simple property style notations to access headers and bodies.
- SimpleLanguage() - Constructor for class org.apache.camel.language.simple.SimpleLanguage
-
Default constructor.
- SimpleLoadBalancerSupport - Class in org.apache.camel.processor.loadbalancer
-
- SimpleLoadBalancerSupport() - Constructor for class org.apache.camel.processor.loadbalancer.SimpleLoadBalancerSupport
-
- SimpleNode - Interface in org.apache.camel.language.simple.ast
-
Represents a node in the Simple AST
- SimpleParserException - Exception in org.apache.camel.language.simple.types
-
Holds information about error parsing the simple expression at a given location
in the input.
- SimpleParserException(String, int) - Constructor for exception org.apache.camel.language.simple.types.SimpleParserException
-
- SimplePredicateParser - Class in org.apache.camel.language.simple
-
A parser to parse simple language as a Camel
Predicate
- SimplePredicateParser(String) - Constructor for class org.apache.camel.language.simple.SimplePredicateParser
-
Deprecated.
- SimplePredicateParser(String, boolean) - Constructor for class org.apache.camel.language.simple.SimplePredicateParser
-
- SimpleRegistry - Class in org.apache.camel.impl
-
- SimpleRegistry() - Constructor for class org.apache.camel.impl.SimpleRegistry
-
- SimpleToken - Class in org.apache.camel.language.simple.types
-
Holder for a token, with associated type and position in the input.
- SimpleToken(SimpleTokenType, int) - Constructor for class org.apache.camel.language.simple.types.SimpleToken
-
- SimpleToken(SimpleTokenType, int, int) - Constructor for class org.apache.camel.language.simple.types.SimpleToken
-
- SimpleTokenizer - Class in org.apache.camel.language.simple
-
- SimpleTokenType - Class in org.apache.camel.language.simple.types
-
The different token types used by the simple parser.
- SimpleTokenType(TokenType, String) - Constructor for class org.apache.camel.language.simple.types.SimpleTokenType
-
- SimpleUuidGenerator - Class in org.apache.camel.impl
-
This implementation uses a counter which increments by one
- SimpleUuidGenerator() - Constructor for class org.apache.camel.impl.SimpleUuidGenerator
-
- singleQuote(String) - Static method in class org.apache.camel.util.StringQuoteHelper
-
Returns the text wrapped single quotes
- singleQuotedLiteralText() - Method in class org.apache.camel.language.simple.SimplePredicateParser
-
- singleQuotedLiteralWithFunctionsText() - Method in class org.apache.camel.language.simple.SimplePredicateParser
-
- SingleQuoteEnd - Class in org.apache.camel.language.simple.ast
-
Ends a block enclosed by single quotes
- SingleQuoteEnd(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.SingleQuoteEnd
-
- SingleQuoteStart - Class in org.apache.camel.language.simple.ast
-
Starts a block enclosed by single quotes
- SingleQuoteStart(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.SingleQuoteStart
-
- size() - Method in class org.apache.camel.impl.ConsumerCache
-
Returns the current size of the cache
- size() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
-
- size() - Method in class org.apache.camel.impl.DefaultInflightRepository
-
- size(Endpoint) - Method in class org.apache.camel.impl.DefaultInflightRepository
-
Deprecated.
- size(String) - Method in class org.apache.camel.impl.DefaultInflightRepository
-
- size() - Method in class org.apache.camel.impl.DefaultRuntimeEndpointRegistry
-
- size() - Method in class org.apache.camel.impl.DefaultServicePool
-
- size() - Method in class org.apache.camel.impl.osgi.tracker.BundleTracker
-
Return the number of bundles being tracked by this
BundleTracker
.
- size() - Method in class org.apache.camel.impl.ProducerCache
-
Returns the current size of the cache
- size(int) - Method in class org.apache.camel.model.ResequenceDefinition
-
Sets the in batch size for number of exchanges received
- size() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
-
Returns the number of elements currently maintained by this resequencer.
- size() - Method in interface org.apache.camel.spi.InflightRepository
-
Current size of inflight exchanges.
- size(Endpoint) - Method in interface org.apache.camel.spi.InflightRepository
-
Deprecated.
will be removed in a future Camel release.
- size(String) - Method in interface org.apache.camel.spi.InflightRepository
-
Current size of inflight exchanges which are from the given route.
- size() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
-
Number of endpoints currently in the cache.
- size() - Method in interface org.apache.camel.spi.ServicePool
-
Returns the current size of the pool
- size() - Method in interface org.apache.camel.spi.TypeConverterRegistry
-
Number of type converters in the registry.
- size() - Method in class org.apache.camel.support.DefaultTimeoutMap
-
- size() - Method in interface org.apache.camel.TimeoutMap
-
Returns the size of the map
- size(Object) - Static method in class org.apache.camel.util.CollectionHelper
-
Returns the size of the collection if it can be determined to be a collection
- size() - Method in class org.apache.camel.util.LRUCache
-
- size() - Method in class org.apache.camel.util.LRUSoftCache
-
- size() - Method in class org.apache.camel.util.LRUWeakCache
-
- SizedScheduledExecutorService - Class in org.apache.camel.util.concurrent
-
- SizedScheduledExecutorService(ScheduledThreadPoolExecutor, long) - Constructor for class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- SKIP_GZIP_ENCODING - Static variable in interface org.apache.camel.Exchange
-
- SKIP_NAMESPACES - Static variable in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- SKIP_WHITESPACE - Static variable in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- SKIP_WWW_FORM_URLENCODED - Static variable in interface org.apache.camel.Exchange
-
- skipDuplicate(boolean) - Method in class org.apache.camel.model.IdempotentConsumerDefinition
-
Sets whether to skip duplicates or not.
- skipSendToOriginalEndpoint() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
-
Skip sending the
Exchange
to the original intended endpoint
- sleep(long, int) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Calculates the new redelivery delay based on the last one and then sleeps for the necessary amount of time.
- sleep(long) - Method in class org.apache.camel.processor.RedeliveryPolicy
-
Sleeps for the given delay
- SLIP_ENDPOINT - Static variable in interface org.apache.camel.Exchange
-
- SOAP_ACTION - Static variable in interface org.apache.camel.Exchange
-
- soapjaxb() - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the Soap 1.1 JAXB data format
- soapjaxb(String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the Soap 1.1 JAXB data format
- soapjaxb(String, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the Soap 1.1 JAXB data format
- soapjaxb(String, Object) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the Soap 1.1 JAXB data format
- soapjaxb12() - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the Soap 1.2 JAXB data format
- soapjaxb12(String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the Soap 1.2 JAXB data format
- soapjaxb12(String, String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the Soap 1.2 JAXB data format
- soapjaxb12(String, Object) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the Soap JAXB data format
- SoapJaxbDataFormat - Class in org.apache.camel.model.dataformat
-
- SoapJaxbDataFormat() - Constructor for class org.apache.camel.model.dataformat.SoapJaxbDataFormat
-
- SoapJaxbDataFormat(String) - Constructor for class org.apache.camel.model.dataformat.SoapJaxbDataFormat
-
- SoapJaxbDataFormat(String, String) - Constructor for class org.apache.camel.model.dataformat.SoapJaxbDataFormat
-
- SoapJaxbDataFormat(String, Object) - Constructor for class org.apache.camel.model.dataformat.SoapJaxbDataFormat
-
- sort(Comparator<?>) - Method in class org.apache.camel.builder.ValueBuilder
-
Sorts the current value using the given comparator.
- sort(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sorts the expression using a default sorting based on toString representation.
- sort(Expression, Comparator<T>) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sorts the expression using the given comparator
- sort() - Method in class org.apache.camel.model.ProcessorDefinition
-
Sorts the expression
- sortBy - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- sortByFileLanguage(CamelContext, String, boolean) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
-
Returns a new sory by file language expression
- sortByFileLanguage(CamelContext, String, boolean, boolean) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
-
Returns a new sory by file language expression
- sortByFileLanguage(CamelContext, String, boolean, boolean, Comparator<Exchange>) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
-
Returns a new sort by file language expression
- sortByLastModified(boolean) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
-
Returns a new sort by last modified (newest first)
- sortByName(boolean) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
-
Returns a new sort by name
- sortByPathName(boolean) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
-
Returns a new sort by path name
- sortBySize(boolean) - Static method in class org.apache.camel.component.file.GenericFileDefaultSorter
-
Returns a new sort by file size (smallest first)
- SortDefinition<T> - Class in org.apache.camel.model
-
Represents an XML <sort/> element
- SortDefinition() - Constructor for class org.apache.camel.model.SortDefinition
-
- SortDefinition(Expression) - Constructor for class org.apache.camel.model.SortDefinition
-
- SortDefinition(Expression, Comparator<? super T>) - Constructor for class org.apache.camel.model.SortDefinition
-
- sorter - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- sortExpression(Expression, Comparator) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns a sort expression which will sort the expression with the given comparator.
- SortProcessor<T> - Class in org.apache.camel.processor
-
A processor that sorts the expression using a comparator
- SortProcessor(Expression, Comparator<? super T>) - Constructor for class org.apache.camel.processor.SortProcessor
-
- SourceCache - Class in org.apache.camel.converter.stream
-
- SourceCache(String) - Constructor for class org.apache.camel.converter.stream.SourceCache
-
- spel(String) - Method in class org.apache.camel.builder.ExpressionClause
-
- spel(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
- SpEL - Annotation Type in org.apache.camel.language
-
An annotation for injection of Spring Expression Language (SpEL) expressions
into method parameters, fields or properties.
- SpELExpression - Class in org.apache.camel.model.language
-
For Spring Expression Language (SpEL) expressions and predicates
- SpELExpression() - Constructor for class org.apache.camel.model.language.SpELExpression
-
- SpELExpression(String) - Constructor for class org.apache.camel.model.language.SpELExpression
-
- split() - Method in class org.apache.camel.model.ProcessorDefinition
-
Splitter EIP:
Creates a splitter allowing you split a message into a number of pieces and process them individually.
- split(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
Splitter EIP:
Creates a splitter allowing you split a message into a number of pieces and process them individually.
- split(Expression, AggregationStrategy) - Method in class org.apache.camel.model.ProcessorDefinition
-
Splitter EIP:
Creates a splitter allowing you split a message into a number of pieces and process them individually.
- SPLIT_COMPLETE - Static variable in interface org.apache.camel.Exchange
-
- SPLIT_INDEX - Static variable in interface org.apache.camel.Exchange
-
- SPLIT_SIZE - Static variable in interface org.apache.camel.Exchange
-
- SplitDefinition - Class in org.apache.camel.model
-
Represents an XML <split/> element
- SplitDefinition() - Constructor for class org.apache.camel.model.SplitDefinition
-
- SplitDefinition(Expression) - Constructor for class org.apache.camel.model.SplitDefinition
-
- SplitDefinition(ExpressionDefinition) - Constructor for class org.apache.camel.model.SplitDefinition
-
- splitOgnl(String) - Static method in class org.apache.camel.util.OgnlHelper
-
Regular expression with repeating groups is a pain to get right
and then nobody understands the reg exp afterwards.
- splitOnCharacter(String, String, int) - Static method in class org.apache.camel.util.ObjectHelper
-
- splitSafeQuote(String, char) - Static method in class org.apache.camel.util.StringQuoteHelper
-
Splits the input safely honoring if values is enclosed in quotes.
- splitSafeQuote(String, char, boolean) - Static method in class org.apache.camel.util.StringQuoteHelper
-
Splits the input safely honoring if values is enclosed in quotes.
- Splitter - Class in org.apache.camel.processor
-
Implements a dynamic
Splitter pattern
where an expression is evaluated to iterate through each of the parts of a
message and then each part is then send to some endpoint.
- Splitter(CamelContext, Expression, Processor, AggregationStrategy) - Constructor for class org.apache.camel.processor.Splitter
-
- Splitter(CamelContext, Expression, Processor, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean) - Constructor for class org.apache.camel.processor.Splitter
-
- sql(String) - Method in class org.apache.camel.builder.ExpressionClause
-
- sql(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
- SqlExpression - Class in org.apache.camel.model.language
-
For SQL expressions and predicates
- SqlExpression() - Constructor for class org.apache.camel.model.language.SqlExpression
-
- SqlExpression(String) - Constructor for class org.apache.camel.model.language.SqlExpression
-
- SSLContextClientParameters - Class in org.apache.camel.util.jsse
-
Configuration model for client side JSSE options.
- SSLContextClientParameters() - Constructor for class org.apache.camel.util.jsse.SSLContextClientParameters
-
- SSLContextParameters - Class in org.apache.camel.util.jsse
-
Represents
SSLContext
configuration options used in instantiating an
SSLContext
instance.
- SSLContextParameters() - Constructor for class org.apache.camel.util.jsse.SSLContextParameters
-
- SSLContextServerParameters - Class in org.apache.camel.util.jsse
-
- SSLContextServerParameters() - Constructor for class org.apache.camel.util.jsse.SSLContextServerParameters
-
- start() - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- start() - Method in interface org.apache.camel.api.management.mbean.ManagedProcessorMBean
-
- start() - Method in interface org.apache.camel.api.management.mbean.ManagedRouteMBean
-
- start() - Method in interface org.apache.camel.api.management.mbean.ManagedServiceMBean
-
- start() - Method in interface org.apache.camel.CamelContext
-
Starts the
CamelContext
(
important: the start method is not blocked, see more details
here).
- start() - Method in class org.apache.camel.impl.DefaultCamelContext
-
- start() - Method in class org.apache.camel.impl.DefaultDebugger
-
- start() - Method in class org.apache.camel.impl.DefaultRoute
-
- start() - Method in class org.apache.camel.impl.DefaultUnitOfWork
-
- start() - Method in class org.apache.camel.impl.EndpointRegistry
-
- start() - Method in class org.apache.camel.impl.InterceptSendToEndpoint
-
- start() - Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
-
- start(BundleContext) - Method in class org.apache.camel.impl.osgi.Activator
-
- start() - Method in class org.apache.camel.impl.SynchronousDelegateProducer
-
- start() - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- start() - Method in class org.apache.camel.management.mbean.ManagedProcessor
-
- start() - Method in class org.apache.camel.management.mbean.ManagedRoute
-
- start() - Method in class org.apache.camel.management.mbean.ManagedService
-
- start() - Method in class org.apache.camel.management.MBeanInfoAssembler
-
- start() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventHandler
-
- start() - Method in class org.apache.camel.processor.interceptor.Tracer
-
- start() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
-
- start() - Method in class org.apache.camel.processor.UnitOfWorkProducer
-
- start() - Method in interface org.apache.camel.Service
-
Starts the service
- start() - Method in class org.apache.camel.support.ChildServiceSupport
-
- start(boolean) - Method in class org.apache.camel.support.ChildServiceSupport
-
- start() - Method in class org.apache.camel.support.ServiceSupport
-
- startAllRoutes() - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- startAllRoutes() - Method in interface org.apache.camel.CamelContext
-
Starts all the routes which currently is not started.
- startAllRoutes() - Method in class org.apache.camel.impl.DefaultCamelContext
-
- startAllRoutes() - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- startChildService(Route, List<Service>) - Method in class org.apache.camel.impl.RouteService
-
- startConsumer(Consumer) - Method in class org.apache.camel.impl.RoutePolicySupport
-
- started - Variable in class org.apache.camel.support.ServiceSupport
-
- starting - Variable in class org.apache.camel.support.ServiceSupport
-
- startingDirectoryMustExist - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- startProducer(Endpoint) - Method in class org.apache.camel.impl.ProducerCache
-
Starts the
Producer
to be used for sending to the given endpoint
This can be used to early start the
Producer
to ensure it can be created,
such as when Camel is started.
- startRoute(RouteDefinition) - Method in interface org.apache.camel.CamelContext
-
- startRoute(String) - Method in interface org.apache.camel.CamelContext
-
Starts the given route if it has been previously stopped
- startRoute(RouteDefinition) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- startRoute(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- startRoute(Route) - Method in class org.apache.camel.impl.RoutePolicySupport
-
- startRoute(RouteDefinition) - Method in interface org.apache.camel.model.ModelCamelContext
-
- startRouteDefinitions(Collection<RouteDefinition>) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- startRouteService(RouteService, boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
Starts the given route service
- startScheduler() - Method in interface org.apache.camel.api.management.mbean.ManagedSchedulePollConsumerMBean
-
- startScheduler() - Method in class org.apache.camel.impl.DefaultScheduledPollConsumerScheduler
-
- startScheduler() - Method in class org.apache.camel.impl.ScheduledPollConsumer
-
Starts the scheduler.
- startScheduler() - Method in class org.apache.camel.management.mbean.ManagedScheduledPollConsumer
-
- startScheduler() - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
-
Starts the scheduler.
- startService(Service, Object, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
-
Stats the given service
- startService(Object) - Static method in class org.apache.camel.util.ServiceHelper
-
Starts the given
value
if it's a
Service
or a collection of it.
- startService(Service) - Static method in class org.apache.camel.util.ServiceHelper
-
Starts the given service
.
- startServices(Object...) - Static method in class org.apache.camel.util.ServiceHelper
-
Starts each element of the given services
if services
itself is
not null
, otherwise this method would return immediately.
- startServices(Collection<?>) - Static method in class org.apache.camel.util.ServiceHelper
-
Starts each element of the given services
if services
itself is
not null
, otherwise this method would return immediately.
- startSingleStepExchange(String, Breakpoint) - Method in class org.apache.camel.impl.DefaultDebugger
-
- startSingleStepExchange(String, Breakpoint) - Method in interface org.apache.camel.spi.Debugger
-
Starts the single step debug mode for the given exchange
- startsWith(Expression, Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
-
- startsWith(Object) - Method in class org.apache.camel.builder.ValueBuilder
-
- startToken - Variable in class org.apache.camel.support.TokenPairExpressionIterator
-
- StartupListener - Interface in org.apache.camel
-
Allows objects to be notified when
CamelContext
has done all work when starting.
- startupOrder(int) - Method in class org.apache.camel.model.ProcessorDefinition
-
- startupOrder(int) - Method in class org.apache.camel.model.RouteDefinition
-
Configures the startup order for this route
Camel will reorder routes and star them ordered by 0..N where 0 is the lowest number and N the highest number.
- StatefulService - Interface in org.apache.camel
-
A
Service
which has all the lifecycle events and offers details about its current state.
- StaticMethodFallbackTypeConverter - Class in org.apache.camel.impl.converter
-
A
TypeConverter
implementation which invokes a static method
as a fallback type converter from a type to another type
- StaticMethodFallbackTypeConverter(Method, TypeConverterRegistry) - Constructor for class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
-
Deprecated.
- StaticMethodFallbackTypeConverter(Method, TypeConverterRegistry, boolean) - Constructor for class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
-
- StaticMethodTypeConverter - Class in org.apache.camel.impl.converter
-
A
TypeConverter
implementation which invokes a static method to convert from a type to another type
- StaticMethodTypeConverter(Method) - Constructor for class org.apache.camel.impl.converter.StaticMethodTypeConverter
-
Deprecated.
- StaticMethodTypeConverter(Method, boolean) - Constructor for class org.apache.camel.impl.converter.StaticMethodTypeConverter
-
- StaticService - Interface in org.apache.camel
-
- Statistic - Class in org.apache.camel.management.mbean
-
- Statistic(String, Object, Statistic.UpdateMode) - Constructor for class org.apache.camel.management.mbean.Statistic
-
Instantiates a new statistic.
- Statistic.UpdateMode - Enum in org.apache.camel.management.mbean
-
Statistics mode
VALUE - A statistic with this update mode is a simple value that is a straight forward
representation of the updated value.
DIFFERENCE - A statistic with this update mode is a value that represents the difference
between the last two recorded values (or the initial value if two updates have
not been recorded).
DELTA - A statistic with this update mode is a value that represents the delta
between the last two recorded values (or the initial value if two updates have
not been recorded).
- statistics - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
-
- StaxConverter - Class in org.apache.camel.converter.jaxp
-
A converter of StAX objects
- StaxConverter() - Constructor for class org.apache.camel.converter.jaxp.StaxConverter
-
- StaxSource - Class in org.apache.camel.converter.jaxp
-
- StaxSource(XMLStreamReader) - Constructor for class org.apache.camel.converter.jaxp.StaxSource
-
- step() - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- step() - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- step() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- stepBreakpoint(String) - Method in interface org.apache.camel.api.management.mbean.ManagedBacklogDebuggerMBean
-
- stepBreakpoint(String) - Method in class org.apache.camel.management.mbean.ManagedBacklogDebugger
-
- stepBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
-
- sticky(Expression) - Method in class org.apache.camel.model.LoadBalanceDefinition
-
Uses sticky load balancer
- StickyLoadBalancer - Class in org.apache.camel.processor.loadbalancer
-
Implements a sticky load balancer using an
Expression
to calculate
a correlation key to perform the sticky load balancing; rather like jsessionid in the web
or JMSXGroupID in JMS.
- StickyLoadBalancer(Expression) - Constructor for class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
-
- StickyLoadBalancer(Expression, QueueLoadBalancer) - Constructor for class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
-
- StickyLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
-
Represents an XML <sticky/> element
- StickyLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
-
- stop() - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- stop() - Method in interface org.apache.camel.api.management.mbean.ManagedProcessorMBean
-
- stop() - Method in interface org.apache.camel.api.management.mbean.ManagedRouteMBean
-
- stop(long) - Method in interface org.apache.camel.api.management.mbean.ManagedRouteMBean
-
- stop(Long, Boolean) - Method in interface org.apache.camel.api.management.mbean.ManagedRouteMBean
-
- stop() - Method in interface org.apache.camel.api.management.mbean.ManagedServiceMBean
-
- stop() - Method in interface org.apache.camel.CamelContext
-
Stop and shutdown the
CamelContext
(will stop all routes/components/endpoints etc and clear internal state/cache).
- stop() - Method in class org.apache.camel.component.seda.SedaEndpoint
-
- stop() - Method in class org.apache.camel.impl.DefaultDebugger
-
- stop() - Method in class org.apache.camel.impl.DefaultRoute
-
- stop() - Method in class org.apache.camel.impl.DefaultUnitOfWork
-
- stop() - Method in class org.apache.camel.impl.EndpointRegistry
-
- stop() - Method in class org.apache.camel.impl.InterceptSendToEndpoint
-
- stop() - Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
-
- stop() - Method in class org.apache.camel.impl.MDCUnitOfWork
-
- stop(BundleContext) - Method in class org.apache.camel.impl.osgi.Activator
-
- stop() - Method in class org.apache.camel.impl.SynchronousDelegateProducer
-
- stop() - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- stop() - Method in class org.apache.camel.management.mbean.ManagedProcessor
-
- stop() - Method in class org.apache.camel.management.mbean.ManagedRoute
-
- stop(long) - Method in class org.apache.camel.management.mbean.ManagedRoute
-
- stop(Long, Boolean) - Method in class org.apache.camel.management.mbean.ManagedRoute
-
- stop() - Method in class org.apache.camel.management.mbean.ManagedService
-
- stop() - Method in class org.apache.camel.management.MBeanInfoAssembler
-
- stop() - Method in class org.apache.camel.model.ProcessorDefinition
-
Stops continue routing the current
Exchange
and marks it as completed.
- stop() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventHandler
-
- stop() - Method in class org.apache.camel.processor.interceptor.Tracer
-
- stop() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
-
Stops this resequencer (i.e.
- stop() - Method in class org.apache.camel.processor.UnitOfWorkProducer
-
- stop() - Method in interface org.apache.camel.Service
-
Stops the service
- stop() - Method in class org.apache.camel.support.ChildServiceSupport
-
- stop() - Method in class org.apache.camel.support.ServiceSupport
-
- stop() - Static method in class org.apache.camel.util.IntrospectionSupport
-
CamelContext
should call this stop method when its stopping.
- stop() - Method in class org.apache.camel.util.StopWatch
-
Stops the stop watch
- stopAndShutdownService(Object) - Static method in class org.apache.camel.util.ServiceHelper
-
Stops and shutdowns the given service
, rethrowing the first exception caught.
- stopAndShutdownServices(Object...) - Static method in class org.apache.camel.util.ServiceHelper
-
Stops and shutdowns each element of the given services
if services
itself is
not null
, otherwise this method would return immediately.
- stopAndShutdownServices(Collection<?>) - Static method in class org.apache.camel.util.ServiceHelper
-
Stops and shutdowns each element of the given services
if services
itself is not null
, otherwise this method would return immediately.
- stopChildService(Route, Set<Service>, boolean) - Method in class org.apache.camel.impl.RouteService
-
- stopConsumer(Consumer) - Method in class org.apache.camel.impl.RoutePolicySupport
-
- StopDefinition - Class in org.apache.camel.model
-
Represents an XML <stop/> element
- StopDefinition() - Constructor for class org.apache.camel.model.StopDefinition
-
- stopOnException() - Method in class org.apache.camel.model.MulticastDefinition
-
Will now stop further processing if an exception or failure occurred during processing of an
Exchange
and the caused exception will be thrown.
- stopOnException() - Method in class org.apache.camel.model.RecipientListDefinition
-
Will now stop further processing if an exception or failure occurred during processing of an
Exchange
and the caused exception will be thrown.
- stopOnException() - Method in class org.apache.camel.model.SplitDefinition
-
Will now stop further processing if an exception or failure occurred during processing of an
Exchange
and the caused exception will be thrown.
- stopped - Variable in class org.apache.camel.support.ServiceSupport
-
- stopping - Variable in class org.apache.camel.support.ServiceSupport
-
- StopProcessor - Class in org.apache.camel.processor
-
Stops continue processing the route and marks it as complete.
- StopProcessor() - Constructor for class org.apache.camel.processor.StopProcessor
-
- stopRoute(RouteDefinition) - Method in interface org.apache.camel.CamelContext
-
- stopRoute(String) - Method in interface org.apache.camel.CamelContext
-
- stopRoute(String, long, TimeUnit) - Method in interface org.apache.camel.CamelContext
-
- stopRoute(String, long, TimeUnit, boolean) - Method in interface org.apache.camel.CamelContext
-
Stops the given route using
ShutdownStrategy
with a specified timeout
and optional abortAfterTimeout mode.
- stopRoute(RouteDefinition) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- stopRoute(String, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- stopRoute(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- stopRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- stopRoute(Route) - Method in class org.apache.camel.impl.RoutePolicySupport
-
- stopRoute(Route, long, TimeUnit) - Method in class org.apache.camel.impl.RoutePolicySupport
-
- stopRoute(RouteDefinition) - Method in interface org.apache.camel.model.ModelCamelContext
-
- stopRouteService(RouteService, boolean) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- stopRouteService(RouteService) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- stopService(Object) - Static method in class org.apache.camel.util.ServiceHelper
-
Stops the given value
, rethrowing the first exception caught.
- stopServices(Object...) - Static method in class org.apache.camel.util.ServiceHelper
-
Stops each element of the given services
if services
itself is
not null
, otherwise this method would return immediately.
- stopServices(Collection<?>) - Static method in class org.apache.camel.util.ServiceHelper
-
Stops each element of the given services
if services
itself is
not null
, otherwise this method would return immediately.
- stopSingleStepExchange(String) - Method in class org.apache.camel.impl.DefaultDebugger
-
- stopSingleStepExchange(String) - Method in interface org.apache.camel.spi.Debugger
-
Stops the single step debug mode for the given exchange.
- StopWatch - Class in org.apache.camel.util
-
A very simple stop watch.
- StopWatch() - Constructor for class org.apache.camel.util.StopWatch
-
Starts the stop watch
- StopWatch(Date) - Constructor for class org.apache.camel.util.StopWatch
-
Starts the stop watch from the given timestamp
- StopWatch(boolean) - Constructor for class org.apache.camel.util.StopWatch
-
Creates the stop watch
- storeFile(String, Exchange) - Method in class org.apache.camel.component.file.FileOperations
-
- storeFile(String, Exchange) - Method in interface org.apache.camel.component.file.GenericFileOperations
-
Stores the content as a new remote file (upload)
- storeInBody() - Method in class org.apache.camel.util.toolbox.FlexibleAggregationStrategy
-
Store the result of this Aggregation Strategy (whether an atomic element or a Collection) in the body of the IN message.
- storeInHeader(String) - Method in class org.apache.camel.util.toolbox.FlexibleAggregationStrategy
-
Store the result of this Aggregation Strategy (whether an atomic element or a Collection) in an IN message header with
the designated name.
- storeInProperty(String) - Method in class org.apache.camel.util.toolbox.FlexibleAggregationStrategy
-
Store the result of this Aggregation Strategy (whether an atomic element or a Collection) in a property with
the designated name.
- storeNulls() - Method in class org.apache.camel.util.toolbox.FlexibleAggregationStrategy
-
Enables storing null values in the resulting collection.
- stream() - Method in class org.apache.camel.model.ResequenceDefinition
-
Configures the stream-based resequencing algorithm using the default
configuration.
- stream(StreamResequencerConfig) - Method in class org.apache.camel.model.ResequenceDefinition
-
- StreamCache - Interface in org.apache.camel
-
Tagging interface to indicate that a type is capable of caching the underlying data stream.
- StreamCacheConverter - Class in org.apache.camel.converter.stream
-
A set of
Converter
methods for wrapping stream-based messages in a
StreamCache
implementation to ensure message re-readability (eg multicasting, retrying)
- streamCaching() - Method in class org.apache.camel.model.RouteDefinition
-
Enable stream caching for this route.
- StreamCaching - Class in org.apache.camel.processor.interceptor
-
Deprecated.
no longer in use, will be removed in next Camel release.
- StreamCaching() - Constructor for class org.apache.camel.processor.interceptor.StreamCaching
-
Deprecated.
- StreamCachingInterceptor - Class in org.apache.camel.processor.interceptor
-
Deprecated.
no longer in use, will be removed in next Camel release.
- StreamCachingInterceptor() - Constructor for class org.apache.camel.processor.interceptor.StreamCachingInterceptor
-
Deprecated.
- StreamCachingInterceptor(Processor) - Constructor for class org.apache.camel.processor.interceptor.StreamCachingInterceptor
-
Deprecated.
- StreamCachingStrategy - Interface in org.apache.camel.spi
-
- StreamCachingStrategy.SpoolRule - Interface in org.apache.camel.spi
-
Rule for determine if stream caching should be spooled to disk or kept in-memory.
- StreamCachingStrategy.SpoolUsedHeapMemoryLimit - Enum in org.apache.camel.spi
-
Used for selecting if the memory limit is committed or maximum heap memory setting.
- StreamCachingStrategy.Statistics - Interface in org.apache.camel.spi
-
Utilization statistics of stream caching.
- streaming() - Method in class org.apache.camel.model.MulticastDefinition
-
Aggregates the responses as the are done (e.g.
- streaming() - Method in class org.apache.camel.model.RecipientListDefinition
-
Doing the recipient list work in streaming model
- streaming() - Method in class org.apache.camel.model.SplitDefinition
-
Enables streaming.
- StreamResequencer - Class in org.apache.camel.processor
-
A resequencer that re-orders a (continuous) stream of
Exchange
s.
- StreamResequencer(CamelContext, Processor, SequenceElementComparator<Exchange>) - Constructor for class org.apache.camel.processor.StreamResequencer
-
- StreamResequencerConfig - Class in org.apache.camel.model.config
-
- StreamResequencerConfig() - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
-
- StreamResequencerConfig(int, long) - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
-
- StreamResequencerConfig(int, long, ExpressionResultComparator) - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
-
- StreamResequencerConfig(int, long, Boolean) - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
-
- StreamResequencerConfig(int, long, Boolean, ExpressionResultComparator) - Constructor for class org.apache.camel.model.config.StreamResequencerConfig
-
- StreamResultHandler - Class in org.apache.camel.builder.xml
-
Processes the XSLT result as a byte[]
- StreamResultHandler() - Constructor for class org.apache.camel.builder.xml.StreamResultHandler
-
- StreamResultHandlerFactory - Class in org.apache.camel.builder.xml
-
- StreamResultHandlerFactory() - Constructor for class org.apache.camel.builder.xml.StreamResultHandlerFactory
-
- StreamSourceCache - Class in org.apache.camel.converter.stream
-
- StreamSourceCache(StreamSource, Exchange) - Constructor for class org.apache.camel.converter.stream.StreamSourceCache
-
- StreamSourceConverter - Class in org.apache.camel.converter.jaxp
-
- string() - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the String data format
- string(String) - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the String data format supporting encoding using given charset
- StringDataFormat - Class in org.apache.camel.impl
-
The text based
data format supporting
charset encoding.
- StringDataFormat() - Constructor for class org.apache.camel.impl.StringDataFormat
-
- StringDataFormat(String) - Constructor for class org.apache.camel.impl.StringDataFormat
-
- StringDataFormat - Class in org.apache.camel.model.dataformat
-
- StringDataFormat() - Constructor for class org.apache.camel.model.dataformat.StringDataFormat
-
- StringHelper - Class in org.apache.camel.util
-
Helper methods for working with Strings.
- StringQuoteHelper - Class in org.apache.camel.util
-
Utility class for parsing quoted string which is intended for parameters, separated by comma.
- stringResult() - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- StringResultHandler - Class in org.apache.camel.builder.xml
-
Processes the XSLT result as a String
- StringResultHandler() - Constructor for class org.apache.camel.builder.xml.StringResultHandler
-
- StringResultHandlerFactory - Class in org.apache.camel.builder.xml
-
- StringResultHandlerFactory() - Constructor for class org.apache.camel.builder.xml.StringResultHandlerFactory
-
- StringSource - Class in org.apache.camel
-
A helper class which provides a JAXP
Source
from a String which can be read as many times as required.
- StringSource() - Constructor for class org.apache.camel.StringSource
-
- StringSource(String) - Constructor for class org.apache.camel.StringSource
-
- StringSource(String, String) - Constructor for class org.apache.camel.StringSource
-
- StringSource(String, String, String) - Constructor for class org.apache.camel.StringSource
-
- stripExt(String) - Static method in class org.apache.camel.util.FileUtil
-
- stripFirstLeadingSeparator(String) - Static method in class org.apache.camel.util.FileUtil
-
Strip first leading separator
- stripLeadingSeparator(String) - Static method in class org.apache.camel.util.FileUtil
-
Strip any leading separators
- stripPath(String) - Static method in class org.apache.camel.util.FileUtil
-
Strips any leading paths
- stripPrefix(String, String) - Static method in class org.apache.camel.util.URISupport
-
Strips the prefix from the value.
- stripTrailingSeparator(String) - Static method in class org.apache.camel.util.FileUtil
-
Strip any trailing separators
- StubComponent - Class in org.apache.camel.component.stub
-
Allows you to easily stub out a middleware transport by prefixing the URI with "stub:" which is
handy for testing out routes, or isolating bits of middleware.
- StubComponent() - Constructor for class org.apache.camel.component.stub.StubComponent
-
- submit(Callable<T>) - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- submit(Runnable) - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- submit(Runnable, T) - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- submit(Callable<V>) - Method in class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
-
- submit(Runnable, Object) - Method in class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
-
- SubmitOrderedCompletionService<V> - Class in org.apache.camel.util.concurrent
-
A
CompletionService
that orders the completed tasks
in the same order as they where submitted.
- SubmitOrderedCompletionService(Executor) - Constructor for class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
-
- subscribeMethod(Method, Object, String, String, String, String) - Method in class org.apache.camel.impl.CamelPostProcessorHelper
-
- SubUnitOfWork - Interface in org.apache.camel.spi
-
A sub unit of work is a way of implement sub-transactions in Camel routing.
- SubUnitOfWorkCallback - Interface in org.apache.camel.spi
-
- successor(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
-
- successor(E) - Method in class org.apache.camel.processor.resequencer.Sequence
-
Returns the immediate successor of the given element in this sequence
or null
if no successor exists.
- successor(E, E) - Method in interface org.apache.camel.processor.resequencer.SequenceElementComparator
-
Returns true
if o1
is an immediate successor
of o2
.
- SUFFIX_TOKEN - Static variable in class org.apache.camel.component.properties.PropertiesComponent
-
- superEntrySet() - Method in class org.apache.camel.util.CaseInsensitiveMap
-
- supportedParameterTypes(BinaryOperatorType) - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType
-
Returns the types of right hand side parameters this operator supports.
- supportsSuspension() - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
-
- supportsSuspension() - Method in interface org.apache.camel.Route
-
Whether or not the route supports suspension (suspend and resume)
- supportTransacted() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
-
- supportTransacted() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- supportTransacted() - Method in interface org.apache.camel.builder.ErrorHandlerBuilder
-
Whether this error handler supports transacted exchanges.
- supportTransacted() - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
-
- supportTransacted() - Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
-
- supportTransacted() - Method in class org.apache.camel.builder.NoErrorHandlerBuilder
-
- supportTransacted() - Method in class org.apache.camel.processor.ErrorHandlerSupport
-
Whether this error handler supports transacted exchanges or not.
- supportTransacted() - Method in class org.apache.camel.processor.RedeliveryErrorHandler
-
- suspend() - Method in interface org.apache.camel.api.management.mbean.ManagedCamelContextMBean
-
- suspend() - Method in interface org.apache.camel.api.management.mbean.ManagedServiceMBean
-
- suspend() - Method in interface org.apache.camel.api.management.mbean.ManagedSuspendableRouteMBean
-
- suspend(long) - Method in interface org.apache.camel.api.management.mbean.ManagedSuspendableRouteMBean
-
- suspend() - Method in class org.apache.camel.impl.BreakpointSupport
-
- suspend(CamelContext, List<RouteStartupOrder>) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
- suspend(CamelContext, List<RouteStartupOrder>, long, TimeUnit) - Method in class org.apache.camel.impl.DefaultShutdownStrategy
-
- suspend() - Method in class org.apache.camel.management.mbean.ManagedCamelContext
-
- suspend() - Method in class org.apache.camel.management.mbean.ManagedService
-
- suspend() - Method in class org.apache.camel.management.mbean.ManagedSuspendableRoute
-
- suspend(long) - Method in class org.apache.camel.management.mbean.ManagedSuspendableRoute
-
- suspend() - Method in interface org.apache.camel.spi.Breakpoint
-
Suspend this breakpoint
- suspend(CamelContext, List<RouteStartupOrder>) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Suspends the routes
- suspend(CamelContext, List<RouteStartupOrder>, long, TimeUnit) - Method in interface org.apache.camel.spi.ShutdownStrategy
-
Suspends the routes using a specified timeout instead of the default timeout values
- suspend() - Method in class org.apache.camel.support.ServiceSupport
-
- suspend() - Method in interface org.apache.camel.SuspendableService
-
Suspends the service.
- SuspendableService - Interface in org.apache.camel
-
A
Service
which is also capable of suspending and resuming.
- suspendAllBreakpoints() - Method in class org.apache.camel.impl.DefaultDebugger
-
- suspendAllBreakpoints() - Method in interface org.apache.camel.spi.Debugger
-
Suspends all breakpoints.
- suspended - Variable in class org.apache.camel.support.ServiceSupport
-
- suspending - Variable in class org.apache.camel.support.ServiceSupport
-
- suspendNow(Consumer) - Static method in class org.apache.camel.impl.DefaultShutdownStrategy
-
Suspends/stops the consumer immediately.
- suspendRoute(String) - Method in interface org.apache.camel.CamelContext
-
- suspendRoute(String, long, TimeUnit) - Method in interface org.apache.camel.CamelContext
-
- suspendRoute(String) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- suspendRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- suspendRoute(Route) - Method in class org.apache.camel.impl.RoutePolicySupport
-
- suspendRoute(Route, long, TimeUnit) - Method in class org.apache.camel.impl.RoutePolicySupport
-
- suspendRouteService(RouteService) - Method in class org.apache.camel.impl.DefaultCamelContext
-
- suspendService(Service) - Static method in class org.apache.camel.util.ServiceHelper
-
Suspends the given service
.
- suspendServices(Collection<?>) - Static method in class org.apache.camel.util.ServiceHelper
-
Suspends each element of the given services
if services
itself is
not null
, otherwise this method would return immediately.
- Synchronization - Interface in org.apache.camel.spi
-
- SynchronizationAdapter - Class in org.apache.camel.impl
-
Deprecated.
use org.apache.camel.support.SynchronizationAdapter instead
- SynchronizationAdapter() - Constructor for class org.apache.camel.impl.SynchronizationAdapter
-
Deprecated.
- SynchronizationAdapter - Class in org.apache.camel.support
-
Simple
Synchronization
adapter with empty methods for easier overriding
of single methods.
- SynchronizationAdapter() - Constructor for class org.apache.camel.support.SynchronizationAdapter
-
- SynchronizationVetoable - Interface in org.apache.camel.spi
-
- SynchronousDelegateProducer - Class in org.apache.camel.impl
-
To process the delegated producer in synchronous mode.
- SynchronousDelegateProducer(Producer) - Constructor for class org.apache.camel.impl.SynchronousDelegateProducer
-
- SynchronousExecutorService - Class in org.apache.camel.util.concurrent
-
A synchronous
ExecutorService
which always invokes
the task in the caller thread (just a thread pool facade).
- SynchronousExecutorService() - Constructor for class org.apache.camel.util.concurrent.SynchronousExecutorService
-
- syslog() - Method in class org.apache.camel.builder.DataFormatClause
-
Uses the Syslog data format
- SyslogDataFormat - Class in org.apache.camel.model.dataformat
-
- SyslogDataFormat() - Constructor for class org.apache.camel.model.dataformat.SyslogDataFormat
-
- SYSTEM_PROPERTIES_NAMESPACE - Static variable in class org.apache.camel.builder.xml.Namespaces
-
- systemEnvironmentExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns an expression for a system environment value with the given name
- systemEnvironmentExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns an expression for a system environment value with the given name
- systemProperty(String) - Static method in class org.apache.camel.builder.Builder
-
Returns an expression for the given system property
- systemProperty(String, String) - Static method in class org.apache.camel.builder.Builder
-
Returns an expression for the given system property
- systemProperty(String) - Method in class org.apache.camel.builder.BuilderSupport
-
Returns a value builder for the given system property
- systemProperty(String, String) - Method in class org.apache.camel.builder.BuilderSupport
-
Returns a value builder for the given system property
- systemPropertyExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns an expression for a system property value with the given name
- systemPropertyExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns an expression for a system property value with the given name
- tagToken - Variable in class org.apache.camel.support.TokenXMLExpressionIterator
-
- take() - Method in class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
-
- taken() - Method in class org.apache.camel.util.StopWatch
-
Returns the time taken in millis.
- task() - Method in interface org.apache.camel.builder.AdviceWithTask
-
The task to execute
- TEMP_DIR - Static variable in class org.apache.camel.converter.stream.CachedOutputStream
-
Deprecated.
- TEMP_DIR - Static variable in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
Deprecated.
- tempFileName - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- templateText() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
-
- tempPrefix - Variable in class org.apache.camel.component.file.GenericFileEndpoint
-
- TestComponent - Class in org.apache.camel.component.test
-
Test Component.
- TestComponent() - Constructor for class org.apache.camel.component.test.TestComponent
-
- TestEndpoint - Class in org.apache.camel.component.test
-
A
Test Endpoint is a
Mock Endpoint for testing but it will
pull all messages from the nested endpoint and use those as expected message body assertions.
- TestEndpoint(String, Component, Endpoint) - Constructor for class org.apache.camel.component.test.TestEndpoint
-
- text - Variable in class org.apache.camel.language.simple.ast.LiteralExpression
-
- ThreadHelper - Class in org.apache.camel.util.concurrent
-
Various helper method for thread naming.
- threadName(String) - Method in class org.apache.camel.model.ThreadsDefinition
-
Sets the thread name to use.
- threadNameExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns the expression for the current thread name
- ThreadPoolBuilder - Class in org.apache.camel.builder
-
A builder to create thread pools.
- ThreadPoolBuilder(CamelContext) - Constructor for class org.apache.camel.builder.ThreadPoolBuilder
-
- ThreadPoolFactory - Interface in org.apache.camel.spi
-
Creates ExecutorService and ScheduledExecutorService objects that work with a thread pool for a given ThreadPoolProfile and ThreadFactory.
- ThreadPoolProfile - Class in org.apache.camel.spi
-
A profile which defines thread pool settings.
- ThreadPoolProfile() - Constructor for class org.apache.camel.spi.ThreadPoolProfile
-
Creates a new thread pool profile, with no id set.
- ThreadPoolProfile(String) - Constructor for class org.apache.camel.spi.ThreadPoolProfile
-
Creates a new thread pool profile
- ThreadPoolProfileBuilder - Class in org.apache.camel.builder
-
- ThreadPoolProfileBuilder(String) - Constructor for class org.apache.camel.builder.ThreadPoolProfileBuilder
-
- ThreadPoolProfileBuilder(String, ThreadPoolProfile) - Constructor for class org.apache.camel.builder.ThreadPoolProfileBuilder
-
- ThreadPoolProfileDefinition - Class in org.apache.camel.model
-
Represents an XML <threadPoolProfile/> element
- ThreadPoolProfileDefinition() - Constructor for class org.apache.camel.model.ThreadPoolProfileDefinition
-
- ThreadPoolProfileSupport - Class in org.apache.camel.impl
-
- ThreadPoolProfileSupport(String) - Constructor for class org.apache.camel.impl.ThreadPoolProfileSupport
-
Deprecated.
- ThreadPoolRejectedPolicy - Enum in org.apache.camel
-
Represent the kinds of options for rejection handlers for thread pools.
- threads() - Method in class org.apache.camel.model.ProcessorDefinition
-
Continues processing the
Exchange
using asynchronous routing engine.
- threads(int) - Method in class org.apache.camel.model.ProcessorDefinition
-
Continues processing the
Exchange
using asynchronous routing engine.
- threads(int, int) - Method in class org.apache.camel.model.ProcessorDefinition
-
Continues processing the
Exchange
using asynchronous routing engine.
- threads(int, int, String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Continues processing the
Exchange
using asynchronous routing engine.
- ThreadsDefinition - Class in org.apache.camel.model
-
Represents an XML <threads/> element
- ThreadsDefinition() - Constructor for class org.apache.camel.model.ThreadsDefinition
-
- ThreadsProcessor - Class in org.apache.camel.processor
-
Threads processor that leverage a thread pool for continue processing the
Exchange
s
using the asynchronous routing engine.
- ThreadsProcessor(CamelContext, ExecutorService, boolean) - Constructor for class org.apache.camel.processor.ThreadsProcessor
-
- THRESHOLD - Static variable in class org.apache.camel.converter.stream.CachedOutputStream
-
Deprecated.
- THRESHOLD - Static variable in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
Deprecated.
- throttle(Route, Exchange) - Method in class org.apache.camel.impl.ThrottlingInflightRoutePolicy
-
Throttles the route when
Exchange
s is done.
- throttle(long) - Method in class org.apache.camel.model.ProcessorDefinition
-
Throttler EIP:
Creates a throttler allowing you to ensure that a specific endpoint does not get overloaded,
or that we don't exceed an agreed SLA with some external service.
- throttle(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
Throttler EIP:
Creates a throttler allowing you to ensure that a specific endpoint does not get overloaded,
or that we don't exceed an agreed SLA with some external service.
- ThrottleDefinition - Class in org.apache.camel.model
-
Represents an XML <throttle/> element
- ThrottleDefinition() - Constructor for class org.apache.camel.model.ThrottleDefinition
-
- ThrottleDefinition(Expression) - Constructor for class org.apache.camel.model.ThrottleDefinition
-
- Throttler - Class in org.apache.camel.processor
-
A
Throttler
will set a limit on the maximum number of message exchanges which can be sent
to a processor within a specific time period.
- Throttler(CamelContext, Processor, Expression, long, ScheduledExecutorService, boolean) - Constructor for class org.apache.camel.processor.Throttler
-
- Throttler.TimeSlot - Class in org.apache.camel.processor
-
- Throttler.TimeSlot() - Constructor for class org.apache.camel.processor.Throttler.TimeSlot
-
- Throttler.TimeSlot(long) - Constructor for class org.apache.camel.processor.Throttler.TimeSlot
-
- ThrottlingInflightRoutePolicy - Class in org.apache.camel.impl
-
A throttle based
RoutePolicy
which is capable of dynamic
throttling a route based on number of current inflight exchanges.
- ThrottlingInflightRoutePolicy() - Constructor for class org.apache.camel.impl.ThrottlingInflightRoutePolicy
-
- ThrottlingInflightRoutePolicy.ThrottlingScope - Enum in org.apache.camel.impl
-
- ThroughputLogger - Class in org.apache.camel.processor
-
A logger for logging message throughput.
- ThroughputLogger(CamelLogger) - Constructor for class org.apache.camel.processor.ThroughputLogger
-
- ThroughputLogger(CamelLogger, Integer) - Constructor for class org.apache.camel.processor.ThroughputLogger
-
- ThroughputLogger(CamelLogger, CamelContext, Long, Long, Boolean) - Constructor for class org.apache.camel.processor.ThroughputLogger
-
- throwException(Exception) - Static method in class org.apache.camel.builder.ProcessorBuilder
-
Throws an exception
- throwException(Exception) - Method in class org.apache.camel.model.ProcessorDefinition
-
- ThrowExceptionDefinition - Class in org.apache.camel.model
-
Represents an XML <throwException/> element
- ThrowExceptionDefinition() - Constructor for class org.apache.camel.model.ThrowExceptionDefinition
-
- ThrowExceptionProcessor - Class in org.apache.camel.processor
-
- ThrowExceptionProcessor(Exception) - Constructor for class org.apache.camel.processor.ThrowExceptionProcessor
-
- tidyMarkup(Class<?>) - Method in class org.apache.camel.builder.DataFormatClause
-
Return WellFormed HTML (an XML Document) either
String
or
Node
- tidyMarkup() - Method in class org.apache.camel.builder.DataFormatClause
-
Return TidyMarkup in the default format
as
Node
- TidyMarkupDataFormat - Class in org.apache.camel.model.dataformat
-
Represents a wellformed HTML document (XML well Formed)
DataFormat
- TidyMarkupDataFormat() - Constructor for class org.apache.camel.model.dataformat.TidyMarkupDataFormat
-
- TidyMarkupDataFormat(Class<?>) - Constructor for class org.apache.camel.model.dataformat.TidyMarkupDataFormat
-
- Time - Class in org.apache.camel.util
-
A helper class for working with times in various units
- Time(long, TimeUnit) - Constructor for class org.apache.camel.util.Time
-
- TimeClause - Class in org.apache.camel.component.mock
-
Represents time based clauses for setting expectations on the mocks.
- TimeClause(Expression, Expression) - Constructor for class org.apache.camel.component.mock.TimeClause
-
- TimeClause.TimeClassUnit - Class in org.apache.camel.component.mock
-
- TimeClause.TimeClassUnit(TimeClause, int) - Constructor for class org.apache.camel.component.mock.TimeClause.TimeClassUnit
-
- TimeClause.TimeClassUnit(TimeClause, int, int) - Constructor for class org.apache.camel.component.mock.TimeClause.TimeClassUnit
-
- timeout(long) - Method in class org.apache.camel.model.MulticastDefinition
-
Sets a timeout value in millis to use when using parallelProcessing.
- timeout(long) - Method in class org.apache.camel.model.RecipientListDefinition
-
Sets a timeout value in millis to use when using parallelProcessing.
- timeout(long) - Method in class org.apache.camel.model.ResequenceDefinition
-
Sets the timeout
- timeout(long) - Method in class org.apache.camel.model.SplitDefinition
-
Sets a timeout value in millis to use when using parallelProcessing.
- timeout(Exchange, int, int, long) - Method in interface org.apache.camel.processor.aggregate.TimeoutAwareAggregationStrategy
-
A timeout occurred.
- Timeout - Class in org.apache.camel.processor.resequencer
-
A timer task that notifies handlers about scheduled timeouts.
- Timeout(Timer, long) - Constructor for class org.apache.camel.processor.resequencer.Timeout
-
Creates a new timeout task using the given
Timer
instance and
timeout value.
- timeout(Timeout) - Method in interface org.apache.camel.processor.resequencer.TimeoutHandler
-
Handles a timeout notification.
- timeout(Exchange, int, int, long) - Method in class org.apache.camel.util.toolbox.FlexibleAggregationStrategy
-
- timeout(Exchange, int, int, long) - Method in interface org.apache.camel.util.toolbox.FlexibleAggregationStrategy.TimeoutAwareMixin
-
- timeoutAware(FlexibleAggregationStrategy.TimeoutAwareMixin) - Method in class org.apache.camel.util.toolbox.FlexibleAggregationStrategy
-
Plugs in logic to execute when a timeout occurs.
- TimeoutAwareAggregationStrategy - Interface in org.apache.camel.processor.aggregate
-
- timeoutCheckerExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.model.AggregateDefinition
-
- timeoutCheckerExecutorServiceRef(String) - Method in class org.apache.camel.model.AggregateDefinition
-
- TimeoutHandler - Interface in org.apache.camel.processor.resequencer
-
Implemented by classes that handle timeout notifications.
- TimeoutMap<K,V> - Interface in org.apache.camel
-
Represents a map of values which timeout after a period of inactivity.
- TimeoutMapEntry<K,V> - Class in org.apache.camel.support
-
- TimeoutMapEntry(K, V, long) - Constructor for class org.apache.camel.support.TimeoutMapEntry
-
- timeoutTask() - Method in class org.apache.camel.util.concurrent.SubmitOrderedCompletionService
-
Marks the current task as timeout, which allows you to poll the next
tasks which may already have been completed.
- TimePatternConverter - Class in org.apache.camel.converter
-
- timePeriodMillis(long) - Method in class org.apache.camel.model.ThrottleDefinition
-
Sets the time period during which the maximum request count is valid for
- TIMER_COUNTER - Static variable in interface org.apache.camel.Exchange
-
- TIMER_FIRED_TIME - Static variable in interface org.apache.camel.Exchange
-
- TIMER_NAME - Static variable in interface org.apache.camel.Exchange
-
- TIMER_PERIOD - Static variable in interface org.apache.camel.Exchange
-
- TIMER_TIME - Static variable in interface org.apache.camel.Exchange
-
- TimerComponent - Class in org.apache.camel.component.timer
-
- TimerComponent() - Constructor for class org.apache.camel.component.timer.TimerComponent
-
- TimerConsumer - Class in org.apache.camel.component.timer
-
The timer consumer.
- TimerConsumer(TimerEndpoint, Processor) - Constructor for class org.apache.camel.component.timer.TimerConsumer
-
- TimerEndpoint - Class in org.apache.camel.component.timer
-
Represents a timer endpoint that can generate periodic inbound exchanges triggered by a timer.
- TimerEndpoint() - Constructor for class org.apache.camel.component.timer.TimerEndpoint
-
- TimerEndpoint(String, Component, String) - Constructor for class org.apache.camel.component.timer.TimerEndpoint
-
- TimerEndpoint(String, Component) - Constructor for class org.apache.camel.component.timer.TimerEndpoint
-
- TimerListener - Interface in org.apache.camel
-
Listener for receiving timer events.
- TimerListenerManager - Class in org.apache.camel.support
-
- TimerListenerManager() - Constructor for class org.apache.camel.support.TimerListenerManager
-
- TIMESTAMP_FORMAT - Static variable in interface org.apache.camel.api.management.mbean.BacklogTracerEventMessage
-
- TIMESTAMP_FORMAT - Static variable in class org.apache.camel.management.mbean.ManagedPerformanceCounter
-
- timeUnit - Variable in class org.apache.camel.main.MainSupport
-
- timeUnit(TimeUnit) - Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- timeUnit(TimeUnit) - Method in class org.apache.camel.model.ThreadsDefinition
-
Sets the keep alive time unit.
- TimeUnitAdapter - Class in org.apache.camel.builder.xml
-
TimeUnitAdapter
is a simple adapter to convert between Strings
and instances of the
TimeUnit
enumeration
- TimeUnitAdapter() - Constructor for class org.apache.camel.builder.xml.TimeUnitAdapter
-
- timeUnits(TimeUnit) - Method in class org.apache.camel.model.SamplingDefinition
-
Sets the time units for the sample period, defaulting to seconds.
- TimeUtils - Class in org.apache.camel.util
-
Time utils.
- to(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sends the exchange to the given endpoint
- to(Endpoint) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sends the exchange to the given endpoint
- to(ExchangePattern, String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sends the exchange with certain exchange pattern to the given endpoint
Notice the existing MEP is preserved
- to(ExchangePattern, Endpoint) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sends the exchange with certain exchange pattern to the given endpoint
Notice the existing MEP is preserved
- to(String...) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sends the exchange to a list of endpoints
- to(Endpoint...) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sends the exchange to a list of endpoints
- to(Iterable<Endpoint>) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sends the exchange to a list of endpoints
- to(ExchangePattern, String...) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sends the exchange to a list of endpoints
Notice the existing MEP is preserved
- to(ExchangePattern, Endpoint...) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sends the exchange to a list of endpoints
Notice the existing MEP is preserved
- to(ExchangePattern, Iterable<Endpoint>) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sends the exchange to a list of endpoints
- TO_ENDPOINT - Static variable in interface org.apache.camel.Exchange
-
- toArray(Collection<?>) - Static method in class org.apache.camel.converter.CollectionConverter
-
Converts a collection to an array
- toArrayList(Iterator<T>) - Static method in class org.apache.camel.converter.CollectionConverter
-
- toBool(Object) - Static method in class org.apache.camel.converter.ObjectConverter
-
Converts the given value to a boolean, handling strings or Boolean
objects; otherwise returning false if the value could not be converted to
a boolean
- toBoolean(NodeList) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given NodeList to a boolean
- toBoolean(Object) - Static method in class org.apache.camel.converter.ObjectConverter
-
Converts the given value to a Boolean, handling strings or Boolean
objects; otherwise returning null if the value cannot be converted to a
boolean
- toBoolean(String) - Static method in class org.apache.camel.converter.ObjectConverter
-
- toBoolean(Object) - Static method in class org.apache.camel.util.ObjectHelper
-
- toByte(Object) - Static method in class org.apache.camel.converter.ObjectConverter
-
Returns the converted value, or null if the value is null
- toByteArray(File) - Static method in class org.apache.camel.converter.IOConverter
-
- toByteArray(Reader) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toByteArray(Reader, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toByteArray(BufferedReader) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toByteArray(BufferedReader, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toByteArray(String) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toByteArray(String, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toByteArray(ByteArrayOutputStream) - Static method in class org.apache.camel.converter.IOConverter
-
- toByteArray(NodeList, Exchange) - Method in class org.apache.camel.converter.jaxp.DomConverter
-
- toByteArray(Source, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given input Source into bytes
- toByteArray(ByteBuffer) - Static method in class org.apache.camel.converter.NIOConverter
-
- toByteBuffer(byte[]) - Static method in class org.apache.camel.converter.NIOConverter
-
- toByteBuffer(File) - Static method in class org.apache.camel.converter.NIOConverter
-
- toByteBuffer(String, Exchange) - Static method in class org.apache.camel.converter.NIOConverter
-
- toByteBuffer(Short) - Static method in class org.apache.camel.converter.NIOConverter
-
- toByteBuffer(Integer) - Static method in class org.apache.camel.converter.NIOConverter
-
- toByteBuffer(Long) - Static method in class org.apache.camel.converter.NIOConverter
-
- toByteBuffer(Float) - Static method in class org.apache.camel.converter.NIOConverter
-
- toByteBuffer(Double) - Static method in class org.apache.camel.converter.NIOConverter
-
- toBytes(InputStream) - Static method in class org.apache.camel.converter.IOConverter
-
- toBytesSource(byte[]) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given byte[] to a Source
- toChar(String) - Static method in class org.apache.camel.converter.ObjectConverter
-
- toCharArray(String) - Static method in class org.apache.camel.converter.ObjectConverter
-
- toClass(Object, Exchange) - Static method in class org.apache.camel.converter.ObjectConverter
-
Returns the converted value, or null if the value is null
- toDate(Long) - Static method in class org.apache.camel.converter.DateTimeConverter
-
- toDate() - Method in class org.apache.camel.util.Time
-
- ToDefinition - Class in org.apache.camel.model
-
Represents an XML <to/> element
- ToDefinition() - Constructor for class org.apache.camel.model.ToDefinition
-
- ToDefinition(String) - Constructor for class org.apache.camel.model.ToDefinition
-
- ToDefinition(Endpoint) - Constructor for class org.apache.camel.model.ToDefinition
-
- ToDefinition(String, ExchangePattern) - Constructor for class org.apache.camel.model.ToDefinition
-
- ToDefinition(Endpoint, ExchangePattern) - Constructor for class org.apache.camel.model.ToDefinition
-
- toDOMDocument(byte[]) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given data to a DOM document
- toDOMDocument(InputStream) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toDOMDocument(Reader) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toDOMDocument(InputSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toDOMDocument(String) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given
String
to a DOM document
- toDOMDocument(File) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given
File
to a DOM document
- toDOMDocument(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Create a DOM document from the given source.
- toDOMDocument(Node) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Create a DOM document from the given Node.
- toDOMDocumentFromSingleNodeList(NodeList) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Convert a NodeList consisting of just 1 node to a DOM Document.
- toDOMElement(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Create a DOM element from the given source.
- toDOMElement(Node) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Create a DOM element from the DOM node.
- toDOMNode(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given TRaX Source into a W3C DOM node
- toDOMNodeFromSAX(SAXSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toDOMNodeFromSingleNodeList(NodeList) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Convert a NodeList consisting of just 1 node to a DOM Node.
- toDOMNodeFromStAX(StAXSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toDOMSource(Node) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given Node to a Source
- toDOMSource(Document) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given Document to a DOMSource
- toDOMSource(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the source instance to a
DOMSource
or returns null if the conversion is not
supported (making it easy to derive from this class to add new kinds of conversion).
- toDOMSource(String) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the source instance to a
DOMSource
or returns null if the conversion is not
supported (making it easy to derive from this class to add new kinds of conversion).
- toDOMSource(byte[]) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the source instance to a
DOMSource
or returns null if the conversion is not
supported (making it easy to derive from this class to add new kinds of conversion).
- toDOMSource(InputStream) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toDOMSource(File) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toDOMSourceFromSAX(SAXSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toDOMSourceFromStAX(StAXSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toDOMSourceFromStream(StreamSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toDouble(Object) - Static method in class org.apache.camel.converter.ObjectConverter
-
Returns the converted value, or null if the value is null
- toDouble(String) - Static method in class org.apache.camel.converter.ObjectConverter
-
- toExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns an expression processing the exchange to the given endpoint uri
- toExpression(Predicate) - Static method in class org.apache.camel.util.PredicateToExpressionAdapter
-
- toExpressionDefinition(Expression) - Static method in class org.apache.camel.model.ExpressionNodeHelper
-
- toExpressionDefinition(Predicate) - Static method in class org.apache.camel.model.ExpressionNodeHelper
-
- toF(String, Object...) - Method in class org.apache.camel.model.ProcessorDefinition
-
Sends the exchange to the given endpoint
- toFile(String) - Static method in class org.apache.camel.converter.IOConverter
-
- toFloat(Object) - Static method in class org.apache.camel.converter.ObjectConverter
-
Returns the converted value, or null if the value is null
- toFloat(String) - Static method in class org.apache.camel.converter.ObjectConverter
-
- toHashMap(Map<? extends K, ? extends V>) - Static method in class org.apache.camel.converter.CollectionConverter
-
- toHashtable(Map<? extends K, ? extends V>) - Static method in class org.apache.camel.converter.CollectionConverter
-
- toInputSource(InputStream, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toInputSource(File, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toInputStream(URL) - Static method in class org.apache.camel.converter.IOConverter
-
- toInputStream(File) - Static method in class org.apache.camel.converter.IOConverter
-
- toInputStream(File, String) - Static method in class org.apache.camel.converter.IOConverter
-
- toInputStream(String) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toInputStream(String, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toInputStream(StringBuffer, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toInputStream(StringBuilder, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toInputStream(BufferedReader) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toInputStream(BufferedReader, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toInputStream(byte[]) - Static method in class org.apache.camel.converter.IOConverter
-
- toInputStream(ByteArrayOutputStream) - Static method in class org.apache.camel.converter.IOConverter
-
- toInputStream(NodeList, Exchange) - Method in class org.apache.camel.converter.jaxp.DomConverter
-
- toInputStream(StreamSource) - Static method in class org.apache.camel.converter.jaxp.StreamSourceConverter
-
- toInputStream(DOMSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toInputStream(DOMSource, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toInputStream(Document) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toInputStream(Document, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toInputStream(ByteBuffer) - Static method in class org.apache.camel.converter.NIOConverter
-
- toInteger(NodeList) - Static method in class org.apache.camel.converter.jaxp.DomConverter
-
- toInteger(Object) - Static method in class org.apache.camel.converter.ObjectConverter
-
Returns the converted value, or null if the value is null
- toInteger(String) - Static method in class org.apache.camel.converter.ObjectConverter
-
- toJson() - Method in class org.apache.camel.impl.ParameterConfiguration
-
Returns the JSON format of this parameter configuration
- toJson(String, String, boolean) - Static method in class org.apache.camel.util.StringHelper
-
Creates a json tuple with the given name/value pair.
- token - Variable in class org.apache.camel.language.simple.ast.BaseSimpleNode
-
- token - Variable in class org.apache.camel.language.simple.BaseSimpleParser
-
- tokenize(String) - Method in class org.apache.camel.builder.ExpressionClause
-
Evaluates a token expression on the message body
- tokenize(String, boolean) - Method in class org.apache.camel.builder.ExpressionClause
-
Evaluates a token expression on the message body
- tokenize(String, boolean, int) - Method in class org.apache.camel.builder.ExpressionClause
-
Evaluates a token expression on the message body
- tokenize(String, int) - Method in class org.apache.camel.builder.ExpressionClause
-
Evaluates a token expression on the message body
- tokenize(String, String) - Method in class org.apache.camel.builder.ExpressionClause
-
Evaluates a token expression on the given header
- tokenize(String, String, boolean) - Method in class org.apache.camel.builder.ExpressionClause
-
Evaluates a token expression on the given header
- tokenize(String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
Evaluates a token expression on the message body
- tokenize(String, int) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
Evaluates a token expression on the message body
- tokenize(String, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
Evaluates a token expression on the message body
- tokenize(String, boolean, int) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
Evaluates a token expression on the message body
- tokenize(String, String) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
Evaluates a token expression on the given header
- tokenize(String, String, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
Evaluates a token expression on the given header
- tokenize(String, String, boolean, int) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
Evaluates a token expression on the given header
- tokenize() - Method in class org.apache.camel.builder.ValueBuilder
-
- tokenize(String) - Method in class org.apache.camel.builder.ValueBuilder
-
- tokenize(String) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- tokenize(String, boolean) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- tokenize(String, String) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- tokenize(String, String, boolean) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- tokenizeExpression(Expression, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns a tokenize expression which will tokenize the string with the
given token
- TokenizeLanguage - Class in org.apache.camel.language.tokenizer
-
A language for tokenizer expressions.
- TokenizeLanguage() - Constructor for class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- tokenizePair(String, String) - Method in class org.apache.camel.builder.ExpressionClause
-
Evaluates a token pair expression on the message body.
- tokenizePair(String, String, boolean) - Method in class org.apache.camel.builder.ExpressionClause
-
Evaluates a token pair expression on the message body
- tokenizePair(String, String, boolean) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
Evaluates a token pair expression on the message body
- tokenizePair(String, String, boolean) - Method in class org.apache.camel.builder.ValueBuilder
-
- tokenizePair(String, String, boolean) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- tokenizePairExpression(String, String, boolean) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
- TokenizerExpression - Class in org.apache.camel.model.language
-
For expressions and predicates using a body or header tokenizer.
- TokenizerExpression() - Constructor for class org.apache.camel.model.language.TokenizerExpression
-
- tokenizeToStringArray(String, String) - Static method in class org.apache.camel.util.AntPathMatcher
-
Tokenize the given String into a String array via a StringTokenizer.
- tokenizeXML(String) - Method in class org.apache.camel.builder.ExpressionClause
-
Evaluates a XML token expression on the message body with XML content
- tokenizeXML(String, int) - Method in class org.apache.camel.builder.ExpressionClause
-
Evaluates a XML token expression on the message body with XML content
- tokenizeXML(String, String) - Method in class org.apache.camel.builder.ExpressionClause
-
Evaluates a token pair expression on the message body with XML content
- tokenizeXML(String, String, int) - Method in class org.apache.camel.builder.ExpressionClause
-
Evaluates a token pair expression on the message body with XML content
- tokenizeXML(String, String) - Method in class org.apache.camel.builder.ValueBuilder
-
- tokenizeXML(String, String) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
-
- tokenizeXMLExpression(String, String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
- tokenizeXMLPair(String, String, int) - Method in class org.apache.camel.builder.ExpressionClauseSupport
-
Evaluates a token pair expression on the message body with XML content
- TokenPairExpressionIterator - Class in org.apache.camel.support
-
- TokenPairExpressionIterator(String, String, boolean) - Constructor for class org.apache.camel.support.TokenPairExpressionIterator
-
- tokens - Variable in class org.apache.camel.language.simple.BaseSimpleParser
-
- TokenType - Enum in org.apache.camel.language.simple.types
-
Classifications of known token types.
- TokenXMLExpressionIterator - Class in org.apache.camel.support
-
Expression
to walk a
Message
XML body
using an
Iterator
, which grabs the content between a XML start and end token,
where the end token corresponds implicitly to either the end tag or the self-closing start tag.
- TokenXMLExpressionIterator(String, String) - Constructor for class org.apache.camel.support.TokenXMLExpressionIterator
-
- TokenXMLPairExpressionIterator - Class in org.apache.camel.support
-
- TokenXMLPairExpressionIterator(String, String, String) - Constructor for class org.apache.camel.support.TokenXMLPairExpressionIterator
-
Deprecated.
- toList(Object[]) - Static method in class org.apache.camel.converter.CollectionConverter
-
Converts an array to a collection
- toList(Collection<T>) - Static method in class org.apache.camel.converter.CollectionConverter
-
Converts a collection to a List if it is not already
- toList(Iterable<T>) - Static method in class org.apache.camel.converter.CollectionConverter
-
- toList(NodeList) - Static method in class org.apache.camel.converter.jaxp.DomConverter
-
- toLong(Date) - Static method in class org.apache.camel.converter.DateTimeConverter
-
- toLong(NodeList) - Static method in class org.apache.camel.converter.jaxp.DomConverter
-
- toLong(Object) - Static method in class org.apache.camel.converter.ObjectConverter
-
Returns the converted value, or null if the value is null
- toLong(String) - Static method in class org.apache.camel.converter.ObjectConverter
-
- toMillis() - Method in class org.apache.camel.util.Time
-
- toMilliSeconds(String) - Static method in class org.apache.camel.converter.TimePatternConverter
-
- toObjectInput(InputStream, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toObjectOutput(OutputStream) - Static method in class org.apache.camel.converter.IOConverter
-
- tooltop - Variable in class org.apache.camel.view.NodeData
-
- toOutputStream(File) - Static method in class org.apache.camel.converter.IOConverter
-
- topic() - Method in class org.apache.camel.model.LoadBalanceDefinition
-
Uses topic load balancer
- TopicLoadBalancer - Class in org.apache.camel.processor.loadbalancer
-
A
LoadBalancer
implementations which sends to all destinations
(rather like JMS Topics).
- TopicLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
-
- TopicLoadBalancerDefinition - Class in org.apache.camel.model.loadbalancer
-
Represents an XML <topic/> element
- TopicLoadBalancerDefinition() - Constructor for class org.apache.camel.model.loadbalancer.TopicLoadBalancerDefinition
-
- toPredicate(Expression) - Static method in class org.apache.camel.builder.PredicateBuilder
-
Converts the given expression into an
Predicate
- toPredicate(Expression) - Static method in class org.apache.camel.util.ExpressionToPredicateAdapter
-
Converts the given expression into an
Predicate
- toProcessor(Predicate) - Static method in class org.apache.camel.converter.CamelConverter
-
- toProcessor(Expression) - Static method in class org.apache.camel.converter.CamelConverter
-
- toProperties(Map<Object, Object>) - Static method in class org.apache.camel.converter.CollectionConverter
-
- toProperties(File) - Static method in class org.apache.camel.converter.IOConverter
-
- toProperties(InputStream) - Static method in class org.apache.camel.converter.IOConverter
-
- toProperties(Reader) - Static method in class org.apache.camel.converter.IOConverter
-
- toReader(File) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toReader(File, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toReader(File, String) - Static method in class org.apache.camel.converter.IOConverter
-
- toReader(InputStream) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toReader(InputStream, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toReader(String) - Static method in class org.apache.camel.converter.IOConverter
-
- toReader(StreamSource) - Static method in class org.apache.camel.converter.jaxp.StreamSourceConverter
-
- toReaderFromSource(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toReaderFromSource(Source, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toResult(Source, Result) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given input Source into the required result
- toResult(Source, Result, Properties) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given input Source into the required result
- toSAXSource(String) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toSAXSource(String, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the source instance to a
SAXSource
or returns null if the conversion is not
supported (making it easy to derive from this class to add new kinds of conversion).
- toSAXSource(InputStream) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toSAXSource(InputStream, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the source instance to a
SAXSource
or returns null if the conversion is not
supported (making it easy to derive from this class to add new kinds of conversion).
- toSAXSource(byte[], Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the source instance to a
SAXSource
or returns null if the conversion is not
supported (making it easy to derive from this class to add new kinds of conversion).
- toSAXSource(File, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the source instance to a
SAXSource
or returns null if the conversion is not
supported (making it easy to derive from this class to add new kinds of conversion).
- toSAXSource(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toSAXSource(Source, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the source instance to a
SAXSource
or returns null if the conversion is not
supported (making it easy to derive from this class to add new kinds of conversion).
- toSAXSourceFromDOM(DOMSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toSAXSourceFromDOM(DOMSource, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toSAXSourceFromStAX(StAXSource, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toSAXSourceFromStream(StreamSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toSet(Object[]) - Static method in class org.apache.camel.converter.CollectionConverter
-
- toSet(Collection<T>) - Static method in class org.apache.camel.converter.CollectionConverter
-
- toSet(Map<K, V>) - Static method in class org.apache.camel.converter.CollectionConverter
-
- toShort(Object) - Static method in class org.apache.camel.converter.ObjectConverter
-
Returns the converted value, or null if the value is null
- toSource(Document) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
use toDOMSource instead
- toSource(Node) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
use toDOMSource instead
- toSource(String) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given String to a Source
- toStAXSource(String, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the source instance to a
StAXSource
or returns null if the conversion is not
supported (making it easy to derive from this class to add new kinds of conversion).
- toStAXSource(byte[], Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the source instance to a
StAXSource
or returns null if the conversion is not
supported (making it easy to derive from this class to add new kinds of conversion).
- toStAXSource(InputStream, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the source instance to a
StAXSource
or returns null if the conversion is not
supported (making it easy to derive from this class to add new kinds of conversion).
- toStAXSource(File, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the source instance to a
StAXSource
or returns null if the conversion is not
supported (making it easy to derive from this class to add new kinds of conversion).
- toStreamSource(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toStreamSource(Source, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toStreamSource(InputStream) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toStreamSource(Reader) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toStreamSource(File) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toStreamSource(byte[], Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toStreamSource(ByteBuffer, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toStreamSourceFromDOM(DOMSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toStreamSourceFromDOM(DOMSource, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toStreamSourceFromSAX(SAXSource) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toStreamSourceFromSAX(SAXSource, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toStreamSourceFromStAX(StAXSource, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
- toString() - Method in class org.apache.camel.builder.BinaryPredicateSupport
-
- toString() - Method in class org.apache.camel.builder.DeadLetterChannelBuilder
-
- toString() - Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- toString() - Method in class org.apache.camel.builder.ErrorHandlerBuilderRef
-
- toString() - Method in class org.apache.camel.builder.NotifyBuilder
-
- toString() - Method in class org.apache.camel.builder.RouteBuilder
-
- toString() - Method in class org.apache.camel.builder.SimpleBuilder
-
- toString() - Method in class org.apache.camel.builder.ValueBuilder
-
- toString() - Method in class org.apache.camel.builder.xml.DefaultNamespaceContext
-
toString() implementation that outputs the namespace mappings with the following format: "[me: {prefix -> value}, {prefix -> value}], [parent: {prefix -> value}, {prefix -> value}].
- toString() - Method in class org.apache.camel.builder.xml.XPathBuilder
-
- toString() - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- toString() - Method in class org.apache.camel.BytesSource
-
- toString() - Method in class org.apache.camel.component.bean.BeanInvocation
-
- toString() - Method in class org.apache.camel.component.bean.BeanProcessor
-
- toString() - Method in class org.apache.camel.component.bean.ConstantBeanHolder
-
- toString() - Method in class org.apache.camel.component.bean.ConstantTypeBeanHolder
-
- toString() - Method in class org.apache.camel.component.bean.MethodInfo
-
- toString() - Method in class org.apache.camel.component.bean.ParameterInfo
-
- toString() - Method in class org.apache.camel.component.bean.RegistryBean
-
- toString() - Method in class org.apache.camel.component.directvm.DirectVmConsumerExpression
-
- toString() - Method in class org.apache.camel.component.directvm.DirectVmProcessor
-
- toString() - Method in class org.apache.camel.component.file.GenericFile
-
- toString() - Method in class org.apache.camel.component.file.GenericFileConfiguration
-
- toString() - Method in class org.apache.camel.component.file.GenericFileMessage
-
- toString() - Method in class org.apache.camel.component.file.GenericFileOnCompletion
-
- toString() - Method in class org.apache.camel.component.mock.TimeClause
-
- toString() - Method in class org.apache.camel.component.seda.SedaConsumer
-
- toString(byte[]) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toString(byte[], Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toString(File) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toString(File, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toString(URL) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toString(URL, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toString(Reader) - Static method in class org.apache.camel.converter.IOConverter
-
- toString(BufferedReader) - Static method in class org.apache.camel.converter.IOConverter
-
- toString(InputStream) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toString(InputStream, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toString(ByteArrayOutputStream) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toString(ByteArrayOutputStream, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toString(NodeList, Exchange) - Method in class org.apache.camel.converter.jaxp.DomConverter
-
- toString(Source) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toString(Source, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given input Source into text
- toString(Node) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toString(Node, Exchange) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given input Node into text
- toString(ByteBuffer, Exchange) - Static method in class org.apache.camel.converter.NIOConverter
-
- toString(Integer) - Static method in class org.apache.camel.converter.ObjectConverter
-
- toString(Long) - Static method in class org.apache.camel.converter.ObjectConverter
-
- toString(Boolean) - Static method in class org.apache.camel.converter.ObjectConverter
-
- toString(StringBuffer) - Static method in class org.apache.camel.converter.ObjectConverter
-
- toString(StringBuilder) - Static method in class org.apache.camel.converter.ObjectConverter
-
- toString() - Method in class org.apache.camel.converter.stream.CachedOutputStream
-
- toString() - Method in class org.apache.camel.impl.AggregateRouteNode
-
- toString() - Method in class org.apache.camel.impl.AnnotatedParameterConfiguration
-
- toString() - Method in class org.apache.camel.impl.ConsumerCache
-
- toString() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry.TypeMapping
-
- toString() - Method in class org.apache.camel.impl.converter.InstanceMethodFallbackTypeConverter
-
- toString() - Method in class org.apache.camel.impl.converter.InstanceMethodTypeConverter
-
- toString() - Method in class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
-
- toString() - Method in class org.apache.camel.impl.converter.StaticMethodTypeConverter
-
- toString() - Method in class org.apache.camel.impl.DefaultCamelContext
-
- toString() - Method in class org.apache.camel.impl.DefaultConsumer
-
- toString() - Method in class org.apache.camel.impl.DefaultDebugger
-
- toString() - Method in class org.apache.camel.impl.DefaultEndpoint
-
- toString() - Method in class org.apache.camel.impl.DefaultExchange
-
- toString() - Method in class org.apache.camel.impl.DefaultExchangeHolder
-
- toString() - Method in class org.apache.camel.impl.DefaultMessage
-
- toString() - Method in class org.apache.camel.impl.DefaultMessageHistory
-
- toString() - Method in class org.apache.camel.impl.DefaultProducer
-
- toString() - Method in class org.apache.camel.impl.DefaultRoute
-
- toString() - Method in class org.apache.camel.impl.DefaultRouteNode
-
- toString() - Method in class org.apache.camel.impl.DefaultRouteStartupOrder
-
- toString() - Method in class org.apache.camel.impl.DefaultStreamCachingStrategy
-
- toString() - Method in class org.apache.camel.impl.DefaultUnitOfWork
-
- toString() - Method in class org.apache.camel.impl.DoCatchRouteNode
-
- toString() - Method in class org.apache.camel.impl.DoFinallyRouteNode
-
- toString() - Method in class org.apache.camel.impl.EmptyProducerCache
-
- toString() - Method in class org.apache.camel.impl.EndpointRegistry
-
- toString() - Method in class org.apache.camel.impl.EventDrivenConsumerRoute
-
- toString() - Method in class org.apache.camel.impl.InterceptSendToEndpoint
-
- toString() - Method in class org.apache.camel.impl.InterceptSendToMockEndpointStrategy
-
- toString() - Method in class org.apache.camel.impl.MDCUnitOfWork
-
- toString() - Method in class org.apache.camel.impl.OnCompletionRouteNode
-
- toString() - Method in class org.apache.camel.impl.OnExceptionRouteNode
-
- toString() - Method in class org.apache.camel.impl.ParameterConfiguration
-
- toString() - Method in class org.apache.camel.impl.PollingConsumerSupport
-
- toString() - Method in class org.apache.camel.impl.ProducerCache
-
- toString() - Method in class org.apache.camel.impl.PropertyPlaceholderDelegateRegistry
-
- toString() - Method in class org.apache.camel.impl.scan.AnnotatedWithAnyPackageScanFilter
-
- toString() - Method in class org.apache.camel.impl.scan.AnnotatedWithPackageScanFilter
-
- toString() - Method in class org.apache.camel.impl.scan.AssignableToPackageScanFilter
-
- toString() - Method in class org.apache.camel.impl.scan.InvertingPackageScanFilter
-
- toString() - Method in class org.apache.camel.impl.SynchronousDelegateProducer
-
- toString() - Method in class org.apache.camel.impl.ThrottlingInflightRoutePolicy
-
- toString() - Method in class org.apache.camel.language.bean.BeanExpression
-
- toString() - Method in class org.apache.camel.language.simple.ast.BaseSimpleNode
-
- toString() - Method in class org.apache.camel.language.simple.ast.BinaryExpression
-
- toString() - Method in class org.apache.camel.language.simple.ast.CompositeNodes
-
- toString() - Method in class org.apache.camel.language.simple.ast.DoubleQuoteStart
-
- toString() - Method in class org.apache.camel.language.simple.ast.LiteralExpression
-
- toString() - Method in class org.apache.camel.language.simple.ast.LogicalExpression
-
- toString() - Method in class org.apache.camel.language.simple.ast.SimpleFunctionStart
-
- toString() - Method in class org.apache.camel.language.simple.ast.SingleQuoteStart
-
- toString() - Method in class org.apache.camel.language.simple.ast.UnaryExpression
-
- toString() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType
-
- toString() - Method in enum org.apache.camel.language.simple.types.LogicalOperatorType
-
- toString() - Method in class org.apache.camel.language.simple.types.SimpleToken
-
- toString() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
-
- toString() - Method in enum org.apache.camel.language.simple.types.UnaryOperatorType
-
- toString() - Method in class org.apache.camel.management.DelegatePerformanceCounter
-
- toString() - Method in class org.apache.camel.management.event.CamelContextResumedEvent
-
- toString() - Method in class org.apache.camel.management.event.CamelContextResumeFailureEvent
-
- toString() - Method in class org.apache.camel.management.event.CamelContextResumingEvent
-
- toString() - Method in class org.apache.camel.management.event.CamelContextStartedEvent
-
- toString() - Method in class org.apache.camel.management.event.CamelContextStartingEvent
-
- toString() - Method in class org.apache.camel.management.event.CamelContextStartupFailureEvent
-
- toString() - Method in class org.apache.camel.management.event.CamelContextStopFailureEvent
-
- toString() - Method in class org.apache.camel.management.event.CamelContextStoppedEvent
-
- toString() - Method in class org.apache.camel.management.event.CamelContextStoppingEvent
-
- toString() - Method in class org.apache.camel.management.event.CamelContextSuspendedEvent
-
- toString() - Method in class org.apache.camel.management.event.CamelContextSuspendingEvent
-
- toString() - Method in class org.apache.camel.management.event.ExchangeCompletedEvent
-
- toString() - Method in class org.apache.camel.management.event.ExchangeCreatedEvent
-
- toString() - Method in class org.apache.camel.management.event.ExchangeFailedEvent
-
- toString() - Method in class org.apache.camel.management.event.ExchangeFailureHandledEvent
-
- toString() - Method in class org.apache.camel.management.event.ExchangeRedeliveryEvent
-
- toString() - Method in class org.apache.camel.management.event.ExchangeSendingEvent
-
- toString() - Method in class org.apache.camel.management.event.ExchangeSentEvent
-
- toString() - Method in class org.apache.camel.management.event.RouteAddedEvent
-
- toString() - Method in class org.apache.camel.management.event.RouteRemovedEvent
-
- toString() - Method in class org.apache.camel.management.event.RouteStartedEvent
-
- toString() - Method in class org.apache.camel.management.event.RouteStoppedEvent
-
- toString() - Method in class org.apache.camel.management.event.ServiceStartupFailureEvent
-
- toString() - Method in class org.apache.camel.management.event.ServiceStopFailureEvent
-
- toString() - Method in class org.apache.camel.management.InstrumentationInterceptStrategy
-
- toString() - Method in class org.apache.camel.management.InstrumentationProcessor
-
- toString() - Method in class org.apache.camel.management.mbean.LoadTriplet
-
- toString() - Method in class org.apache.camel.management.mbean.Statistic
-
- toString() - Method in class org.apache.camel.management.PublishEventNotifier
-
- toString() - Method in class org.apache.camel.model.AggregateDefinition
-
- toString() - Method in class org.apache.camel.model.AOPDefinition
-
Deprecated.
- toString() - Method in class org.apache.camel.model.BeanDefinition
-
- toString() - Method in class org.apache.camel.model.CatchDefinition
-
- toString() - Method in class org.apache.camel.model.ChoiceDefinition
-
- toString() - Method in class org.apache.camel.model.ConvertBodyDefinition
-
- toString() - Method in class org.apache.camel.model.dataformat.CustomDataFormat
-
- toString() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.AliasEntry
-
- toString() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.ImplicitCollectionEntry
-
- toString() - Method in class org.apache.camel.model.dataformat.XStreamDataFormat.OmitFieldEntry
-
- toString() - Method in class org.apache.camel.model.DelayDefinition
-
- toString() - Method in class org.apache.camel.model.DynamicRouterDefinition
-
- toString() - Method in class org.apache.camel.model.EnrichDefinition
-
- toString() - Method in class org.apache.camel.model.ExpressionSubElementDefinition
-
- toString() - Method in class org.apache.camel.model.FilterDefinition
-
- toString() - Method in class org.apache.camel.model.FinallyDefinition
-
- toString() - Method in class org.apache.camel.model.FromDefinition
-
- toString() - Method in class org.apache.camel.model.IdempotentConsumerDefinition
-
- toString() - Method in class org.apache.camel.model.InOnlyDefinition
-
- toString() - Method in class org.apache.camel.model.InOutDefinition
-
- toString() - Method in class org.apache.camel.model.InterceptDefinition
-
- toString() - Method in class org.apache.camel.model.InterceptFromDefinition
-
- toString() - Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
-
- toString() - Method in class org.apache.camel.model.language.ExpressionDefinition
-
- toString() - Method in class org.apache.camel.model.language.MethodCallExpression
-
- toString() - Method in class org.apache.camel.model.language.TokenizerExpression
-
- toString() - Method in class org.apache.camel.model.LoadBalanceDefinition
-
- toString() - Method in class org.apache.camel.model.loadbalancer.CustomLoadBalancerDefinition
-
- toString() - Method in class org.apache.camel.model.loadbalancer.FailoverLoadBalancerDefinition
-
- toString() - Method in class org.apache.camel.model.loadbalancer.RandomLoadBalancerDefinition
-
- toString() - Method in class org.apache.camel.model.loadbalancer.RoundRobinLoadBalancerDefinition
-
- toString() - Method in class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
-
- toString() - Method in class org.apache.camel.model.loadbalancer.TopicLoadBalancerDefinition
-
- toString() - Method in class org.apache.camel.model.loadbalancer.WeightedLoadBalancerDefinition
-
- toString() - Method in class org.apache.camel.model.LoadBalancerDefinition
-
- toString() - Method in class org.apache.camel.model.LogDefinition
-
- toString() - Method in class org.apache.camel.model.LoopDefinition
-
- toString() - Method in class org.apache.camel.model.MarshalDefinition
-
- toString() - Method in class org.apache.camel.model.MulticastDefinition
-
- toString() - Method in class org.apache.camel.model.OnCompletionDefinition
-
- toString() - Method in class org.apache.camel.model.OnExceptionDefinition
-
- toString() - Method in class org.apache.camel.model.OtherwiseDefinition
-
- toString() - Method in class org.apache.camel.model.OutputDefinition
-
- toString() - Method in class org.apache.camel.model.PolicyDefinition
-
- toString() - Method in class org.apache.camel.model.PollEnrichDefinition
-
- toString() - Method in class org.apache.camel.model.ProcessDefinition
-
- toString() - Method in class org.apache.camel.model.RecipientListDefinition
-
- toString() - Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- toString() - Method in class org.apache.camel.model.RemoveHeaderDefinition
-
- toString() - Method in class org.apache.camel.model.RemoveHeadersDefinition
-
- toString() - Method in class org.apache.camel.model.RemovePropertyDefinition
-
- toString() - Method in class org.apache.camel.model.ResequenceDefinition
-
- toString() - Method in class org.apache.camel.model.RollbackDefinition
-
- toString() - Method in class org.apache.camel.model.RouteBuilderDefinition
-
- toString() - Method in class org.apache.camel.model.RouteContextRefDefinition
-
- toString() - Method in class org.apache.camel.model.RouteDefinition
-
- toString() - Method in class org.apache.camel.model.RoutesDefinition
-
- toString() - Method in class org.apache.camel.model.RoutingSlipDefinition
-
- toString() - Method in class org.apache.camel.model.SamplingDefinition
-
- toString() - Method in class org.apache.camel.model.SetBodyDefinition
-
- toString() - Method in class org.apache.camel.model.SetExchangePatternDefinition
-
- toString() - Method in class org.apache.camel.model.SetFaultBodyDefinition
-
- toString() - Method in class org.apache.camel.model.SetHeaderDefinition
-
- toString() - Method in class org.apache.camel.model.SetOutHeaderDefinition
-
Deprecated.
- toString() - Method in class org.apache.camel.model.SetPropertyDefinition
-
- toString() - Method in class org.apache.camel.model.SortDefinition
-
- toString() - Method in class org.apache.camel.model.SplitDefinition
-
- toString() - Method in class org.apache.camel.model.StopDefinition
-
- toString() - Method in class org.apache.camel.model.ThreadsDefinition
-
- toString() - Method in class org.apache.camel.model.ThrottleDefinition
-
- toString() - Method in class org.apache.camel.model.ThrowExceptionDefinition
-
- toString() - Method in class org.apache.camel.model.ToDefinition
-
- toString() - Method in class org.apache.camel.model.TransactedDefinition
-
- toString() - Method in class org.apache.camel.model.TransformDefinition
-
- toString() - Method in class org.apache.camel.model.TryDefinition
-
- toString() - Method in class org.apache.camel.model.UnmarshalDefinition
-
- toString() - Method in class org.apache.camel.model.ValidateDefinition
-
- toString() - Method in class org.apache.camel.model.WhenDefinition
-
- toString() - Method in class org.apache.camel.model.WireTapDefinition
-
- toString() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
-
- toString() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
-
- toString() - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
-
- toString() - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
-
- toString() - Method in class org.apache.camel.processor.AOPProcessor
-
- toString() - Method in class org.apache.camel.processor.BatchProcessor
-
Deprecated.
- toString() - Method in class org.apache.camel.processor.CamelInternalProcessor
-
- toString() - Method in class org.apache.camel.processor.CamelLogger
-
Deprecated.
- toString() - Method in class org.apache.camel.processor.CamelLogProcessor
-
- toString() - Method in class org.apache.camel.processor.CatchProcessor
-
- toString() - Method in class org.apache.camel.processor.ChoiceProcessor
-
- toString() - Method in class org.apache.camel.processor.ConvertBodyProcessor
-
- toString() - Method in class org.apache.camel.processor.DeadLetterChannel
-
- toString() - Method in class org.apache.camel.processor.DefaultErrorHandler
-
- toString() - Method in class org.apache.camel.processor.Delayer
-
- toString() - Method in class org.apache.camel.processor.DelegateAsyncProcessor
-
- toString() - Method in class org.apache.camel.processor.DelegateProcessor
-
- toString() - Method in class org.apache.camel.processor.DelegateSyncProcessor
-
- toString() - Method in class org.apache.camel.processor.Enricher
-
- toString() - Method in class org.apache.camel.processor.EvaluateExpressionProcessor
-
- toString() - Method in class org.apache.camel.processor.exceptionpolicy.ExceptionPolicyKey
-
- toString() - Method in class org.apache.camel.processor.ExchangePatternProcessor
-
- toString() - Method in class org.apache.camel.processor.FatalFallbackErrorHandler
-
- toString() - Method in class org.apache.camel.processor.FilterProcessor
-
- toString() - Method in class org.apache.camel.processor.FinallyProcessor
-
- toString() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
-
- toString() - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
-
- toString() - Method in class org.apache.camel.processor.InterceptEndpointProcessor
-
- toString() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
-
- toString() - Method in class org.apache.camel.processor.interceptor.DefaultChannel
-
- toString() - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- toString() - Method in class org.apache.camel.processor.interceptor.Delayer
-
Deprecated.
- toString() - Method in class org.apache.camel.processor.interceptor.DelayInterceptor
-
Deprecated.
- toString() - Method in class org.apache.camel.processor.interceptor.HandleFault
-
- toString() - Method in class org.apache.camel.processor.interceptor.HandleFaultInterceptor
-
- toString() - Method in class org.apache.camel.processor.interceptor.StreamCaching
-
Deprecated.
- toString() - Method in class org.apache.camel.processor.interceptor.StreamCachingInterceptor
-
Deprecated.
- toString() - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
- toString() - Method in class org.apache.camel.processor.interceptor.Tracer
-
- toString() - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
-
- toString() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
-
- toString() - Method in class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
-
- toString() - Method in class org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer
-
- toString() - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
-
- toString() - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
-
- toString() - Method in class org.apache.camel.processor.LoggingErrorHandler
-
- toString() - Method in class org.apache.camel.processor.LogProcessor
-
- toString() - Method in class org.apache.camel.processor.LoopProcessor
-
- toString() - Method in class org.apache.camel.processor.MarshalProcessor
-
- toString() - Method in class org.apache.camel.processor.MulticastProcessor
-
- toString() - Method in class org.apache.camel.processor.OnCompletionProcessor
-
- toString() - Method in class org.apache.camel.processor.Pipeline
-
- toString() - Method in class org.apache.camel.processor.PollEnricher
-
- toString() - Method in class org.apache.camel.processor.RecipientList
-
- toString() - Method in class org.apache.camel.processor.RecipientListProcessor
-
- toString() - Method in class org.apache.camel.processor.RedeliveryPolicy
-
- toString() - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
-
- toString() - Method in class org.apache.camel.processor.Resequencer
-
- toString() - Method in class org.apache.camel.processor.RollbackProcessor
-
- toString() - Method in class org.apache.camel.processor.RoutingSlip
-
- toString() - Method in class org.apache.camel.processor.SamplingThrottler
-
- toString() - Method in class org.apache.camel.processor.SendProcessor
-
- toString() - Method in class org.apache.camel.processor.SetBodyProcessor
-
- toString() - Method in class org.apache.camel.processor.SortProcessor
-
- toString() - Method in class org.apache.camel.processor.Splitter
-
- toString() - Method in class org.apache.camel.processor.StopProcessor
-
- toString() - Method in class org.apache.camel.processor.StreamResequencer
-
- toString() - Method in class org.apache.camel.processor.ThreadsProcessor
-
- toString() - Method in class org.apache.camel.processor.Throttler
-
- toString() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
-
- toString() - Method in class org.apache.camel.processor.TransformProcessor
-
- toString() - Method in class org.apache.camel.processor.TryProcessor
-
- toString() - Method in class org.apache.camel.processor.UnitOfWorkProducer
-
- toString() - Method in class org.apache.camel.processor.UnmarshalProcessor
-
- toString() - Method in class org.apache.camel.processor.validation.PredicateValidatingProcessor
-
- toString() - Method in class org.apache.camel.processor.WireTapProcessor
-
- toString() - Method in class org.apache.camel.processor.WrapProcessor
-
- toString() - Method in class org.apache.camel.spi.ThreadPoolProfile
-
- toString() - Method in class org.apache.camel.StringSource
-
- toString() - Method in class org.apache.camel.support.TimeoutMapEntry
-
- toString() - Method in class org.apache.camel.support.TokenPairExpressionIterator
-
- toString() - Method in class org.apache.camel.util.CamelLogger
-
- toString() - Method in class org.apache.camel.util.CollectionStringBuffer
-
- toString() - Method in class org.apache.camel.util.concurrent.CamelThreadFactory
-
- toString() - Method in class org.apache.camel.util.concurrent.RejectableScheduledThreadPoolExecutor
-
- toString() - Method in class org.apache.camel.util.concurrent.RejectableThreadPoolExecutor
-
- toString() - Method in class org.apache.camel.util.concurrent.SizedScheduledExecutorService
-
- toString() - Method in class org.apache.camel.util.ExpressionToPredicateAdapter
-
- toString() - Method in class org.apache.camel.util.jsse.BaseSSLContextParameters.SSLContextDecorator
-
- toString() - Method in class org.apache.camel.util.jsse.CipherSuitesParameters
-
- toString() - Method in class org.apache.camel.util.jsse.FilterParameters.Patterns
-
- toString() - Method in class org.apache.camel.util.jsse.FilterParameters
-
- toString() - Method in class org.apache.camel.util.jsse.KeyManagersParameters
-
- toString() - Method in class org.apache.camel.util.jsse.KeyStoreParameters
-
- toString() - Method in class org.apache.camel.util.jsse.SecureRandomParameters
-
- toString() - Method in class org.apache.camel.util.jsse.SecureSocketProtocolsParameters
-
- toString() - Method in class org.apache.camel.util.jsse.SSLContextClientParameters
-
- toString() - Method in class org.apache.camel.util.jsse.SSLContextParameters
-
- toString() - Method in class org.apache.camel.util.jsse.SSLContextServerParameters
-
- toString() - Method in class org.apache.camel.util.jsse.TrustManagersParameters
-
- toString() - Method in class org.apache.camel.util.KeyValueHolder
-
- toString() - Method in class org.apache.camel.util.LRUCache
-
- toString() - Method in class org.apache.camel.util.LRUSoftCache
-
- toString() - Method in class org.apache.camel.util.LRUWeakCache
-
- toString() - Method in class org.apache.camel.util.PredicateToExpressionAdapter
-
- toString() - Method in class org.apache.camel.util.Time
-
- toStringSource(String) - Method in class org.apache.camel.converter.jaxp.XmlConverter
-
Converts the given String to a Source
- ToStringTypeConverter - Class in org.apache.camel.impl.converter
-
A simple converter that can convert any object to a String type by using the
toString() method of the object.
- ToStringTypeConverter() - Constructor for class org.apache.camel.impl.converter.ToStringTypeConverter
-
- toTimeZone(String) - Static method in class org.apache.camel.converter.DateTimeConverter
-
- toUriString(EndpointConfiguration.UriFormat) - Method in interface org.apache.camel.EndpointConfiguration
-
Returns the formatted configuration string of an
Endpoint
.
- toUriString(EndpointConfiguration.UriFormat) - Method in class org.apache.camel.impl.MappedEndpointConfiguration
-
- toUriString(EndpointConfiguration.UriFormat) - Method in class org.apache.camel.impl.UriEndpointConfiguration
-
- toWriter(File) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toWriter(File, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toWriter(File, boolean, String) - Static method in class org.apache.camel.converter.IOConverter
-
- toWriter(FileOutputStream, String) - Static method in class org.apache.camel.converter.IOConverter
-
- toWriter(OutputStream) - Static method in class org.apache.camel.converter.IOConverter
-
Deprecated.
will be removed in Camel 3.0. Use the method which has 2 parameters.
- toWriter(OutputStream, Exchange) - Static method in class org.apache.camel.converter.IOConverter
-
- toXml(int) - Method in interface org.apache.camel.api.management.mbean.BacklogTracerEventMessage
-
- toXml(int) - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
-
- trace - Variable in class org.apache.camel.main.MainSupport
-
- TRACE_EVENT - Static variable in interface org.apache.camel.Exchange
-
- TRACE_EVENT_EXCHANGE - Static variable in interface org.apache.camel.Exchange
-
- TRACE_EVENT_NODE_ID - Static variable in interface org.apache.camel.Exchange
-
- TRACE_EVENT_TIMESTAMP - Static variable in interface org.apache.camel.Exchange
-
- Traceable - Interface in org.apache.camel.processor
-
Deprecated.
- Traceable - Interface in org.apache.camel
-
Traceable processors allowing easier tracing using constructed labels to help identify the processor
and where it's defined in the route model.
- TracedRouteNodes - Interface in org.apache.camel.spi
-
- TraceEventHandler - Interface in org.apache.camel.processor.interceptor
-
A handler which reacts on trace events.
- TraceEventMessage - Interface in org.apache.camel.processor.interceptor
-
A trace event message that contains decomposed information about the traced
Exchange
at the point of interception.
- traceExchange(ProcessorDefinition<?>, Processor, TraceInterceptor, Exchange) - Method in class org.apache.camel.management.mbean.JMXNotificationTraceEventHandler
-
- traceExchange(ProcessorDefinition<?>, Processor, TraceInterceptor, Exchange) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventHandler
-
- traceExchange(ProcessorDefinition<?>, Processor, TraceInterceptor, Exchange) - Method in interface org.apache.camel.processor.interceptor.TraceEventHandler
-
Event called when an
Exchange
is about to be processed
This event is only called if trace out has been disabled (which it is by default).
- traceExchange(Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
- traceExchangeIn(ProcessorDefinition<?>, Processor, TraceInterceptor, Exchange) - Method in class org.apache.camel.management.mbean.JMXNotificationTraceEventHandler
-
- traceExchangeIn(ProcessorDefinition<?>, Processor, TraceInterceptor, Exchange) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventHandler
-
- traceExchangeIn(ProcessorDefinition<?>, Processor, TraceInterceptor, Exchange) - Method in interface org.apache.camel.processor.interceptor.TraceEventHandler
-
Event called when an
Exchange
is about to be processed (in)
This event is only called if trace out has been enabled.
- traceExchangeIn(Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
- traceExchangeOut(ProcessorDefinition<?>, Processor, TraceInterceptor, Exchange, Object) - Method in class org.apache.camel.management.mbean.JMXNotificationTraceEventHandler
-
- traceExchangeOut(ProcessorDefinition<?>, Processor, TraceInterceptor, Exchange, Object) - Method in class org.apache.camel.processor.interceptor.DefaultTraceEventHandler
-
- traceExchangeOut(ProcessorDefinition<?>, Processor, TraceInterceptor, Exchange, Object) - Method in interface org.apache.camel.processor.interceptor.TraceEventHandler
-
Event called when an
Exchange
has been processed (out)
This event is only called if trace out has been enabled.
- traceExchangeOut(Exchange, Object) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
- TraceFormatter - Interface in org.apache.camel.processor.interceptor
-
Formatter to format trace logs when tracing
Exchange
during routing.
- traceIntercept(InterceptDefinition, TracedRouteNodes, Exchange) - Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
- TraceInterceptor - Class in org.apache.camel.processor.interceptor
-
An interceptor for debugging and tracing routes
- TraceInterceptor(ProcessorDefinition<?>, Processor, TraceFormatter, Tracer) - Constructor for class org.apache.camel.processor.interceptor.TraceInterceptor
-
- TraceInterceptorFactory - Interface in org.apache.camel.processor.interceptor
-
Factory to create the trace interceptor.
- Tracer - Class in org.apache.camel.processor.interceptor
-
An interceptor strategy for tracing routes
- Tracer() - Constructor for class org.apache.camel.processor.interceptor.Tracer
-
- tracing() - Method in class org.apache.camel.model.RouteDefinition
-
Enable tracing for this route.
- transacted() - Method in class org.apache.camel.model.ProcessorDefinition
-
Marks this route as transacted and uses the default transacted policy found in the registry.
- transacted(String) - Method in class org.apache.camel.model.ProcessorDefinition
-
Marks this route as transacted.
- TransactedDefinition - Class in org.apache.camel.model
-
Represents an XML <transacted/> element
- TransactedDefinition() - Constructor for class org.apache.camel.model.TransactedDefinition
-
- TransactedDefinition(Policy) - Constructor for class org.apache.camel.model.TransactedDefinition
-
- TransactedPolicy - Interface in org.apache.camel.spi
-
A marker for defining the policy to be used for applying transaction to routes.
- TRANSFER_ENCODING - Static variable in interface org.apache.camel.Exchange
-
- transform(Expression) - Method in class org.apache.camel.model.ProcessorDefinition
-
- transform() - Method in class org.apache.camel.model.ProcessorDefinition
-
- TransformDefinition - Class in org.apache.camel.model
-
Represents an XML <transform/> element
- TransformDefinition() - Constructor for class org.apache.camel.model.TransformDefinition
-
- TransformDefinition(Expression) - Constructor for class org.apache.camel.model.TransformDefinition
-
- transformerCacheSize(int) - Method in class org.apache.camel.builder.xml.XsltBuilder
-
- TransformProcessor - Class in org.apache.camel.processor
-
A processor which sets the body on the OUT message with an
Expression
- TransformProcessor(Expression) - Constructor for class org.apache.camel.processor.TransformProcessor
-
- TRIM_SPACES - Static variable in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- trunkStore() - Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
-
Trunks the file store when the max store size is hit by rewriting the 1st level cache
to the file store.
- TrustManagersParameters - Class in org.apache.camel.util.jsse
-
- TrustManagersParameters() - Constructor for class org.apache.camel.util.jsse.TrustManagersParameters
-
- TRY_ROUTE_BLOCK - Static variable in interface org.apache.camel.Exchange
-
- tryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
-
- tryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
-
- tryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.PropertyEditorTypeConverter
-
Deprecated.
- tryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.PropertyEditorTypeConverter
-
Deprecated.
- tryConvertTo(Class<T>, Object) - Method in class org.apache.camel.support.TypeConverterSupport
-
- tryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.support.TypeConverterSupport
-
- tryConvertTo(Class<T>, Object) - Method in interface org.apache.camel.TypeConverter
-
Tries to convert the value to the specified type,
returning null if not possible to convert.
- tryConvertTo(Class<T>, Exchange, Object) - Method in interface org.apache.camel.TypeConverter
-
Tries to convert the value to the specified type in the context of an exchange,
returning null if not possible to convert.
- TryDefinition - Class in org.apache.camel.model
-
Represents an XML <try/> element
- TryDefinition() - Constructor for class org.apache.camel.model.TryDefinition
-
- TryProcessor - Class in org.apache.camel.processor
-
Implements try/catch/finally type processing
- TryProcessor(Processor, List<Processor>, Processor) - Constructor for class org.apache.camel.processor.TryProcessor
-
- tryProcessor - Variable in class org.apache.camel.processor.TryProcessor
-
- type - Variable in class org.apache.camel.model.PolicyDefinition
-
- type - Variable in class org.apache.camel.model.TransactedDefinition
-
- type - Variable in class org.apache.camel.util.jsse.KeyStoreParameters
-
The optional type of the key store to load.
- type(Object) - Static method in class org.apache.camel.util.ObjectHelper
-
Returns the type of the given object or null if the value is null
- TYPE_COMPONENT - Static variable in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- TYPE_CONSUMER - Static variable in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- TYPE_CONTEXT - Static variable in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- TYPE_ENDPOINT - Static variable in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- TYPE_ERRORHANDLER - Static variable in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- TYPE_EVENT_NOTIFIER - Static variable in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- TYPE_HINTS - Static variable in class org.apache.camel.model.dataformat.XmlJsonDataFormat
-
- TYPE_PROCESSOR - Static variable in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- TYPE_PRODUCER - Static variable in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- TYPE_ROUTE - Static variable in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- TYPE_SERVICE - Static variable in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- TYPE_THREAD_POOL - Static variable in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- TYPE_TRACER - Static variable in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- typeCoerceCompare(TypeConverter, Object, Object) - Static method in class org.apache.camel.util.ObjectHelper
-
A helper method for comparing objects ordering in which it uses type coercion to coerce
types between the left and right values.
- typeCoerceEquals(TypeConverter, Object, Object) - Static method in class org.apache.camel.util.ObjectHelper
-
A helper method for comparing objects for equality in which it uses type coercion to coerce
types between the left and right values.
- typeCoerceNotEquals(TypeConverter, Object, Object) - Static method in class org.apache.camel.util.ObjectHelper
-
A helper method for comparing objects for inequality in which it uses type coercion to coerce
types between the left and right values.
- TypeConversionException - Exception in org.apache.camel
-
Exception when failing during type conversion.
- TypeConversionException(Object, Class<?>, Throwable) - Constructor for exception org.apache.camel.TypeConversionException
-
- TypeConverter - Interface in org.apache.camel
-
A pluggable strategy to be able to convert objects
to different
types such as to and from String, InputStream/OutputStream,
Reader/Writer, Document, byte[], ByteBuffer etc
- TypeConverterAware - Interface in org.apache.camel.spi
-
An interface for an object which is interested in being injected with the root
TypeConverter
such as for implementing a fallback type converter
- typeConverterExpression() - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns an expression for the type converter
- TypeConverterLoader - Interface in org.apache.camel.spi
-
- TypeConverterLoaderException - Exception in org.apache.camel
-
Exception when failing to load type converters.
- TypeConverterLoaderException(String) - Constructor for exception org.apache.camel.TypeConverterLoaderException
-
- TypeConverterLoaderException(String, Throwable) - Constructor for exception org.apache.camel.TypeConverterLoaderException
-
- typeConverterLoaders - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
-
- TypeConverterRegistry - Interface in org.apache.camel.spi
-
Registry for type converters.
- TypeConverterRegistry.Statistics - Interface in org.apache.camel.spi
-
Utilization statistics of the this registry.
- TypeConverterSupport - Class in org.apache.camel.support
-
- TypeConverterSupport() - Constructor for class org.apache.camel.support.TypeConverterSupport
-
- typeExpression(String) - Static method in class org.apache.camel.builder.ExpressionBuilder
-
Returns an expression for a type value
- typeMappings - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
-