- NAME_PARSER - Static variable in class org.apache.camel.support.jndi.JndiContext
-
- NamespacePrefix - Annotation Type in org.apache.camel.support.language
-
Creates a namespace prefix for an XPath
- Namespaces - Class in org.apache.camel.support.builder
-
A helper class for working with namespaces.
- Namespaces() - Constructor for class org.apache.camel.support.builder.Namespaces
-
Creates an empty namespaces object
- Namespaces(String, String) - Constructor for class org.apache.camel.support.builder.Namespaces
-
Creates a namespace context with a single prefix and URI
- newCachedThreadPool(ThreadFactory) - Method in class org.apache.camel.support.DefaultThreadPoolFactory
-
- newCondition() - Method in class org.apache.camel.support.NoLock
-
- newContext() - Method in class org.apache.camel.support.jndi.JndiContext
-
- newInputStreamCache() - Method in class org.apache.camel.converter.stream.CachedByteArrayOutputStream
-
- newInstance(CamelContext, Class<T>) - Static method in class org.apache.camel.support.CamelContextHelper
-
Creates a new instance of the given type using the Injector
on the given
CamelContext
- newInstance() - Method in class org.apache.camel.support.DefaultMessage
-
- newInstance(Exchange, Class<T>) - Static method in class org.apache.camel.support.ExchangeHelper
-
Creates a new instance of the given type from the injector
- newInstance() - Method in class org.apache.camel.support.MessageSupport
-
Returns a new instance
- newInstance(Class<T>) - Static method in class org.apache.camel.support.ObjectHelper
-
A helper method to create a new instance of a type using the default constructor arguments.
- newInstance(Class<?>, Class<T>) - Static method in class org.apache.camel.support.ObjectHelper
-
A helper method to create a new instance of a type using the default constructor arguments.
- newInstanceConstructorParameters(CamelContext, Class<?>, String) - Static method in class org.apache.camel.support.PropertyBindingSupport
-
Creates a new bean instance using the constructor that takes the given set of parameters.
- newInstanceFactoryParameters(CamelContext, Class<?>, String, String) - Static method in class org.apache.camel.support.PropertyBindingSupport
-
Creates a new bean instance using a public static factory method from the given class
- newLRUCache(int) - Static method in class org.apache.camel.support.LRUCacheFactory
-
Constructs an empty LRUCache instance with the specified maximumCacheSize, and will stop on eviction.
- newLRUCache(int, Consumer<V>) - Static method in class org.apache.camel.support.LRUCacheFactory
-
Constructs an empty LRUCache instance with the specified maximumCacheSize, and will stop on eviction.
- newLRUCache(int, int) - Static method in class org.apache.camel.support.LRUCacheFactory
-
Constructs an empty LRUCache instance with the specified initial capacity, maximumCacheSize, and will
stop on eviction.
- newLRUCache(int, int, boolean) - Static method in class org.apache.camel.support.LRUCacheFactory
-
Constructs an empty LRUCache instance with the specified initial capacity, maximumCacheSize,load factor
and ordering mode.
- newLRUSoftCache(int) - Static method in class org.apache.camel.support.LRUCacheFactory
-
Constructs an empty LRUSoftCache instance with the specified maximumCacheSize, and will stop on
eviction.
- newLRUSoftCache(int, int) - Static method in class org.apache.camel.support.LRUCacheFactory
-
Constructs an empty LRUSoftCache instance with the specified maximumCacheSize, and will stop on
eviction.
- newLRUSoftCache(int, int, boolean) - Static method in class org.apache.camel.support.LRUCacheFactory
-
Constructs an empty LRUSoftCache instance with the specified maximumCacheSize, and will stop on
eviction.
- newLRUWeakCache(int) - Static method in class org.apache.camel.support.LRUCacheFactory
-
Constructs an empty LRUWeakCache instance with the specified maximumCacheSize, and will stop on
eviction.
- newLRUWeakCache(int, int) - Static method in class org.apache.camel.support.LRUCacheFactory
-
Constructs an empty LRUWeakCache instance with the specified maximumCacheSize, and will stop on
eviction.
- newLRUWeakCache(int, int, boolean) - Static method in class org.apache.camel.support.LRUCacheFactory
-
Constructs an empty LRUWeakCache instance with the specified maximumCacheSize, and will stop on
eviction.
- newNormalizedUri(String, boolean) - Static method in class org.apache.camel.support.NormalizedUri
-
- newSaga() - Method in interface org.apache.camel.saga.CamelSagaService
-
- newSaga() - Method in class org.apache.camel.saga.InMemorySagaService
-
- newScheduledThreadPool(ThreadPoolProfile, ThreadFactory) - Method in class org.apache.camel.support.DefaultThreadPoolFactory
-
- newStreamCache() - Method in class org.apache.camel.converter.stream.CachedOutputStream
-
Creates a new
StreamCache
from the data cached in this
OutputStream
.
- newThreadPool(ThreadPoolProfile, ThreadFactory) - Method in class org.apache.camel.support.DefaultThreadPoolFactory
-
- newThreadPool(int, int, long, TimeUnit, int, boolean, RejectedExecutionHandler, ThreadFactory) - Method in class org.apache.camel.support.DefaultThreadPoolFactory
-
- next() - Method in class org.apache.camel.support.GroupIterator
-
- next() - Method in class org.apache.camel.support.GroupTokenIterator
-
- next() - Method in class org.apache.camel.support.processor.DelegateAsyncProcessor
-
- next() - Method in class org.apache.camel.support.processor.DelegateProcessor
-
- next() - Method in class org.apache.camel.support.processor.DelegateSyncProcessor
-
- next() - Method in interface org.apache.camel.support.task.budget.Budget
-
Move the task to the next iteration
- next() - Method in class org.apache.camel.support.task.budget.IterationBoundedBudget
-
- next() - Method in class org.apache.camel.support.task.budget.IterationTimeBoundedBudget
-
- next() - Method in class org.apache.camel.support.task.budget.TimeBoundedBudget
-
- nodeProcessingDone() - Method in class org.apache.camel.support.DefaultMessageHistory
-
- NoLock - Class in org.apache.camel.support
-
Empty lock implementation
- NoLock() - Constructor for class org.apache.camel.support.NoLock
-
- NormalizedUri - Class in org.apache.camel.support
-
Implementation of NormalizedEndpointUri
.
- normalizeEndpointUri(String) - Static method in class org.apache.camel.support.EndpointHelper
-
Normalize uri so we can do endpoint hits with minor mistakes and parameters is not in the same order.
- NoSuchOptionException - Exception in org.apache.camel.component.extension.verifier
-
- NoSuchOptionException(String) - Constructor for exception org.apache.camel.component.extension.verifier.NoSuchOptionException
-
- not(Predicate) - Static method in class org.apache.camel.support.builder.PredicateBuilder
-
A helper method to return the logical not of the given predicate
- not(Predicate) - Method in class org.apache.camel.support.builder.ValueBuilder
-
- not() - Method in class org.apache.camel.support.builder.ValueBuilder
-
Negates the built expression.
- NotificationSenderAdapter - Class in org.apache.camel.support.management
-
Can be used to broadcast JMX notifications.
- NotificationSenderAdapter(ModelMBeanNotificationBroadcaster) - Constructor for class org.apache.camel.support.management.NotificationSenderAdapter
-
- notifyCamelContextInitialized(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextInitializing(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextResumed(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextResumeFailed(CamelContext, Throwable) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextResuming(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextRoutesStarted(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextRoutesStarting(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextRoutesStopped(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextRoutesStopping(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextStarted(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextStarting(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextStartupFailed(CamelContext, Throwable) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextStopFailed(CamelContext, Throwable) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextStopped(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextStopping(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextSuspended(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyCamelContextSuspending(CamelContext) - Static method in class org.apache.camel.support.EventHelper
-
- notifyExchangeCreated(CamelContext, Exchange) - Static method in class org.apache.camel.support.EventHelper
-
- notifyExchangeDone(CamelContext, Exchange) - Static method in class org.apache.camel.support.EventHelper
-
- notifyExchangeFailed(CamelContext, Exchange) - Static method in class org.apache.camel.support.EventHelper
-
- notifyExchangeFailureHandled(CamelContext, Exchange, Processor, boolean, String) - Static method in class org.apache.camel.support.EventHelper
-
- notifyExchangeFailureHandling(CamelContext, Exchange, Processor, boolean, String) - Static method in class org.apache.camel.support.EventHelper
-
- notifyExchangeRedelivery(CamelContext, Exchange, int) - Static method in class org.apache.camel.support.EventHelper
-
- notifyExchangeSending(CamelContext, Exchange, Endpoint) - Static method in class org.apache.camel.support.EventHelper
-
- notifyExchangeSent(CamelContext, Exchange, Endpoint, long) - Static method in class org.apache.camel.support.EventHelper
-
- notifyRouteAdded(CamelContext, Route) - Static method in class org.apache.camel.support.EventHelper
-
- notifyRouteReloaded(CamelContext, Route, int, int) - Static method in class org.apache.camel.support.EventHelper
-
- notifyRouteRemoved(CamelContext, Route) - Static method in class org.apache.camel.support.EventHelper
-
- notifyRouteStarted(CamelContext, Route) - Static method in class org.apache.camel.support.EventHelper
-
- notifyRouteStarting(CamelContext, Route) - Static method in class org.apache.camel.support.EventHelper
-
- notifyRouteStopped(CamelContext, Route) - Static method in class org.apache.camel.support.EventHelper
-
- notifyRouteStopping(CamelContext, Route) - Static method in class org.apache.camel.support.EventHelper
-
- notifyServiceStartupFailure(CamelContext, Object, Throwable) - Static method in class org.apache.camel.support.EventHelper
-
- notifyServiceStopFailure(CamelContext, Object, Throwable) - Static method in class org.apache.camel.support.EventHelper
-
- notifyStepDone(CamelContext, Exchange, String) - Static method in class org.apache.camel.support.EventHelper
-
- notifyStepFailed(CamelContext, Exchange, String) - Static method in class org.apache.camel.support.EventHelper
-
- notifyStepStarted(CamelContext, Exchange, String) - Static method in class org.apache.camel.support.EventHelper
-
- ObjectHelper - Class in org.apache.camel.support
-
A number of useful helper methods for working with Objects
- OffUuidGenerator - Class in org.apache.camel.support
-
UuidGenerator
which is turned off for exchange ids, but generated UUIDs for everything else.
- OffUuidGenerator() - Constructor for class org.apache.camel.support.OffUuidGenerator
-
- on(CamelContext) - Static method in class org.apache.camel.component.extension.metadata.MetaDataBuilder
-
- onAfterRoute(Route, Exchange) - Method in class org.apache.camel.support.SynchronizationAdapter
-
- onAutowire(Object, String, Class, Object) - Method in interface org.apache.camel.support.PropertyBindingSupport.OnAutowiring
-
Callback when a property was autowired on a bean
- onBeforeRoute(Route, Exchange) - Method in class org.apache.camel.support.SynchronizationAdapter
-
- onBeginStep(StartupStep) - Method in class org.apache.camel.support.startup.DefaultStartupStepRecorder
-
- onCamelContextInitialized(Consumer<CamelContext>) - Static method in class org.apache.camel.support.LifecycleStrategySupport
-
- onCamelContextInitializing(Consumer<CamelContext>) - Static method in class org.apache.camel.support.LifecycleStrategySupport
-
- onCamelContextStart(Consumer<CamelContext>) - Static method in class org.apache.camel.support.LifecycleStrategySupport
-
Deprecated.
- onCamelContextStarted(Consumer<CamelContext>) - Static method in class org.apache.camel.support.LifecycleStrategySupport
-
- onCamelContextStarting(Consumer<CamelContext>) - Static method in class org.apache.camel.support.LifecycleStrategySupport
-
- onCamelContextStop(Consumer<CamelContext>) - Static method in class org.apache.camel.support.LifecycleStrategySupport
-
Deprecated.
- onCamelContextStopped(Consumer<CamelContext>) - Static method in class org.apache.camel.support.LifecycleStrategySupport
-
- onCamelContextStopping(Consumer<CamelContext>) - Static method in class org.apache.camel.support.LifecycleStrategySupport
-
- onClassloaded(Logger) - Static method in class org.apache.camel.support.ExchangeHelper
-
- onClassloaded(Logger) - Static method in class org.apache.camel.support.MessageHelper
-
- onClassloaded(Logger) - Static method in class org.apache.camel.support.UnitOfWorkHelper
-
- onComplete(Exchange) - Method in class org.apache.camel.support.SynchronizationAdapter
-
- onComponentAdd(String, Component) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- onComponentRemove(String, Component) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- onContextStart(CamelContext) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- onContextStop(CamelContext) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- onDone(PooledExchange.OnDoneTask) - Method in class org.apache.camel.support.DefaultPooledExchange
-
- onDone(Exchange) - Method in class org.apache.camel.support.SynchronizationAdapter
-
- onEndpointAdd(Endpoint) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- onEndpointRemove(Endpoint) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- onEndStep(StartupStep) - Method in class org.apache.camel.support.startup.DefaultStartupStepRecorder
-
- onEndStep(StartupStep) - Method in class org.apache.camel.support.startup.LoggingStartupStepRecorder
-
- onEvent(Exchange, CamelEvent.ExchangeEvent, NamedNode) - Method in class org.apache.camel.support.BreakpointSupport
-
- onExchange(Exchange) - Method in class org.apache.camel.support.ProcessorEndpoint
-
- onExchangeBegin(Route, Exchange) - Method in class org.apache.camel.support.RoutePolicySupport
-
- onExchangeDone(Route, Exchange) - Method in class org.apache.camel.support.RoutePolicySupport
-
- onExchangeDone(Route, Exchange) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
-
- onExchangeDone(Route, Exchange) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
-
- onFailure(Exchange) - Method in class org.apache.camel.support.SynchronizationAdapter
-
- onHit(String) - Method in class org.apache.camel.support.DefaultEndpointUtilizationStatistics
-
- onInit(Consumer) - Method in class org.apache.camel.support.DefaultScheduledPollConsumerScheduler
-
- onInit(Route) - Method in class org.apache.camel.support.RoutePolicySupport
-
- onInit() - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- onInit(Route) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
-
- onInit(Route) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
-
- onNewPredicate(Predicate) - Method in class org.apache.camel.support.builder.ValueBuilder
-
A strategy method to allow derived classes to deal with the newly created predicate in different ways
- onNewValueBuilder(Expression) - Method in class org.apache.camel.support.builder.ValueBuilder
-
- onPropertiesReload(Resource) - Method in class org.apache.camel.support.RouteWatcherReloadStrategy
-
- onRemove(Route) - Method in class org.apache.camel.support.RoutePolicySupport
-
- onResume(Route) - Method in class org.apache.camel.support.RoutePolicySupport
-
- onRouteContextCreate(Route) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- onRouteReload(Resource) - Method in class org.apache.camel.support.RouteWatcherReloadStrategy
-
- onRoutesAdd(Collection<Route>) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- onRoutesRemove(Collection<Route>) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- onServiceAdd(CamelContext, Service, Route) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- onServiceRemove(CamelContext, Service, Route) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- onStart(Route) - Method in class org.apache.camel.support.RoutePolicySupport
-
- onStart(Route) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
-
- onStop(Route) - Method in class org.apache.camel.support.RoutePolicySupport
-
- onSuspend(Route) - Method in class org.apache.camel.support.RoutePolicySupport
-
- onThreadPoolAdd(CamelContext, ThreadPoolExecutor, String, String, String, String) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- onThreadPoolRemove(CamelContext, ThreadPoolExecutor) - Method in class org.apache.camel.support.LifecycleStrategySupport
-
- openCircuit(Route) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
-
- option(String) - Method in class org.apache.camel.component.extension.verifier.OptionsGroup
-
Adds a option definition to this group.
- options(String...) - Method in class org.apache.camel.component.extension.verifier.OptionsGroup
-
Adds a number of option definitions to this group.
- OptionsGroup - Class in org.apache.camel.component.extension.verifier
-
A named group of options.
- OptionsGroup(String) - Constructor for class org.apache.camel.component.extension.verifier.OptionsGroup
-
- OptionsGroup(String, Collection<String>) - Constructor for class org.apache.camel.component.extension.verifier.OptionsGroup
-
Creates new named
OptionsGroup
with a set of option definitions.
- or(Predicate, Predicate) - Static method in class org.apache.camel.support.builder.PredicateBuilder
-
A helper method to combine two predicates by a logical OR.
- or(List<Predicate>) - Static method in class org.apache.camel.support.builder.PredicateBuilder
-
Concat the given predicates into a single predicate, which matches
if at least one predicates matches.
- or(Predicate...) - Static method in class org.apache.camel.support.builder.PredicateBuilder
-
Concat the given predicates into a single predicate, which matches
if at least one predicates matches.
- order() - Static method in class org.apache.camel.support.cluster.ClusterServiceSelectors
-
- OrderedComparator - Class in org.apache.camel.support
-
A comparator to sort Ordered
- OrderedComparator() - Constructor for class org.apache.camel.support.OrderedComparator
-
- OrderedComparator(boolean) - Constructor for class org.apache.camel.support.OrderedComparator
-
- org.apache.camel.component - package org.apache.camel.component
-
Base classes for components
- org.apache.camel.component.extension.metadata - package org.apache.camel.component.extension.metadata
-
MetaData component extension
- org.apache.camel.component.extension.verifier - package org.apache.camel.component.extension.verifier
-
Verifier component extension
- org.apache.camel.converter.stream - package org.apache.camel.converter.stream
-
Package with converters for dealing with stream-based messages
- org.apache.camel.saga - package org.apache.camel.saga
-
Camel Saga EIP
- org.apache.camel.support - package org.apache.camel.support
-
Base classes that help to implement the camel API and are expected to be extended by the user
- org.apache.camel.support.builder - package org.apache.camel.support.builder
-
Base classes for builders
- org.apache.camel.support.cache - package org.apache.camel.support.cache
-
Base classes for caching and pooling
- org.apache.camel.support.cluster - package org.apache.camel.support.cluster
-
Base classes for Camel clustering
- org.apache.camel.support.component - package org.apache.camel.support.component
-
Base classes and utilities for API based components
- org.apache.camel.support.jndi - package org.apache.camel.support.jndi
-
A simple JNDI context which can be used with the JndiRegistry
- org.apache.camel.support.language - package org.apache.camel.support.language
-
Base classes that help to implement custom languages
- org.apache.camel.support.management - package org.apache.camel.support.management
-
Base classes for JMX management support
- org.apache.camel.support.processor - package org.apache.camel.support.processor
-
Base classes and utilities for EIP and Camel processors
- org.apache.camel.support.processor.idempotent - package org.apache.camel.support.processor.idempotent
-
Basic idempotent repository implementations that can be extended by Camel end users
- org.apache.camel.support.startup - package org.apache.camel.support.startup
-
Camel startup recorder support (Java Flight Recorder)
- org.apache.camel.support.task - package org.apache.camel.support.task
-
- org.apache.camel.support.task.budget - package org.apache.camel.support.task.budget
-
- org.apache.camel.support.task.budget.backoff - package org.apache.camel.support.task.budget.backoff
-
- org.apache.camel.throttling - package org.apache.camel.throttling
-
Base classes for throttler EIP
- OUT_NAMESPACE - Static variable in class org.apache.camel.support.builder.Namespaces
-
- OutputStreamBuilder - Class in org.apache.camel.support.builder
-
Utility to hide the complexity of choosing which OutputStream implementation to choose.
- owned(List<String>) - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- padString(int) - Static method in class org.apache.camel.support.startup.LoggingStartupStepRecorder
-
- parameterKey(String) - Method in class org.apache.camel.component.extension.verifier.ResultErrorBuilder
-
- parameterKeys(Collection<String>) - Method in class org.apache.camel.component.extension.verifier.ResultErrorBuilder
-
- parse(CamelContext, Class<T>, String) - Static method in class org.apache.camel.support.CamelContextHelper
-
Parses the given text and converts it to the specified class and handling property placeholders as well
- parse() - Method in class org.apache.camel.support.component.ApiMethodParser
-
Parses the method signatures from getSignatures()
.
- parseBoolean(CamelContext, String) - Static method in class org.apache.camel.support.CamelContextHelper
-
Parses the given text and converts it to an Boolean and handling property placeholders as well
- parseDouble(CamelContext, String) - Static method in class org.apache.camel.support.CamelContextHelper
-
Parses the given text and converts it to a Double and handling property placeholders as well
- parseDuration(CamelContext, String) - Static method in class org.apache.camel.support.CamelContextHelper
-
Parses the given text and converts it to a Duration and handling property placeholders as well
- parseFloat(CamelContext, String) - Static method in class org.apache.camel.support.CamelContextHelper
-
Parses the given text and converts it to a Float and handling property placeholders as well
- parseInt(CamelContext, String) - Static method in class org.apache.camel.support.CamelContextHelper
-
Parses the given text and converts it to an Integer and handling property placeholders as well
- parseInteger(CamelContext, String) - Static method in class org.apache.camel.support.CamelContextHelper
-
Parses the given text and converts it to an Integer and handling property placeholders as well
- parseLong(CamelContext, String) - Static method in class org.apache.camel.support.CamelContextHelper
-
Parses the given text and converts it to an Long and handling property placeholders as well
- parseText(CamelContext, String) - Static method in class org.apache.camel.support.CamelContextHelper
-
Parses the given text and handling property placeholders as well
- partitionList() - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- PatternHelper - Class in org.apache.camel.support
-
- pendingExchanges - Variable in class org.apache.camel.support.ScheduledBatchPollingConsumer
-
- periodMillis - Variable in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- PlatformHelper - Class in org.apache.camel.support
-
Deprecated.
- poll() - Method in class org.apache.camel.support.component.AbstractApiConsumer
-
- poll() - Method in class org.apache.camel.support.DefaultScheduledPollConsumer
-
- poll() - Method in class org.apache.camel.support.ScheduledPollConsumer
-
The polling method which is invoked periodically to poll this consumer
- pollEndpoint(Endpoint, Processor, long) - Static method in class org.apache.camel.support.EndpointHelper
-
Creates a PollingConsumer
and polls all pending messages on the endpoint and invokes the given
Processor
to process each Exchange
and then closes down the consumer and throws any exceptions
thrown.
- pollEndpoint(Endpoint, Processor) - Static method in class org.apache.camel.support.EndpointHelper
-
Creates a PollingConsumer
and polls all pending messages on the endpoint and invokes the given
Processor
to process each Exchange
and then closes down the consumer and throws any exceptions
thrown.
- PollingConsumerServicePool - Class in org.apache.camel.support.cache
-
PollingConsumer
pool.
- PollingConsumerServicePool(ThrowingFunction<Endpoint, PollingConsumer, Exception>, Function<PollingConsumer, Endpoint>, int) - Constructor for class org.apache.camel.support.cache.PollingConsumerServicePool
-
- PollingConsumerSupport - Class in org.apache.camel.support
-
A useful base class for implementations of PollingConsumer
- PollingConsumerSupport(Endpoint) - Constructor for class org.apache.camel.support.PollingConsumerSupport
-
- pool - Variable in class org.apache.camel.support.PooledObjectFactorySupport
-
- PooledObjectFactorySupport<T> - Class in org.apache.camel.support
-
Base class for building PooledObjectFactory
based factories.
- PooledObjectFactorySupport() - Constructor for class org.apache.camel.support.PooledObjectFactorySupport
-
- PooledObjectFactorySupport(Object) - Constructor for class org.apache.camel.support.PooledObjectFactorySupport
-
- PooledObjectFactorySupport.UtilizationStatistics - Class in org.apache.camel.support
-
Represents utilization statistics
- populateInitialHeaders(Map<String, Object>) - Method in class org.apache.camel.support.DefaultMessage
-
A strategy method populate the initial set of headers on an inbound message from an underlying binding
- populateVariableMap(Exchange, Map<String, Object>, boolean) - Static method in class org.apache.camel.support.ExchangeHelper
-
Populates the Map with the variables which are made available to a script or template
- PredicateAssertHelper - Class in org.apache.camel.support
-
A helper for doing Predicate
assertions.
- PredicateBuilder - Class in org.apache.camel.support.builder
-
A helper class for working with predicates
- PredicateBuilder() - Constructor for class org.apache.camel.support.builder.PredicateBuilder
-
- PredicateToExpressionAdapter - Class in org.apache.camel.support
-
To adapt Predicate
as an Expression
- PredicateToExpressionAdapter(Predicate) - Constructor for class org.apache.camel.support.PredicateToExpressionAdapter
-
- PredicateValidatingProcessor - Class in org.apache.camel.support.processor
-
A processor which validates the content of the inbound message body against a Predicate
.
- PredicateValidatingProcessor(Predicate) - Constructor for class org.apache.camel.support.processor.PredicateValidatingProcessor
-
- PredicateValidationException - Exception in org.apache.camel.support.processor
-
A predicate validation exception occurred
- PredicateValidationException(Exchange, Predicate) - Constructor for exception org.apache.camel.support.processor.PredicateValidationException
-
- prepareAggregation(Exchange, Exchange) - Static method in class org.apache.camel.support.ExchangeHelper
-
Prepares the exchanges for aggregation.
- prepareCopy(Exchange, boolean) - Method in class org.apache.camel.support.EventDrivenPollingConsumer
-
- prepareOutToIn(Exchange) - Static method in class org.apache.camel.support.ExchangeHelper
-
Strategy to prepare results before next iterator or when we are complete, which is done by copying OUT to IN, so
there is only an IN as input for the next iteration.
- prepareShutdown(boolean, boolean) - Method in class org.apache.camel.support.ScheduledBatchPollingConsumer
-
- prepend(Expression, Expression) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Prepends the String evaluations of the two expressions together
- prepend(Object) - Method in class org.apache.camel.support.builder.ValueBuilder
-
Prepends the string evaluation of this expression with the given value
- process(AsyncProcessor, Exchange) - Static method in class org.apache.camel.support.AsyncProcessorHelper
-
Calls the async version of the processor's process method and waits for it to complete before returning.
- process(Exchange) - Method in class org.apache.camel.support.AsyncProcessorSupport
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.support.component.AbstractApiProducer
-
- process(Exchange) - Method in class org.apache.camel.support.DefaultAsyncProducer
-
- process(Exchange) - Method in class org.apache.camel.support.DeferProducer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.support.DeferProducer
-
- process(Exchange) - Method in class org.apache.camel.support.EventDrivenPollingConsumer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.support.HeaderSelectorProducer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.support.LazyStartProducer
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.support.processor.CamelLogProcessor
-
- process(Exchange, Throwable) - Method in class org.apache.camel.support.processor.CamelLogProcessor
-
- process(Exchange, String) - Method in class org.apache.camel.support.processor.CamelLogProcessor
-
- process(Exchange) - Method in class org.apache.camel.support.processor.ConvertBodyProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.support.processor.ConvertBodyProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.support.processor.DelegateAsyncProcessor
-
- process(Exchange) - Method in class org.apache.camel.support.processor.DelegateProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.support.processor.DelegateSyncProcessor
-
- process(Exchange) - Method in class org.apache.camel.support.processor.DelegateSyncProcessor
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.support.processor.MarshalProcessor
-
- process(Exchange) - Method in class org.apache.camel.support.processor.PredicateValidatingProcessor
-
- process(Exchange) - Method in class org.apache.camel.support.processor.ThroughputLogger
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.support.processor.ThroughputLogger
-
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.support.processor.UnmarshalProcessor
-
- process(Exchange) - Method in class org.apache.camel.support.SynchronousDelegateProducer
-
- processAsync(Exchange) - Method in class org.apache.camel.support.AsyncProcessorSupport
-
- processAsync(Exchange) - Method in class org.apache.camel.support.DefaultAsyncProducer
-
- processAsync(Exchange) - Method in class org.apache.camel.support.DeferProducer
-
- processAsync(Exchange) - Method in class org.apache.camel.support.processor.ConvertBodyProcessor
-
- processAsync(Exchange) - Method in class org.apache.camel.support.processor.DelegateSyncProcessor
-
- processEmptyMessage() - Method in class org.apache.camel.support.ScheduledBatchPollingConsumer
-
- processEmptyMessage() - Method in class org.apache.camel.support.ScheduledPollConsumer
-
No messages to poll so send an empty message instead.
- processNext(Exchange) - Method in class org.apache.camel.support.processor.DelegateProcessor
-
- processor - Variable in class org.apache.camel.support.processor.DelegateAsyncProcessor
-
- processor - Variable in class org.apache.camel.support.processor.DelegateProcessor
-
- processor - Variable in class org.apache.camel.support.processor.DelegateSyncProcessor
-
- ProcessorEndpoint - Class in org.apache.camel.support
-
An endpoint which allows exchanges to be sent into it which just invokes a given Processor
.
- ProcessorEndpoint() - Constructor for class org.apache.camel.support.ProcessorEndpoint
-
- ProcessorEndpoint(String, CamelContext, Processor) - Constructor for class org.apache.camel.support.ProcessorEndpoint
-
- ProcessorEndpoint(String, Component, Processor) - Constructor for class org.apache.camel.support.ProcessorEndpoint
-
- ProcessorEndpoint(String, Component) - Constructor for class org.apache.camel.support.ProcessorEndpoint
-
- ProcessorPollingConsumer - Class in org.apache.camel.support
-
A simple implementation of PollingConsumer
which just uses a Processor
.
- ProcessorPollingConsumer(Endpoint, Processor) - Constructor for class org.apache.camel.support.ProcessorPollingConsumer
-
- processResult(Exchange, Object) - Method in class org.apache.camel.support.HeaderSelectorProducer
-
Process the result.
- processResults(List<ApiMethodParser.ApiMethodModel>) - Method in class org.apache.camel.support.component.ApiMethodParser
-
- processResults(List<ApiMethodParser.ApiMethodModel>) - Method in class org.apache.camel.support.component.ArgumentSubstitutionParser
-
- ProducerServicePool - Class in org.apache.camel.support.cache
-
Producer
pool.
- ProducerServicePool(ThrowingFunction<Endpoint, AsyncProducer, Exception>, Function<AsyncProducer, Endpoint>, int) - Constructor for class org.apache.camel.support.cache.ProducerServicePool
-
- propertiesComponentExpression(String, String) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
- propertiesHelper - Variable in class org.apache.camel.support.component.AbstractApiProducer
-
- PropertiesInterceptor - Interface in org.apache.camel.support.component
-
Intercepts Property values used to invoke API Method.
- property(CamelContext, Class<T>, Object) - Static method in class org.apache.camel.support.component.PropertyConfigurerSupport
-
Converts the property to the expected type
- property(Class<T>, Object[], int, Object) - Method in class org.apache.camel.support.LanguageSupport
-
Converts the property to the expected type
- PropertyBindingSupport - Class in org.apache.camel.support
-
A convenient support class for binding String valued properties to an instance which uses a set of conventions:
property placeholders - Keys and values using Camels property placeholder will be resolved
nested - Properties can be nested using the dot syntax (OGNL and builder pattern using with as prefix), eg
foo.bar=123
map - Properties can lookup in Map's using map syntax, eg foo[bar] where foo is the name of the property
that is a Map instance, and bar is the name of the key.
list - Properties can refer or add to in List's using list syntax, eg foo[0] where foo is the name of the
property that is a List instance, and 0 is the index.
- PropertyBindingSupport.Builder - Class in org.apache.camel.support
-
To use a fluent builder style to configure this property binding support.
- PropertyBindingSupport.OnAutowiring - Interface in org.apache.camel.support
-
- PropertyConfigurerHelper - Class in org.apache.camel.support
-
Helper class for dealing with configurers.
- PropertyConfigurerSupport - Class in org.apache.camel.support.component
-
Base class used by Camel Package Maven Plugin when it generates source code for fast property configurations via
PropertyConfigurer
.
- PropertyConfigurerSupport() - Constructor for class org.apache.camel.support.component.PropertyConfigurerSupport
-
- PropertyNamesInterceptor - Interface in org.apache.camel.support.component
-
Intercepts Property names used to find methods.
- propertyPrefix - Variable in class org.apache.camel.support.component.ApiMethodPropertiesHelper
-
- PrototypeObjectFactorySupport<T> - Class in org.apache.camel.support
-
PooledObjectFactory
that creates a new instance (does not pool).
- PrototypeObjectFactorySupport() - Constructor for class org.apache.camel.support.PrototypeObjectFactorySupport
-
- PrototypeObjectFactorySupport.UtilizationStatistics - Class in org.apache.camel.support
-
Represents utilization statistics
- purge() - Method in class org.apache.camel.support.cache.DefaultConsumerCache
-
Purges this cache
- purge() - Method in class org.apache.camel.support.cache.DefaultProducerCache
-
- purge() - Method in class org.apache.camel.support.DefaultTimeoutMap
-
- purge() - Method in class org.apache.camel.support.PooledObjectFactorySupport
-
- purge() - Method in class org.apache.camel.support.PrototypeObjectFactorySupport
-
- put(K, V, long) - Method in class org.apache.camel.support.DefaultTimeoutMap
-
- putIfAbsent(K, V, long) - Method in class org.apache.camel.support.DefaultTimeoutMap
-
- read() - Method in class org.apache.camel.converter.stream.FileInputStreamCache
-
- read(byte[]) - Method in class org.apache.camel.converter.stream.FileInputStreamCache
-
- read(byte[], int, int) - Method in class org.apache.camel.converter.stream.FileInputStreamCache
-
- read() - Method in class org.apache.camel.support.InputStreamIterator
-
- ReaderCache - Class in org.apache.camel.converter.stream
-
A
StreamCache
for String
Reader
s
- ReaderCache(String) - Constructor for class org.apache.camel.converter.stream.ReaderCache
-
- rebalanceGroup(List<String>, int) - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- RebalancingCamelClusterService - Class in org.apache.camel.support.cluster
-
- RebalancingCamelClusterService(CamelPreemptiveClusterService, long) - Constructor for class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- RebalancingCamelClusterService(CamelContext, CamelPreemptiveClusterService, long) - Constructor for class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- rebind(Name, Object) - Method in class org.apache.camel.support.jndi.JndiContext
-
- rebind(String, Object) - Method in class org.apache.camel.support.jndi.JndiContext
-
- receive(Endpoint) - Method in class org.apache.camel.support.cache.DefaultConsumerCache
-
- receive(Endpoint, long) - Method in class org.apache.camel.support.cache.DefaultConsumerCache
-
- receive() - Method in class org.apache.camel.support.EventDrivenPollingConsumer
-
- receive(long) - Method in class org.apache.camel.support.EventDrivenPollingConsumer
-
- receive() - Method in class org.apache.camel.support.ProcessorPollingConsumer
-
- receive(long) - Method in class org.apache.camel.support.ProcessorPollingConsumer
-
- receiveNoWait(Endpoint) - Method in class org.apache.camel.support.cache.DefaultConsumerCache
-
- receiveNoWait() - Method in class org.apache.camel.support.EventDrivenPollingConsumer
-
- receiveNoWait() - Method in class org.apache.camel.support.ProcessorPollingConsumer
-
- reconcile() - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- refExpression(String) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns an expression for lookup a bean in the Registry
- refExpression(Expression) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns an expression for lookup a bean in the Registry
- regex(Expression, String) - Static method in class org.apache.camel.support.builder.PredicateBuilder
-
Returns a predicate which is true if the expression matches the given
regular expression
- regex(Expression, Pattern) - Static method in class org.apache.camel.support.builder.PredicateBuilder
-
Returns a predicate which is true if the expression matches the given
regular expression
- regex(String) - Method in class org.apache.camel.support.builder.ValueBuilder
-
Creates a predicate which is true if this expression matches the given regular expression
- regexReplaceAll(Expression, String, String) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Transforms the expression into a String then performs the regex
replaceAll to transform the String and return the result
- regexReplaceAll(Expression, String, Expression) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Transforms the expression into a String then performs the regex
replaceAll to transform the String and return the result
- regexReplaceAll(String, String) - Method in class org.apache.camel.support.builder.ValueBuilder
-
Replaces all occurrences of the regular expression with the given replacement
- regexReplaceAll(String, Expression) - Method in class org.apache.camel.support.builder.ValueBuilder
-
Replaces all occurrences of the regular expression with the given replacement
- regexTokenize(String) - Method in class org.apache.camel.support.builder.ValueBuilder
-
Tokenizes the string conversion of this expression using the given regular expression
- regexTokenizeExpression(Expression, String) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns a tokenize expression which will tokenize the string with the
given regex
- registerExtension(ComponentExtension) - Method in class org.apache.camel.support.DefaultComponent
-
- registerExtension(Supplier<ComponentExtension>) - Method in class org.apache.camel.support.DefaultComponent
-
- registerStep(CamelSagaStep) - Method in interface org.apache.camel.saga.CamelSagaService
-
- registerStep(CamelSagaStep) - Method in class org.apache.camel.saga.InMemorySagaService
-
- registryExpression() - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns an expression for the Registry
- released - Variable in class org.apache.camel.support.PooledObjectFactorySupport.UtilizationStatistics
-
- released - Variable in class org.apache.camel.support.PrototypeObjectFactorySupport.UtilizationStatistics
-
- releaseExchange(Exchange, boolean) - Method in class org.apache.camel.support.DefaultConsumer
-
- releaseExchange(Exchange, boolean) - Method in class org.apache.camel.support.PollingConsumerSupport
-
- releasePollingConsumer(Endpoint, PollingConsumer) - Method in class org.apache.camel.support.cache.DefaultConsumerCache
-
Releases an acquired producer back after usage.
- releaseProducer(Endpoint, AsyncProducer) - Method in class org.apache.camel.support.cache.DefaultProducerCache
-
- releaseProducer(Endpoint, AsyncProducer) - Method in class org.apache.camel.support.cache.EmptyProducerCache
-
- releaseView(CamelClusterView) - Method in class org.apache.camel.support.cluster.AbstractCamelClusterService
-
- releaseView(CamelClusterView) - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- remove(String) - Method in class org.apache.camel.support.DefaultEndpointUtilizationStatistics
-
- remove(K) - Method in class org.apache.camel.support.DefaultTimeoutMap
-
- remove() - Method in class org.apache.camel.support.GroupIterator
-
- remove() - Method in class org.apache.camel.support.GroupTokenIterator
-
- remove(String) - Method in class org.apache.camel.support.processor.idempotent.FileIdempotentRepository
-
- remove(String) - Method in class org.apache.camel.support.processor.idempotent.MemoryIdempotentRepository
-
- removeChildService(Object) - Method in class org.apache.camel.support.ChildServiceSupport
-
- removeEventListener(CamelClusterEventListener) - Method in class org.apache.camel.support.cluster.AbstractCamelClusterView
-
- removeFromEnvironment(String) - Method in class org.apache.camel.support.jndi.JndiContext
-
- removeFromStore(String) - Method in class org.apache.camel.support.processor.idempotent.FileIdempotentRepository
-
- removeHeader(String) - Method in class org.apache.camel.support.DefaultMessage
-
- removeHeaders(String) - Method in class org.apache.camel.support.DefaultMessage
-
- removeHeaders(String, String...) - Method in class org.apache.camel.support.DefaultMessage
-
- removeTimerListener(TimerListener) - Method in class org.apache.camel.support.TimerListenerManager
-
Removes the listener.
- rename(Name, Name) - Method in class org.apache.camel.support.jndi.JndiContext
-
- rename(String, String) - Method in class org.apache.camel.support.jndi.JndiContext
-
- replaceMessage(Exchange, Message, boolean) - Static method in class org.apache.camel.support.ExchangeHelper
-
Replaces the existing message with the new message
- repositories - Variable in class org.apache.camel.support.DefaultRegistry
-
- requiresAny(Map<String, Object>, OptionsGroup...) - Static method in class org.apache.camel.component.extension.verifier.ResultErrorHelper
-
Validates that the given parameters satisfy any grouped options (
OptionsGroup
).
- requiresAny(Map<String, Object>, Collection<OptionsGroup>) - Static method in class org.apache.camel.component.extension.verifier.ResultErrorHelper
-
Validates that the given parameters satisfy any grouped options (
OptionsGroup
).
- requiresOption(String, Map<String, Object>) - Static method in class org.apache.camel.component.extension.verifier.ResultErrorHelper
-
- reset() - Method in class org.apache.camel.converter.stream.ByteArrayInputStreamCache
-
- reset() - Method in class org.apache.camel.converter.stream.FileInputStreamCache
-
- reset() - Method in class org.apache.camel.converter.stream.ReaderCache
-
- reset() - Method in class org.apache.camel.support.DefaultMessage
-
- reset(long) - Method in class org.apache.camel.support.DefaultPooledExchange
-
- reset() - Method in class org.apache.camel.support.MessageSupport
-
- reset() - Method in class org.apache.camel.support.PooledObjectFactorySupport.UtilizationStatistics
-
- reset() - Method in class org.apache.camel.support.processor.idempotent.FileIdempotentRepository
-
Reset and clears the 1st-level cache to force it to reload from file
- reset() - Method in class org.apache.camel.support.processor.ThroughputLogger
-
- reset() - Method in class org.apache.camel.support.PrototypeObjectFactorySupport.UtilizationStatistics
-
- resetCounters() - Method in class org.apache.camel.support.ResourceReloadStrategySupport
-
- resetStatistics() - Method in interface org.apache.camel.support.LRUCache
-
- resetStatistics() - Method in class org.apache.camel.support.PooledObjectFactorySupport
-
- resetStatistics() - Method in class org.apache.camel.support.PrototypeObjectFactorySupport
-
- resetStreamCache(Message) - Static method in class org.apache.camel.support.MessageHelper
-
If the message body contains a StreamCache
instance, reset the cache to enable reading from it again.
- resolve(String) - Method in class org.apache.camel.support.ResourceResolverSupport
-
- resolveAndRemoveReferenceListParameter(Map<String, Object>, String, Class<T>) - Method in class org.apache.camel.support.DefaultComponent
-
Resolves a reference list parameter in the registry and removes it from the map.
- resolveAndRemoveReferenceListParameter(Map<String, Object>, String, Class<T>, List<T>) - Method in class org.apache.camel.support.DefaultComponent
-
Resolves a reference list parameter in the registry and removes it from the map.
- resolveAndRemoveReferenceParameter(Map<String, Object>, String, Class<T>) - Method in class org.apache.camel.support.DefaultComponent
-
Resolves a reference parameter in the registry and removes it from the map.
- resolveAndRemoveReferenceParameter(Map<String, Object>, String, Class<T>, T) - Method in class org.apache.camel.support.DefaultComponent
-
Resolves a reference parameter in the registry and removes it from the map.
- resolveBean(CamelContext, Object) - Static method in class org.apache.camel.support.PropertyBindingSupport
-
Resolves the value as either a class, type or bean.
- resolveClass(ObjectStreamClass) - Method in class org.apache.camel.support.CamelObjectInputStream
-
- resolveEndpoint(CamelContext, String, String) - Static method in class org.apache.camel.support.CamelContextHelper
-
- resolveEndpoint(Exchange, Object) - Static method in class org.apache.camel.support.ExchangeHelper
-
Attempts to resolve the endpoint for the given value
- resolveEndpoint(CamelContext, Object) - Static method in class org.apache.camel.support.ExchangeHelper
-
Attempts to resolve the endpoint for the given value
- resolveEndpointUriPropertyPlaceholders(CamelContext, String) - Static method in class org.apache.camel.support.EndpointHelper
-
Resolves the endpoint uri that may have property placeholders (supports optional property placeholders).
- resolveExchangePatternFromUrl(String) - Static method in class org.apache.camel.support.EndpointHelper
-
Attempts to resolve if the url has an exchangePattern option configured
- resolveMandatoryResourceAsInputStream(CamelContext, String) - Static method in class org.apache.camel.support.ResourceHelper
-
Resolves the mandatory resource.
- resolveMandatoryResourceAsUrl(CamelContext, String) - Static method in class org.apache.camel.support.ResourceHelper
-
Resolves the mandatory resource.
- resolveOptionalExternalScript(CamelContext, String) - Static method in class org.apache.camel.support.ScriptHelper
-
Resolves the expression/predicate whether it refers to an external script on the file/classpath etc.
- resolveOptionalExternalScript(CamelContext, Exchange, String) - Static method in class org.apache.camel.support.ScriptHelper
-
Resolves the expression/predicate whether it refers to an external script on the file/classpath etc.
- resolveParameter(CamelContext, String, Class<T>) - Static method in class org.apache.camel.support.EndpointHelper
-
Resolves a parameter, by doing a reference lookup if the parameter is a reference, and converting the parameter
to the given type.
- resolvePropertyConfigurer(CamelContext, Object) - Static method in class org.apache.camel.support.PropertyConfigurerHelper
-
Resolves the given configurer.
- resolvePropertyConfigurer(CamelContext, Class<?>) - Static method in class org.apache.camel.support.PropertyConfigurerHelper
-
Resolves the given configurer.
- resolvePropertyConfigurer(CamelContext, Object, Class<T>) - Static method in class org.apache.camel.support.PropertyConfigurerHelper
-
Resolves the given configurer.
- resolvePrototypeEndpoint(Exchange, Object) - Static method in class org.apache.camel.support.ExchangeHelper
-
Attempts to resolve the endpoint (prototype scope) for the given value
- resolvePrototypeEndpoint(CamelContext, Object) - Static method in class org.apache.camel.support.ExchangeHelper
-
Attempts to resolve the endpoint (prototype scope) for the given value
- resolveRawParameterValues() - Method in class org.apache.camel.support.component.SendDynamicAwareSupport
-
- resolveRawParameterValues() - Method in class org.apache.camel.support.DefaultComponent
-
- resolveReferenceListParameter(CamelContext, String, Class<T>) - Static method in class org.apache.camel.support.EndpointHelper
-
Resolves a reference list parameter by making lookups in the registry.
- resolveReferenceParameter(CamelContext, String, Class<T>) - Static method in class org.apache.camel.support.EndpointHelper
-
Resolves a reference parameter by making a lookup in the registry.
- resolveReferenceParameter(CamelContext, String, Class<T>, boolean) - Static method in class org.apache.camel.support.EndpointHelper
-
Resolves a reference parameter by making a lookup in the registry.
- resolveResourceAsInputStream(CamelContext, String) - Static method in class org.apache.camel.support.ResourceHelper
-
Resolves the resource.
- resolveResourceAsUrl(CamelContext, String) - Static method in class org.apache.camel.support.ResourceHelper
-
Resolves the resource.
- resolveRestHostName(String, RestConfiguration) - Static method in class org.apache.camel.support.RestComponentHelper
-
Sets the Rest consumer host based on RestConfiguration
- ResolverHelper - Class in org.apache.camel.support
-
Some helper methods for new resolvers (like ComponentResolver
,
DataFormatResolver
, etc.).
- ResolverHelper.LookupExceptionHandler - Class in org.apache.camel.support
-
- resolveScheme(String) - Static method in class org.apache.camel.support.ExchangeHelper
-
Resolve the component scheme (aka name) from the given endpoint uri
- resolveService(CamelContext, String, String, Class<T>) - Static method in class org.apache.camel.support.ResolverHelper
-
Create an instance of the given factory.
- resolveService(CamelContext, String, Class<T>) - Static method in class org.apache.camel.support.ResolverHelper
-
Create an instance of the given factory using the default factory finder
- resolveService(CamelContext, FactoryFinder, String, Class<T>) - Static method in class org.apache.camel.support.ResolverHelper
-
Create an instance of the given factory.
- RESOURCE - Static variable in class org.apache.camel.support.LanguageSupport
-
- RESOURCE_PATH - Static variable in class org.apache.camel.support.HeaderSelectorProducer
-
- ResourceEndpoint - Class in org.apache.camel.component
-
A useful base class for endpoints which depend on a resource such as things like Velocity or XQuery based components.
- ResourceEndpoint() - Constructor for class org.apache.camel.component.ResourceEndpoint
-
- ResourceEndpoint(String, Component, String) - Constructor for class org.apache.camel.component.ResourceEndpoint
-
- ResourceHelper - Class in org.apache.camel.support
-
Helper class for loading resources on the classpath or file system.
- ResourceReloadStrategySupport - Class in org.apache.camel.support
-
Base class for implementing custom ResourceReloadStrategy
SPI plugins.
- ResourceReloadStrategySupport() - Constructor for class org.apache.camel.support.ResourceReloadStrategySupport
-
- ResourceResolverSupport - Class in org.apache.camel.support
-
Base class for ResourceResolver
implementations.
- ResourceResolverSupport(String) - Constructor for class org.apache.camel.support.ResourceResolverSupport
-
- ResourceSupport - Class in org.apache.camel.support
-
Base class for Resource
implementations.
- ResourceSupport(String) - Constructor for class org.apache.camel.support.ResourceSupport
-
- RestComponentHelper - Class in org.apache.camel.support
-
Helper class for rest-dsl components.
- RestConsumerContextPathMatcher - Class in org.apache.camel.support
-
A context path matcher when using rest-dsl that allows components to reuse the same matching logic.
- RestConsumerContextPathMatcher.ConsumerPath<T> - Interface in org.apache.camel.support
-
Consumer path details which must be implemented and provided by the components.
- RestProducerFactoryHelper - Class in org.apache.camel.support
-
Helper for creating configured Component
s used by the RestProducerFactory
contract.
- ResultBuilder - Class in org.apache.camel.component.extension.verifier
-
- ResultBuilder() - Constructor for class org.apache.camel.component.extension.verifier.ResultBuilder
-
- ResultErrorBuilder - Class in org.apache.camel.component.extension.verifier
-
- ResultErrorBuilder() - Constructor for class org.apache.camel.component.extension.verifier.ResultErrorBuilder
-
- ResultErrorHelper - Class in org.apache.camel.component.extension.verifier
-
Helper that validates component parameters.
- ResultInterceptor - Interface in org.apache.camel.support.component
-
Intercepts API method invocation result Exchange.
- resumeOrStartConsumer(Consumer) - Method in class org.apache.camel.support.RoutePolicySupport
-
Resumes or starts the consumer.
- resumeRoute(Route) - Method in class org.apache.camel.support.RoutePolicySupport
-
- rollback(Consumer, Endpoint, int, Exception) - Method in class org.apache.camel.support.DefaultPollingConsumerPollStrategy
-
- routeIdExpression() - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns an Expression for the route id
- RoutePolicySupport - Class in org.apache.camel.support
-
A base class for developing custom RoutePolicy
implementations.
- RoutePolicySupport() - Constructor for class org.apache.camel.support.RoutePolicySupport
-
- RoutesBuilderLoaderSupport - Class in org.apache.camel.support
-
Base class for RoutesBuilderLoader
implementations.
- RoutesBuilderLoaderSupport() - Constructor for class org.apache.camel.support.RoutesBuilderLoaderSupport
-
- RouteTemplateHelper - Class in org.apache.camel.support
-
Helper for working with route templates.
- RouteWatcherReloadStrategy - Class in org.apache.camel.support
-
Watcher strategy for triggering reloading of Camel routes in a running Camel application.
- RouteWatcherReloadStrategy() - Constructor for class org.apache.camel.support.RouteWatcherReloadStrategy
-
- RouteWatcherReloadStrategy(String) - Constructor for class org.apache.camel.support.RouteWatcherReloadStrategy
-
- RouteWatcherReloadStrategy(String, boolean) - Constructor for class org.apache.camel.support.RouteWatcherReloadStrategy
-
- run() - Method in class org.apache.camel.support.FileWatcherResourceReloadStrategy.WatchFileChangesTask
-
- run() - Method in class org.apache.camel.support.ScheduledPollConsumer
-
Invoked whenever we should be polled
- run(Predicate<T>, T) - Method in class org.apache.camel.support.task.BackgroundTask
-
- run(BooleanSupplier) - Method in class org.apache.camel.support.task.BackgroundTask
-
- run(Predicate<T>, T) - Method in interface org.apache.camel.support.task.BlockingTask
-
Run the task
- run(BooleanSupplier) - Method in interface org.apache.camel.support.task.BlockingTask
-
Run the task
- run(Predicate<T>, T) - Method in class org.apache.camel.support.task.ForegroundTask
-
- run(BooleanSupplier) - Method in class org.apache.camel.support.task.ForegroundTask
-
- run(Supplier<T>, Predicate<T>) - Method in class org.apache.camel.support.task.ForegroundTask
-
Run a task until it produces a result
- run() - Method in class org.apache.camel.support.TimerListenerManager
-
- sanitizeHostName(String) - Static method in class org.apache.camel.support.ClassicUuidGenerator
-
- ScheduledBatchPollingConsumer - Class in org.apache.camel.support
-
A useful base class for any consumer which is polling batch based
- ScheduledBatchPollingConsumer(Endpoint, Processor) - Constructor for class org.apache.camel.support.ScheduledBatchPollingConsumer
-
- ScheduledBatchPollingConsumer(Endpoint, Processor, ScheduledExecutorService) - Constructor for class org.apache.camel.support.ScheduledBatchPollingConsumer
-
- ScheduledPollConsumer - Class in org.apache.camel.support
-
A useful base class for any consumer which is polling based
- ScheduledPollConsumer(Endpoint, Processor) - Constructor for class org.apache.camel.support.ScheduledPollConsumer
-
- ScheduledPollConsumer(Endpoint, Processor, ScheduledExecutorService) - Constructor for class org.apache.camel.support.ScheduledPollConsumer
-
- ScheduledPollConsumerHealthCheck - Class in org.apache.camel.support
-
- ScheduledPollConsumerHealthCheck(ScheduledPollConsumer, String) - Constructor for class org.apache.camel.support.ScheduledPollConsumerHealthCheck
-
- ScheduledPollEndpoint - Class in org.apache.camel.support
-
- ScheduledPollEndpoint(String, Component) - Constructor for class org.apache.camel.support.ScheduledPollEndpoint
-
- ScheduledPollEndpoint() - Constructor for class org.apache.camel.support.ScheduledPollEndpoint
-
- schedulePoll() - Method in class org.apache.camel.support.DefaultTimeoutMap
-
lets schedule each time to allow folks to change the time at runtime
- scheduleTask(Runnable) - Method in class org.apache.camel.support.DefaultScheduledPollConsumerScheduler
-
- scope(ComponentVerifierExtension.Scope) - Method in class org.apache.camel.component.extension.verifier.ResultBuilder
-
- ScriptHelper - Class in org.apache.camel.support
-
- select(Collection<CamelClusterService>) - Method in class org.apache.camel.support.cluster.ClusterServiceSelectors.SelectByAttribute
-
- select(Collection<CamelClusterService>) - Method in class org.apache.camel.support.cluster.ClusterServiceSelectors.SelectByOrder
-
- select(Collection<CamelClusterService>) - Method in class org.apache.camel.support.cluster.ClusterServiceSelectors.SelectByType
-
- select(Collection<CamelClusterService>) - Method in class org.apache.camel.support.cluster.ClusterServiceSelectors.SelectFirst
-
- select(Collection<CamelClusterService>) - Method in class org.apache.camel.support.cluster.ClusterServiceSelectors.SelectSingle
-
- SelectByAttribute(String, Object) - Constructor for class org.apache.camel.support.cluster.ClusterServiceSelectors.SelectByAttribute
-
- SelectByOrder() - Constructor for class org.apache.camel.support.cluster.ClusterServiceSelectors.SelectByOrder
-
- SelectByType(Class<? extends CamelClusterService>) - Constructor for class org.apache.camel.support.cluster.ClusterServiceSelectors.SelectByType
-
- SelectFirst() - Constructor for class org.apache.camel.support.cluster.ClusterServiceSelectors.SelectFirst
-
- SelectSingle() - Constructor for class org.apache.camel.support.cluster.ClusterServiceSelectors.SelectSingle
-
- send(Endpoint, Exchange, Processor) - Method in class org.apache.camel.support.cache.DefaultProducerCache
-
- SendDynamicAwareSupport - Class in org.apache.camel.support.component
-
Support class for SendDynamicAware
implementations.
- SendDynamicAwareSupport() - Constructor for class org.apache.camel.support.component.SendDynamicAwareSupport
-
- sendNotification(Notification) - Method in class org.apache.camel.support.management.NotificationSenderAdapter
-
- SEPARATOR - Static variable in class org.apache.camel.support.jndi.JndiContext
-
- serializedExecutor - Variable in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- setAction(String) - Method in class org.apache.camel.support.processor.ThroughputLogger
-
- setAfter(Processor) - Method in class org.apache.camel.support.DefaultInterceptSendToEndpoint
-
- setAllowContextMapAll(boolean) - Method in class org.apache.camel.component.ResourceEndpoint
-
Sets whether the context map should allow access to all details.
- setAllowNullValues(boolean) - Method in class org.apache.camel.support.DefaultHeaderFilterStrategy
-
Whether to allow null values.
- setApiHelpers(Map<E, ApiMethodHelper<? extends ApiMethod>>) - Method in class org.apache.camel.support.component.ApiCollection
-
- setApiMethods(Map<Class<? extends ApiMethod>, E>) - Method in class org.apache.camel.support.component.ApiCollection
-
- setAttribute(String, Object) - Method in class org.apache.camel.support.cluster.AbstractCamelClusterService
-
- setAttributes(Map<String, Object>) - Method in class org.apache.camel.support.cluster.AbstractCamelClusterService
-
- setAutoRelease(boolean) - Method in class org.apache.camel.support.DefaultPooledExchange
-
- setAutowiredEnabled(boolean) - Method in class org.apache.camel.support.DefaultComponent
-
Whether autowiring is enabled.
- setAutowiredEnabled(boolean) - Method in class org.apache.camel.support.DefaultEndpoint
-
Whether autowiring is enabled.
- setBackoffErrorThreshold(int) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setBackoffErrorThreshold(int) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
The number of subsequent error polls (failed due some error) that should happen before the backoffMultipler
should kick-in.
- setBackoffIdleThreshold(int) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setBackoffIdleThreshold(int) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
The number of subsequent idle polls that should happen before the backoffMultipler should kick-in.
- setBackoffMultiplier(int) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setBackoffMultiplier(int) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
To let the scheduled polling consumer backoff if there has been a number of subsequent idles/errors in a row.
- setBefore(Processor) - Method in class org.apache.camel.support.DefaultInterceptSendToEndpoint
-
- setBlockTimeout(long) - Method in class org.apache.camel.support.EventDrivenPollingConsumer
-
- setBlockWhenFull(boolean) - Method in class org.apache.camel.support.EventDrivenPollingConsumer
-
- setBody(Object) - Method in class org.apache.camel.support.MessageSupport
-
- setBody(Object, Class<T>) - Method in class org.apache.camel.support.MessageSupport
-
- setBody(Object, DataType) - Method in class org.apache.camel.support.MessageSupport
-
- setBridgeErrorHandler(boolean) - Method in class org.apache.camel.support.DefaultComponent
-
Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the
consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by
the routing Error Handler.
- setBridgeErrorHandler(boolean) - Method in class org.apache.camel.support.DefaultEndpoint
-
Allows for bridging the consumer to the Camel routing Error Handler, which mean any exceptions occurred while the
consumer is trying to pickup incoming messages, or the likes, will now be processed as a message and handled by
the routing Error Handler.
- setCache(Map<String, Object>) - Method in class org.apache.camel.support.processor.idempotent.FileIdempotentRepository
-
- setCacheSize(int) - Method in class org.apache.camel.support.processor.idempotent.FileIdempotentRepository
-
Sets the 1st-level cache size.
- setCacheSize(int) - Method in class org.apache.camel.support.processor.idempotent.MemoryIdempotentRepository
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.component.extension.metadata.AbstractMetaDataExtension
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.component.extension.verifier.DefaultComponentVerifierExtension
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.converter.stream.StreamCacheBulkConverterLoader
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.saga.InMemorySagaService
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.cluster.AbstractCamelClusterService
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.cluster.AbstractCamelClusterView
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.component.EndpointUriFactorySupport
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.component.SendDynamicAwareSupport
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.DefaultComponent
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.DefaultEndpoint
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.DefaultInterceptSendToEndpoint
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.DefaultRegistry
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.DefaultScheduledPollConsumerScheduler
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.DefaultThreadPoolFactory
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.ExpressionToPredicateAdapter
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.HeaderSelectorProducer
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.LanguageSupport
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.MessageSupport
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.PooledObjectFactorySupport
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.processor.MarshalProcessor
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.processor.UnmarshalProcessor
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.PrototypeObjectFactorySupport
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.ResourceReloadStrategySupport
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.ResourceResolverSupport
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.RoutesBuilderLoaderSupport
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.support.TimerListenerManager
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
-
- setCamelContext(CamelContext) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
-
- setCapacity(int) - Method in class org.apache.camel.support.PooledObjectFactorySupport
-
- setCapacity(int) - Method in class org.apache.camel.support.PrototypeObjectFactorySupport
-
- setCaseInsensitive(boolean) - Method in class org.apache.camel.support.DefaultHeaderFilterStrategy
-
Sets the caseInsensitive property which is a boolean to determine whether header names should be case insensitive
when checking it with the filter set.
- setClassLoader(ClassLoader) - Method in class org.apache.camel.support.component.ApiMethodParser
-
- setComponent(Component) - Method in class org.apache.camel.component.extension.metadata.AbstractMetaDataExtension
-
- setComponent(Component) - Method in class org.apache.camel.component.extension.verifier.DefaultComponentVerifierExtension
-
- setComponent(Component) - Method in class org.apache.camel.support.DefaultEndpoint
-
- setConcurrentConsumers(int) - Method in class org.apache.camel.support.DefaultScheduledPollConsumerScheduler
-
- setConfiguration(T) - Method in class org.apache.camel.support.component.AbstractApiComponent
-
- setContentCache(boolean) - Method in class org.apache.camel.component.ResourceEndpoint
-
Sets whether to use resource content cache or not.
- setContext(Context) - Method in class org.apache.camel.support.jndi.JndiBeanRepository
-
- setCopy(boolean) - Method in class org.apache.camel.support.EventDrivenPollingConsumer
-
- setCustomKeywords(Set<String>) - Method in class org.apache.camel.support.processor.DefaultMaskingFormatter
-
Adds custom keywords for masking.
- setDataType(DataType) - Method in class org.apache.camel.support.MessageSupport
-
- setDelay(long) - Method in class org.apache.camel.support.DefaultScheduledPollConsumerScheduler
-
- setDelay(long) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setDelay(long) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
Milliseconds before the next poll.
- setDelegate(CamelPreemptiveClusterService) - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- setDescriptions(Map<String, String>) - Method in class org.apache.camel.support.component.ApiMethodParser
-
- setDisabled(String, boolean) - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- setDropOldestFileStore(long) - Method in class org.apache.camel.support.processor.idempotent.FileIdempotentRepository
-
Sets the number of oldest entries to drop from the file store when the maximum capacity is hit to reduce disk
space to allow room for new entries.
- setEnabled(boolean) - Method in class org.apache.camel.support.startup.DefaultStartupStepRecorder
-
- setEndpointHeaderFilterStrategy(Endpoint) - Method in class org.apache.camel.support.HeaderFilterStrategyComponent
-
Sets the header filter strategy to use from the given endpoint if the endpoint is a
HeaderFilterStrategyAware
type.
- setEndpointUri(String) - Method in class org.apache.camel.support.DefaultEndpoint
-
Sets the URI that created this endpoint.
- setEndpointUriIfNotSpecified(String) - Method in class org.apache.camel.support.DefaultEndpoint
-
Sets the endpointUri if it has not been specified yet via some kind of dependency injection mechanism.
- setEventNotifierEnabled(boolean) - Method in class org.apache.camel.support.cache.DefaultProducerCache
-
- setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.support.DefaultConsumer
-
- setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.support.DefaultEndpoint
-
To let the consumer use a custom ExceptionHandler.
- setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.support.PollingConsumerSupport
-
- setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.support.RoutePolicySupport
-
- setExchange(Exchange) - Method in class org.apache.camel.support.MessageSupport
-
- setExchangePattern(ExchangePattern) - Method in class org.apache.camel.support.DefaultEndpoint
-
Sets the default exchange pattern when creating an exchange.
- setExpireTime(long) - Method in class org.apache.camel.support.TimeoutMapEntry
-
- setExtendedStatistics(boolean) - Method in class org.apache.camel.support.cache.DefaultConsumerCache
-
Whether extended JMX statistics is enabled for EndpointUtilizationStatistics
- setExtendedStatistics(boolean) - Method in class org.apache.camel.support.cache.DefaultProducerCache
-
Whether extended JMX statistics is enabled for EndpointUtilizationStatistics
- setFailed(int) - Method in class org.apache.camel.support.ResourceReloadStrategySupport
-
- setFailureHandled(Exchange) - Static method in class org.apache.camel.support.ExchangeHelper
-
Sets the exchange to be failure handled.
- setFailureThreshold(int) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
-
- setFailureWindow(long) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
-
- setFallbackRegistry(Registry) - Method in class org.apache.camel.support.DefaultRegistry
-
To use a custom Registry
as fallback.
- setFileFilter(FileFilter) - Method in class org.apache.camel.support.FileWatcherResourceReloadStrategy
-
To use a custom filter for accepting files.
- setFileStore(File) - Method in class org.apache.camel.support.processor.idempotent.FileIdempotentRepository
-
- setFilterOnMatch(boolean) - Method in class org.apache.camel.support.DefaultHeaderFilterStrategy
-
Sets the filterOnMatch property which is a boolean to determine what to do when a pattern or filter set is
matched.
- setFolder(String) - Method in class org.apache.camel.support.FileWatcherResourceReloadStrategy
-
- setGreedy(boolean) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setGreedy(boolean) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
If greedy is enabled, then the ScheduledPollConsumer will run immediately again, if the previous run polled 1 or
more messages.
- setGroupDelay(long) - Method in class org.apache.camel.support.processor.ThroughputLogger
-
- setGroupInterval(Long) - Method in class org.apache.camel.support.processor.ThroughputLogger
-
- setGroupSize(Integer) - Method in class org.apache.camel.support.processor.ThroughputLogger
-
- setHalfOpenAfter(long) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
-
- setHalfOpenHandler(ThrottlingExceptionHalfOpenHandler) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
-
- setHeader(String, Object) - Method in class org.apache.camel.support.DefaultMessage
-
- setHeaderFilterStrategy(HeaderFilterStrategy) - Method in class org.apache.camel.support.HeaderFilterStrategyComponent
-
To use a custom HeaderFilterStrategy
to filter header to and from Camel message.
- setHeaders(Map<String, Object>) - Method in class org.apache.camel.support.DefaultMessage
-
- setHealthCheck(HealthCheck) - Method in class org.apache.camel.support.DefaultConsumer
-
- setId(String) - Method in class org.apache.camel.support.cluster.AbstractCamelClusterService
-
- setId(String) - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- setId(String) - Method in class org.apache.camel.support.processor.CamelLogProcessor
-
- setId(String) - Method in class org.apache.camel.support.processor.ConvertBodyProcessor
-
- setId(String) - Method in class org.apache.camel.support.processor.MarshalProcessor
-
- setId(String) - Method in class org.apache.camel.support.processor.ThroughputLogger
-
- setId(String) - Method in class org.apache.camel.support.processor.UnmarshalProcessor
-
- setIgnoreCamelContextEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreCamelContextEvents(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setIgnoreCamelContextInitEvents(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setIgnoreExchangeCompletedEvent(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeCompletedEvent(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setIgnoreExchangeCreatedEvent(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeCreatedEvent(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setIgnoreExchangeEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeEvents(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setIgnoreExchangeFailedEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeFailedEvents(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setIgnoreExchangeRedeliveryEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeRedeliveryEvents(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setIgnoreExchangeSendingEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeSendingEvents(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setIgnoreExchangeSentEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreExchangeSentEvents(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setIgnoreRouteEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreRouteEvents(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setIgnoreServiceEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreServiceEvents(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setIgnoreStepEvents(boolean) - Method in class org.apache.camel.support.EventNotifierSupport
-
- setIgnoreStepEvents(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setIn(Message) - Method in class org.apache.camel.support.DefaultPooledExchange
-
- setInBody(String) - Method in class org.apache.camel.support.component.AbstractApiEndpoint
-
Sets the name of a parameter to be passed in the exchange In Body.
- setIncludeInvalidBoolean(boolean) - Method in class org.apache.camel.component.extension.verifier.CatalogVerifierCustomizer
-
- setIncludeInvalidEnum(boolean) - Method in class org.apache.camel.component.extension.verifier.CatalogVerifierCustomizer
-
- setIncludeInvalidInteger(boolean) - Method in class org.apache.camel.component.extension.verifier.CatalogVerifierCustomizer
-
- setIncludeInvalidNumber(boolean) - Method in class org.apache.camel.component.extension.verifier.CatalogVerifierCustomizer
-
- setIncludeRequired(boolean) - Method in class org.apache.camel.component.extension.verifier.CatalogVerifierCustomizer
-
- setIncludeUnknown(boolean) - Method in class org.apache.camel.component.extension.verifier.CatalogVerifierCustomizer
-
- setInFilter(Set<String>) - Method in class org.apache.camel.support.DefaultHeaderFilterStrategy
-
Sets the "in" direction filter set.
- setInFilterPattern(String) - Method in class org.apache.camel.support.DefaultHeaderFilterStrategy
-
Sets the "in" direction filter regular expression
Pattern
.
- setInFilterPattern(Pattern) - Method in class org.apache.camel.support.DefaultHeaderFilterStrategy
-
Sets the "in" direction filter regular expression
Pattern
.
- setInFilterStartsWith(String...) - Method in class org.apache.camel.support.DefaultHeaderFilterStrategy
-
Sets the "in" direction filter by starts with pattern.
- setInitialDelay(long) - Method in class org.apache.camel.support.DefaultScheduledPollConsumerScheduler
-
- setInitialDelay(long) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setInitialDelay(long) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
Milliseconds before the first poll starts.
- setInterruptedExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.support.EventDrivenPollingConsumer
-
- setInterval(long) - Method in class org.apache.camel.support.TimerListenerManager
-
Sets the interval in millis.
- setKeepOpen(boolean) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
-
- setLazyStartProducer(boolean) - Method in class org.apache.camel.support.DefaultComponent
-
Whether the producer should be started lazy (on the first message).
- setLazyStartProducer(boolean) - Method in class org.apache.camel.support.DefaultEndpoint
-
Whether the producer should be started lazy (on the first message).
- setLevel(LoggingLevel) - Method in class org.apache.camel.support.processor.CamelLogProcessor
-
- setLocalBeanRepository(BeanRepository) - Method in class org.apache.camel.support.DefaultRegistry
-
Sets a special local bean repository (ie thread local) that take precedence and will use first, if a bean exists.
- setLogger(CamelLogger) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
-
Sets the logger to use for logging throttling activity.
- setLoggingLevel(LoggingLevel) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
-
Sets the logging level to report the throttling activity.
- setLogName(String) - Method in class org.apache.camel.support.processor.CamelLogProcessor
-
- setLowerCase(boolean) - Method in class org.apache.camel.support.DefaultHeaderFilterStrategy
-
Sets the isLowercase property which is a boolean to determine whether header names should be converted to lower
case before checking it with the filter Set.
- setLRUCacheFactory(LRUCacheFactory) - Static method in class org.apache.camel.support.LRUCacheFactory
-
Use this to set a specific LRUCacheFactory instance, such as before starting Camel, that then avoids doing auto
discovery of the cache factory via classpath.
- setMarker(String) - Method in class org.apache.camel.support.processor.CamelLogProcessor
-
- setMaskingFormatter(MaskingFormatter) - Method in class org.apache.camel.support.processor.CamelLogProcessor
-
- setMaskJson(boolean) - Method in class org.apache.camel.support.processor.DefaultMaskingFormatter
-
- setMaskKeyValue(boolean) - Method in class org.apache.camel.support.processor.DefaultMaskingFormatter
-
- setMaskString(String) - Method in class org.apache.camel.support.processor.DefaultMaskingFormatter
-
The string to use for replacement such as xxxxx
- setMaskXmlElement(boolean) - Method in class org.apache.camel.support.processor.DefaultMaskingFormatter
-
- setMaxChars(int) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
Limits the number of characters logged per line.
- setMaxDepth(int) - Method in class org.apache.camel.support.startup.DefaultStartupStepRecorder
-
- setMaxFileStoreSize(long) - Method in class org.apache.camel.support.processor.idempotent.FileIdempotentRepository
-
Sets the maximum file size for the file store in bytes.
- setMaxInflightExchanges(int) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
-
Sets the upper limit of number of concurrent inflight exchanges at which point reached the throttler should
suspend the route.
- setMaxMessagesPerPoll(int) - Method in class org.apache.camel.support.ScheduledBatchPollingConsumer
-
- setMaxRetryAttempts(int) - Method in class org.apache.camel.saga.InMemorySagaService
-
- setMessageId(String) - Method in class org.apache.camel.support.MessageSupport
-
- setMultiline(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
If enabled then each information is outputted on a newline.
- setNumberFormat(NumberFormat) - Method in class org.apache.camel.support.processor.ThroughputLogger
-
- setOrder(int) - Method in class org.apache.camel.support.cluster.AbstractCamelClusterService
-
- setOut(Message) - Method in class org.apache.camel.support.DefaultPooledExchange
-
- setOutFilter(Set<String>) - Method in class org.apache.camel.support.DefaultHeaderFilterStrategy
-
Sets the "out" direction filter set.
- setOutFilterPattern(String) - Method in class org.apache.camel.support.DefaultHeaderFilterStrategy
-
Sets the "out" direction filter regular expression
Pattern
.
- setOutFilterPattern(Pattern) - Method in class org.apache.camel.support.DefaultHeaderFilterStrategy
-
Sets the "out" direction filter regular expression
Pattern
.
- setOutFilterStartsWith(String...) - Method in class org.apache.camel.support.DefaultHeaderFilterStrategy
-
Sets the "out" direction filter by starts with pattern.
- setParameters(Map<String, Map<String, String>>) - Method in class org.apache.camel.support.component.ApiMethodParser
-
- setPattern(String) - Method in class org.apache.camel.support.RouteWatcherReloadStrategy
-
Used for inclusive filtering of routes from directories.
- setPollingConsumerBlockTimeout(long) - Method in class org.apache.camel.support.DefaultEndpoint
-
- setPollingConsumerBlockWhenFull(boolean) - Method in class org.apache.camel.support.DefaultEndpoint
-
- setPollingConsumerCopy(boolean) - Method in class org.apache.camel.support.DefaultEndpoint
-
- setPollingConsumerQueueSize(int) - Method in class org.apache.camel.support.DefaultEndpoint
-
- setPollStrategy(PollingConsumerPollStrategy) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setPollStrategy(PollingConsumerPollStrategy) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
A pluggable org.apache.camel.PollingConsumerPollingStrategy allowing you to provide your custom implementation to
control error handling usually occurred during the poll operation before an Exchange have been created and being
routed in Camel.
- setPollTimeout(long) - Method in class org.apache.camel.support.FileWatcherResourceReloadStrategy
-
Sets the poll timeout in millis.
- setPoolSize(int) - Method in class org.apache.camel.support.DefaultScheduledPollConsumerScheduler
-
- setProcessor(AsyncProcessor) - Method in class org.apache.camel.support.processor.DelegateAsyncProcessor
-
- setProcessor(Processor) - Method in class org.apache.camel.support.processor.DelegateAsyncProcessor
-
- setProcessor(Processor) - Method in class org.apache.camel.support.processor.DelegateProcessor
-
- setProcessor(Processor) - Method in class org.apache.camel.support.ProcessorEndpoint
-
- setProperties(T, Map<String, Object>) - Method in class org.apache.camel.component.extension.verifier.DefaultComponentVerifierExtension
-
- setProperties(T, String, Map<String, Object>) - Method in class org.apache.camel.component.extension.verifier.DefaultComponentVerifierExtension
-
- setProperties(Endpoint, Map<String, Object>) - Method in class org.apache.camel.support.DefaultComponent
-
Configure an endpoint using the given parameters.
- setProperties(Object, Map<String, Object>) - Method in class org.apache.camel.support.DefaultComponent
-
Sets the bean properties on the given bean
- setProperties(CamelContext, Object, Map<String, Object>) - Method in class org.apache.camel.support.DefaultComponent
-
Sets the bean properties on the given bean using the given CamelContext
.
- setProperties(Object, Map<String, Object>) - Method in class org.apache.camel.support.DefaultEndpoint
-
Sets the bean properties on the given bean.
- setProperties(CamelContext, Object, Map<String, Object>) - Static method in class org.apache.camel.support.EndpointHelper
-
- setProperties(Object, Map<String, Object>, String, boolean) - Static method in class org.apache.camel.support.IntrospectionSupport
-
- setProperties(Object, Map<String, Object>, String) - Static method in class org.apache.camel.support.IntrospectionSupport
-
- setProperties(CamelContext, TypeConverter, Object, Map<String, Object>) - Static method in class org.apache.camel.support.IntrospectionSupport
-
- setProperties(TypeConverter, Object, Map<String, Object>) - Static method in class org.apache.camel.support.IntrospectionSupport
-
- setProperties(Object, Map<String, Object>) - Static method in class org.apache.camel.support.IntrospectionSupport
-
- setProperty(CamelContext, TypeConverter, Object, String, Object, String, boolean) - Static method in class org.apache.camel.support.IntrospectionSupport
-
Deprecated.
This method supports three modes to set a property:
1.
- setProperty(CamelContext, TypeConverter, Object, String, Object, String, boolean, boolean, boolean) - Static method in class org.apache.camel.support.IntrospectionSupport
-
Deprecated.
This method supports three modes to set a property:
1.
- setProperty(CamelContext, Object, String, Object) - Static method in class org.apache.camel.support.IntrospectionSupport
-
Deprecated.
- setProperty(CamelContext, TypeConverter, Object, String, Object) - Static method in class org.apache.camel.support.IntrospectionSupport
-
Deprecated.
- setProperty(TypeConverter, Object, String, Object) - Static method in class org.apache.camel.support.IntrospectionSupport
-
Deprecated.
- setProperty(Object, String, Object, boolean) - Static method in class org.apache.camel.support.IntrospectionSupport
-
Deprecated.
- setProperty(Object, String, Object) - Static method in class org.apache.camel.support.IntrospectionSupport
-
Deprecated.
- setRecording(boolean) - Method in class org.apache.camel.support.startup.DefaultStartupStepRecorder
-
- setRecordingDir(String) - Method in class org.apache.camel.support.startup.DefaultStartupStepRecorder
-
- setRecordingProfile(String) - Method in class org.apache.camel.support.startup.DefaultStartupStepRecorder
-
- setRecursive(boolean) - Method in class org.apache.camel.support.FileWatcherResourceReloadStrategy
-
- setReferenceProperties(CamelContext, Object, Map<String, Object>) - Static method in class org.apache.camel.support.EndpointHelper
-
- setRemoveAllRoutes(boolean) - Method in class org.apache.camel.support.RouteWatcherReloadStrategy
-
When reloading routes should all existing routes be stopped and removed.
- setRepeatCount(long) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setRepeatCount(long) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
Specifies a maximum limit of number of fires.
- setResourceReload(ResourceReload) - Method in class org.apache.camel.support.ResourceReloadStrategySupport
-
- setResourceUri(String) - Method in class org.apache.camel.component.ResourceEndpoint
-
Path to the resource.
- setResult(T) - Method in class org.apache.camel.support.AsyncCallbackToCompletableFutureAdapter
-
- setResumePercentOfMax(int) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
-
Sets at which percentage of the max the throttler should start resuming the route.
- setRetryDelayInMilliseconds(long) - Method in class org.apache.camel.saga.InMemorySagaService
-
- setRoute(Route) - Method in class org.apache.camel.support.DefaultConsumer
-
- setRouteId(String) - Method in class org.apache.camel.support.DefaultConsumer
-
- setRouteId(String) - Method in class org.apache.camel.support.processor.CamelLogProcessor
-
- setRouteId(String) - Method in class org.apache.camel.support.processor.ConvertBodyProcessor
-
- setRouteId(String) - Method in class org.apache.camel.support.processor.MarshalProcessor
-
- setRouteId(String) - Method in class org.apache.camel.support.processor.ThroughputLogger
-
- setRouteId(String) - Method in class org.apache.camel.support.processor.UnmarshalProcessor
-
- setRunLoggingLevel(LoggingLevel) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setRunLoggingLevel(LoggingLevel) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
The consumer logs a start/complete log line when it polls.
- setScheduledExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.support.DefaultScheduledPollConsumerScheduler
-
- setScheduledExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setScheduledExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
Allows for configuring a custom/shared thread pool to use for the consumer.
- setScheduler(ScheduledPollConsumerScheduler) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setScheduler(Object) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
Allow to plugin a custom org.apache.camel.spi.ScheduledPollConsumerScheduler to use as the scheduler for firing
when the polling consumer runs.
- setSchedulerProperties(Map<String, Object>) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setSchedulerProperties(Map<String, Object>) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
To configure additional properties when using a custom scheduler or any of the Quartz, Spring based scheduler.
- setScheme(String) - Method in class org.apache.camel.support.component.SendDynamicAwareSupport
-
- setScope(ThrottlingInflightRoutePolicy.ThrottlingScope) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
-
Sets which scope the throttling should be based upon, either route or total scoped.
- setSendEmptyMessageWhenIdle(boolean) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setSendEmptyMessageWhenIdle(boolean) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
If the polling consumer did not poll any files, you can enable this option to send an empty message (no body)
instead.
- setShowAll(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
Quick option for turning all options on.
- setShowAllProperties(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
Show all of the exchange properties (both internal and custom).
- setShowBody(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
- setShowBodyType(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
Show the body Java type.
- setShowCaughtException(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
If the exchange has a caught exception, show the exception message (no stack trace).
- setShowException(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
If the exchange has an exception, show the exception message (no stacktrace)
- setShowExchangeId(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
Show the unique exchange ID.
- setShowExchangePattern(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
Shows the Message Exchange Pattern (or MEP for short).
- setShowFiles(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
If enabled Camel will output files
- setShowFuture(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
If enabled Camel will on Future objects wait for it to complete to obtain the payload to be logged.
- setShowHeaders(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
Show the message headers.
- setShowProperties(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
Show the exchange properties (only custom).
- setShowStackTrace(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
Show the stack trace, if an exchange has an exception.
- setShowStreams(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
Whether Camel should show stream bodies or not (eg such as java.io.InputStream).
- setSignatures(List<String>) - Method in class org.apache.camel.support.component.ApiMethodParser
-
- setSkip(boolean) - Method in class org.apache.camel.support.DefaultInterceptSendToEndpoint
-
- setSkipBodyLineSeparator(boolean) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
Whether to skip line separators when logging the message body.
- setSplitResult(boolean) - Method in class org.apache.camel.support.component.AbstractApiConfiguration
-
- setSplitResult(boolean) - Method in class org.apache.camel.support.component.AbstractApiConsumer
-
- setStartScheduler(boolean) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setStartScheduler(boolean) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
Whether the scheduler should be auto started.
- setStartupRecorderDuration(long) - Method in class org.apache.camel.support.startup.DefaultStartupStepRecorder
-
- setStatisticsEnabled(boolean) - Method in class org.apache.camel.support.PooledObjectFactorySupport
-
- setStatisticsEnabled(boolean) - Method in class org.apache.camel.support.PrototypeObjectFactorySupport
-
- setStyle(DefaultExchangeFormatter.OutputStyle) - Method in class org.apache.camel.support.processor.DefaultExchangeFormatter
-
Sets the outputs style to use.
- setSucceeded(int) - Method in class org.apache.camel.support.ResourceReloadStrategySupport
-
- setSupplierRegistry(Registry) - Method in class org.apache.camel.support.DefaultRegistry
-
To use a custom Registry
for suppliers.
- setTimeout(int) - Method in class org.apache.camel.support.DefaultScheduledPollConsumer
-
Sets a timeout to use with PollingConsumer
.
- setTimeout(long) - Method in class org.apache.camel.support.TimeoutMapEntry
-
- setTimeUnit(TimeUnit) - Method in class org.apache.camel.support.DefaultScheduledPollConsumerScheduler
-
- setTimeUnit(TimeUnit) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setTimeUnit(TimeUnit) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
Time unit for initialDelay and delay options.
- setupComponent(String, CamelContext, Map<String, Object>) - Static method in class org.apache.camel.support.RestProducerFactoryHelper
-
- setupComponentFor(String, CamelContext, Map<String, Object>) - Static method in class org.apache.camel.support.RestProducerFactoryHelper
-
- setupIgnore(boolean) - Method in class org.apache.camel.support.SimpleEventNotifierSupport
-
- setUseFixedDelay(boolean) - Method in class org.apache.camel.support.DefaultScheduledPollConsumerScheduler
-
- setUseFixedDelay(boolean) - Method in class org.apache.camel.support.ScheduledPollConsumer
-
- setUseFixedDelay(boolean) - Method in class org.apache.camel.support.ScheduledPollEndpoint
-
Controls if fixed delay or fixed rate is used.
- setValue(Object) - Method in class org.apache.camel.support.ConstantExpressionAdapter
-
- setValue(V) - Method in class org.apache.camel.support.TimeoutMapEntry
-
- ShortUuidGenerator - Class in org.apache.camel.support
-
UuidGenerator
that is 50% the size of the default (16 chars) optimized for Camel usage.
- ShortUuidGenerator() - Constructor for class org.apache.camel.support.ShortUuidGenerator
-
- shutdown() - Method in class org.apache.camel.support.ChildServiceSupport
-
- shutdown() - Method in class org.apache.camel.support.DefaultInterceptSendToEndpoint
-
- shutdownRunningTask - Variable in class org.apache.camel.support.ScheduledBatchPollingConsumer
-
- SimpleEventNotifierSupport - Class in org.apache.camel.support
-
Base class to extend for custom EventNotifier
implementations.
- SimpleEventNotifierSupport() - Constructor for class org.apache.camel.support.SimpleEventNotifierSupport
-
- simpleExpression(String) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
- SimpleRegistry - Class in org.apache.camel.support
-
- SimpleRegistry() - Constructor for class org.apache.camel.support.SimpleRegistry
-
- SimpleTypeConverter - Class in org.apache.camel.support
-
Another base class for TypeConverter
implementations.
- SimpleTypeConverter(boolean, SimpleTypeConverter.ConversionMethod) - Constructor for class org.apache.camel.support.SimpleTypeConverter
-
- SimpleTypeConverter.ConversionMethod - Interface in org.apache.camel.support
-
- SimpleUuidGenerator - Class in org.apache.camel.support
-
This implementation uses a counter which increments by one.
- SimpleUuidGenerator() - Constructor for class org.apache.camel.support.SimpleUuidGenerator
-
- single() - Static method in class org.apache.camel.support.cluster.ClusterServiceSelectors
-
- size() - Method in class org.apache.camel.converter.stream.StreamCacheBulkConverterLoader
-
- size() - Method in class org.apache.camel.support.cache.DefaultConsumerCache
-
Returns the current size of the cache
- size() - Method in class org.apache.camel.support.cache.DefaultProducerCache
-
- size() - Method in class org.apache.camel.support.DefaultEndpointUtilizationStatistics
-
- size() - Method in class org.apache.camel.support.DefaultTimeoutMap
-
- skip(long) - Method in class org.apache.camel.converter.stream.FileInputStreamCache
-
- skipFirstExpression(Expression) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns an expression that skips the first element
- sort(Comparator<?>) - Method in class org.apache.camel.support.builder.ValueBuilder
-
Sorts the current value using the given comparator.
- sortExpression(Expression, Comparator) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns a sort expression which will sort the expression with the given comparator.
- source - Variable in class org.apache.camel.support.PooledObjectFactorySupport
-
- splitResult(Object) - Method in class org.apache.camel.support.component.AbstractApiConsumer
-
- splitResult(Object) - Method in class org.apache.camel.support.component.AbstractApiProducer
-
- splitResult(Object) - Method in interface org.apache.camel.support.component.ResultInterceptor
-
Split a complex result into result elements.
- start() - Method in class org.apache.camel.support.ChildServiceSupport
-
- start() - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- start() - Method in class org.apache.camel.support.DefaultInterceptSendToEndpoint
-
- start() - Method in class org.apache.camel.support.management.MBeanInfoAssembler
-
- startConsumer(Consumer) - Method in class org.apache.camel.support.RoutePolicySupport
-
Starts the consumer.
- startRoute(Route) - Method in class org.apache.camel.support.RoutePolicySupport
-
- startScheduler() - Method in class org.apache.camel.support.DefaultScheduledPollConsumerScheduler
-
- startScheduler() - Method in class org.apache.camel.support.ScheduledPollConsumer
-
Starts the scheduler.
- startsWith(Expression, Expression) - Static method in class org.apache.camel.support.builder.PredicateBuilder
-
- startsWith(Object) - Method in class org.apache.camel.support.builder.ValueBuilder
-
- startToken - Variable in class org.apache.camel.support.builder.TokenPairExpressionIterator
-
- startView(String) - Method in class org.apache.camel.support.cluster.AbstractCamelClusterService
-
- startView(String) - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- statistics - Variable in class org.apache.camel.support.PooledObjectFactorySupport
-
- statistics - Variable in class org.apache.camel.support.PrototypeObjectFactorySupport
-
- statisticsEnabled - Variable in class org.apache.camel.support.PooledObjectFactorySupport
-
- statisticsEnabled - Variable in class org.apache.camel.support.PrototypeObjectFactorySupport
-
- status(ComponentVerifierExtension.Result.Status) - Method in class org.apache.camel.component.extension.verifier.ResultBuilder
-
- stepIdExpression() - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns the expression for the current step id (if any)
- stop() - Method in class org.apache.camel.support.ChildServiceSupport
-
- stop() - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- stop() - Method in class org.apache.camel.support.DefaultInterceptSendToEndpoint
-
- stop() - Static method in class org.apache.camel.support.IntrospectionSupport
-
Deprecated.
CamelContext
should call this stop method when its stopping.
- stop() - Method in class org.apache.camel.support.management.MBeanInfoAssembler
-
- stopConsumer(Consumer) - Method in class org.apache.camel.support.RoutePolicySupport
-
Stops the consumer.
- stopRoute(Route) - Method in class org.apache.camel.support.RoutePolicySupport
-
- stopRoute(Route, long, TimeUnit) - Method in class org.apache.camel.support.RoutePolicySupport
-
- stopRouteAsync(Route) - Method in class org.apache.camel.support.RoutePolicySupport
-
Allows to stop a route asynchronously using a separate background thread which can allow any current in-flight
exchange to complete while the route is being shutdown.
- stopView(String) - Method in class org.apache.camel.support.cluster.AbstractCamelClusterService
-
- stopView(String) - Method in class org.apache.camel.support.cluster.RebalancingCamelClusterService
-
- StreamCacheBulkConverterLoader - Class in org.apache.camel.converter.stream
-
Generated by camel build tools - do NOT edit this file!
- StreamCacheBulkConverterLoader() - Constructor for class org.apache.camel.converter.stream.StreamCacheBulkConverterLoader
-
- 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)
- Substitution(String, String, String) - Constructor for class org.apache.camel.support.component.ArgumentSubstitutionParser.Substitution
-
Creates a substitution for all argument types.
- Substitution(String, String, String, String) - Constructor for class org.apache.camel.support.component.ArgumentSubstitutionParser.Substitution
-
Creates a substitution for a specific argument type.
- Substitution(String, String, String, String, boolean) - Constructor for class org.apache.camel.support.component.ArgumentSubstitutionParser.Substitution
-
Create a substitution for a specific argument type and flag to indicate whether the replacement uses
- supplierRegistry - Variable in class org.apache.camel.support.DefaultRegistry
-
- SupplierRegistry - Class in org.apache.camel.support
-
Used for storing beans that are supplied via a
Supplier
.
- SupplierRegistry() - Constructor for class org.apache.camel.support.SupplierRegistry
-
- suspend() - Method in class org.apache.camel.support.BreakpointSupport
-
- suspendOrStopConsumer(Consumer) - Method in class org.apache.camel.support.RoutePolicySupport
-
Suspends or stops the consumer.
- suspendRoute(Route) - Method in class org.apache.camel.support.RoutePolicySupport
-
- suspendRoute(Route, long, TimeUnit) - Method in class org.apache.camel.support.RoutePolicySupport
-
- swapKey(String, String) - Method in class org.apache.camel.support.LocalBeanRegistry
-
Swaps the key which is used when this local registry have a number of bound beans that would clash with global
registry or endpoint registry in Camel.
- SynchronizationAdapter - Class in org.apache.camel.support
-
Simple Synchronization
adapter with empty methods for easier overriding of single methods.
- SynchronizationAdapter() - Constructor for class org.apache.camel.support.SynchronizationAdapter
-
- SynchronousDelegateProducer - Class in org.apache.camel.support
-
To process the delegated producer in synchronous mode.
- SynchronousDelegateProducer(Producer) - Constructor for class org.apache.camel.support.SynchronousDelegateProducer
-
- SYSTEM_PROPERTIES_NAMESPACE - Static variable in class org.apache.camel.support.builder.Namespaces
-
- systemEnvironmentExpression(String) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns an expression for a system environment value with the given name
- systemEnvironmentExpression(String, String) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns an expression for a system environment value with the given name
- systemEnvironmentExpression(Expression, Expression) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns an expression for a system environment value with the given name
- systemPropertyExpression(String) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns an expression for a system property value with the given name
- systemPropertyExpression(String, String) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns an expression for a system property value with the given name
- systemPropertyExpression(Expression, Expression) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns an expression for a system property value with the given name
- tagToken - Variable in class org.apache.camel.support.builder.TokenXMLExpressionIterator
-
- Task - Interface in org.apache.camel.support.task
-
A task defines a piece of code that may be executed - in the foreground or background - within a certain budget that
is specific to the task type.
- task(Supplier<Y>) - Static method in class org.apache.camel.support.task.Tasks
-
A generic builder for task builders
- TaskBuilder<T extends Task> - Interface in org.apache.camel.support.task
-
Provides a common pattern for building tasks
- Tasks - Class in org.apache.camel.support.task
-
A helper class for building tasks
- test(String, Component) - Method in class org.apache.camel.support.CustomizersSupport.ComponentCustomizationEnabledPolicy
-
- test(String, DataFormat) - Method in class org.apache.camel.support.CustomizersSupport.DataFormatCustomizationEnabledPolicy
-
- test(String, Language) - Method in class org.apache.camel.support.CustomizersSupport.LanguageCustomizationEnabledPolicy
-
- threadNameExpression() - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns the expression for the current thread name
- throttle(Route, Exchange) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
-
Throttles the route when Exchange
s is done.
- ThrottlingExceptionHalfOpenHandler - Interface in org.apache.camel.throttling
-
Used by the
ThrottlingExceptionRoutePolicy
to allow custom code to handle the half open circuit state and how
to determine if a route should be closed
- ThrottlingExceptionRoutePolicy - Class in org.apache.camel.throttling
-
Modeled after the circuit breaker
ThrottlingInflightRoutePolicy
this
RoutePolicy
will stop consuming
from an endpoint based on the type of exceptions that are thrown and the threshold setting.
- ThrottlingExceptionRoutePolicy(int, long, long, List<Class<?>>) - Constructor for class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
-
- ThrottlingExceptionRoutePolicy(int, long, long, List<Class<?>>, boolean) - Constructor for class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
-
- ThrottlingInflightRoutePolicy - Class in org.apache.camel.throttling
-
A throttle based RoutePolicy
which is capable of dynamic throttling a route based on
number of current inflight exchanges.
- ThrottlingInflightRoutePolicy() - Constructor for class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
-
- ThrottlingInflightRoutePolicy.ThrottlingScope - Enum in org.apache.camel.throttling
-
- ThroughputLogger - Class in org.apache.camel.support.processor
-
A logger for logging message throughput.
- ThroughputLogger(CamelLogger) - Constructor for class org.apache.camel.support.processor.ThroughputLogger
-
- ThroughputLogger(CamelLogger, Integer) - Constructor for class org.apache.camel.support.processor.ThroughputLogger
-
- ThroughputLogger(CamelLogger, CamelContext, Long, Long, Boolean) - Constructor for class org.apache.camel.support.processor.ThroughputLogger
-
- TimeBoundedBudget - Class in org.apache.camel.support.task.budget
-
This task budget limits the execution by both a maximum amount of time for the execution.
- TimeBoundedBudgetBuilder() - Constructor for class org.apache.camel.support.task.budget.Budgets.TimeBoundedBudgetBuilder
-
- timeBudget() - Static method in class org.apache.camel.support.task.budget.Budgets
-
- TimeBudget - Interface in org.apache.camel.support.task.budget
-
Defines a budget that limits the task execution to certain length of time
- TimeoutMapEntry<K,V> - Class in org.apache.camel.support
-
Represents an entry in a TimeoutMap
- TimeoutMapEntry(K, V, long) - Constructor for class org.apache.camel.support.TimeoutMapEntry
-
- TimerListenerManager - Class in org.apache.camel.support
-
A TimerListener
manager which triggers the TimerListener
listeners once every
second.
- TimerListenerManager() - Constructor for class org.apache.camel.support.TimerListenerManager
-
- toExpression(Predicate) - Static method in class org.apache.camel.support.PredicateToExpressionAdapter
-
Converts the given predicate into an Expression
- tokenize() - Method in class org.apache.camel.support.builder.ValueBuilder
-
- tokenize(String) - Method in class org.apache.camel.support.builder.ValueBuilder
-
- tokenize(String, int, boolean) - Method in class org.apache.camel.support.builder.ValueBuilder
-
- tokenize(String, String, boolean) - Method in class org.apache.camel.support.builder.ValueBuilder
-
- tokenizeExpression(Expression, String) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns a tokenize expression which will tokenize the string with the
given token
- tokenizeExpression(Expression, Expression) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns a tokenize expression which will tokenize the string with the
given token
- tokenizePairExpression(String, String, boolean) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
- tokenizeXMLAwareExpression(String, char) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
- tokenizeXMLAwareExpression(String, char, int) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
- tokenizeXMLAwareExpression(String, char, int, Namespaces) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
- tokenizeXMLAwareExpression(String, String, char, int, Namespaces) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
- tokenizeXMLExpression(String, String) - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
- TokenPairExpressionIterator - Class in org.apache.camel.support.builder
-
Expression
to walk a
Message
body using an
Iterator
, which
grabs the content between a start and end token.
- TokenPairExpressionIterator(String, String, boolean) - Constructor for class org.apache.camel.support.builder.TokenPairExpressionIterator
-
- TokenXMLExpressionIterator - Class in org.apache.camel.support.builder
-
Expression
to walk a
Message
XML body using an
Iterator
, which grabs the content between a XML start and end token, where the end token
corresponds implicitly to either the end tag or the self-closing start tag.
- TokenXMLExpressionIterator(String, String) - Constructor for class org.apache.camel.support.builder.TokenXMLExpressionIterator
-
- toPredicate(Expression) - Static method in class org.apache.camel.support.builder.PredicateBuilder
-
Converts the given expression into an Predicate
- toPredicate(Expression) - Static method in class org.apache.camel.support.ExpressionToPredicateAdapter
-
Converts the given expression into an Predicate
- toString() - Method in class org.apache.camel.component.extension.verifier.DefaultResult
-
- toString() - Method in class org.apache.camel.component.extension.verifier.DefaultResultVerificationError
-
- toString() - Method in class org.apache.camel.converter.stream.CachedOutputStream
-
- toString() - Method in class org.apache.camel.support.builder.BinaryPredicateSupport
-
- toString() - Method in class org.apache.camel.support.builder.TokenPairExpressionIterator
-
- toString() - Method in class org.apache.camel.support.builder.ValueBuilder
-
- toString() - Method in class org.apache.camel.support.cache.DefaultConsumerCache
-
- toString() - Method in class org.apache.camel.support.cache.DefaultProducerCache
-
- toString() - Method in class org.apache.camel.support.cache.EmptyProducerCache
-
- toString() - Method in class org.apache.camel.support.component.ApiMethodArg
-
- toString() - Method in class org.apache.camel.support.component.ApiMethodImpl
-
- toString() - Method in class org.apache.camel.support.component.ApiMethodParser.ApiMethodModel
-
- toString() - Method in class org.apache.camel.support.DefaultConsumer
-
- toString() - Method in class org.apache.camel.support.DefaultEndpoint
-
- toString() - Method in class org.apache.camel.support.DefaultExchangeHolder
-
- toString() - Method in class org.apache.camel.support.DefaultInterceptSendToEndpoint
-
- toString() - Method in class org.apache.camel.support.DefaultMessageHistory
-
- toString() - Method in class org.apache.camel.support.DefaultProducer
-
- toString() - Method in class org.apache.camel.support.DeferProducer
-
- toString() - Method in class org.apache.camel.support.ExpressionToPredicateAdapter
-
- toString() - Method in class org.apache.camel.support.MessageSupport
-
- toString() - Method in class org.apache.camel.support.NormalizedUri
-
- toString() - Method in class org.apache.camel.support.PollingConsumerSupport
-
- toString() - Method in class org.apache.camel.support.PredicateToExpressionAdapter
-
- toString() - Method in class org.apache.camel.support.processor.CamelLogProcessor
-
- toString() - Method in class org.apache.camel.support.processor.ConvertBodyProcessor
-
- toString() - Method in class org.apache.camel.support.processor.DelegateAsyncProcessor
-
- toString() - Method in class org.apache.camel.support.processor.DelegateProcessor
-
- toString() - Method in class org.apache.camel.support.processor.DelegateSyncProcessor
-
- toString() - Method in class org.apache.camel.support.processor.MarshalProcessor
-
- toString() - Method in class org.apache.camel.support.processor.PredicateValidatingProcessor
-
- toString() - Method in class org.apache.camel.support.processor.UnmarshalProcessor
-
- toString() - Method in class org.apache.camel.support.ResourceSupport
-
- toString() - Method in class org.apache.camel.support.startup.LoggingStartupStepRecorder
-
- toString() - Method in class org.apache.camel.support.SynchronousDelegateProducer
-
- toString() - Method in class org.apache.camel.support.TimeoutMapEntry
-
- toString() - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
-
- trunkStore() - Method in class org.apache.camel.support.processor.idempotent.FileIdempotentRepository
-
Trunks the file store when the max store size is hit by dropping the most oldest entries.
- tryConvertTo(CamelContext, Class<T>, Object) - Static method in class org.apache.camel.support.CamelContextHelper
-
Tried to convert the given value to the requested type
- tryConvertTo(Class<T>, Object) - Method in class org.apache.camel.support.SimpleTypeConverter
-
- tryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.support.SimpleTypeConverter
-
- tryConvertTo(Class<T>, Object) - Method in class org.apache.camel.support.TypeConverterSupport
-
- tryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.support.TypeConverterSupport
-
- tryLock() - Method in class org.apache.camel.support.NoLock
-
- tryLock(long, TimeUnit) - Method in class org.apache.camel.support.NoLock
-
- type(Class<? extends CamelClusterService>) - Static method in class org.apache.camel.support.cluster.ClusterServiceSelectors
-
- typeCoerceCompare(TypeConverter, Object, Object) - Static method in class org.apache.camel.support.ObjectHelper
-
A helper method for comparing objects ordering in which it uses type coercion to coerce types between the left
and right values.
- typeCoerceContains(TypeConverter, Object, Object, boolean) - Static method in class org.apache.camel.support.ObjectHelper
-
Returns true if the collection contains the specified value
- typeCoerceEquals(TypeConverter, Object, Object) - Static method in class org.apache.camel.support.ObjectHelper
-
A helper method for comparing objects for equality in which it uses type coercion to coerce types between the
left and right values.
- typeCoerceEquals(TypeConverter, Object, Object, boolean) - Static method in class org.apache.camel.support.ObjectHelper
-
A helper method for comparing objects for equality in which it uses type coercion to coerce types between the
left and right values.
- typeCoerceNotEquals(TypeConverter, Object, Object) - Static method in class org.apache.camel.support.ObjectHelper
-
A helper method for comparing objects for inequality in which it uses type coercion to coerce types between the
left and right values.
- typeConverterExpression() - Static method in class org.apache.camel.support.builder.ExpressionBuilder
-
Returns an expression for the type converter
- TypeConverterSupport - Class in org.apache.camel.support
-
Base class for TypeConverter
implementations.
- TypeConverterSupport() - Constructor for class org.apache.camel.support.TypeConverterSupport
-
- TypedProcessorFactory<T extends org.apache.camel.NamedNode> - Class in org.apache.camel.support
-
- TypedProcessorFactory(Class<T>) - Constructor for class org.apache.camel.support.TypedProcessorFactory
-