- 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.
- 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
-
- SamplingThrottler - Class in org.apache.camel.processor
- A
SamplingThrottler
is a special kind of throttler. - 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.
- sanitizeUri(String) -
Static method in class org.apache.camel.impl.DefaultEndpoint
-
- 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.
- ScheduledPollConsumer - Class in org.apache.camel.impl
- A useful base class for any consumer which is polling based
- ScheduledPollConsumer(DefaultEndpoint, Processor) -
Constructor for class org.apache.camel.impl.ScheduledPollConsumer
-
- ScheduledPollConsumer(Endpoint, Processor, ScheduledExecutorService) -
Constructor for class org.apache.camel.impl.ScheduledPollConsumer
-
- ScheduledPollEndpoint - Class in org.apache.camel.impl
- A base class for
Endpoint
which creates a ScheduledPollConsumer
- ScheduledPollEndpoint(String, Component) -
Constructor for class org.apache.camel.impl.ScheduledPollEndpoint
-
- ScheduledPollEndpoint(String, CamelContext) -
Constructor for class org.apache.camel.impl.ScheduledPollEndpoint
-
- ScheduledPollEndpoint(String) -
Constructor for class org.apache.camel.impl.ScheduledPollEndpoint
-
- ScheduledPollEndpoint() -
Constructor for class org.apache.camel.impl.ScheduledPollEndpoint
-
- schedulePoll() -
Method in class org.apache.camel.util.DefaultTimeoutMap
- lets schedule each time to allow folks to change the time at runtime
- 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(long) -
Static method in class org.apache.camel.util.Time
-
- 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, 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
- SedaComponent - Class in org.apache.camel.component.seda
- An implementation of the SEDA components
for asynchronous SEDA exchanges on a
BlockingQueue
within a CamelContext - 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
-
- SedaEndpoint - Class in org.apache.camel.component.seda
- An implementation of the Queue components for
asynchronous SEDA exchanges on a
BlockingQueue
within a CamelContext - 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, BlockingQueue<Exchange>) -
Constructor for class org.apache.camel.component.seda.SedaEndpoint
-
- SedaEndpoint(String, BlockingQueue<Exchange>, int) -
Constructor for class org.apache.camel.component.seda.SedaEndpoint
-
- SedaProducer - Class in org.apache.camel.component.seda
-
- SedaProducer(SedaEndpoint, BlockingQueue<Exchange>, WaitForTaskToComplete, long) -
Constructor for class org.apache.camel.component.seda.SedaProducer
-
- 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(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, String) -
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 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(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
- Base class for sending to an endpoint with an optional
ExchangePattern
- 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
-
- 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
-
- sendTimerExchange() -
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
- Creates a new
Sequence
instance.
- 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
- An interface used by the
ResequencerEngine.deliver()
and
ResequencerEngine.deliverNext()
methods to send out re-ordered
elements. - serialization() -
Method in class org.apache.camel.builder.DataFormatClause
- Uses the Java Serialization data format
- SerializationDataFormat - Class in org.apache.camel.impl
- The data format
using Java Serialiation.
- SerializationDataFormat() -
Constructor for class org.apache.camel.impl.SerializationDataFormat
-
- SerializationDataFormat - Class in org.apache.camel.model.dataformat
- Represents the Java Serialization
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
- 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.impl.ServiceSupport
-
- set(V) -
Method in class org.apache.camel.util.ValueHolder
-
- 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
-
- setAction(String) -
Method in class org.apache.camel.processor.ThroughputLogger
-
- setAggregateDot(boolean) -
Method in class org.apache.camel.impl.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.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
-
- 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
-
- 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
-
- setAllowNullValues(boolean) -
Method in class org.apache.camel.impl.DefaultHeaderFilterStrategy
-
- 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
-
- 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(Boolean) -
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
-
- 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 it should automatic start when Camel starts.
- setBackOffMultiplier(Double) -
Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setBackOffMultiplier(Double) -
Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setBackOffMultiplier(double) -
Method in class org.apache.camel.processor.RedeliveryPolicy
- Sets the multiplier used to increase the delay between redeliveries if
RedeliveryPolicy.setUseExponentialBackOff(boolean)
is enabled
- 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
-
- setBeanHolder(BeanHolder) -
Method in class org.apache.camel.component.bean.BeanEndpoint
-
- setBeanName(String) -
Method in class org.apache.camel.component.bean.BeanEndpoint
-
- setBeanType(Class<?>) -
Method in class org.apache.camel.model.BeanDefinition
-
- 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(GenericFileBinding<T>) -
Method in class org.apache.camel.component.file.GenericFile
-
- setBody(Expression) -
Static method in class org.apache.camel.builder.ProcessorBuilder
- Creates a processor which sets the body of the IN 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
- Message Translator EIP:
Adds a processor which sets the body on the IN message
- setBody(Expression) -
Method in class org.apache.camel.model.ProcessorDefinition
- Message Translator EIP:
Adds a processor which sets the body on the IN message
- setBody(String) -
Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- 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
-
- SetBodyProcessor - Class in org.apache.camel.processor
- A processor which sets the body on the IN 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 class org.apache.camel.component.file.GenericFileEndpoint
-
- setBuffersize(Integer) -
Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setCache(boolean) -
Method in class org.apache.camel.component.bean.BeanEndpoint
-
- setCache(boolean) -
Method in class org.apache.camel.component.properties.PropertiesComponent
-
- setCache(Map<String, Object>) -
Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
-
- setCache(Map<String, Object>) -
Method in class org.apache.camel.processor.idempotent.MemoryIdempotentRepository
-
- setCacheSize(int) -
Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
- Sets the cache size
- 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
- Injects the
CamelContext
- setCamelContext(CamelContext) -
Method in class org.apache.camel.component.file.AntPathMatcherGenericFileFilter
-
- 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.DefaultShutdownStrategy
-
- setCamelContext(CamelContext) -
Method in class org.apache.camel.impl.InterceptSendToEndpoint
-
- 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.DefaultManagementStrategy
-
- setCamelContext(CamelContext) -
Method in class org.apache.camel.management.PublishEventNotifier
-
- setCamelContext(CamelContext) -
Method in class org.apache.camel.model.RoutesDefinition
-
- 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.
- setCausedByException(String) -
Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setCharset(String) -
Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setCharset(String) -
Method in class org.apache.camel.model.ConvertBodyDefinition
-
- setCharset(String) -
Method in class org.apache.camel.model.dataformat.StringDataFormat
-
- setChildDefinition(ProcessorDefinition<?>) -
Method in interface org.apache.camel.Channel
- 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.DefaultChannel
-
- setClasses(String[]) -
Method in class org.apache.camel.model.dataformat.CastorDataFormat
-
- setClassLoaders(Set<ClassLoader>) -
Method in class org.apache.camel.impl.DefaultPackageScanClassResolver
-
- setClassLoaders(Set<ClassLoader>) -
Method in interface org.apache.camel.spi.PackageScanClassResolver
- Sets the ClassLoader instances that should be used when scanning for
classes.
- 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
-
- 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 class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setCollisionAvoidanceFactor(Double) -
Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setCollisionAvoidanceFactor(double) -
Method in class org.apache.camel.processor.RedeliveryPolicy
- Sets the factor used for collision avoidance if enabled via
RedeliveryPolicy.setUseCollisionAvoidance(boolean)
- setCollisionAvoidancePercent(Double) -
Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setCollisionAvoidancePercent(double) -
Method in class org.apache.camel.processor.RedeliveryPolicy
- Sets the percentage used for collision avoidance if enabled via
RedeliveryPolicy.setUseCollisionAvoidance(boolean)
- setCommitRenamer(GenericFileRenamer<T>) -
Method in class org.apache.camel.component.file.strategy.GenericFileRenameProcessStrategy
-
- setComparator(ExpressionResultComparator) -
Method in class org.apache.camel.model.config.StreamResequencerConfig
-
- setComparator(Comparator<Object>) -
Method in class org.apache.camel.model.SortDefinition
-
- 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.model.dataformat.ZipDataFormat
-
- setConcurrentConsumers(int) -
Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setConfiguration(GenericFileConfiguration) -
Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setConnectorPort(Integer) -
Method in class org.apache.camel.management.DefaultManagementAgent
-
- setConnectorPort(Integer) -
Method in interface org.apache.camel.spi.ManagementAgent
-
- 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
- setConsumerProperties(Map<String, Object>) -
Method in class org.apache.camel.impl.ScheduledPollEndpoint
-
- setContext(CamelContext) -
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 conext 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.WireTapDefinition
-
- setCopy(boolean) -
Method in class org.apache.camel.processor.WireTapProcessor
-
- setCorePoolSize(int) -
Method in class org.apache.camel.management.mbean.ManagedThreadPool
-
- setCorrelationExpression(ExpressionSubElementDefinition) -
Method in class org.apache.camel.model.AggregateDefinition
-
- setCorrelationExpression(ExpressionSubElementDefinition) -
Method in class org.apache.camel.model.loadbalancer.StickyLoadBalancerDefinition
-
- setCounter(int) -
Static method in class org.apache.camel.impl.DefaultCamelContextNameStrategy
- To reset the counter, should only be used for testing purposes.
- setCounter(PerformanceCounter) -
Method in class org.apache.camel.management.DelegatePerformanceCounter
-
- setCounter(ManagedPerformanceCounter) -
Method in class org.apache.camel.management.InstrumentationProcessor
-
- setCreateConnector(Boolean) -
Method in class org.apache.camel.management.DefaultManagementAgent
-
- setCreateConnector(Boolean) -
Method in interface org.apache.camel.spi.ManagementAgent
-
- setCryptoProvider(String) -
Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setDaemon(boolean) -
Method in class org.apache.camel.component.timer.TimerEndpoint
-
- setDataFormat(DataFormat) -
Method in class org.apache.camel.model.DataFormatDefinition
-
- 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
- Sets the data formats that can be referenced in the routes.
- setDataFormats(Map<String, DataFormatDefinition>) -
Method in class org.apache.camel.impl.DefaultCamelContext
-
- setDataFormats(List<DataFormatDefinition>) -
Method in class org.apache.camel.model.dataformat.DataFormatsDefinition
-
- 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
-
- 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
- Sets a custom
Debugger
- 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.
- setDefaultBody(Object) -
Method in class org.apache.camel.component.dataset.SimpleDataSet
-
- setDefaultEndpoint(Endpoint) -
Method in class org.apache.camel.impl.DefaultProducerTemplate
-
- setDefaultEndpointUri(String) -
Method in class org.apache.camel.impl.DefaultProducerTemplate
- Sets the default endpoint 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.impl.ThreadPoolProfileSupport
-
- setDefaultProfile(Boolean) -
Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setDefaultProfile(Boolean) -
Method in interface org.apache.camel.spi.ThreadPoolProfile
- Sets whether this profile is the default profile (there can only be one).
- setDefaultThreadPoolProfile(ThreadPoolProfile) -
Method in class org.apache.camel.impl.DefaultExecutorServiceStrategy
-
- setDefaultThreadPoolProfile(ThreadPoolProfile) -
Method in interface org.apache.camel.spi.ExecutorServiceStrategy
- 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 class org.apache.camel.component.timer.TimerEndpoint
-
- 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,
to slow things down to better helps you to see what goes
Is disabled by default
- 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
-
- 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
-
- setDescription(DescriptionDefinition) -
Method in class org.apache.camel.model.OptionalIdentifiedDefinition
-
- setDestination(String) -
Method in class org.apache.camel.management.mbean.ManagedSendProcessor
-
- setDestination(Endpoint) -
Method in class org.apache.camel.processor.interceptor.Tracer
- See
Tracer.setDestinationUri(String)
- setDestination(Endpoint) -
Method in class org.apache.camel.processor.SendProcessor
-
- 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
-
- setDirectory(String) -
Method in class org.apache.camel.component.file.GenericFileConfiguration
-
- setDirectoryMustExist(boolean) -
Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setDisableRedelivery(Boolean) -
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
-
- setDistributionRatioList(List<Integer>) -
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
-
- setDotOutputDir(String) -
Method in class org.apache.camel.impl.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
-
- setDuration(long) -
Method in class org.apache.camel.impl.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
-
- 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 class org.apache.camel.management.mbean.ManagedTracer
-
- setEnabled(boolean) -
Method in class org.apache.camel.processor.interceptor.Delayer
-
- setEnabled(boolean) -
Method in class org.apache.camel.processor.interceptor.Tracer
-
- setEncoding(String) -
Method in class org.apache.camel.model.dataformat.CastorDataFormat
-
- setEncoding(String) -
Method in class org.apache.camel.model.dataformat.SoapJaxbDataFormat
-
- 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
-
- setEndpointHeaderFilterStrategy(Endpoint) -
Method in class org.apache.camel.impl.HeaderFilterStrategyComponent
-
- setEndpointPath(String) -
Method in class org.apache.camel.component.file.GenericFile
-
- setEndpointUri(String) -
Method in class org.apache.camel.impl.DefaultEndpoint
-
- 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.
- setErrorHandler(Processor) -
Method in interface org.apache.camel.Channel
- Sets the
ErrorHandler
this Channel uses.
- setErrorHandler(Processor) -
Method in class org.apache.camel.processor.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(ErrorHandlerBuilder) -
Method in interface org.apache.camel.CamelContext
- Sets the default error handler builder which is inherited by the routes
- setErrorHandlerBuilder(ErrorHandlerBuilder) -
Method in class org.apache.camel.impl.DefaultCamelContext
-
- setErrorHandlerBuilder(ErrorHandlerBuilder) -
Method in class org.apache.camel.model.ProcessorDefinition
- Sets the error handler to use with processors created by this builder
- setErrorHandlerBuilder(ErrorHandlerBuilder) -
Method in class org.apache.camel.model.RoutesDefinition
-
- setErrorHandlerBuilderIfNull(ErrorHandlerBuilder) -
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(List<OnExceptionDefinition>) -
Method in interface org.apache.camel.builder.ErrorHandlerBuilder
- Adds the error handlers for the given list of exception types
- setErrorHandlers(List<OnExceptionDefinition>) -
Method in class org.apache.camel.builder.ErrorHandlerBuilderSupport
-
- 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
- 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
- Sets the exception associated with this exchange
Camel will wrap Throwable
into Exception
type to
accommodate for the Exchange.getException()
method returning a plain Exception
type.
- setException(Throwable) -
Method in class org.apache.camel.impl.DefaultExchange
-
- setException(Exception) -
Method in class org.apache.camel.model.ThrowExceptionDefinition
-
- setExceptionClasses(List<Class>) -
Method in class org.apache.camel.model.CatchDefinition
-
- setExceptionClasses(List<Class>) -
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
- Sets the strategy to use for resolving the
OnExceptionDefinition
to use
for handling thrown exceptions.
- setExceptionPolicyStrategy(ExceptionPolicyStrategy) -
Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- 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
-
- 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
-
- setExchangePattern(ExchangePattern) -
Method in class org.apache.camel.impl.DefaultEndpoint
-
- setExchangePattern(ExchangePattern) -
Method in class org.apache.camel.model.ProcessorDefinition
- ExchangePattern:
set the ExchangePattern
ExchangePattern
into the exchange
- 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
-
- setExclude(String) -
Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- 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.management.DefaultManagementAgent
-
- 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.
- 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
-
- setExecutorServiceStrategy(ExecutorServiceStrategy) -
Method in interface org.apache.camel.CamelContext
- Sets a custom
ExecutorServiceStrategy
- setExecutorServiceStrategy(ExecutorServiceStrategy) -
Method in class org.apache.camel.impl.DefaultCamelContext
-
- 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.util.TimeoutMapEntry
-
- setExpression(String) -
Method in class org.apache.camel.builder.ExpressionClause
-
- setExpression(String) -
Method in class org.apache.camel.builder.ExpressionClauseSupport
-
- setExpression(Expression) -
Method in class org.apache.camel.component.bean.ParameterInfo
-
- setExpression(Expression) -
Method in class org.apache.camel.component.file.strategy.GenericFileExpressionRenamer
-
- 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(Expression) -
Method in class org.apache.camel.model.SortDefinition
-
- setExpression(ExpressionSubElementDefinition) -
Method in class org.apache.camel.model.SortDefinition
-
- setExpression(Expression) -
Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
-
- setExpressions(List<Expression>) -
Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
-
- setExpressions(List<Expression>) -
Method in interface org.apache.camel.processor.resequencer.ExpressionResultComparator
- Sets the list expressions used 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
-
- setFailOnNullBody(boolean) -
Method in class org.apache.camel.builder.xml.XsltBuilder
-
- setFailureHandled(Exchange) -
Static method in class org.apache.camel.util.ExchangeHelper
-
- 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
-
- 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 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
- setFaultHeader(String, Expression) -
Static method in class org.apache.camel.builder.ProcessorBuilder
- Sets the header on the FAULT message
- setFaultHeader(String, Expression) -
Method in class org.apache.camel.model.ProcessorDefinition
- Adds a processor which sets the header on the FAULT message
- 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
- Sets the file expression based on
SimpleLanguage
- 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
-
- setFixedRate(boolean) -
Method in class org.apache.camel.component.timer.TimerEndpoint
-
- setFlatten(boolean) -
Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setFormatter(TraceFormatter) -
Method in class org.apache.camel.processor.interceptor.Tracer
-
- setFormatter(ExchangeFormatter) -
Method in class org.apache.camel.processor.Logger
-
- setFormatterBreadCrumbLength(int) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterMaxChars(int) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterNodeLength(int) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowBody(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowBodyType(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowBreadCrumb(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowException(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowExchangeId(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowExchangePattern(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowHeaders(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowNode(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowOutBody(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowOutBodyType(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowOutHeaders(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowProperties(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowRouteId(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setFormatterShowShortExchangeId(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- 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
-
- setFunctionResolver(XPathFunctionResolver) -
Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setGenericFile(GenericFile<T>) -
Method in class org.apache.camel.component.file.GenericFileMessage
-
- setGroup(String) -
Method in class org.apache.camel.model.RouteDefinition
-
- setGroupExchanges(Boolean) -
Method in class org.apache.camel.model.AggregateDefinition
-
- setGroupExchanges(boolean) -
Method in class org.apache.camel.processor.BatchProcessor
- Deprecated.
- setGroupSize(int) -
Method in class org.apache.camel.processor.ThroughputLogger
-
- setHandled(boolean) -
Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
- Deprecated.
- 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.builder.DefaultErrorHandlerBuilder
- Deprecated.
- 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 handle fault is enabled or not (default is disabled).
- setHeader(String, Expression) -
Static method in class org.apache.camel.builder.ProcessorBuilder
- Sets the header on the IN 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.language.tokenizer.TokenizeLanguage
-
- setHeaderName(String) -
Method in class org.apache.camel.model.language.TokenizerExpression
-
- 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
-
- 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
- setHeaders(String) -
Method in class org.apache.camel.processor.interceptor.DefaultTraceEventMessage
-
- setHostName(String) -
Method in class org.apache.camel.management.DefaultManagementNamingStrategy
-
- 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.
- setIdempotent(Boolean) -
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.EventNotifierSupport
-
- 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
-
- setIgnoreExchangeCompletedEvent(boolean) -
Method in class org.apache.camel.management.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
-
- setIgnoreExchangeCreatedEvent(boolean) -
Method in class org.apache.camel.management.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
-
- setIgnoreExchangeEvents(boolean) -
Method in class org.apache.camel.management.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
-
- setIgnoreExchangeFailedEvents(boolean) -
Method in class org.apache.camel.management.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
-
- setIgnoreExchangeRedeliveryEvents(boolean) -
Method in class org.apache.camel.management.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
-
- setIgnoreExchangeSentEvents(boolean) -
Method in class org.apache.camel.management.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
-
- 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
-
- setIgnoreJAXBElement(Boolean) -
Method in class org.apache.camel.model.dataformat.JaxbDataFormat
-
- setIgnoreRouteEvents(boolean) -
Method in class org.apache.camel.management.EventNotifierSupport
-
- 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
-
- setIgnoreServiceEvents(boolean) -
Method in class org.apache.camel.management.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
-
- 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
-
- 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
-
- 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
-
- setInitialDelay(long) -
Method in class org.apache.camel.component.dataset.DataSetEndpoint
-
- setInitialDelay(long) -
Method in class org.apache.camel.impl.ScheduledPollConsumer
-
- setInitialDelay(long) -
Method in class org.apache.camel.management.mbean.ManagedScheduledPollConsumer
-
- 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 convertions.
- 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
-
- setInstanceClass(String) -
Method in class org.apache.camel.model.dataformat.ProtobufDataFormat
-
- 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
-
- setIsRouteAdded(boolean) -
Method in class org.apache.camel.impl.DefaultRouteContext
-
- setIsRouteAdded(boolean) -
Method in interface org.apache.camel.spi.RouteContext
- If this flag is true,
ProcessorDefinition.addRoutes(RouteContext, java.util.Collection)
will not add processor to addEventDrivenProcessor to the RouteContext and it
will prevent from adding an EventDrivenRoute.
- 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.
- setKeepAliveTime(Long) -
Method in class org.apache.camel.impl.ThreadPoolProfileSupport
-
- setKeepAliveTime(int) -
Method in class org.apache.camel.management.mbean.ManagedThreadPool
-
- setKeepAliveTime(Long) -
Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setKeepAliveTime(Integer) -
Method in class org.apache.camel.model.ThreadsDefinition
-
- setKeepAliveTime(Long) -
Method in interface org.apache.camel.spi.ThreadPoolProfile
- Sets the keep alive time for inactive threads
- setKeepLastModified(boolean) -
Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setKey(String) -
Method in class org.apache.camel.model.config.PropertyDefinition
-
- setKeyReference(String) -
Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setLang(String) -
Method in class org.apache.camel.model.DescriptionDefinition
-
- setLanguage(String) -
Method in class org.apache.camel.builder.ExpressionClauseSupport
-
- 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
-
- setLastModified(long) -
Method in class org.apache.camel.component.file.GenericFile
-
- 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
-
- setLazyLoadTypeConverters(Boolean) -
Method in interface org.apache.camel.CamelContext
- Sets whether type converters should be loaded lazy
- setLazyLoadTypeConverters(Boolean) -
Method in class org.apache.camel.impl.DefaultCamelContext
-
- setLevel(LoggingLevel) -
Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
-
- setLevel(LoggingLevel) -
Method in class org.apache.camel.processor.Logger
-
- setLifecycleStrategies(List<LifecycleStrategy>) -
Method in class org.apache.camel.impl.DefaultCamelContext
-
- 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.
- 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
-
- 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(Log) -
Method in class org.apache.camel.builder.LoggingErrorHandlerBuilder
-
- setLog(Log) -
Method in class org.apache.camel.processor.Logger
-
- setLogContinued(Boolean) -
Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setLogContinued(Boolean) -
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 class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setLogExhausted(Boolean) -
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
- setLogger(Logger) -
Method in class org.apache.camel.builder.DefaultErrorHandlerBuilder
-
- setLogger(Logger) -
Method in class org.apache.camel.component.log.LogEndpoint
-
- setLogger(Logger) -
Method in class org.apache.camel.impl.ThrottlingInflightRoutePolicy
- Sets the logger to use for logging throttling activity.
- 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.ManagedThrottlingInflightRoutePolicy
-
- setLoggingLevel(LoggingLevel) -
Method in class org.apache.camel.model.LogDefinition
-
- setLogHandled(Boolean) -
Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setLogHandled(Boolean) -
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 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 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.interceptor.Tracer
- Sets the logging name to use.
- setLogName(String) -
Method in class org.apache.camel.processor.Logger
-
- setLogRetryAttempted(Boolean) -
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 class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setLogRetryStackTrace(Boolean) -
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 class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setLogStackTrace(boolean) -
Method in class org.apache.camel.management.mbean.ManagedTracer
-
- setLogStackTrace(Boolean) -
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 determinte
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
- 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
- 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
-
- setMappingFile(String) -
Method in class org.apache.camel.model.dataformat.CastorDataFormat
-
- 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
-
- setMaxChars(int) -
Method in class org.apache.camel.component.log.LogFormatter
-
- setMaxChars(int) -
Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setMaxFileStoreSize(long) -
Method in class org.apache.camel.processor.idempotent.FileIdempotentRepository
- Sets the maximum filesize 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 class org.apache.camel.management.mbean.ManagedThreadPool
-
- setMaximumRedeliveries(Integer) -
Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setMaximumRedeliveries(Integer) -
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 class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setMaximumRedeliveryDelay(Long) -
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 class org.apache.camel.management.mbean.ManagedThrottler
-
- setMaximumRequestsPerPeriod(Long) -
Method in class org.apache.camel.model.ThrottleDefinition
-
- setMaximumRequestsPerPeriod(long) -
Method in class org.apache.camel.processor.Throttler
- Sets the maximum number of requests per time period
- 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.GenericFileConsumer
-
- setMaxMessagesPerPoll(int) -
Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setMaxPoolSize(Integer) -
Method in class org.apache.camel.impl.ThreadPoolProfileSupport
-
- setMaxPoolSize(Integer) -
Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setMaxPoolSize(Integer) -
Method in class org.apache.camel.model.ThreadsDefinition
-
- setMaxPoolSize(Integer) -
Method in interface org.apache.camel.spi.ThreadPoolProfile
- Sets the maximum pool size
- setMaxQueueSize(Integer) -
Method in class org.apache.camel.impl.ThreadPoolProfileSupport
-
- setMaxQueueSize(Integer) -
Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setMaxQueueSize(Integer) -
Method in class org.apache.camel.model.ThreadsDefinition
-
- setMaxQueueSize(Integer) -
Method in interface 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
-
- 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
-
- setMessage(String) -
Method in class org.apache.camel.model.LogDefinition
-
- 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
-
- 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
-
- setMethodObject(Method) -
Method in class org.apache.camel.component.bean.BeanProcessor
-
- 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
- Sets the minimum expected amount of time (in millis) the
MockEndpoint.assertIsSatisfied()
will
wait on a latch until it is satisfied
- 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
- Sets the move expression based on
SimpleLanguage
- setMoveFailed(String) -
Method in class org.apache.camel.component.file.GenericFileEndpoint
- Sets the move failure expression based on
SimpleLanguage
- setMoveFailed(Expression) -
Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setMultiline(boolean) -
Method in class org.apache.camel.component.log.LogFormatter
- 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
-
- setNamespaceContext(DefaultNamespaceContext) -
Method in class org.apache.camel.builder.xml.XPathBuilder
-
- setNamespaceIfNotPresent(DefaultNamespaceContext, String, String) -
Method in class org.apache.camel.builder.xml.XPathBuilder
-
- 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.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
-
- setNewExchangeProcessor(Processor) -
Method in class org.apache.camel.processor.WireTapProcessor
-
- setNewExchangeProcessorRef(String) -
Method in class org.apache.camel.model.WireTapDefinition
-
- 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.DefaultChannel
-
- setNodeFactory(NodeFactory) -
Method in class org.apache.camel.model.ProcessorDefinition
-
- 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.management.JmxNotificationBroadcasterAware
-
- setNotificationBroadcaster(NotificationBroadcasterSupport) -
Method in class org.apache.camel.management.JmxNotificationEventNotifier
-
- setNumberFormat(NumberFormat) -
Method in class org.apache.camel.processor.ThroughputLogger
-
- setNumberOfHashGroups(int) -
Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
-
- 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
-
- 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
-
- 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.
- 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
- Creates a processor which sets the body of the OUT message to the value of the expression
- 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
- Sets the header on the OUT message
- setOutHeader(String) -
Method in class org.apache.camel.model.ProcessorDefinition
- Adds a processor which sets the header on the OUT message
- setOutHeader(String, Expression) -
Method in class org.apache.camel.model.ProcessorDefinition
- Adds a processor which sets the header on the OUT message
- SetOutHeaderDefinition - Class in org.apache.camel.model
- Represents an XML <setOutHeader/> element
- SetOutHeaderDefinition() -
Constructor for class org.apache.camel.model.SetOutHeaderDefinition
-
- SetOutHeaderDefinition(String, ExpressionDefinition) -
Constructor for class org.apache.camel.model.SetOutHeaderDefinition
-
- SetOutHeaderDefinition(String, Expression) -
Constructor for class org.apache.camel.model.SetOutHeaderDefinition
-
- 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.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
-
- 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
-
- setParameterMappingStrategy(ParameterMappingStrategy) -
Method in class org.apache.camel.component.bean.RegistryBean
-
- setParameters(Map<String, Object>) -
Method in class org.apache.camel.builder.xml.XsltBuilder
-
- setParameterTypes(Class<?>[]) -
Method in class org.apache.camel.component.bean.MethodBean
-
- setParent(ProcessorDefinition) -
Method in class org.apache.camel.model.ProcessorDefinition
-
- 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
-
- setPattern(ExchangePattern) -
Method in interface org.apache.camel.Exchange
- Allows the
ExchangePattern
(MEP) of this exchange to be customized.
- 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
- Sets the optional
ExchangePattern
used to invoke this endpoint
- setPeriod(long) -
Method in class org.apache.camel.component.timer.TimerEndpoint
-
- setPollStrategy(PollingConsumerPollStrategy) -
Method in class org.apache.camel.impl.ScheduledPollConsumer
-
- setPoolSize(Integer) -
Method in class org.apache.camel.impl.ThreadPoolProfileSupport
-
- setPoolSize(Integer) -
Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setPoolSize(Integer) -
Method in class org.apache.camel.model.ThreadsDefinition
-
- setPoolSize(Integer) -
Method in interface 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
-
- 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
- Sets the pre move expression based on
SimpleLanguage
- 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
- Sets a custom
ProcessorFactory
- setProcessorFactory(ProcessorFactory) -
Method in class org.apache.camel.impl.DefaultCamelContext
-
- setProcessorPosition(int) -
Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
-
- 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
- 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(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) -
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, Expression) -
Static method in class org.apache.camel.builder.ProcessorBuilder
- Sets the property on the exchange
- 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(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(TypeConverter, Object, String, Object) -
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
-
- setQueue(BlockingQueue<Exchange>) -
Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setReadLock(String) -
Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setReadLockTimeout(long) -
Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- 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
- Deprecated.
- setRedeliveryDelay(Long) -
Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setRedeliveryDelay(Long) -
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
-
- setRef(String) -
Method in class org.apache.camel.model.BeanDefinition
-
- 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.LoadBalanceDefinition
-
- 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.RedeliveryPolicyDefinition
-
- 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.TransactedDefinition
-
- setRef(String) -
Method in class org.apache.camel.model.UnmarshalDefinition
-
- 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
-
- 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
-
- setRejectedPolicy(ThreadPoolRejectedPolicy) -
Method in class org.apache.camel.impl.ThreadPoolProfileSupport
-
- setRejectedPolicy(ThreadPoolRejectedPolicy) -
Method in class org.apache.camel.model.ThreadPoolProfileDefinition
-
- setRejectedPolicy(ThreadPoolRejectedPolicy) -
Method in class org.apache.camel.model.ThreadsDefinition
-
- setRejectedPolicy(ThreadPoolRejectedPolicy) -
Method in interface org.apache.camel.spi.ThreadPoolProfile
- Sets the handler for tasks which cannot be executed by the thread pool.
- setRelativeFilePath(String) -
Method in class org.apache.camel.component.file.GenericFile
-
- setRemovingRoutes(boolean) -
Method in class org.apache.camel.impl.RouteService
- Deprecated.
- 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.dataset.DataSetEndpoint
- Sets a custom progress reporter
- 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
- setResourceRef(String) -
Method in class org.apache.camel.model.EnrichDefinition
-
- setResourceRef(String) -
Method in class org.apache.camel.model.PollEnrichDefinition
-
- 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.xml.XPathBuilder
-
- setResultType(QName) -
Method in class org.apache.camel.language.xpath.XPathLanguage
-
- setResultType(Class<?>) -
Method in class org.apache.camel.model.language.XPathExpression
-
- setResultType(Class<?>) -
Method in class org.apache.camel.model.language.XQueryExpression
-
- setResultWaitTime(long) -
Method in class org.apache.camel.component.mock.MockEndpoint
- Sets the maximum amount of time (in millis) the
MockEndpoint.assertIsSatisfied()
will
wait on a latch until it is satisfied
- 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
-
- 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 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.
- 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
-
- 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.management.mbean.ManagedProcessor
-
- setRoute(Route) -
Method in class org.apache.camel.management.mbean.ManagedService
-
- setRoute(Route) -
Method in class org.apache.camel.processor.RoutePolicyProcessor
-
- setRouteBuilders(List<RouteBuilder>) -
Method in class org.apache.camel.impl.MainSupport
-
- setRouteCollection(RoutesDefinition) -
Method in class org.apache.camel.builder.RouteBuilder
-
- setRouteContext(RouteContext) -
Method in class org.apache.camel.processor.interceptor.TraceInterceptor
-
- setRoutePolicy(RoutePolicy) -
Method in class org.apache.camel.impl.DefaultRouteContext
-
- setRoutePolicy(RoutePolicy) -
Method in class org.apache.camel.model.RouteDefinition
-
- setRoutePolicy(RoutePolicy) -
Method in interface org.apache.camel.spi.RouteContext
- Sets a custom route policy
- 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
-
- setRoutesOutputFile(String) -
Method in class org.apache.camel.impl.MainSupport
-
- 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
-
- setSchema(Schema) -
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(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
- setSecureTag(String) -
Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setSecureTagContents(boolean) -
Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- 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.
- setServiceUrlPath(String) -
Method in class org.apache.camel.management.DefaultManagementAgent
-
- setServiceUrlPath(String) -
Method in interface org.apache.camel.spi.ManagementAgent
-
- 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
-
- setShouldInlineInitVector(Boolean) -
Method in class org.apache.camel.model.dataformat.CryptoDataFormat
-
- setShowAll(boolean) -
Method in class org.apache.camel.component.log.LogFormatter
-
- setShowBody(boolean) -
Method in class org.apache.camel.component.log.LogFormatter
-
- setShowBody(boolean) -
Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowBodyType(boolean) -
Method in class org.apache.camel.component.log.LogFormatter
-
- 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.component.log.LogFormatter
-
- setShowException(boolean) -
Method in class org.apache.camel.component.log.LogFormatter
-
- setShowException(boolean) -
Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowExchangeId(boolean) -
Method in class org.apache.camel.component.log.LogFormatter
-
- setShowExchangeId(boolean) -
Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowExchangePattern(boolean) -
Method in class org.apache.camel.component.log.LogFormatter
-
- setShowExchangePattern(boolean) -
Method in class org.apache.camel.processor.interceptor.DefaultTraceFormatter
-
- setShowFuture(boolean) -
Method in class org.apache.camel.component.log.LogFormatter
- 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.component.log.LogFormatter
-
- 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.component.log.LogFormatter
-
- 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.component.log.LogFormatter
-
- 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.component.log.LogFormatter
-
- 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 option to use when shutting down 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 option to use when shutting down a route and how to act when it has running tasks.
- setShutdownStrategy(ShutdownStrategy) -
Method in interface org.apache.camel.CamelContext
- Sets a custom shutdown strategy
- setShutdownStrategy(ShutdownStrategy) -
Method in class org.apache.camel.impl.DefaultCamelContext
-
- 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
-
- setSkipSendToOriginalEndpoint(Boolean) -
Method in class org.apache.camel.model.InterceptSendToEndpointDefinition
-
- setSleepForEmptyTest(long) -
Method in class org.apache.camel.component.mock.MockEndpoint
- Allows a sleep to be specified to wait to check that this endpoint really
is empty when
MockEndpoint.expectedMessageCount(int)
is called with zero
- 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.
- setStartingDirectoryMustExist(boolean) -
Method in class org.apache.camel.component.file.GenericFileEndpoint
-
- setStartupOrder(Integer) -
Method in class org.apache.camel.model.RouteDefinition
-
- 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 interface org.apache.camel.management.PerformanceCounter
- 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
- Sets the statistics level
Default is ManagementStatisticsLevel.All
- 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
-
- setStrategyRef(String) -
Method in class org.apache.camel.model.AggregateDefinition
-
- 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).
- 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
-
- 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.
- setText(String) -
Method in class org.apache.camel.model.DescriptionDefinition
-
- setThreadName(String) -
Method in class org.apache.camel.model.ThreadsDefinition
-
- setThreadNamePattern(String) -
Method in class org.apache.camel.impl.DefaultExecutorServiceStrategy
-
- setThreadNamePattern(String) -
Method in interface org.apache.camel.spi.ExecutorServiceStrategy
- Sets the thread name pattern used for creating the full thread name.
- setTime(Date) -
Method in class org.apache.camel.component.timer.TimerEndpoint
-
- 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
- Sets an optional timeout period.
- 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.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.util.TimeoutMapEntry
-
- setTimeoutHandler(TimeoutHandler) -
Method in class org.apache.camel.processor.resequencer.Timeout
- Sets a timeout handler for receiving timeout notifications.
- 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 class org.apache.camel.impl.DefaultShutdownStrategy
-
- setTimeUnit(TimeUnit) -
Method in class org.apache.camel.impl.MainSupport
- Sets the time unit duration
- setTimeUnit(TimeUnit) -
Method in class org.apache.camel.impl.ScheduledPollConsumer
-
- setTimeUnit(TimeUnit) -
Method in class org.apache.camel.impl.ThreadPoolProfileSupport
-
- 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 interface 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
-
- setTrace(String) -
Method in class org.apache.camel.model.RouteDefinition
-
- 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(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
-
- setTraceHandler(TraceEventHandler) -
Method in class org.apache.camel.processor.interceptor.Tracer
- Set the object to be used to perform tracing.
- 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 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 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
- 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
- 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.
- 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
-
- 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
-
- setUnits(String) -
Method in class org.apache.camel.model.SamplingDefinition
-
- setUnits(TimeUnit) -
Method in class org.apache.camel.model.SamplingDefinition
-
- setUnmarshalType(Class<?>) -
Method in class org.apache.camel.model.dataformat.JsonDataFormat
-
- 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
-
- setUriDelimiter(String) -
Method in class org.apache.camel.model.DynamicRouterDefinition
-
- setUriDelimiter(String) -
Method in class org.apache.camel.model.RoutingSlipDefinition
-
- setUriResolver(URIResolver) -
Method in class org.apache.camel.builder.xml.XsltBuilder
-
- setUseCollisionAvoidance(Boolean) -
Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setUseCollisionAvoidance(Boolean) -
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
- Sets whether DOMSource and DOMResult should be used, or
SaxSource and SaxResult.
- setUseExponentialBackOff(Boolean) -
Method in class org.apache.camel.management.mbean.ManagedErrorHandler
-
- setUseExponentialBackOff(Boolean) -
Method in class org.apache.camel.model.RedeliveryPolicyDefinition
-
- setUseExponentialBackOff(boolean) -
Method in class org.apache.camel.processor.RedeliveryPolicy
- Enables/disables exponential backoff using the
RedeliveryPolicy.getBackOffMultiplier()
to increase the time between retries
- 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.
- 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
-
- setUseRecovery(boolean) -
Method in interface org.apache.camel.spi.RecoverableAggregationRepository
- Sets whether or not recovery is enabled
- setUseSharedSchema(boolean) -
Method in class org.apache.camel.processor.validation.ValidatingProcessor
-
- setUuidGenerator(UuidGenerator) -
Method in interface org.apache.camel.CamelContext
- Sets a custom
UuidGenerator
(should only be set once)
- 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.util.TimeoutMapEntry
-
- setWaitForTaskToComplete(WaitForTaskToComplete) -
Method in class org.apache.camel.component.seda.SedaEndpoint
-
- setWhenClauses(List<WhenDefinition>) -
Method in class org.apache.camel.model.ChoiceDefinition
-
- setXmlCipherAlgorithm(String) -
Method in class org.apache.camel.model.dataformat.XMLSecurityDataFormat
-
- setXPathFactory(XPathFactory) -
Method in class org.apache.camel.builder.xml.XPathBuilder
-
- shape -
Variable in class org.apache.camel.view.NodeData
-
- SharedProducerServicePool - Class in org.apache.camel.impl
- A shared
DefaultProducerServicePool
which is used by
CamelContext
by default. - SharedProducerServicePool() -
Constructor for class org.apache.camel.impl.SharedProducerServicePool
-
- SharedProducerServicePool(int) -
Constructor for class org.apache.camel.impl.SharedProducerServicePool
-
- 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.
- 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.
- shouldStartRoutes() -
Method in class org.apache.camel.impl.DefaultCamelContext
- Should we start newly added routes?
- 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.impl.MainSupport
- Displays the command line options
- showOptionsHeader() -
Method in class org.apache.camel.impl.MainSupport
- Displays the header message for the command line options
- shutdown(ExecutorService) -
Method in class org.apache.camel.impl.DefaultExecutorServiceStrategy
-
- 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() -
Method in class org.apache.camel.impl.ServiceSupport
-
- shutdown() -
Method in class org.apache.camel.management.mbean.ManagedRoute
- Deprecated.
- shutdown(long) -
Method in class org.apache.camel.management.mbean.ManagedRoute
- Deprecated.
- 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.ExecutorServiceStrategy
- 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
- ShutdownableService - Interface in org.apache.camel
- A
Service
which is also capable of shutting 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. - shutdownNow(ExecutorService) -
Method in class org.apache.camel.impl.DefaultExecutorServiceStrategy
-
- shutdownNow(List<Consumer>) -
Method in class org.apache.camel.impl.DefaultShutdownStrategy
- Shutdown all the consumers immediately.
- shutdownNow(Consumer) -
Method in class org.apache.camel.impl.DefaultShutdownStrategy
- Shutdown the consumer immediately.
- shutdownNow(ExecutorService) -
Method in interface org.apache.camel.spi.ExecutorServiceStrategy
- Shutdown now the given executor service.
- shutdownRoute(String) -
Method in interface org.apache.camel.CamelContext
- Deprecated. use
CamelContext.stopRoute(String)
and CamelContext.removeRoute(String)
- shutdownRoute(String, long, TimeUnit) -
Method in interface org.apache.camel.CamelContext
- Deprecated. use
CamelContext.stopRoute(String, long, java.util.concurrent.TimeUnit)
and CamelContext.removeRoute(String)
- 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
- Represent the kinds of options for shutting down.
- 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(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.
- simple(String) -
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) -
Method in class org.apache.camel.builder.ExpressionClause
- Evaluates a Simple
expression
- simple(String) -
Method in class org.apache.camel.builder.ExpressionClauseSupport
- Evaluates a Simple
expression
- simple(String) -
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
-
- 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
- For expressions and predicates using the
simple language
- SimpleExpression() -
Constructor for class org.apache.camel.model.language.SimpleExpression
-
- SimpleExpression(String) -
Constructor for class org.apache.camel.model.language.SimpleExpression
-
- 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
-
- SimpleLanguageOperator - Enum in org.apache.camel.language.simple
- Operators supported by simple language
== : equals
> : greater than
>= : greater than or equals
< : less than
<= : less than or equals
!= : not
contains : tested for if it contains the value
not contains : tested for if it does not contain the value
regex : matching a regular expression
not regex : not matching a regular expression
in : tested for in a list of values separated by comma
not in : tested for not in a list of values separated by comma
is : tested for if type is an instanceof the given type
not is: tested for not if type is an instanceof the given type
range : tested for if it is within the provided range
not range : tested for not if it is within the provided range
and : and operator to combine two groups of expressions
or : or operator to combine two groups of expressions
The and and or operator is special as they are used as optional operator to combine two expressions.
- SimpleLanguageSupport - Class in org.apache.camel.language.simple
- Abstract base class for Simple languages.
- SimpleLanguageSupport() -
Constructor for class org.apache.camel.language.simple.SimpleLanguageSupport
-
- SimpleLoadBalancerSupport - Class in org.apache.camel.processor.loadbalancer
- A default base class for a
LoadBalancer
implementation. - SimpleLoadBalancerSupport() -
Constructor for class org.apache.camel.processor.loadbalancer.SimpleLoadBalancerSupport
-
- SimpleRegistry - Class in org.apache.camel.impl
- A
Map
-based registry. - SimpleRegistry() -
Constructor for class org.apache.camel.impl.SimpleRegistry
-
- 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
-
- size() -
Method in class org.apache.camel.impl.DefaultInflightRepository
-
- size(Endpoint) -
Method in class org.apache.camel.impl.DefaultInflightRepository
-
- 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
- Current size of inflight exchanges which are from the given endpoint.
- size() -
Method in interface org.apache.camel.spi.ServicePool
- Returns the current size of the pool
- 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.DefaultTimeoutMap
-
- size() -
Method in interface org.apache.camel.util.TimeoutMap
- Returns the size of the map
- SKIP_GZIP_ENCODING -
Static variable in interface org.apache.camel.Exchange
-
- 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 JAXB data format
- soapjaxb(String) -
Method in class org.apache.camel.builder.DataFormatClause
- Uses the Soap JAXB data format
- soapjaxb(String, String) -
Method in class org.apache.camel.builder.DataFormatClause
- Uses the Soap JAXB data format
- soapjaxb(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, Comparator) -
Method in class org.apache.camel.model.ProcessorDefinition
- Sorts the expression 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.
- sortBody(Comparator) -
Method in class org.apache.camel.model.ProcessorDefinition
- Sorts the IN message body using the given comparator.
- sortBody() -
Method in class org.apache.camel.model.ProcessorDefinition
- Sorts the IN message body using a default sorting based on toString representation.
- 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 - 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<Object>) -
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 - Class in org.apache.camel.processor
- A processor that sorts the expression using a comparator
- SortProcessor(Expression, Comparator<Object>) -
Constructor for class org.apache.camel.processor.SortProcessor
-
- SourceCache - Class in org.apache.camel.converter.stream
StreamCache
implementation for StringSource
s- SourceCache() -
Constructor for class org.apache.camel.converter.stream.SourceCache
-
- SourceCache(String) -
Constructor for class org.apache.camel.converter.stream.SourceCache
-
- 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
-
- 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, long) -
Constructor for class org.apache.camel.processor.Splitter
-
- sql(String) -
Method in class org.apache.camel.builder.ExpressionClause
- Evaluates an SQL
expression
- sql(String) -
Method in class org.apache.camel.builder.ExpressionClauseSupport
- Evaluates an SQL
expression
- 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
-
- start() -
Method in class org.apache.camel.builder.xml.XPathBuilder
-
- start() -
Method in class org.apache.camel.component.browse.BrowseEndpoint
-
- start() -
Method in class org.apache.camel.component.dataset.DataSetEndpoint
-
- start() -
Method in class org.apache.camel.component.timer.TimerEndpoint
-
- start() -
Method in class org.apache.camel.impl.converter.PropertyEditorTypeConverter
-
- 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.DefaultEndpoint
-
- start() -
Method in class org.apache.camel.impl.DefaultUnitOfWork
-
- 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.ServiceSupport
-
- start(boolean) -
Method in class org.apache.camel.impl.ServiceSupport
-
- start() -
Method in class org.apache.camel.impl.SynchronousDelegateProducer
-
- start() -
Method in class org.apache.camel.management.DefaultManagementLifecycleStrategy
-
- start() -
Method in class org.apache.camel.management.DefaultManagementStrategy
-
- 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.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.util.DefaultTimeoutMap
-
- start() -
Method in class org.apache.camel.util.LRUCache
-
- START_ANDOR_PATTERN -
Static variable in class org.apache.camel.language.simple.SimpleLanguageSupport
-
- startChildService(Route, List<Service>) -
Method in class org.apache.camel.impl.RouteService
-
- startConsumer(Consumer) -
Method in class org.apache.camel.impl.RoutePolicySupport
-
- 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
- Starts the given route if it has been previously stopped
- 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
-
- 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
- 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 all of the given services
- startServices(Object...) -
Static method in class org.apache.camel.util.ServiceHelper
- Starts all of the given services
- startServices(Collection<?>) -
Static method in class org.apache.camel.util.ServiceHelper
- Starts all of the given services
- 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
-
- StartupListener - Interface in org.apache.camel
- Allows objects to be notified when
CamelContext
have just been started. - 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.
- 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
-
- 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
-
- StaxConverter - Class in org.apache.camel.converter.jaxp
- A converter of StAX objects
- StaxConverter() -
Constructor for class org.apache.camel.converter.jaxp.StaxConverter
-
- 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 class org.apache.camel.builder.xml.XPathBuilder
-
- stop() -
Method in class org.apache.camel.component.browse.BrowseEndpoint
-
- stop() -
Method in class org.apache.camel.component.dataset.DataSetEndpoint
-
- stop() -
Method in class org.apache.camel.component.timer.TimerEndpoint
-
- stop() -
Method in class org.apache.camel.impl.converter.PropertyEditorTypeConverter
-
- stop() -
Method in class org.apache.camel.impl.DefaultDebugger
-
- stop() -
Method in class org.apache.camel.impl.DefaultEndpoint
-
- stop() -
Method in class org.apache.camel.impl.DefaultUnitOfWork
-
- stop() -
Method in class org.apache.camel.impl.InterceptSendToEndpoint
-
- stop() -
Method in class org.apache.camel.impl.LimitedPollingConsumerPollStrategy
-
- stop(BundleContext) -
Method in class org.apache.camel.impl.osgi.Activator
-
- stop() -
Method in class org.apache.camel.impl.ServiceSupport
-
- stop() -
Method in class org.apache.camel.impl.SynchronousDelegateProducer
-
- stop() -
Method in class org.apache.camel.management.DefaultManagementLifecycleStrategy
-
- stop() -
Method in class org.apache.camel.management.DefaultManagementStrategy
-
- 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() -
Method in class org.apache.camel.management.mbean.ManagedService
-
- 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.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.util.DefaultTimeoutMap
-
- stop() -
Method in class org.apache.camel.util.LRUCache
-
- 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 all of the given services, throwing the first exception caught
- stopAndShutdownServices(Object...) -
Static method in class org.apache.camel.util.ServiceHelper
- Stops and shutdowns all of the given services, throwing the first exception caught
- stopAndShutdownServices(Collection<?>) -
Static method in class org.apache.camel.util.ServiceHelper
- Stops and shutdowns all of the given services, throwing the first exception caught
- 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 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 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 occurred during processing of an
Exchange
and the caused exception will be thrown.
- 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
- Stops the given route.
- stopRoute(String) -
Method in interface org.apache.camel.CamelContext
- Stops the given route using
ShutdownStrategy
.
- stopRoute(String, long, TimeUnit) -
Method in interface org.apache.camel.CamelContext
- Stops the given route using
ShutdownStrategy
with a specified timeout.
- stopRoute(RouteDefinition) -
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
-
- stopRouteService(RouteService) -
Method in class org.apache.camel.impl.DefaultCamelContext
-
- stopService(Object) -
Static method in class org.apache.camel.util.ServiceHelper
- Stops all of the given services, throwing the first exception caught
- stopServices(Object...) -
Static method in class org.apache.camel.util.ServiceHelper
- Stops all of the given services, throwing the first exception caught
- stopServices(Collection<?>) -
Static method in class org.apache.camel.util.ServiceHelper
- Stops all of the given services, throwing the first exception caught
- 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(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)
- 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
- Configures the stream-based resequencing algorithm using the given
StreamResequencerConfig
.
- 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) - StreamCacheConverter() -
Constructor for class org.apache.camel.converter.stream.StreamCacheConverter
-
- streamCaching() -
Method in class org.apache.camel.model.RouteDefinition
- Enable stream caching for this route.
- StreamCaching - Class in org.apache.camel.processor.interceptor
InterceptStrategy
implementation to configure stream caching on a RouteContext- StreamCaching() -
Constructor for class org.apache.camel.processor.interceptor.StreamCaching
-
- StreamCachingInterceptor - Class in org.apache.camel.processor.interceptor
- An interceptor that converts streams messages into a re-readable format
by wrapping the stream into a
StreamCache
. - StreamCachingInterceptor() -
Constructor for class org.apache.camel.processor.interceptor.StreamCachingInterceptor
-
- StreamCachingInterceptor(Processor) -
Constructor for class org.apache.camel.processor.interceptor.StreamCachingInterceptor
-
- 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
- Creates a new
StreamResequencer
instance.
- StreamResequencerConfig - Class in org.apache.camel.model.config
- Defines the configuration parameters for the
StreamResequencer
. - StreamResequencerConfig() -
Constructor for class org.apache.camel.model.config.StreamResequencerConfig
- Creates a new
StreamResequencerConfig
instance using default
values for capacity
(1000) and timeout
(1000L).
- StreamResequencerConfig(int, long) -
Constructor for class org.apache.camel.model.config.StreamResequencerConfig
- Creates a new
BatchResequencerConfig
instance using the given
values for capacity
and timeout
.
- StreamResequencerConfig(int, long, ExpressionResultComparator) -
Constructor for class org.apache.camel.model.config.StreamResequencerConfig
- Creates a new
BatchResequencerConfig
instance using the given
values for capacity
and timeout
.
- 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
- Factory for
StreamResultHandler
- StreamResultHandlerFactory() -
Constructor for class org.apache.camel.builder.xml.StreamResultHandlerFactory
-
- StreamSourceCache - Class in org.apache.camel.converter.stream
StreamCache
implementation for Cache the StreamSource StreamSource
s- StreamSourceCache(StreamSource, Exchange) -
Constructor for class org.apache.camel.converter.stream.StreamSourceCache
-
- StreamSourceConverter - Class in org.apache.camel.converter.jaxp
- A converter from
StreamSource
objects - 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(String) -
Constructor for class org.apache.camel.impl.StringDataFormat
-
- StringDataFormat - Class in org.apache.camel.model.dataformat
- Represents the String (text based)
DataFormat
- StringDataFormat() -
Constructor for class org.apache.camel.model.dataformat.StringDataFormat
-
- StringHelper - Class in org.apache.camel.util
- Helper methods for working with Strings.
- stringResult() -
Method in class org.apache.camel.builder.xml.XPathBuilder
- Sets the expression result type to boolean
- 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
- Factory for
StringResultHandler
- StringResultHandlerFactory() -
Constructor for class org.apache.camel.builder.xml.StringResultHandlerFactory
-
- StringSource - Class in org.apache.camel.converter.jaxp
- 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.converter.jaxp.StringSource
-
- StringSource(String) -
Constructor for class org.apache.camel.converter.jaxp.StringSource
-
- StringSource(String, String) -
Constructor for class org.apache.camel.converter.jaxp.StringSource
-
- StringSource(String, String, String) -
Constructor for class org.apache.camel.converter.jaxp.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
-
- stripTrailingSeparator(String) -
Static method in class org.apache.camel.util.FileUtil
- Strip any trailing separators
- submit(Callable) -
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) -
Method in class org.apache.camel.impl.CamelPostProcessorHelper
-
- 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
-
- supportsSuspension() -
Method in class org.apache.camel.impl.EventDrivenConsumerRoute
-
- supportsSuspension() -
Method in interface org.apache.camel.Route
- Whether or not the route supports suspension
- 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 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.impl.ServiceSupport
-
- 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 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.
- suspendNow(Consumer) -
Method in class org.apache.camel.impl.DefaultShutdownStrategy
- Suspends/stops the consumer immediately.
- suspendRoute(String) -
Method in interface org.apache.camel.CamelContext
- Suspends the given route using
ShutdownStrategy
.
- suspendRoute(String, long, TimeUnit) -
Method in interface org.apache.camel.CamelContext
- Suspends the given route using
ShutdownStrategy
with a specified timeout.
- suspendRoute(String) -
Method in class org.apache.camel.impl.DefaultCamelContext
-
- suspendRoute(String, long, TimeUnit) -
Method in class org.apache.camel.impl.DefaultCamelContext
-
- 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
-
- Synchronization - Interface in org.apache.camel.spi
- Provides a hook for custom
Processor
or Component
instances to respond to completed or failed processing of an Exchange
rather like Spring's
TransactionSynchronization - SynchronizationAdapter - Class in org.apache.camel.impl
- Simple
Synchronization
adapter with empty methods for easier overriding
of single methods. - SynchronizationAdapter() -
Constructor for class org.apache.camel.impl.SynchronizationAdapter
-
- SynchronizationVetoable - Interface in org.apache.camel.spi
- A vetoable
Synchronization
. - 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
-
- 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