Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X 

A

accept(CamelContext) - Method in class org.apache.camel.spi.CamelContextTracker
Called to determine whether this tracker should accept the given context.
accept(CamelContext) - Method in interface org.apache.camel.spi.CamelContextTracker.Filter
 
ACCEPT_CONTENT_TYPE - Static variable in interface org.apache.camel.Exchange
Deprecated.
acquirePollingConsumer(Endpoint) - Method in interface org.apache.camel.spi.ConsumerCache
Acquires a pooled polling consumer which you must release back again after usage using the ConsumerCache.releasePollingConsumer(Endpoint, PollingConsumer) method.
acquireProducer(Endpoint) - Method in interface org.apache.camel.spi.ProducerCache
Acquires a pooled producer which you must release back again after usage using the ProducerCache.releaseProducer(org.apache.camel.Endpoint, org.apache.camel.AsyncProducer) method.
activate() - Method in interface org.apache.camel.spi.Breakpoint
Activates this breakpoint
activateAllBreakpoints() - Method in interface org.apache.camel.spi.Debugger
Activate all breakpoints.
adapt(Class<T>) - Method in interface org.apache.camel.CamelContext
Adapts this CamelContext to the specialized type.
adapt(Class<T>) - Method in interface org.apache.camel.Exchange
Adapts this Exchange to the specialized type.
adapt(Class<T>) - Method in interface org.apache.camel.spi.RouteController
Adapts this RouteController to the specialized type.
add(CamelContext, String, Exchange) - Method in interface org.apache.camel.spi.AggregationRepository
Add the given Exchange under the correlation key.
add(String, Exchange) - Method in interface org.apache.camel.spi.ClaimCheckRepository
Adds the exchange to the repository.
add(String) - Method in interface org.apache.camel.spi.IdempotentRepository
Adds the key to the repository.
add(Exchange, String) - Method in interface org.apache.camel.spi.IdempotentRepository
Adds the key to the repository.
add(Exchange) - Method in interface org.apache.camel.spi.InflightRepository
Adds the exchange to the inflight registry to the total counter
add(Exchange, String) - Method in interface org.apache.camel.spi.InflightRepository
Adds the exchange to the inflight registry associated to the given route
add(CamelContext, String, Exchange, Exchange) - Method in interface org.apache.camel.spi.OptimisticLockingAggregationRepository
Add the given Exchange under the correlation key.
addAdvice(CamelInternalProcessorAdvice<?>) - Method in interface org.apache.camel.spi.InternalProcessor
Adds an CamelInternalProcessorAdvice advice to the list of advices to execute by this internal processor.
addAllSniHostNames(List<String>) - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
 
addBootstrap(BootstrapCloseable) - Method in interface org.apache.camel.ExtendedCamelContext
Adds a BootstrapCloseable task.
addBootstrapConfigurerClearer(Runnable) - Static method in class org.apache.camel.spi.ConfigurerStrategy
 
addBreakpoint(Breakpoint) - Method in interface org.apache.camel.spi.Debugger
Add the given breakpoint
addBreakpoint(Breakpoint, Condition...) - Method in interface org.apache.camel.spi.Debugger
Add the given breakpoint
addBulkTypeConverters(BulkTypeConverters) - Method in interface org.apache.camel.spi.TypeConverterRegistry
Registers a new set of type converters that are bulked together into a single BulkTypeConverters class.
addChildUnitOfWorkProcessorAdvice(CamelContext, Processor, Route, UnitOfWork) - Method in interface org.apache.camel.spi.InternalProcessorFactory
 
addClassLoader(ClassLoader) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Adds the class loader to the existing loaders
addClassLoader(ClassLoader) - Method in interface org.apache.camel.spi.PackageScanResourceResolver
Adds the class loader to the existing loaders
addComponent(String, Component) - Method in interface org.apache.camel.CamelContext
Adds a component to the context.
addConfiguration(String, HealthCheckConfiguration) - Method in interface org.apache.camel.health.HealthCheckRepository
Adds a health check configuration
addDefaults(ThreadPoolProfile) - Method in class org.apache.camel.spi.ThreadPoolProfile
Overwrites each attribute that is null with the attribute from defaultProfile
addEndpoint(String, Endpoint) - Method in interface org.apache.camel.CamelContext
Adds and starts the endpoint to the EndpointRegistry using the given URI.
addErrorHandler(ErrorHandlerFactory, NamedNode) - Method in interface org.apache.camel.Route
Adds error handler for the given exception type
addErrorHandlerFactoryReference(ErrorHandlerFactory, ErrorHandlerFactory) - Method in interface org.apache.camel.Route
Link the error handlers from a factory to another
addEventListener(CamelClusterEventListener) - Method in interface org.apache.camel.cluster.CamelClusterView
Add an event listener.
addEventNotifier(EventNotifier) - Method in interface org.apache.camel.spi.ManagementStrategy
Adds the event notifier to use.
addFallbackTypeConverter(TypeConverter, boolean) - Method in interface org.apache.camel.spi.TypeConverterRegistry
Registers a new fallback type converter
addFilter(PackageScanFilter) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Add a filter that will be applied to all scan operations
addInterceptStrategy(InterceptStrategy) - Method in interface org.apache.camel.ExtendedCamelContext
Adds the given interceptor strategy
addLenient(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
 
addLifecycleStrategy(LifecycleStrategy) - Method in interface org.apache.camel.CamelContext
Adds the given lifecycle strategy to be used.
addListener(TimeoutMap.Listener<K, V>) - Method in interface org.apache.camel.TimeoutMap
Assign the (singular) TimeoutMap.Listener
addLocation(String) - Method in interface org.apache.camel.spi.PropertiesComponent
Adds the list of locations to the current locations, where to load properties.
addLogListener(LogListener) - Method in interface org.apache.camel.ExtendedCamelContext
Adds a LogListener.
addManagementInterceptStrategy(ManagementInterceptStrategy.InstrumentationProcessor) - Method in interface org.apache.camel.spi.InternalProcessor
 
addNotConsumerOnly(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
 
addNotProducerOnly(String) - Method in class org.apache.camel.catalog.EndpointValidationResult
 
addOnCompletion(Synchronization) - Method in interface org.apache.camel.ExtendedExchange
Adds a Synchronization to be invoked as callback when this exchange is completed.
addPropertiesFunction(PropertiesFunction) - Method in interface org.apache.camel.spi.PropertiesComponent
Registers the PropertiesFunction as a function to this component.
addPropertiesSource(PropertiesSource) - Method in interface org.apache.camel.spi.PropertiesComponent
Adds a custom PropertiesSource to use as source for loading and/or looking up property values.
addPrototypeService(Object) - Method in interface org.apache.camel.CamelContext
Adds a service to this CamelContext (prototype scope).
addReifierClearer(Runnable) - Static method in class org.apache.camel.spi.ReifierStrategy
 
addRestService(Consumer, String, String, String, String, String, String, String, String, String, String, String) - Method in interface org.apache.camel.spi.RestRegistry
Adds a new REST service to the registry.
addRoute(Route) - Method in interface org.apache.camel.ExtendedCamelContext
Internal API for adding routes.
addRoute(String) - Method in interface org.apache.camel.spi.InflightRepository
Adds the route from the in flight registry.
addRouteFromTemplate(String, String, Map<String, Object>) - Method in interface org.apache.camel.CamelContext
Adds a new route from a given route template.
addRouteInflightRepositoryAdvice(InflightRepository, String) - Method in interface org.apache.camel.spi.InternalProcessor
 
addRouteLifecycleAdvice() - Method in interface org.apache.camel.spi.InternalProcessor
 
addRoutePolicyAdvice(List<RoutePolicy>) - Method in interface org.apache.camel.spi.InternalProcessor
 
addRoutePolicyFactory(RoutePolicyFactory) - Method in interface org.apache.camel.CamelContext
Adds the given route policy factory
addRoutes(RoutesBuilder) - Method in interface org.apache.camel.CamelContext
Adds a collection of routes to this CamelContext using the given builder to build them.
addRoutesToCamelContext(CamelContext) - Method in interface org.apache.camel.RoutesBuilder
Adds the routes from this Route Builder to the CamelContext.
addService(Object) - Method in interface org.apache.camel.CamelContext
Adds a service to this CamelContext, which allows this CamelContext to control the lifecycle, ensuring the service is stopped when the CamelContext stops.
addService(Object, boolean) - Method in interface org.apache.camel.CamelContext
Adds a service to this CamelContext.
addService(Object, boolean, boolean) - Method in interface org.apache.camel.CamelContext
Adds a service to this CamelContext.
addService(Service) - Method in interface org.apache.camel.Route
Adds a service to this route
addSingleStepBreakpoint(Breakpoint) - Method in interface org.apache.camel.spi.Debugger
Add the given breakpoint which will be used in single step mode

The debugger will single step the first message arriving.

addSingleStepBreakpoint(Breakpoint, Condition...) - Method in interface org.apache.camel.spi.Debugger
Add the given breakpoint which will be used in single step mode

The debugger will single step the first message arriving.

addSpoolRule(StreamCachingStrategy.SpoolRule) - Method in interface org.apache.camel.spi.StreamCachingStrategy
Adds the StreamCachingStrategy.SpoolRule rule to be used.
addStartupListener(StartupListener) - Method in interface org.apache.camel.CamelContext
Adds the given listener to be invoked when CamelContext have just been started.
addSynchronization(Synchronization) - Method in interface org.apache.camel.spi.UnitOfWork
Adds a synchronization hook
addTypeConverter(Class<?>, Class<?>, TypeConverter) - Method in interface org.apache.camel.spi.TypeConverterRegistry
Registers a new type converter.
addTypeConverters(TypeConverters) - Method in interface org.apache.camel.spi.TypeConverterRegistry
Registers all the type converters from the class, each converter must be implemented as a method and annotated with Converter.
addUnitOfWorkProcessorAdvice(CamelContext, Processor, Route) - Method in interface org.apache.camel.spi.InternalProcessorFactory
 
after(Exchange, T) - Method in interface org.apache.camel.spi.CamelInternalProcessorAdvice
Callback executed after processing a step in the route.
after(Exchange, T) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy.InstrumentationProcessor
 
afterPoll() - Method in interface org.apache.camel.PollingConsumerPollingStrategy
Callback invoked after the poll.
afterProcess(Exchange, Processor, NamedNode, long) - Method in interface org.apache.camel.spi.Breakpoint
Callback invoked when the breakpoint was hit and the Exchange has been processed (after).
afterProcess(Exchange, Processor, NamedNode, long) - Method in interface org.apache.camel.spi.Debugger
Callback invoked when an Exchange has been processed which allows implementators to notify breakpoints.
afterProcess(Processor, Exchange, AsyncCallback, boolean) - Method in interface org.apache.camel.spi.UnitOfWork
Strategy for work to be executed after the processing

This requires UnitOfWork.isBeforeAfterProcess() returns true to be enabled.

AfterPropertiesConfigured - Interface in org.apache.camel
To perform optional initialization on an element after its properties has been configured.
afterPropertiesConfigured(CamelContext) - Method in interface org.apache.camel.AfterPropertiesConfigured
Callback invoked after the element have configured its properties.
afterPropertiesConfigured(CamelContext) - Method in interface org.apache.camel.spi.UnitOfWorkFactory
 
afterRoute(Exchange, Route) - Method in interface org.apache.camel.spi.UnitOfWork
Invoked when this unit of work is done being routed by the given route.
aggregate(Exchange, Exchange) - Method in interface org.apache.camel.AggregationStrategy
Aggregates an old and new exchange together to create a single combined exchange

Important: In the aggregate method, do not create a new exchange instance to return, instead return either the old or new exchange from the input parameters; favor returning the old exchange whenever possible.

aggregate(Exchange, Exchange, Exchange) - Method in interface org.apache.camel.AggregationStrategy
Aggregates an old and new exchange together to create a single combined exchange.
AGGREGATED_COLLECTION_GUARD - Static variable in interface org.apache.camel.Exchange
 
AGGREGATED_COMPLETED_BY - Static variable in interface org.apache.camel.Exchange
 
AGGREGATED_CORRELATION_KEY - Static variable in interface org.apache.camel.Exchange
 
AGGREGATED_SIZE - Static variable in interface org.apache.camel.Exchange
 
AGGREGATED_TIMEOUT - Static variable in interface org.apache.camel.Exchange
 
AGGREGATION_COMPLETE_ALL_GROUPS - Static variable in interface org.apache.camel.Exchange
 
AGGREGATION_COMPLETE_ALL_GROUPS_INCLUSIVE - Static variable in interface org.apache.camel.Exchange
 
AGGREGATION_COMPLETE_CURRENT_GROUP - Static variable in interface org.apache.camel.Exchange
 
AGGREGATION_STRATEGY - Static variable in interface org.apache.camel.Exchange
 
AggregationRepository - Interface in org.apache.camel.spi
Access to a repository to store aggregated exchanges to support pluggable implementations.
AggregationStrategy - Interface in org.apache.camel
A strategy for aggregating two exchanges together into a single exchange.
algorithm - Variable in class org.apache.camel.support.jsse.KeyManagersParameters
The optional algorithm name for the KeyManagerFactory used to create the KeyManagers represented by this object's configuration.
algorithm - Variable in class org.apache.camel.support.jsse.SecureRandomParameters
The Random Number Generator algorithm identifier for the SecureRandom factory method used to create the SecureRandom represented by this object's configuration.
algorithm - Variable in class org.apache.camel.support.jsse.TrustManagersParameters
The optional algorithm name for the TrustManagerFactory used to create the TrustManagers represented by this object's configuration.
AliasedX509ExtendedKeyManager - Class in org.apache.camel.support.jsse
KeyManager to select a key with desired alias while delegating processing to specified KeyManager Can be used both with server and client sockets
AliasedX509ExtendedKeyManager(String, X509KeyManager) - Constructor for class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
Construct KeyManager instance
allowHandover() - Method in interface org.apache.camel.spi.SynchronizationVetoable
Whether or not handover this synchronization is allowed.
allowNull() - Method in interface org.apache.camel.spi.BulkTypeConverters
 
allowNull() - Method in interface org.apache.camel.TypeConverter
Whether the type converter allows returning null as a valid response.
AlreadyStoppedException - Exception in org.apache.camel
Exception thrown in situations when a Service has already been stopped.
AlreadyStoppedException() - Constructor for exception org.apache.camel.AlreadyStoppedException
 
AnnotationBasedProcessorFactory - Interface in org.apache.camel.spi
Factory to create Processor for annotation based EIPs.
AnnotationScanTypeConverters - Interface in org.apache.camel.spi
A TypeConverter which is capable of annotation scanning for Converter classes and add these as type converters.
any() - Static method in interface org.apache.camel.spi.ComponentCustomizer.Policy
A simple allow-all policy.
any() - Static method in interface org.apache.camel.spi.DataFormatCustomizer.Policy
A simple allow-all policy.
any() - Static method in interface org.apache.camel.spi.LanguageCustomizer.Policy
A simple allow-all policy.
apiDocAsJson() - Method in interface org.apache.camel.spi.RestRegistry
Outputs the Rest services API documentation in JSON (requires camel-swagger-java on classpath)
ApiEndpoint - Interface in org.apache.camel
Marks the Endpoint as an endpoint from an API based component.
ApiMethod - Annotation Type in org.apache.camel.spi
Represents an API method as part of a parent API.
ApiParam - Annotation Type in org.apache.camel.spi
Used for annotating a UriParam parameter that its for use by API based endpoints.
ApiParams - Annotation Type in org.apache.camel.spi
Used to annotate a nested configuration parameter type (such as a nested Configuration object) which can then be used on a API based component, endpoint.
apply(List<ServiceDefinition>) - Method in interface org.apache.camel.cloud.ServiceFilter
Chooses one of the service to use
apply(ServiceDefinition) - Method in interface org.apache.camel.cloud.ServiceLoadBalancerFunction
 
apply(String) - Method in interface org.apache.camel.spi.PropertiesFunction
Applies the function
applyFilterToCamelHeaders(String, Object, Exchange) - Method in interface org.apache.camel.spi.HeaderFilterStrategy
Applies filtering logic to Camel Message header that is going to be copied to target message such as CXF and JMS message.
applyFilterToExternalHeaders(String, Object, Exchange) - Method in interface org.apache.camel.spi.HeaderFilterStrategy
Applies filtering logic to an external message header such as CXF and JMS message that is going to be copied to Camel message header.
asAttribute(String) - Static method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
asCode(String) - Static method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
asEndpointUri(String, Map<String, String>, boolean) - Method in interface org.apache.camel.catalog.RuntimeCamelCatalog
Creates an endpoint uri in Java style from the information from the properties

This API is needed by SendDynamicAware.

AsEndpointUri - Annotation Type in org.apache.camel.spi
Indicates that the Camel string/expression should be used as an endpoint uri.
asEnum(String) - Static method in enum org.apache.camel.ExchangePattern
 
AsPredicate - Annotation Type in org.apache.camel.spi
Indicates that the Camel language/expression should be used as predicate.
assemble(MBeanServer, Object, ObjectName) - Method in interface org.apache.camel.spi.ManagementMBeanAssembler
Assemble the ModelMBean.
ASYNC_WAIT - Static variable in interface org.apache.camel.Exchange
 
AsyncCallback - Interface in org.apache.camel
The callback interface for an AsyncProcessor so that it can notify you when an Exchange is done.
asyncCallback(String, Exchange, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint.
asyncCallback(Endpoint, Exchange, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint.
asyncCallback(String, Processor, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint using a supplied processor.
asyncCallback(Endpoint, Processor, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint using a supplied processor.
asyncCallbackRequestBody(String, Object, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncCallbackRequestBody(Endpoint, Object, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncCallbackSendBody(String, Object, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncCallbackSendBody(Endpoint, Object, Synchronization) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
AsyncEndpoint - Interface in org.apache.camel
Marks the Endpoint as support asynchronous non-blocking routing in its consumer and producer.
AsyncProcessor - Interface in org.apache.camel
An asynchronous processor which can process an Exchange in an asynchronous fashion and signal completion by invoking the AsyncCallback.
AsyncProcessorAwaitManager - Interface in org.apache.camel.spi
A manager to handle async routing engine, when Exchanges are being handed over from one thread to another, while the callee thread is blocked waiting for the other threads to complete, before it can continue.
AsyncProcessorAwaitManager.AwaitThread - Interface in org.apache.camel.spi
Information about the thread and exchange that are inflight.
AsyncProcessorAwaitManager.Statistics - Interface in org.apache.camel.spi
Utilization statistics of the this manager.
AsyncProducer - Interface in org.apache.camel
Asynchronous producer
asyncRequest() - Method in interface org.apache.camel.FluentProducerTemplate
Sends asynchronously to the given endpoint (InOut).
asyncRequest(Class<T>) - Method in interface org.apache.camel.FluentProducerTemplate
Sends asynchronously to the given endpoint (InOut).
asyncRequestBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBody(String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBody(Endpoint, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeader(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeader(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeaders(String, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeaders(String, Object, Map<String, Object>, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncRequestBodyAndHeaders(Endpoint, Object, Map<String, Object>, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncSend() - Method in interface org.apache.camel.FluentProducerTemplate
Sends asynchronously to the given endpoint (InOnly).
asyncSend(String, Exchange) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint.
asyncSend(String, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint.
asyncSend(Endpoint, Exchange) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint.
asyncSend(Endpoint, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous exchange to the given endpoint.
asyncSendBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncSendBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends an asynchronous body to the given endpoint.
asyncSendExchange(Endpoint, ExchangePattern, Processor, Processor, Exchange, CompletableFuture<Exchange>) - Method in interface org.apache.camel.spi.ProducerCache
Asynchronously sends an exchange to an endpoint using a supplied Processor to populate the exchange
AUTHENTICATION - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
Authentication failed
AUTHENTICATION - Static variable in interface org.apache.camel.Exchange
 
AUTHENTICATION_FAILURE_POLICY_ID - Static variable in interface org.apache.camel.Exchange
 
AuthorizationPolicy - Interface in org.apache.camel.spi
A marker for defining the policy to be used for applying authorization to routes.
awaitTermination(ExecutorService, long) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Awaits the termination of the thread pool.

B

BaseService - Class in org.apache.camel.support.service
A useful base class which ensures that a service is only initialized once and provides some helper methods for enquiring of its status.
BaseService() - Constructor for class org.apache.camel.support.service.BaseService
 
BaseSSLContextParameters - Class in org.apache.camel.support.jsse
Represents configuration options that can be applied in the client-side or server-side context depending on what they are applied to.
BaseSSLContextParameters() - Constructor for class org.apache.camel.support.jsse.BaseSSLContextParameters
 
BaseSSLContextParameters.SSLContextDecorator - Class in org.apache.camel.support.jsse
Makes a decorated SSLContext appear as a normal SSLContext.
BaseSSLContextParameters.SSLContextSpiDecorator - Class in org.apache.camel.support.jsse
Class needed to provide decoration of an existing SSLContext.
BaseSSLContextParameters.SSLServerSocketFactoryDecorator - Class in org.apache.camel.support.jsse
A decorator that enables the application of configuration options to be applied to created sockets even after this factory has been created and turned over to client code.
BaseSSLContextParameters.SSLSocketFactoryDecorator - Class in org.apache.camel.support.jsse
A decorator that enables the application of configuration options to be applied to created sockets even after this factory has been created and turned over to client code.
BATCH_COMPLETE - Static variable in interface org.apache.camel.Exchange
 
BATCH_INDEX - Static variable in interface org.apache.camel.Exchange
 
BATCH_SIZE - Static variable in interface org.apache.camel.Exchange
 
BatchConsumer - Interface in org.apache.camel
A consumer of a batch of message exchanges from an Endpoint
BEAN_METHOD_NAME - Static variable in interface org.apache.camel.Exchange
 
BeanConfigInject - Annotation Type in org.apache.camel
Used to indicate an injection point of a configuration bean (obtained from the Registry, or a new instance is created) into a POJO.
BeanInject - Annotation Type in org.apache.camel
Used to indicate an injection point of a bean obtained from the Registry, into a POJO.
BeanIntrospection - Interface in org.apache.camel.spi
Used for introspecting beans properties via Java reflection; such as extracting current property values, or updating one or more properties etc.
BeanIntrospection.ClassInfo - Class in org.apache.camel.spi
Structure of an introspected class.
BeanIntrospection.MethodInfo - Class in org.apache.camel.spi
Structure of an introspected method.
BeanProcessorFactory - Interface in org.apache.camel.spi
Factory for creating a Processor that can invoke a method on a bean and supporting using Camel bean parameter bindings.
BeanProxyFactory - Interface in org.apache.camel.spi
A factory for creating a Proxy for a bean.
BeanRepository - Interface in org.apache.camel.spi
Represents a bean repository used to lookup components by name and type.
BeanScope - Enum in org.apache.camel
 
before(Exchange) - Method in interface org.apache.camel.spi.CamelInternalProcessorAdvice
Callback executed before processing a step in the route.
before(Exchange) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy.InstrumentationProcessor
 
beforePoll(long) - Method in interface org.apache.camel.PollingConsumerPollingStrategy
Callback invoked before the poll.
beforeProcess(Exchange, Processor, NamedNode) - Method in interface org.apache.camel.spi.Breakpoint
Callback invoked when the breakpoint was hit and the Exchange is about to be processed (before).
beforeProcess(Exchange, Processor, NamedNode) - Method in interface org.apache.camel.spi.Debugger
Callback invoked when an Exchange is about to be processed which allows implementators to notify breakpoints.
beforeProcess(Processor, Exchange, AsyncCallback) - Method in interface org.apache.camel.spi.UnitOfWork
Strategy for work to be execute before processing.
beforeRoute(Exchange, Route) - Method in interface org.apache.camel.spi.UnitOfWork
Invoked when this unit of work is about to be routed by the given route.
beforeWrap(Route, NamedNode) - Method in interface org.apache.camel.spi.Policy
Hook invoked before the wrap.
begin(Consumer, Endpoint) - Method in interface org.apache.camel.spi.PollingConsumerPollStrategy
Called when poll is about to begin
beginTransactedBy(Object) - Method in interface org.apache.camel.spi.UnitOfWork
Mark this UnitOfWork as being transacted by the given transaction key.
BinaryPredicate - Interface in org.apache.camel
A predicate which evaluates a binary expression.
bind(String, Object) - Method in interface org.apache.camel.spi.Registry
Binds the bean to the repository (if possible).
bind(String, Class<?>, Object) - Method in interface org.apache.camel.spi.Registry
Binds the bean to the repository (if possible).
BINDING - Static variable in interface org.apache.camel.Exchange
 
BindToRegistry - Annotation Type in org.apache.camel
Used for binding a bean to the registry.
Body - Annotation Type in org.apache.camel
Marks a parameter as being the body of an inbound Message
BootstrapCloseable - Interface in org.apache.camel.spi
A marker interface for a service, or other kind of process that is only used during bootstrapping Camel.
BREADCRUMB_ID - Static variable in interface org.apache.camel.Exchange
 
Breakpoint - Interface in org.apache.camel.spi
Breakpoint are used by the Debugger API.
Breakpoint.State - Enum in org.apache.camel.spi
State of the breakpoint as either active or suspended.
BrowsableEndpoint - Interface in org.apache.camel.spi
An optional interface an Endpoint may choose to implement which allows it to expose a way of browsing the exchanges available.
browse() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
A read-only browser of the AsyncProcessorAwaitManager.AwaitThreads that are currently inflight.
browse() - Method in interface org.apache.camel.spi.InflightRepository
A read-only browser of the InflightRepository.InflightExchanges that are currently inflight.
browse(String) - Method in interface org.apache.camel.spi.InflightRepository
A read-only browser of the InflightRepository.InflightExchanges that are currently inflight that started from the given route.
browse(int, boolean) - Method in interface org.apache.camel.spi.InflightRepository
A read-only browser of the InflightRepository.InflightExchanges that are currently inflight.
browse(String, int, boolean) - Method in interface org.apache.camel.spi.InflightRepository
A read-only browser of the InflightRepository.InflightExchanges that are currently inflight that started from the given route.
build() - Method in interface org.apache.camel.Builder
 
build() - Method in interface org.apache.camel.CamelContextLifecycle
 
build() - Method in class org.apache.camel.health.HealthCheckConfiguration.Builder
 
build() - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
build() - Method in interface org.apache.camel.Service
Optional build phase which is executed by frameworks that supports pre-building projects (pre-compile) which allows special optimizations such as camel-quarkus.
build(ThrowingConsumer<T, Exception>) - Method in class org.apache.camel.spi.ComponentCustomizer.Builder
 
build(ThrowingBiConsumer<String, T, Exception>) - Method in class org.apache.camel.spi.ComponentCustomizer.Builder
 
build(ThrowingConsumer<T, Exception>) - Method in class org.apache.camel.spi.DataFormatCustomizer.Builder
 
build(ThrowingBiConsumer<String, T, Exception>) - Method in class org.apache.camel.spi.DataFormatCustomizer.Builder
 
build(ThrowingConsumer<T, Exception>) - Method in class org.apache.camel.spi.LanguageCustomizer.Builder
 
build(ThrowingBiConsumer<String, T, Exception>) - Method in class org.apache.camel.spi.LanguageCustomizer.Builder
 
build() - Method in class org.apache.camel.support.service.BaseService
 
Builder<T> - Interface in org.apache.camel
 
builder() - Static method in class org.apache.camel.health.HealthCheckConfiguration
 
builder() - Static method in interface org.apache.camel.spi.ComponentCustomizer
Create a generic ComponentCustomizer.Builder.
builder(Class<T>) - Static method in interface org.apache.camel.spi.ComponentCustomizer
Create a typed ComponentCustomizer.Builder that can process a concrete component type instance.
Builder(Class<T>) - Constructor for class org.apache.camel.spi.ComponentCustomizer.Builder
 
builder() - Static method in interface org.apache.camel.spi.DataFormatCustomizer
builder(Class<T>) - Static method in interface org.apache.camel.spi.DataFormatCustomizer
Create a typed DataFormatCustomizer.Builder that can process a concrete data format type instance.
Builder(Class<T>) - Constructor for class org.apache.camel.spi.DataFormatCustomizer.Builder
 
builder() - Static method in interface org.apache.camel.spi.LanguageCustomizer
Create a generic LanguageCustomizer.Builder.
builder(Class<T>) - Static method in interface org.apache.camel.spi.LanguageCustomizer
Create a typed LanguageCustomizer.Builder that can process a concrete language type instance.
Builder(Class<T>) - Constructor for class org.apache.camel.spi.LanguageCustomizer.Builder
 
buildUri(String, Map<String, Object>) - Method in interface org.apache.camel.spi.EndpointUriFactory
Assembles an endpoint uri for the given component name with the given parameters.
buildUri(String, Map<String, Object>, boolean) - Method in interface org.apache.camel.spi.EndpointUriFactory
Assembles an endpoint uri for the given component name with the given parameters.
BUILT - Static variable in class org.apache.camel.support.service.BaseService
 
BulkTypeConverters - Interface in org.apache.camel.spi
Bulk type converters that often comes out of the box with Apache Camel.

C

cache(Exchange) - Method in interface org.apache.camel.spi.StreamCachingStrategy
Caches the body aas a StreamCache.
cacheClass(Class<?>) - Method in interface org.apache.camel.spi.BeanIntrospection
Introspects the given class.
call() - Method in interface org.apache.camel.health.HealthCheck
Invoke the check.
call(Map<String, Object>) - Method in interface org.apache.camel.health.HealthCheck
Invoke the check.
CamelAuthorizationException - Exception in org.apache.camel
An exception thrown for either authentication or authorization errors occurring in a Camel exchange.
CamelAuthorizationException(String, Exchange) - Constructor for exception org.apache.camel.CamelAuthorizationException
 
CamelAuthorizationException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.CamelAuthorizationException
 
CamelBeanPostProcessor - Interface in org.apache.camel.spi
Bean post processor.
CamelClusterEventListener - Interface in org.apache.camel.cluster
Marker interface for cluster events
CamelClusterEventListener.Leadership - Interface in org.apache.camel.cluster
 
CamelClusterEventListener.Membership - Interface in org.apache.camel.cluster
 
CamelClusterMember - Interface in org.apache.camel.cluster
 
CamelClusterService - Interface in org.apache.camel.cluster
 
CamelClusterService.Selector - Interface in org.apache.camel.cluster
 
CamelClusterView - Interface in org.apache.camel.cluster
Represents the View of the cluster at some given period of time.
CamelContext - Interface in org.apache.camel
Interface used to represent the CamelContext used to configure routes and the policies to use during message exchanges between endpoints.
CamelContextAware - Interface in org.apache.camel
An interface to represent an object which wishes to be injected with the CamelContext
CamelContextCustomizer - Interface in org.apache.camel.spi
To apply custom configurations to CamelContext instances.
CamelContextLifecycle - Interface in org.apache.camel
Lifecycle API for CamelContext.
CamelContextNameStrategy - Interface in org.apache.camel.spi
Strategy for assigning name to a CamelContext.
CamelContextTracker - Class in org.apache.camel.spi
A CamelContext creation and destruction tracker.
CamelContextTracker() - Constructor for class org.apache.camel.spi.CamelContextTracker
 
CamelContextTracker(CamelContextTracker.Filter) - Constructor for class org.apache.camel.spi.CamelContextTracker
 
CamelContextTracker.Filter - Interface in org.apache.camel.spi
 
CamelEvent - Interface in org.apache.camel.spi
This interface is implemented by all events.
CamelEvent.CamelContextEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextInitializedEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextInitializingEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextResumedEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextResumeFailureEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextResumingEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextRoutesStartedEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextRoutesStartingEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextRoutesStoppedEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextRoutesStoppingEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextStartedEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextStartingEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextStartupFailureEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextStopFailureEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextStoppedEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextStoppingEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextSuspendedEvent - Interface in org.apache.camel.spi
 
CamelEvent.CamelContextSuspendingEvent - Interface in org.apache.camel.spi
 
CamelEvent.ExchangeCompletedEvent - Interface in org.apache.camel.spi
 
CamelEvent.ExchangeCreatedEvent - Interface in org.apache.camel.spi
 
CamelEvent.ExchangeEvent - Interface in org.apache.camel.spi
 
CamelEvent.ExchangeFailedEvent - Interface in org.apache.camel.spi
 
CamelEvent.ExchangeFailureEvent - Interface in org.apache.camel.spi
 
CamelEvent.ExchangeFailureHandledEvent - Interface in org.apache.camel.spi
 
CamelEvent.ExchangeFailureHandlingEvent - Interface in org.apache.camel.spi
 
CamelEvent.ExchangeRedeliveryEvent - Interface in org.apache.camel.spi
 
CamelEvent.ExchangeSendingEvent - Interface in org.apache.camel.spi
 
CamelEvent.ExchangeSentEvent - Interface in org.apache.camel.spi
 
CamelEvent.FailureEvent - Interface in org.apache.camel.spi
This interface is implemented by all events that contain an exception and is used to retrieve the exception in a universal way.
CamelEvent.RouteAddedEvent - Interface in org.apache.camel.spi
 
CamelEvent.RouteEvent - Interface in org.apache.camel.spi
 
CamelEvent.RouteRemovedEvent - Interface in org.apache.camel.spi
 
CamelEvent.RouteStartedEvent - Interface in org.apache.camel.spi
 
CamelEvent.RouteStoppedEvent - Interface in org.apache.camel.spi
 
CamelEvent.ServiceEvent - Interface in org.apache.camel.spi
 
CamelEvent.ServiceStartupFailureEvent - Interface in org.apache.camel.spi
 
CamelEvent.ServiceStopFailureEvent - Interface in org.apache.camel.spi
 
CamelEvent.StepCompletedEvent - Interface in org.apache.camel.spi
 
CamelEvent.StepEvent - Interface in org.apache.camel.spi
 
CamelEvent.StepFailedEvent - Interface in org.apache.camel.spi
 
CamelEvent.StepStartedEvent - Interface in org.apache.camel.spi
 
CamelEvent.Type - Enum in org.apache.camel.spi
 
CamelException - Exception in org.apache.camel
Base class for all Camel checked exceptions typically thrown by a Processor
CamelException() - Constructor for exception org.apache.camel.CamelException
 
CamelException(String) - Constructor for exception org.apache.camel.CamelException
 
CamelException(String, Throwable) - Constructor for exception org.apache.camel.CamelException
 
CamelException(Throwable) - Constructor for exception org.apache.camel.CamelException
 
CamelExchangeException - Exception in org.apache.camel
An exception caused by a specific message Exchange
CamelExchangeException(String, Exchange) - Constructor for exception org.apache.camel.CamelExchangeException
 
CamelExchangeException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.CamelExchangeException
 
CamelExecutionException - Exception in org.apache.camel
Exception occurred during execution/processing of an Exchange.
CamelExecutionException(String, Exchange) - Constructor for exception org.apache.camel.CamelExecutionException
 
CamelExecutionException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.CamelExecutionException
 
CamelInternalProcessorAdvice<T> - Interface in org.apache.camel.spi
An advice (before and after) to execute cross cutting functionality in the Camel routing engine.
CamelLogger - Class in org.apache.camel.spi
A logger which logs to a slf4j Logger.
CamelLogger() - Constructor for class org.apache.camel.spi.CamelLogger
 
CamelLogger(Logger) - Constructor for class org.apache.camel.spi.CamelLogger
 
CamelLogger(Logger, LoggingLevel) - Constructor for class org.apache.camel.spi.CamelLogger
 
CamelLogger(Logger, LoggingLevel, String) - Constructor for class org.apache.camel.spi.CamelLogger
 
CamelLogger(String) - Constructor for class org.apache.camel.spi.CamelLogger
 
CamelLogger(String, LoggingLevel) - Constructor for class org.apache.camel.spi.CamelLogger
 
CamelLogger(String, LoggingLevel, String) - Constructor for class org.apache.camel.spi.CamelLogger
 
CamelPreemptiveClusterService - Interface in org.apache.camel.cluster
CamelPreemptiveClusterView - Interface in org.apache.camel.cluster
A CamelPreemptiveClusterView is a CamelClusterView that can be externally disabled by another controller.
CamelUnitOfWorkException - Exception in org.apache.camel
A UnitOfWork failed with a number of caused exceptions.
CamelUnitOfWorkException(Exchange, List<Exception>) - Constructor for exception org.apache.camel.CamelUnitOfWorkException
 
canPreComplete() - Method in interface org.apache.camel.AggregationStrategy
Indicates if this aggregation strategy uses pre-completion mode.
CatalogCamelContext - Interface in org.apache.camel
Catalog level interface for the CamelContext
Category - Enum in org.apache.camel
This enum set various categories options into the UriEndpoint.
changeOutput(Processor) - Method in interface org.apache.camel.spi.ErrorHandlerRedeliveryCustomizer
Allows to change the output of the error handler which are used when optimising the JMX instrumentation to use either an advice or wrapped processor when calling a processor.
Channel - Interface in org.apache.camel
Channel acts as a channel between Processors in the route graph.
CHARSET_NAME - Static variable in interface org.apache.camel.Exchange
 
choose(List<ServiceDefinition>) - Method in interface org.apache.camel.cloud.ServiceChooser
Chooses one of the service to use
chooseClientAlias(String[], Principal[], Socket) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
 
chooseEngineClientAlias(String[], Principal[], SSLEngine) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
 
chooseEngineServerAlias(String, Principal[], SSLEngine) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
 
chooseServerAlias(String, Principal[], Socket) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
 
CipherSuitesParameters - Class in org.apache.camel.support.jsse
Represents a list of TLS/SSL cipher suite names.
CipherSuitesParameters() - Constructor for class org.apache.camel.support.jsse.CipherSuitesParameters
 
CIRCUIT_BREAKER_STATE - Static variable in interface org.apache.camel.Exchange
 
CircuitBreakerConstants - Interface in org.apache.camel.spi
 
CLAIM_CHECK_REPOSITORY - Static variable in interface org.apache.camel.Exchange
 
ClaimCheckRepository - Interface in org.apache.camel.spi
Access to a repository of keys to implement the Claim Check pattern.
ClassInfo() - Constructor for class org.apache.camel.spi.BeanIntrospection.ClassInfo
 
ClassResolver - Interface in org.apache.camel.spi
A class resolver for loading classes in a loosly coupled manner to cater for different platforms such as standalone, web container, j2ee container and OSGi platforms.
clazz - Variable in class org.apache.camel.spi.BeanIntrospection.ClassInfo
 
cleanUp() - Method in interface org.apache.camel.ConsumerTemplate
Cleanup the cache (purging stale entries)
cleanUp() - Method in interface org.apache.camel.FluentProducerTemplate
Cleanup the cache (purging stale entries)
cleanUp() - Method in interface org.apache.camel.ProducerTemplate
Cleanup the cache (purging stale entries)
cleanUp() - Method in interface org.apache.camel.spi.ConsumerCache
Cleanup the cache (purging stale entries)
cleanUp() - Method in interface org.apache.camel.spi.EndpointRegistry
Cleanup the cache (purging stale entries)
cleanUp() - Method in interface org.apache.camel.spi.ProducerCache
Cleanup the cache (purging stale entries)
cleanUp() - Method in interface org.apache.camel.spi.TransformerRegistry
Cleanup the cache (purging stale entries)
cleanUp() - Method in interface org.apache.camel.spi.ValidatorRegistry
Cleanup the cache (purging stale entries)
clear() - Method in interface org.apache.camel.spi.ClaimCheckRepository
Clear the repository.
clear() - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
Clears all information.
clear() - Method in interface org.apache.camel.spi.IdempotentRepository
Clear the repository.
clear() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
Clears the registry
clearAll() - Method in interface org.apache.camel.FluentProducerTemplate
Deprecated.
the template automatic clears when sending
clearBody() - Method in interface org.apache.camel.FluentProducerTemplate
Deprecated.
the template automatic clears when sending
clearBootstrapConfigurers() - Static method in class org.apache.camel.spi.ConfigurerStrategy
Clears the bootstrap configurers map.
clearCache() - Method in interface org.apache.camel.spi.BeanIntrospection
Clears the introspection cache.
clearCache() - Method in interface org.apache.camel.spi.PackageScanClassResolver
Clears and frees the internal cache.
clearHeaders() - Method in interface org.apache.camel.FluentProducerTemplate
Deprecated.
the template automatic clears when sending
clearReifiers() - Static method in class org.apache.camel.spi.ReifierStrategy
DANGER: Clears the refifiers map.
clearRouteModel() - Method in interface org.apache.camel.Route
Clears the route model when its no longer needed.
ClientAuthentication - Enum in org.apache.camel.support.jsse
Represents the options for the client authentication settings of a server socket.
clientAuthentication - Variable in class org.apache.camel.support.jsse.SSLContextServerParameters
The optional configuration options for server-side client-authentication requirements.
clone() - Method in class org.apache.camel.spi.ThreadPoolProfile
 
close() - Method in interface org.apache.camel.CamelContextLifecycle
Closes (Shutdown) the CamelContext, which means it cannot be started again.
close() - Method in interface org.apache.camel.Service
Delegates to Service.stop() so it can be used in try-with-resources expression.
close() - Method in class org.apache.camel.spi.CamelContextTracker
Closes the tracker so it not longer tracks.
CloudServiceFactory - Annotation Type in org.apache.camel.spi.annotations
 
commit(Consumer, Endpoint, int) - Method in interface org.apache.camel.spi.PollingConsumerPollStrategy
Called when poll is completed successfully
compareTo(CamelContextCustomizer) - Method in interface org.apache.camel.spi.CamelContextCustomizer
 
COMPILE_SCRIPT - Static variable in interface org.apache.camel.Exchange
 
complete(HealthCheckConfiguration) - Method in class org.apache.camel.health.HealthCheckConfiguration.Builder
 
Component - Interface in org.apache.camel
A component is a factory of Endpoint objects.
Component - Annotation Type in org.apache.camel.spi.annotations
 
ComponentAware - Interface in org.apache.camel
An interface to represent an object which wishes to be injected with a Component.
ComponentCustomizer - Interface in org.apache.camel.spi
To apply custom configurations to Component instances.
ComponentCustomizer.Builder<T extends Component> - Class in org.apache.camel.spi
A fluent builder to create a ComponentCustomizer instance.
ComponentCustomizer.Policy - Interface in org.apache.camel.spi
Used as additional filer mechanism to control if customizers need to be applied or not.
ComponentExtension - Interface in org.apache.camel.component.extension
Marker interface for component extensions.
componentJSonSchema(String) - Method in interface org.apache.camel.catalog.RuntimeCamelCatalog
Returns the component information as JSON format.
ComponentNameResolver - Interface in org.apache.camel.spi
Discovers which components are available on the classpath.
ComponentResolver - Interface in org.apache.camel.spi
Represents a resolver of components from a URI to be able to auto-load them using some discovery mechanism like org.apache.camel.impl.DefaultComponentResolver
ComponentVerifierExtension - Interface in org.apache.camel.component.extension
Defines the interface used for validating component/endpoint parameters.
ComponentVerifierExtension.Result - Interface in org.apache.camel.component.extension
The result of a verification
ComponentVerifierExtension.Result.Status - Enum in org.apache.camel.component.extension
Status of the verification
ComponentVerifierExtension.Scope - Enum in org.apache.camel.component.extension
The scope defines how the parameters should be verified.
ComponentVerifierExtension.VerificationError - Interface in org.apache.camel.component.extension
This interface represents a detailed error in case when the verification fails.
ComponentVerifierExtension.VerificationError.Attribute - Interface in org.apache.camel.component.extension
Interface defining an attribute which is a key for the detailed error messages.
ComponentVerifierExtension.VerificationError.Code - Interface in org.apache.camel.component.extension
Interface defining an error code.
ComponentVerifierExtension.VerificationError.ExceptionAttribute - Interface in org.apache.camel.component.extension
Attributes for details about an exception that was raised
ComponentVerifierExtension.VerificationError.GroupAttribute - Interface in org.apache.camel.component.extension
Group related details
ComponentVerifierExtension.VerificationError.HttpAttribute - Interface in org.apache.camel.component.extension
HTTP related error details
ComponentVerifierExtension.VerificationError.StandardCode - Interface in org.apache.camel.component.extension
Standard set of error codes
Condition - Interface in org.apache.camel.spi
A condition to define when a given Exchange matches when is being routed.
ConfigurationPropertiesValidationResult - Class in org.apache.camel.catalog
Details result of validating configuration properties (eg application.properties for camel-main).
ConfigurationPropertiesValidationResult() - Constructor for class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
 
configure(CamelContext) - Method in interface org.apache.camel.spi.CamelContextCustomizer
Configure the CamelContext.
configure(String, Component) - Method in interface org.apache.camel.spi.ComponentCustomizer
Customize the specified Component.
configure(String, DataFormat) - Method in interface org.apache.camel.spi.DataFormatCustomizer
Customize the specified DataFormat.
configure(String, Language) - Method in interface org.apache.camel.spi.LanguageCustomizer
Customize the specified Language.
configure(CamelContext, Object, String, Object, boolean) - Method in interface org.apache.camel.spi.PropertyConfigurer
Configures the property
configureProperties(Map<String, Object>) - Method in interface org.apache.camel.Endpoint
Configure properties on this endpoint.
Configurer - Annotation Type in org.apache.camel.spi
An annotation used to mark classes to indicate code capable of configuring its options via a getter/setters that can be called via Camels PropertyConfigurer.
ConfigurerResolver - Interface in org.apache.camel.spi
A pluggable strategy for resolving different configurers in a loosely coupled manner
ConfigurerStrategy - Class in org.apache.camel.spi
Strategy for configurers.
ConfigurerStrategy() - Constructor for class org.apache.camel.spi.ConfigurerStrategy
 
configureSessionContext(SSLSessionContext, String) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Configures a SSLSessionContext, client or server, with the supplied session timeout.
configureSSLContext(SSLContext) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Configures the actual SSLContext itself with direct setter calls.
configureSSLContext(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
 
configureSSLContext(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
configureSSLContext(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
 
configureSSLEngine(SSLEngine) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
Configures an SSLEngine based on the configurers in instance.
configureSSLServerSocketFactory(SSLServerSocketFactory) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
Configures an SSLServerSocketFactory based on the configurers in this instance.
configureSSLSocketFactory(SSLSocketFactory) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
Configures an SSLSocketFactory based on the configurers in this instance.
confirm(CamelContext, String) - Method in interface org.apache.camel.spi.AggregationRepository
Confirms the completion of the Exchange.
confirm(String) - Method in interface org.apache.camel.spi.IdempotentRepository
Confirms the key, after the exchange has been processed successfully.
confirm(Exchange, String) - Method in interface org.apache.camel.spi.IdempotentRepository
Confirms the key, after the exchange has been processed successfully.
ConstantProvider - Annotation Type in org.apache.camel.spi.annotations
 
Consume - Annotation Type in org.apache.camel
Subscribes a method to an Endpoint either via its URI or via the name of the endpoint reference which is then resolved in a registry such as the Spring Application Context.
Consumer - Interface in org.apache.camel
A consumer of message exchanges from an Endpoint
ConsumerCache - Interface in org.apache.camel.spi
Cache containing created PollingConsumer.
ConsumerTemplate - Interface in org.apache.camel
Template for working with Camel and consuming Message instances in an Exchange from an Endpoint.
contains(String) - Method in interface org.apache.camel.spi.ClaimCheckRepository
Returns true if this repository contains the specified key.
contains(String) - Method in interface org.apache.camel.spi.IdempotentRepository
Returns true if this repository contains the specified element.
contains(Exchange, String) - Method in interface org.apache.camel.spi.IdempotentRepository
Returns true if this repository contains the specified element.
containsOnCompletion(Synchronization) - Method in interface org.apache.camel.ExtendedExchange
Checks if the passed Synchronization instance is already contained on this exchange.
containsSynchronization(Synchronization) - Method in interface org.apache.camel.spi.UnitOfWork
Checks if the passed synchronization hook is already part of this unit of work.
CONTENT_ENCODING - Static variable in interface org.apache.camel.Exchange
 
CONTENT_LENGTH - Static variable in interface org.apache.camel.Exchange
 
CONTENT_TYPE - Static variable in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
 
CONTENT_TYPE - Static variable in interface org.apache.camel.Exchange
 
CONTEXT - Static variable in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
 
contextCreated(CamelContext) - Method in class org.apache.camel.spi.CamelContextTracker
Called when a context is created.
contextDestroyed(CamelContext) - Method in class org.apache.camel.spi.CamelContextTracker
Called when a context has been shutdown.
Contract - Class in org.apache.camel.spi
A Contract which represents the input type and/or output type of the Endpoint or Processor.
Contract() - Constructor for class org.apache.camel.spi.Contract
 
Converter - Annotation Type in org.apache.camel
An annotation used to mark classes and methods to indicate code capable of converting from a type to another type which are then auto-discovered using the Type Conversion Support
convertTo(Class<?>, Class<T>, Exchange, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
Converts the value to the specified type in the context of an exchange

Used when conversion requires extra information from the current exchange (such as encoding).

convertTo(Class<T>, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
 
convertTo(Class<T>, Exchange, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
 
convertTo(Class<T>, Object) - Method in interface org.apache.camel.TypeConverter
Converts the value to the specified type
convertTo(Class<T>, Exchange, Object) - Method in interface org.apache.camel.TypeConverter
Converts the value to the specified type in the context of an exchange

Used when conversion requires extra information from the current exchange (such as encoding).

COOKIE_HANDLER - Static variable in interface org.apache.camel.Exchange
 
copy() - Method in interface org.apache.camel.Exchange
Creates a copy of the current message exchange so that it can be forwarded to another destination
copy() - Method in class org.apache.camel.health.HealthCheckConfiguration
 
copy() - Method in interface org.apache.camel.Message
Creates a copy of this message so that it can be used and possibly modified further in another exchange.
copy(Exchange) - Method in interface org.apache.camel.StreamCache
Create a copy of the stream.
copyFrom(Message) - Method in interface org.apache.camel.Message
Copies the contents of the other message into this message

If you need to do a copy and then set a new body, then use Message.copyFromWithNewBody(Message, Object) method instead.

copyFromWithNewBody(Message, Object) - Method in interface org.apache.camel.Message
Copies the contents (except the body) of the other message into this message and uses the provided new body instead

The returned Message copy will have its Exchange set to the same Exchange instance as from the source.

CORRELATION_ID - Static variable in interface org.apache.camel.Exchange
 
CORS_ACCESS_CONTROL_ALLOW_HEADERS - Static variable in class org.apache.camel.spi.RestConfiguration
 
CORS_ACCESS_CONTROL_ALLOW_METHODS - Static variable in class org.apache.camel.spi.RestConfiguration
 
CORS_ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class org.apache.camel.spi.RestConfiguration
 
CORS_ACCESS_CONTROL_MAX_AGE - Static variable in class org.apache.camel.spi.RestConfiguration
 
create(CamelContext, Map<String, Object>) - Method in interface org.apache.camel.spi.ManagementStrategyFactory
Creates the ManagementStrategy.
createApiConsumer(CamelContext, Processor, String, RestConfiguration, Map<String, Object>) - Method in interface org.apache.camel.spi.RestApiConsumerFactory
Creates a new REST API Event Driven Consumer, which provides API listing of the REST services
createApiProcessor(CamelContext, String, String, boolean, RestConfiguration, Map<String, Object>) - Method in interface org.apache.camel.spi.RestApiProcessorFactory
Creates a new REST API Processor , which provides API listing of the REST services
createAsyncProducer() - Method in interface org.apache.camel.Endpoint
Creates a new producer which is used send messages into the endpoint
createBeanProcessor(CamelContext, Object, Method) - Method in interface org.apache.camel.spi.BeanProcessorFactory
Creates the bean processor from the existing bean instance
createBeanProcessor(CamelContext, Object, String, Class<?>, String, String, BeanScope) - Method in interface org.apache.camel.spi.BeanProcessorFactory
Creates the bean processor from a given set of parameters that can refer to the bean via an existing bean, a reference to a bean, or its class name etc.
createCamelContextInitializedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel has been initialized successfully.
createCamelContextInitializingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel is initializing.
createCamelContextResumedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel has been resumed successfully.
createCamelContextResumeFailureEvent(CamelContext, Throwable) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel failing to resume
createCamelContextResumingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel is resuming.
createCamelContextRoutesStartedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel routes started.
createCamelContextRoutesStartingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel routes starting.
createCamelContextRoutesStoppedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel routes stopped.
createCamelContextRoutesStoppingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel routes stopping.
createCamelContextStartedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel has been started successfully.
createCamelContextStartingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel is starting.
createCamelContextStartupFailureEvent(CamelContext, Throwable) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel failing to start
createCamelContextStopFailureEvent(CamelContext, Throwable) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel failing to stop cleanly
createCamelContextStoppedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel has been stopped successfully.
createCamelContextStoppingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel is stopping.
createCamelContextSuspendedEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel has been suspended successfully.
createCamelContextSuspendingEvent(CamelContext) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Camel is suspending.
createChannel(CamelContext) - Method in interface org.apache.camel.spi.InternalProcessorFactory
 
createChildProcessor(Route, NamedNode, boolean) - Method in interface org.apache.camel.spi.ProcessorFactory
Creates the child processor.
createChildUnitOfWork(Exchange) - Method in interface org.apache.camel.spi.UnitOfWork
Create a child unit of work, which is associated to this unit of work as its parent.
createConsumer(Processor) - Method in interface org.apache.camel.Endpoint
Creates a new Event Driven Consumer which consumes messages from the endpoint using the given processor
createConsumer(CamelContext, Processor, String, String, String, String, String, RestConfiguration, Map<String, Object>) - Method in interface org.apache.camel.spi.RestConsumerFactory
Creates a new REST Event Driven Consumer, which consumes messages from the endpoint using the given processor
createConsumerTemplate() - Method in interface org.apache.camel.CamelContext
Creates a new ConsumerTemplate which is started and therefore ready to use right away.
createConsumerTemplate(int) - Method in interface org.apache.camel.CamelContext
Creates a new ConsumerTemplate which is started and therefore ready to use right away.
CREATED_TIMESTAMP - Static variable in interface org.apache.camel.Exchange
Deprecated.
createDataFormat(String) - Method in interface org.apache.camel.CamelContext
Creates a new instance of the given data format given its name.
createDataFormat(String, CamelContext) - Method in interface org.apache.camel.spi.DataFormatResolver
Creates the given data format given its name.
createDataFormat(CamelContext, Object) - Method in interface org.apache.camel.spi.ModelReifierFactory
 
createDefaultErrorHandler() - Method in interface org.apache.camel.spi.ModelReifierFactory
 
createDynamicRouter(CamelContext, DynamicRouter) - Method in interface org.apache.camel.spi.AnnotationBasedProcessorFactory
Creates dynamic router processor from the configured annotation.
createEndpoint(String) - Method in interface org.apache.camel.Component
Attempt to resolve an endpoint for the given URI if the component is capable of handling the URI.
createEndpoint(String, Map<String, Object>) - Method in interface org.apache.camel.Component
Attempt to resolve an endpoint for the given URI if the component is capable of handling the URI.
createErrorHandler(Route, Processor) - Method in interface org.apache.camel.ExtendedCamelContext
Internal API for creating error handler.
createErrorHandler(Route, Processor) - Method in interface org.apache.camel.spi.ModelReifierFactory
 
createErrorHandler(Route, ErrorHandlerFactory, Processor) - Method in interface org.apache.camel.spi.ModelReifierFactory
 
createExceptionMessage(String, Exchange, Throwable) - Static method in exception org.apache.camel.CamelExchangeException
Creates an exception message with the provided details.
createExchange() - Method in interface org.apache.camel.Endpoint
Create a new exchange for communicating with this endpoint
createExchange(ExchangePattern) - Method in interface org.apache.camel.Endpoint
Create a new exchange for communicating with this endpoint with the specified ExchangePattern such as whether its going to be an ExchangePattern.InOnly or ExchangePattern.InOut exchange
createExchangeCompletedEvent(Exchange) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent when an Exchange has been completed successfully
createExchangeCreatedEvent(Exchange) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent when an Exchange has been created
createExchangeFailedEvent(Exchange) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent when an Exchange has failed
createExchangeFailureHandledEvent(Exchange, Processor, boolean, String) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent when an Exchange has failed but was handled by the Camel error handlers such as an dead letter channel, or a doTry ..
createExchangeFailureHandlingEvent(Exchange, Processor, boolean, String) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent when an Exchange has failed but is being handled by the Camel error handlers such as an dead letter channel, or a doTry ..
createExchangeRedeliveryEvent(Exchange, int) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent when an Exchange is about to be redelivered
createExchangeSendingEvent(Exchange, Endpoint) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent when an Exchange is about to be sent to the endpoint (eg before).
createExchangeSentEvent(Exchange, Endpoint, long) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent when an Exchange has completely been sent to the endpoint (eg after).
createExpression(CamelContext) - Method in interface org.apache.camel.ExpressionFactory
Creates an expression
createExpression(String) - Method in interface org.apache.camel.spi.Language
Creates an expression based on only the given string input
createExpression(String, Object[]) - Method in interface org.apache.camel.spi.Language
Creates an expression based on the input with properties
createExpression(CamelContext, Object) - Method in interface org.apache.camel.spi.ModelReifierFactory
 
createFluentProducerTemplate() - Method in interface org.apache.camel.CamelContext
Creates a new FluentProducerTemplate which is started and therefore ready to use right away.
createFluentProducerTemplate(int) - Method in interface org.apache.camel.CamelContext
Creates a new FluentProducerTemplate which is started and therefore ready to use right away.
createId(NamedNode) - Method in interface org.apache.camel.spi.NodeIdFactory
Creates an id for the given model definition.
createInterceptSendToEndpoint(CamelContext, Endpoint, boolean, Processor, Processor) - Method in interface org.apache.camel.spi.InterceptEndpointFactory
Creates an endpoint when intercepting sending to an endpoint (detour).
createInterceptSendToEndpointProcessor(InterceptSendToEndpoint, Endpoint, AsyncProducer, boolean) - Method in interface org.apache.camel.spi.InternalProcessorFactory
 
createKeyManagers() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
Creates KeyManagers based on this instance's configuration and the KeyStore produced by the configuration returned from KeyManagersParameters.getKeyStore().
createKeyStore() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
Creates a KeyStoreParameters instance based off of the configuration state of this instance.
createLifecycle(CamelContext) - Method in interface org.apache.camel.spi.ManagementStrategyFactory
Creates the associated LifecycleStrategy that the management strategy uses.
createMessage(Object, Class<?>) - Static method in exception org.apache.camel.NoTypeConversionAvailableException
Returns an error message for no type converter available.
createMessage(Object, Class<?>, Throwable) - Static method in exception org.apache.camel.NoTypeConversionAvailableException
Returns an error message for no type converter available with the cause.
createMessage(String, Exchange) - Static method in exception org.apache.camel.RuntimeExchangeException
 
createMessage(Object, Class<?>, Throwable) - Static method in exception org.apache.camel.TypeConversionException
Returns an error message for type conversion failed.
createModelFromXml(CamelContext, String, Class<T>) - Method in interface org.apache.camel.spi.XMLRoutesDefinitionLoader
Creates a model of the given type from the xml
createPollingConsumer() - Method in interface org.apache.camel.Endpoint
Creates a new Polling Consumer so that the caller can poll message exchanges from the consumer using PollingConsumer.receive(), PollingConsumer.receiveNoWait() or PollingConsumer.receive(long) whenever it is ready to do so rather than using the Event Based Consumer returned by Endpoint.createConsumer(Processor)
createPostProcessor(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in interface org.apache.camel.spi.SendDynamicAware
Creates an optional post Processor that will be executed afterwards when the message has been sent dynamic.
createPredicate(String) - Method in interface org.apache.camel.spi.Language
Creates a predicate based on only the given string input
createPredicate(String, Object[]) - Method in interface org.apache.camel.spi.Language
Creates an expression based on the input with properties
createPredicate(CamelContext, Object) - Method in interface org.apache.camel.spi.ModelReifierFactory
 
createPreProcessor(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in interface org.apache.camel.spi.SendDynamicAware
Creates the pre Processor that will prepare the Exchange with dynamic details from the given recipient.
createProcessor(NamedNode, Processor) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy
 
createProcessor(String) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy
 
createProcessor(Route, NamedNode) - Method in interface org.apache.camel.spi.ProcessorFactory
Creates the processor.
createProcessor(CamelContext, String, Object[]) - Method in interface org.apache.camel.spi.ProcessorFactory
Creates a processor by the name of the definition.
createProducer() - Method in interface org.apache.camel.Endpoint
Creates a new producer which is used send messages into the endpoint
createProducer(Endpoint) - Method in interface org.apache.camel.spi.DeferServiceFactory
Creates the Producer which is deferred started until CamelContext is being started.
createProducer(CamelContext, String, String, String, String, String, String, String, RestConfiguration, Map<String, Object>) - Method in interface org.apache.camel.spi.RestProducerFactory
Creates a new REST producer.
createProducerTemplate() - Method in interface org.apache.camel.CamelContext
Creates a new ProducerTemplate which is started and therefore ready to use right away.
createProducerTemplate(int) - Method in interface org.apache.camel.CamelContext
Creates a new ProducerTemplate which is started and therefore ready to use right away.
createProxy(Endpoint, boolean, Class<T>...) - Method in interface org.apache.camel.spi.BeanProxyFactory
Creates a proxy bean facaded with the interfaces that when invoked will send the data as a message to a Camel endpoint.
createRecipientList(CamelContext, RecipientList) - Method in interface org.apache.camel.spi.AnnotationBasedProcessorFactory
Creates recipient list processor from the configured annotation.
createRegistry() - Method in interface org.apache.camel.spi.RestRegistryFactory
Create a new RestRegistry.
createRoute(CamelContext, Object) - Method in interface org.apache.camel.spi.ModelReifierFactory
 
createRoute(CamelContext, NamedNode, String, String, Endpoint) - Method in interface org.apache.camel.spi.RouteFactory
Creates the route which should be configured afterwards with more configurations.
createRouteAddedEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Route has been added successfully.
createRoutePolicy(CamelContext, String, NamedNode) - Method in interface org.apache.camel.spi.RoutePolicyFactory
Creates a new RoutePolicy which will be assigned to the given route.
createRouteRemovedEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Route has been removed successfully.
createRouteStartedEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Route has been started successfully.
createRouteStoppedEvent(Route) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for Route has been stopped successfully.
createRoutingSlip(CamelContext, RoutingSlip) - Method in interface org.apache.camel.spi.AnnotationBasedProcessorFactory
Creates routing slip processor from the configured annotation.
createSecureRandom() - Method in class org.apache.camel.support.jsse.SecureRandomParameters
Returns a SecureRandom instance initialized using the configured algorithm and provider, if specified.
createServerSocket() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
 
createServerSocket(int, int, InetAddress) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
 
createServerSocket(int, int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
 
createServerSocket(int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
 
createServiceStartupFailureEvent(CamelContext, Object, Throwable) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for a Service failed to start cleanly
createServiceStopFailureEvent(CamelContext, Object, Throwable) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent for a Service failed to stop cleanly
createSharedCamelInternalProcessor(CamelContext) - Method in interface org.apache.camel.spi.InternalProcessorFactory
 
createSocket() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
 
createSocket(Socket, String, int, boolean) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
 
createSocket(String, int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
 
createSocket(String, int, InetAddress, int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
 
createSocket(InetAddress, int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
 
createSocket(InetAddress, int, InetAddress, int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
 
createSSLContext(CamelContext) - Method in class org.apache.camel.support.jsse.SSLContextParameters
Creates an SSLContext based on the related configuration options of this instance.
createStepCompletedEvent(Exchange, String) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent when a step has been completed successfully
createStepFailedEvent(Exchange, String) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent when a step has failed
createStepStartedEvent(Exchange, String) - Method in interface org.apache.camel.spi.EventFactory
Creates an CamelEvent when a step has been started
createTransformer(CamelContext, Object) - Method in interface org.apache.camel.spi.ModelReifierFactory
 
createTrustManagers() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
Creates TrustManagers based on this instance's configuration and the KeyStore produced by the configuration returned from TrustManagersParameters.getKeyStore().
createUnitOfWork(Exchange) - Method in interface org.apache.camel.spi.UnitOfWorkFactory
Creates a new UnitOfWork
createUnitOfWorkProducer(Producer) - Method in interface org.apache.camel.spi.InternalProcessorFactory
 
createValidator(CamelContext, Object) - Method in interface org.apache.camel.spi.ModelReifierFactory
 
createWrapProcessor(Processor, Processor) - Method in interface org.apache.camel.spi.InternalProcessorFactory
 
CUSTOM_ID_PROPERTY - Static variable in interface org.apache.camel.Route
 
CUSTOM_LOG_MASK_REF - Static variable in interface org.apache.camel.spi.MaskingFormatter
 

D

Dataformat - Annotation Type in org.apache.camel.spi.annotations
 
DataFormat - Interface in org.apache.camel.spi
Represents a data format used to marshal objects to and from streams such as Java Serialization or using JAXB2 to encode/decode objects using XML or using SOAP encoding.
DataFormatContentTypeHeader - Interface in org.apache.camel.spi
Special accessor for a DataFormat
DataFormatCustomizer - Interface in org.apache.camel.spi
To apply custom configurations to DataFormat instances.
DataFormatCustomizer.Builder<T extends DataFormat> - Class in org.apache.camel.spi
A fluent builder to create a DataFormatCustomizer instance.
DataFormatCustomizer.Policy - Interface in org.apache.camel.spi
Used as additional filer mechanism to control if customizers need to be applied or not.
DataFormatFactory - Interface in org.apache.camel.spi
A factory to create DataFormat.
DataFormatName - Interface in org.apache.camel.spi
The name of the DataFormat which allows to know which kind of data format the implementation is.
DataFormatResolver - Interface in org.apache.camel.spi
Represents a resolver of data formats.
DATASET_INDEX - Static variable in interface org.apache.camel.Exchange
 
DataType - Class in org.apache.camel.spi
Represents the data type URN which is used for message data type contract.
DataType(String) - Constructor for class org.apache.camel.spi.DataType
 
DataType(Class<?>) - Constructor for class org.apache.camel.spi.DataType
 
DataTypeAware - Interface in org.apache.camel.spi
Allows Message to store a DataType which represents the data type of the Message.
Debugger - Interface in org.apache.camel.spi
A debugger which allows tooling to attach breakpoints which is is being invoked when Exchanges is being routed.
DEFAULT_CHARSET_PROPERTY - Static variable in interface org.apache.camel.Exchange
 
DEFAULT_CIPHER_SUITES_FILTER_EXCLUDE - Static variable in class org.apache.camel.support.jsse.BaseSSLContextParameters
 
DEFAULT_CIPHER_SUITES_FILTER_INCLUDE - Static variable in class org.apache.camel.support.jsse.BaseSSLContextParameters
 
DEFAULT_PATH - Static variable in interface org.apache.camel.spi.FactoryFinder
 
DEFAULT_REST_CONFIGURATION_ID - Static variable in class org.apache.camel.spi.RestConfiguration
 
DEFAULT_SECURE_SOCKET_PROTOCOL - Static variable in class org.apache.camel.support.jsse.SSLContextParameters
 
DEFAULT_SECURE_SOCKET_PROTOCOLS_FILTER_EXCLUDE - Static variable in class org.apache.camel.support.jsse.BaseSSLContextParameters
 
DEFAULT_SECURE_SOCKET_PROTOCOLS_FILTER_INCLUDE - Static variable in class org.apache.camel.support.jsse.BaseSSLContextParameters
 
DEFAULT_SPOOL_THRESHOLD - Static variable in interface org.apache.camel.StreamCache
 
DeferredContextBinding - Annotation Type in org.apache.camel
Used to indicate that if the target type is CamelContextAware, the context does not need to be mandatory injected during bean post processing but can be injected later on as example during Camel Context configuration.
DeferServiceFactory - Interface in org.apache.camel.spi
Factory to create services such as Producers and defer starting the created service, until CamelContext has been started.
deferShutdown(ShutdownRunningTask) - Method in interface org.apache.camel.spi.ShutdownAware
To defer shutdown during first phase of shutdown.
deferStartService(Object, boolean) - Method in interface org.apache.camel.CamelContext
Defers starting the service until CamelContext is (almost started) or started and has initialized all its prior services and routes.
DelegateEndpoint - Interface in org.apache.camel
An interface to represent an Endpoint which are delegated.
DelegateProcessor - Interface in org.apache.camel
Interface to be used for processors that delegate to the real processor
deregister(ServiceDefinition) - Method in interface org.apache.camel.cloud.ServiceRegistry
Remove the service definition.
DESCRIPTION_PROPERTY - Static variable in interface org.apache.camel.Route
 
DESTINATION_OVERRIDE_URL - Static variable in interface org.apache.camel.Exchange
 
detail(String) - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
detail(String, Object) - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
details(Map<String, Object>) - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
determineIfRedeliveryIsEnabled() - Method in interface org.apache.camel.spi.ErrorHandlerRedeliveryCustomizer
Determines if redelivery is enabled by checking if any of the redelivery policy settings may allow redeliveries.
DISABLE_HTTP_STREAM_CACHE - Static variable in interface org.apache.camel.Exchange
 
disableJMX() - Method in interface org.apache.camel.CamelContext
Disables using JMX as ManagementStrategy.
DiscoverableService - Interface in org.apache.camel.cloud
 
disposeModel() - Method in interface org.apache.camel.ExtendedCamelContext
Danger!!! This will dispose the route model from the CamelContext which is used for lightweight mode.
doBuild() - Method in class org.apache.camel.support.service.BaseService
Optional build phase of the service.
DOCUMENT_BUILDER_FACTORY - Static variable in interface org.apache.camel.Exchange
 
doFail(Exception) - Method in class org.apache.camel.support.service.BaseService
Implementations override this method to perform any action upon failure.
doInAsyncProducer(AsyncProducer, Exchange, AsyncCallback) - Method in interface org.apache.camel.spi.ProducerCache.AsyncProducerCallback
Performs operation on the given producer to send the given exchange.
doInAsyncProducer(Endpoint, Exchange, AsyncCallback, ProducerCache.AsyncProducerCallback) - Method in interface org.apache.camel.spi.ProducerCache
Sends an exchange to an endpoint using a supplied callback supporting the asynchronous routing engine.
doInit() - Method in class org.apache.camel.support.service.BaseService
Initialize the service.
doLifecycleChange() - Method in class org.apache.camel.support.service.BaseService
Implementations may return an object that will be closed when the lifecycle action is completed.
doLog(String) - Method in class org.apache.camel.spi.CamelLogger
Logs the message without checking the CamelLogger.shouldLog() method first.
done(boolean) - Method in interface org.apache.camel.AsyncCallback
This method is invoked once the Exchange is done.
done(Exchange) - Method in interface org.apache.camel.spi.UnitOfWork
Invoked when this unit of work has been completed, whether it has failed or completed
doneUoW(Exchange) - Method in interface org.apache.camel.ConsumerTemplate
If you have used any of the receive methods which returns a Exchange type then you need to invoke this method when you are done using the returned Exchange.
doResume() - Method in class org.apache.camel.support.service.BaseService
Implementations override this method to support customized suspend/resume.
doShutdown() - Method in class org.apache.camel.support.service.BaseService
Implementations override this method to perform customized shutdown.
doStart() - Method in class org.apache.camel.spi.Transformer
 
doStart() - Method in class org.apache.camel.spi.Validator
 
doStart() - Method in class org.apache.camel.support.service.BaseService
Implementations override this method to support customized start/stop.
doStop() - Method in class org.apache.camel.spi.Transformer
 
doStop() - Method in class org.apache.camel.spi.Validator
 
doStop() - Method in class org.apache.camel.support.service.BaseService
Implementations override this method to support customized start/stop.
doSuspend() - Method in class org.apache.camel.support.service.BaseService
Implementations override this method to support customized suspend/resume.
down() - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
dumpModelAsXml(CamelContext, NamedNode) - Method in interface org.apache.camel.spi.ModelToXMLDumper
Dumps the definition as XML
dumpModelAsXml(CamelContext, NamedNode, boolean, boolean) - Method in interface org.apache.camel.spi.ModelToXMLDumper
Dumps the definition as XML
DUPLICATE_MESSAGE - Static variable in interface org.apache.camel.Exchange
 
DynamicAwareEntry(String, String, Map<String, Object>, Map<String, Object>) - Constructor for class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
 
DynamicRouter - Annotation Type in org.apache.camel
Indicates that this method is to be used as a Dynamic Router routing the incoming message through a series of processing steps.
dynamicSize() - Method in interface org.apache.camel.spi.EndpointRegistry
Number of endpoints in the dynamic registry
dynamicSize() - Method in interface org.apache.camel.spi.TransformerRegistry
Number of transformers in the dynamic registry
dynamicSize() - Method in interface org.apache.camel.spi.ValidatorRegistry
Number of validators in the dynamic registry

E

enabled(boolean) - Method in class org.apache.camel.health.HealthCheckConfiguration.Builder
 
Endpoint - Interface in org.apache.camel
An endpoint implements the Message Endpoint pattern and represents an endpoint that can send and receive message exchanges
ENDPOINT_URI_ASSEMBLER_FACTORY - Static variable in interface org.apache.camel.catalog.RuntimeCamelCatalog
Factory key for EndpointUriFactory
EndpointAware - Interface in org.apache.camel
An interface to represent an object such as a Processor that uses an Endpoint
EndpointConsumerResolver - Interface in org.apache.camel
An interface to represent an object that can be resolved as a consumer Endpoint
EndpointInject - Annotation Type in org.apache.camel
Used to indicate an injection point of an Endpoint, Producer or ProducerTemplate into a POJO.
endpointLenientProperties(String) - Method in interface org.apache.camel.catalog.RuntimeCamelCatalog
Parses the endpoint uri and constructs a key/value properties of only the lenient properties (eg custom options)

For example using the HTTP components to provide query parameters in the endpoint uri.

EndpointProducerResolver - Interface in org.apache.camel
An interface to represent an object that can be resolved as a producer Endpoint
endpointProperties(String) - Method in interface org.apache.camel.catalog.RuntimeCamelCatalog
Parses the endpoint uri and constructs a key/value properties of each option.
EndpointRegistry<K> - Interface in org.apache.camel.spi
Registry to cache endpoints in memory.
EndpointStrategy - Interface in org.apache.camel.spi
Endpoint strategy with callback invoked when an Endpoint is about to be registered to the endpoint registry in CamelContext.
EndpointUriFactory - Interface in org.apache.camel.spi
Factory to create Endpoint URI string from a Map of parameters.
EndpointUtilizationStatistics - Interface in org.apache.camel.spi
Various statistics about endpoint utilization, such as from EIP patterns that uses dynamic endpoints.
EndpointValidationResult - Class in org.apache.camel.catalog
Details result of validating endpoint uri.
EndpointValidationResult() - Constructor for class org.apache.camel.catalog.EndpointValidationResult
 
EndpointValidationResult(String) - Constructor for class org.apache.camel.catalog.EndpointValidationResult
 
endTransactedBy(Object) - Method in interface org.apache.camel.spi.UnitOfWork
Mark this UnitOfWork as not transacted anymore by the given transaction definition.
engineCreateSSLEngine() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
 
engineCreateSSLEngine(String, int) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
 
engineGetClientSessionContext() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
 
engineGetServerSessionContext() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
 
engineGetServerSocketFactory() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
 
engineGetSocketFactory() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
 
engineInit(KeyManager[], TrustManager[], SecureRandom) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
 
equals(Object) - Method in class org.apache.camel.spi.Contract
 
equals(Object) - Method in class org.apache.camel.spi.DataType
 
equals(Object) - Method in class org.apache.camel.ValueHolder
 
error() - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
error(Throwable) - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
ErrorHandler - Interface in org.apache.camel.spi
An interface used to represent an error handler
ERRORHANDLER_CIRCUIT_DETECTED - Static variable in interface org.apache.camel.Exchange
 
ERRORHANDLER_HANDLED - Static variable in interface org.apache.camel.Exchange
Deprecated.
ErrorHandlerAware - Interface in org.apache.camel.spi
An interface for Processor aware of its ErrorHandler which are wrapped via the Channel during route initialization, or specially used by RecipientList EIP annotation.
ErrorHandlerFactory - Interface in org.apache.camel
Factory for creating ErrorHandlers.
ErrorHandlerRedeliveryCustomizer - Interface in org.apache.camel.spi
Customizer for ErrorHandler which supports redeliveries.
evaluate(Exchange, Class<T>) - Method in interface org.apache.camel.Expression
Returns the value of the expression on the given exchange
EVALUATE_EXPRESSION_RESULT - Static variable in interface org.apache.camel.Exchange
 
EventFactory - Interface in org.apache.camel.spi
Factory to create events that are emitted when such an event occur.
EventNotifier - Interface in org.apache.camel.spi
Notifier to send events.
EXCEPTION - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
An exception occurred
EXCEPTION_CAUGHT - Static variable in interface org.apache.camel.Exchange
 
EXCEPTION_CLASS - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.ExceptionAttribute
The exception class
EXCEPTION_HANDLED - Static variable in interface org.apache.camel.Exchange
 
EXCEPTION_INSTANCE - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.ExceptionAttribute
The exception object that has been thrown.
ExceptionHandler - Interface in org.apache.camel.spi
A Strategy pattern for handling exceptions; particularly in asynchronous processes such as consumers.
Exchange - Interface in org.apache.camel
An Exchange is the message container holding the information during the entire routing of a Message received by a Consumer.
ExchangeConstantProvider - Class in org.apache.camel
Generated by camel build tools - do NOT edit this file!
ExchangeConstantProvider() - Constructor for class org.apache.camel.ExchangeConstantProvider
 
ExchangeException - Annotation Type in org.apache.camel
Marks a parameter as being the exception set on an exchange
ExchangeFormatter - Interface in org.apache.camel.spi
A plugin used to turn an Exchange into a String representation usually to be used for logging or tracing purposes.
ExchangePattern - Enum in org.apache.camel
Represents the kind of message exchange pattern
ExchangeProperties - Annotation Type in org.apache.camel
Marks a parameter as being an injection point of the exchange properties of an Exchange
ExchangeProperty - Annotation Type in org.apache.camel
Marks a parameter as being an injection point of a property of an Exchange
ExchangeTimedOutException - Exception in org.apache.camel
An exception thrown if an InOut exchange times out receiving the OUT message
ExchangeTimedOutException(Exchange, long) - Constructor for exception org.apache.camel.ExchangeTimedOutException
 
ExchangeTimedOutException(Exchange, long, String) - Constructor for exception org.apache.camel.ExchangeTimedOutException
 
exclude - Variable in class org.apache.camel.support.jsse.FilterParameters
 
executeFromQueue() - Method in interface org.apache.camel.spi.ReactiveExecutor
Executes the next task (if supported by the reactive executor implementation)
ExecutorServiceAware - Interface in org.apache.camel
Is used for easy configuration of ExecutorService.
ExecutorServiceManager - Interface in org.apache.camel.spi
Strategy to create thread pools.
ExpectedBodyTypeException - Exception in org.apache.camel
Thrown if the body could not be converted to the required type
ExpectedBodyTypeException(Exchange, Class<?>) - Constructor for exception org.apache.camel.ExpectedBodyTypeException
 
Experimental - Annotation Type in org.apache.camel
An experimental user-facing API.
Expression - Interface in org.apache.camel
An expression provides a plugin strategy for evaluating expressions on a message exchange.
ExpressionEvaluationException - Exception in org.apache.camel
An exception thrown if evaluation of the expression failed.
ExpressionEvaluationException(Expression, Exchange, Throwable) - Constructor for exception org.apache.camel.ExpressionEvaluationException
 
ExpressionEvaluationException(Expression, String, Exchange, Throwable) - Constructor for exception org.apache.camel.ExpressionEvaluationException
 
ExpressionFactory - Interface in org.apache.camel
A factory for creating Expression
ExpressionFactoryAware - Interface in org.apache.camel.spi
When an instance is aware of ExpressionFactory.
ExpressionIllegalSyntaxException - Exception in org.apache.camel
An exception thrown if the expression contains illegal syntax.
ExpressionIllegalSyntaxException(String) - Constructor for exception org.apache.camel.ExpressionIllegalSyntaxException
 
ExpressionIllegalSyntaxException(String, Throwable) - Constructor for exception org.apache.camel.ExpressionIllegalSyntaxException
 
ExpressionResultTypeAware - Interface in org.apache.camel.spi
Represents an Expression or Predicate that supports a result type.
ExtendedCamelContext - Interface in org.apache.camel
Extended CamelContext which contains the methods and APIs that are not primary intended for Camel end users but for SPI, custom components, or more advanced used-cases with Camel.
ExtendedExchange - Interface in org.apache.camel
Extended Exchange which contains the methods and APIs that are not intended for Camel end users but used internally by Camel for optimization purposes, SPI, custom components, or more advanced used-cases with Camel.
ExtendedPropertyConfigurerGetter - Interface in org.apache.camel.spi
A marker interface to identify the object as being a configurer which can provide details about the options the configurer supports.
ExtendedStartupListener - Interface in org.apache.camel
Extended StartupListener that is invoked when the CamelContext is fully started.
EXTERNAL_REDELIVERED - Static variable in interface org.apache.camel.Exchange
Deprecated.
extractFutureBody(Future<?>, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Gets the response body from the future handle, will wait until the response is ready.
extractFutureBody(Future<?>, long, TimeUnit, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Gets the response body from the future handle, will wait at most the given time for the response to be ready.

F

FACTORY - Static variable in interface org.apache.camel.catalog.RuntimeCamelCatalog
Service factory key.
FACTORY - Static variable in interface org.apache.camel.health.HealthCheckRegistry
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.AnnotationBasedProcessorFactory
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.BeanProcessorFactory
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.BeanProxyFactory
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.DeferServiceFactory
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.HeadersMapFactory
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.InternalProcessorFactory
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.MockSendToEndpointStrategyFactory
 
FACTORY - Static variable in interface org.apache.camel.spi.ModelJAXBContextFactory
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.ModelToXMLDumper
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.ProcessorFactory
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.PropertiesComponent
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.ReactiveExecutor
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.RestBindingJaxbDataFormatFactory
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.RestRegistryFactory
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.ThreadPoolFactory
Service factory key.
FACTORY - Static variable in interface org.apache.camel.spi.XMLRoutesDefinitionLoader
Service factory key.
FactoryFinder - Interface in org.apache.camel.spi
Finder to find factories from the resource classpath, usually META-INF/services/org/apache/camel/.
FactoryFinderResolver - Interface in org.apache.camel.spi
Represents a resolver for FactoryFinder
fail(Exception) - Method in class org.apache.camel.support.service.BaseService
 
FAILED - Static variable in class org.apache.camel.support.service.BaseService
 
FailedToCreateConsumerException - Exception in org.apache.camel
Thrown if Camel failed to create a consumer for a given endpoint.
FailedToCreateConsumerException(String, Throwable) - Constructor for exception org.apache.camel.FailedToCreateConsumerException
 
FailedToCreateConsumerException(Endpoint, Throwable) - Constructor for exception org.apache.camel.FailedToCreateConsumerException
 
FailedToCreateConsumerException(Endpoint, String, Throwable) - Constructor for exception org.apache.camel.FailedToCreateConsumerException
 
FailedToCreateConsumerException(Endpoint, String) - Constructor for exception org.apache.camel.FailedToCreateConsumerException
 
FailedToCreateProducerException - Exception in org.apache.camel
Thrown if Camel failed to create a producer for a given endpoint.
FailedToCreateProducerException(Endpoint, Throwable) - Constructor for exception org.apache.camel.FailedToCreateProducerException
 
FailedToCreateRouteException - Exception in org.apache.camel
Exception when failing to create a Route.
FailedToCreateRouteException(String, String, Throwable) - Constructor for exception org.apache.camel.FailedToCreateRouteException
 
FailedToCreateRouteException(String, String, String, Throwable) - Constructor for exception org.apache.camel.FailedToCreateRouteException
 
FailedToStartRouteException - Exception in org.apache.camel
Exception when failing to start a Route.
FailedToStartRouteException(String, String) - Constructor for exception org.apache.camel.FailedToStartRouteException
 
FailedToStartRouteException(String, String, Throwable) - Constructor for exception org.apache.camel.FailedToStartRouteException
 
FAILURE_ENDPOINT - Static variable in interface org.apache.camel.Exchange
 
FAILURE_HANDLED - Static variable in interface org.apache.camel.Exchange
 
FAILURE_ROUTE_ID - Static variable in interface org.apache.camel.Exchange
 
failureThreshold(int) - Method in class org.apache.camel.health.HealthCheckConfiguration.Builder
 
FallbackConverter - Annotation Type in org.apache.camel
Deprecated.
use @Converter(fallback = true) instead
FATAL_FALLBACK_ERROR_HANDLER - Static variable in interface org.apache.camel.Exchange
 
FILE_CONTENT_TYPE - Static variable in interface org.apache.camel.Exchange
 
FILE_LAST_MODIFIED - Static variable in interface org.apache.camel.Exchange
 
FILE_LENGTH - Static variable in interface org.apache.camel.Exchange
 
FILE_LOCAL_WORK_PATH - Static variable in interface org.apache.camel.Exchange
 
FILE_LOCK_CHANNEL_FILE - Static variable in interface org.apache.camel.Exchange
 
FILE_LOCK_EXCLUSIVE_LOCK - Static variable in interface org.apache.camel.Exchange
 
FILE_LOCK_FILE_ACQUIRED - Static variable in interface org.apache.camel.Exchange
 
FILE_LOCK_FILE_NAME - Static variable in interface org.apache.camel.Exchange
 
FILE_LOCK_RANDOM_ACCESS_FILE - Static variable in interface org.apache.camel.Exchange
 
FILE_NAME - Static variable in interface org.apache.camel.Exchange
 
FILE_NAME_CONSUMED - Static variable in interface org.apache.camel.Exchange
 
FILE_NAME_ONLY - Static variable in interface org.apache.camel.Exchange
 
FILE_NAME_PRODUCED - Static variable in interface org.apache.camel.Exchange
 
FILE_PARENT - Static variable in interface org.apache.camel.Exchange
 
FILE_PATH - Static variable in interface org.apache.camel.Exchange
 
filter(String) - Method in interface org.apache.camel.Route
Returns a list of all the Processors from this route that has id's matching the pattern
filter(Collection<String>, Collection<String>, Collection<String>, FilterParameters.Patterns, FilterParameters.Patterns, boolean) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Filters the values in availableValues returning only the values that are explicitly listed in explicitValues (returns them regardless of if they appear in availableValues or not) if explicitValues is not null or according to the following rules: Match the include patterns in patterns and don't match the exclude patterns in patterns if patterns is not null. Match the include patterns in defaultPatterns and don't match the exclude patterns in defaultPatterns if patterns is null and applyDefaults is true. Are provided in currentValues if if patterns is null and applyDefaults is false.
filter(Collection<String>, Collection<String>, List<Pattern>, List<Pattern>) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Filters the values in availableValues returning only the values that are explicitly listed in explicitValues (returns them regardless of if they appear in availableValues or not) if explicitValues is not null or as match the patterns in includePatterns and do not match the patterns in excludePatterns if explicitValues is null.
FILTER_MATCHED - Static variable in interface org.apache.camel.Exchange
 
FILTER_NON_XML_CHARS - Static variable in interface org.apache.camel.Exchange
 
FilterParameters - Class in org.apache.camel.support.jsse
Represents a set of regular expression based filter patterns for including and excluding content of some type.
FilterParameters() - Constructor for class org.apache.camel.support.jsse.FilterParameters
 
FilterParameters.Patterns - Class in org.apache.camel.support.jsse
An immutable collection of compiled includes and excludes filter Patterns.
findAnnotated(Class<? extends Annotation>, String...) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Attempts to discover classes that are annotated with to the annotation.
findAnnotated(Set<Class<? extends Annotation>>, String...) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Attempts to discover classes that are annotated with to the annotation.
findByFilter(PackageScanFilter, String...) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Attempts to discover classes filter by the provided filter
findByType(Class<T>) - Method in interface org.apache.camel.spi.BeanRepository
Finds beans in the registry by their type.
findByTypeWithName(Class<T>) - Method in interface org.apache.camel.spi.BeanRepository
Finds beans in the registry by their type.
findClass(String) - Method in interface org.apache.camel.spi.FactoryFinder
Finds the given factory class using the key to lookup.
findImplementations(Class<?>, String...) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Attempts to discover classes that are assignable to the type provided (exclude abstract classes).
findOptionalClass(String) - Method in interface org.apache.camel.spi.FactoryFinder
Finds the optional factory class using the key to lookup.
findResourceNames(String) - Method in interface org.apache.camel.spi.PackageScanResourceResolver
Finds the resource names from the given location.
findResources(String) - Method in interface org.apache.camel.spi.PackageScanResourceResolver
Finds the resources from the given location.
findSetterMethods(Class<?>, String, boolean, boolean, boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
Find all the setter methods on the class
FluentProducerTemplate - Interface in org.apache.camel
Template for working with Camel and sending Message instances in an Exchange to an Endpoint using a fluent build style.
forceShutdown(Service) - Method in interface org.apache.camel.spi.ShutdownStrategy
Whether a service is forced to shutdown.
format(Exchange) - Method in interface org.apache.camel.spi.ExchangeFormatter
Generates a string representation of the exchange
format(String) - Method in interface org.apache.camel.spi.MaskingFormatter
Format a given string.
forType(Class<T>, ThrowingConsumer<T, Exception>) - Static method in interface org.apache.camel.spi.ComponentCustomizer
Create a ComponentCustomizer that can process a concrete component type instance.
forType(Class<T>, ThrowingConsumer<T, Exception>) - Static method in interface org.apache.camel.spi.DataFormatCustomizer
Create a DataFormatCustomizer that can process a concrete data format type instance.
forType(Class<T>, ThrowingConsumer<T, Exception>) - Static method in interface org.apache.camel.spi.LanguageCustomizer
Create a DataFormatCustomizer that can process a concrete language type instance.
fromString(String) - Static method in enum org.apache.camel.component.extension.ComponentVerifierExtension.Scope
Get an instance of this scope from a string representation

G

GeneratedPropertyConfigurer - Interface in org.apache.camel.spi
A auto generated PropertyConfigurer for fast configuration of Camel components & endpoints.
generateUuid() - Method in interface org.apache.camel.spi.UuidGenerator
Generates a UUID string representation.
GENERIC - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
Generic error which is explained in more details with ComponentVerifierExtension.VerificationError.getDetails()
get(CamelContext) - Static method in interface org.apache.camel.health.HealthCheckRegistry
Returns an optional HealthCheckRegistry, by default no registry is present and it must be explicit activated.
get(CamelContext, String) - Method in interface org.apache.camel.spi.AggregationRepository
Gets the given exchange with the correlation key

This method is always invoked for any incoming exchange in the aggregator.

get(String) - Method in interface org.apache.camel.spi.ClaimCheckRepository
Gets the exchange from the repository.
get(K) - Method in interface org.apache.camel.TimeoutMap
Looks up the value in the map by the given key.
get() - Method in class org.apache.camel.ValueHolder
 
getAdvice(Class<T>) - Method in interface org.apache.camel.spi.InternalProcessor
Gets the advice with the given type.
getAfter() - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
The processor (optional) for routing after sending to the original endpoint.
getAlgorithm() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
 
getAlgorithm() - Method in class org.apache.camel.support.jsse.SecureRandomParameters
 
getAlgorithm() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
 
getAllEndpoints(boolean) - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
Gets all the endpoint uris captured during runtime routing that are in-use of the routes.
getAllOptions(Object) - Method in interface org.apache.camel.spi.ExtendedPropertyConfigurerGetter
Provides a map of which options the cofigurer supports and their class type.
getAllowCoreThreadTimeOut() - Method in class org.apache.camel.spi.ThreadPoolProfile
Gets whether to allow core threads to timeout
getAllowPassthrough() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Returns a flag indicating if default values should be applied in the event that no other property of the instance configures a particular aspect of the entity produced by the instance.
getAllowPassthrough() - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
 
getAllowPassthrough() - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
 
getAndRemove(String) - Method in interface org.apache.camel.spi.ClaimCheckRepository
Gets and removes the exchange from the repository.
getAnnotationBasedProcessorFactory() - Method in interface org.apache.camel.ExtendedCamelContext
getApiComponent() - Method in class org.apache.camel.spi.RestConfiguration
Gets the name of the Camel component to use as the REST API (such as swagger or openapi).
getApiContextIdPattern() - Method in class org.apache.camel.spi.RestConfiguration
 
getApiContextPath() - Method in class org.apache.camel.spi.RestConfiguration
 
getApiContextRouteId() - Method in class org.apache.camel.spi.RestConfiguration
 
getApiHost() - Method in class org.apache.camel.spi.RestConfiguration
 
getApiProperties() - Method in class org.apache.camel.spi.RestConfiguration
 
getApplicationContextClassLoader() - Method in interface org.apache.camel.CamelContext
Gets the application CamelContext class loader which may be helpful for running camel in other containers
getAsyncProcessorAwaitManager() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the AsyncProcessor await manager.
getAtRouteId() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
The id of the route where the exchange currently is being processed

Is null if message history is disabled.

getAttempt() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeRedeliveryEvent
 
getAttemptCounter() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
Number of type conversion attempts
getAttribute(String) - Method in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
Returns an attribute associated with this meta data by name.
getAttribute(String, Class<T>) - Method in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
Returns an attribute associated with this meta data by name and specifying the type required.
getAttributes() - Method in interface org.apache.camel.cloud.ServiceRegistry
Attributes associated to the service.
getAttributes() - Method in interface org.apache.camel.cluster.CamelClusterService
Attributes associated to the service.
getAttributes() - Method in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
 
getAutowiredNames() - Method in interface org.apache.camel.spi.PropertyConfigurerGetter
Gets the names of the autowired options.
getBackOffDelay() - Method in interface org.apache.camel.spi.SupervisingRouteController
 
getBackOffMaxAttempts() - Method in interface org.apache.camel.spi.SupervisingRouteController
 
getBackOffMaxDelay() - Method in interface org.apache.camel.spi.SupervisingRouteController
 
getBackOffMaxElapsedTime() - Method in interface org.apache.camel.spi.SupervisingRouteController
 
getBackOffMultiplier() - Method in interface org.apache.camel.spi.SupervisingRouteController
 
getBasePath() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Gets the base path to the REST service
getBaseUrl() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Gets the base url to the REST service
getBeanIntrospection() - Method in interface org.apache.camel.ExtendedCamelContext
getBeanPostProcessor() - Method in interface org.apache.camel.ExtendedCamelContext
Returns the bean post processor used to do any bean customization.
getBeanProcessorFactory() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the BeanProcessorFactory to use.
getBeanProxyFactory() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the BeanProxyFactory to use.
getBefore() - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
The processor for routing in a detour before sending to the original endpoint.
getBindingMode() - Method in class org.apache.camel.spi.RestConfiguration
Gets the binding mode used by the REST consumer
getBlockedThread() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.AwaitThread
The thread which is blocked waiting for other threads to signal the callback.
getBody() - Method in interface org.apache.camel.Message
Returns the body of the message as a POJO

The body can be null if no body is set.

getBody(Class<T>) - Method in interface org.apache.camel.Message
Returns the body as the specified type

Notice if the message body is stream based then calling this method multiple times may lead to the stream not being able to be re-read again.

getBody() - Method in interface org.apache.camel.WrappedFile
Gets the content of the file.
getBootstrapConfigurerResolver() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the bootstrap ConfigurerResolver to use.
getBootstrapFactoryFinder() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the bootstrap FactoryFinder which will be used for the loading the factory class from META-INF.
getBreakpoints() - Method in interface org.apache.camel.spi.Debugger
Gets a list of all the breakpoints
getBufferSize() - Method in interface org.apache.camel.spi.StreamCachingStrategy
 
getCachedClassesCounter() - Method in interface org.apache.camel.spi.BeanIntrospection
Number of classes in the introspection cache.
getCacheMemoryAverageSize() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
Gets the average number of bytes per cached stream for in-memory stream caches.
getCacheMemoryCounter() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
Gets the counter for number of in-memory StreamCache created.
getCacheMemorySize() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
Gets the total accumulated number of bytes which has been stream cached for in-memory stream caches.
getCacheSpoolAverageSize() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
Gets the average number of bytes per cached stream for spooled (not in-memory) stream caches.
getCacheSpoolCounter() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
Gets the counter for number of spooled (not in-memory) StreamCache created.
getCacheSpoolSize() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
Gets the total accumulated number of bytes which has been stream cached for spooled stream caches.
getCamelContext() - Method in interface org.apache.camel.CamelContextAware
Get the CamelContext
getCamelContext() - Method in interface org.apache.camel.ConsumerTemplate
Get the CamelContext
getCamelContext() - Method in interface org.apache.camel.Endpoint
Returns the context which created the endpoint
getCamelContext() - Method in interface org.apache.camel.FluentProducerTemplate
Get the CamelContext
getCamelContext() - Method in interface org.apache.camel.ProducerTemplate
Get the CamelContext
getCamelContext() - Method in interface org.apache.camel.Route
Gets the camel context
getCamelContext() - Method in interface org.apache.camel.spi.HasCamelContext
Returns the camel context.
getCamelContext() - Method in class org.apache.camel.spi.Transformer
 
getCamelContext() - Method in class org.apache.camel.spi.Validator
 
getCamelContext() - Method in class org.apache.camel.support.jsse.JsseParameters
 
getCapacity() - Method in interface org.apache.camel.spi.ConsumerCache
Gets the maximum cache size (capacity).
getCapacity() - Method in interface org.apache.camel.spi.ProducerCache
Gets the maximum cache size (capacity).
getCause() - Method in interface org.apache.camel.spi.CamelEvent.FailureEvent
 
getCauses() - Method in exception org.apache.camel.CamelUnitOfWorkException
 
getCertAlias() - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
getCertificateChain(String) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
 
getCheck() - Method in interface org.apache.camel.health.HealthCheck.Result
The HealthCheck associated to this response.
getCheck(String) - Method in interface org.apache.camel.health.HealthCheckRegistry
Returns the check identified by the given id if available.
getCheckIDs() - Method in interface org.apache.camel.health.HealthCheckRegistry
A collection of health check IDs.
getChildServices(Service) - Static method in class org.apache.camel.support.service.ServiceHelper
Gathers all child services by navigating the service to recursively gather all child services.
getChildServices(Service, boolean) - Static method in class org.apache.camel.support.service.ServiceHelper
Gathers all child services by navigating the service to recursively gather all child services.
getCipherSuite() - Method in class org.apache.camel.support.jsse.CipherSuitesParameters
Returns a live reference to the list of cipher suite names.
getCipherSuites() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Returns the optional explicitly configured cipher suites for this configuration.
getCipherSuitesFilter() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Returns the optional cipher suite filter for this configuration.
getClassLoaders() - Method in interface org.apache.camel.spi.PackageScanClassResolver
Gets the ClassLoader instances that should be used when scanning for classes.
getClassLoaders() - Method in interface org.apache.camel.spi.PackageScanResourceResolver
Gets the ClassLoader instances that should be used when scanning for resources.
getClassResolver() - Method in interface org.apache.camel.CamelContext
Returns the class resolver to be used for loading/lookup of classes.
getClientAliases(String, Principal[]) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
 
getClientAuthentication() - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
 
getClientParameters() - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
getClusterService() - Method in interface org.apache.camel.cluster.CamelClusterView
 
getCode() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
The overall error code, which can be either a ComponentVerifierExtension.VerificationError.StandardCode or a custom code.
getCollectionValueType(Object, String, boolean) - Method in interface org.apache.camel.spi.PropertyConfigurerGetter
This method can be used to retrieve the class type for an option if the option is a collection kind (list, map, or array).
getComponent(String) - Method in interface org.apache.camel.CamelContext
Gets a component from the CamelContext by name.
getComponent(String, boolean) - Method in interface org.apache.camel.CamelContext
Gets a component from the CamelContext by name.
getComponent(String, boolean, boolean) - Method in interface org.apache.camel.CamelContext
Gets a component from the CamelContext by name.
getComponent(String, Class<T>) - Method in interface org.apache.camel.CamelContext
Gets a component from the CamelContext by name and specifying the expected type of component.
getComponent() - Method in interface org.apache.camel.ComponentAware
Get the Component
getComponent(Class<T>) - Method in interface org.apache.camel.ComponentAware
Get the Component as the specified type.
getComponent() - Method in class org.apache.camel.spi.RestConfiguration
Gets the name of the Camel component to use as the REST consumer
getComponentJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
Returns the component information as JSON format.
getComponentNameResolver() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the ComponentNameResolver to use.
getComponentNames() - Method in interface org.apache.camel.CamelContext
Gets a readonly list of names of the components currently registered
getComponentParameterJsonSchema(String) - Method in interface org.apache.camel.CatalogCamelContext
Returns the JSON schema representation of the component and endpoint parameters for the given component name.
getComponentProperties() - Method in class org.apache.camel.spi.RestConfiguration
Gets additional options on component level
getComponentPropertyConfigurer() - Method in interface org.apache.camel.Component
Gets the component PropertyConfigurer.
getComponentResolver() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the ComponentResolver to use.
getConfiguration() - Method in interface org.apache.camel.health.HealthCheck
Return the configuration associated with this HealthCheck.
getConfigurations() - Method in interface org.apache.camel.health.HealthCheckRepository
Configurations for health checks based on their ids
getConfigurerResolver() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the ConfigurerResolver to use.
getConsumer() - Method in interface org.apache.camel.Route
Gets the inbound Consumer
getConsumer() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Gets the consumer of the REST service
getConsumerProperties() - Method in class org.apache.camel.spi.RestConfiguration
Gets additional options on consumer level
getConsumes() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Optional details about what media-types the REST service accepts
getContext() - Method in interface org.apache.camel.Exchange
Returns the container so that a processor can resolve endpoints from URIs
getContext() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextEvent
 
getContext() - Method in exception org.apache.camel.VetoCamelContextStartException
 
getContextPath() - Method in class org.apache.camel.spi.RestConfiguration
Gets the configured context-path
getControlledRoutes() - Method in interface org.apache.camel.spi.RouteController
Return the list of routes controlled by this controller.
getCorsHeaders() - Method in class org.apache.camel.spi.RestConfiguration
Gets the CORS headers to use if CORS has been enabled.
getCreated() - Method in interface org.apache.camel.Exchange
Gets the timestamp in millis when this exchange was created.
getCurrentCacheSize() - Method in interface org.apache.camel.ConsumerTemplate
Gets an approximated size of the current cached resources in the backing cache pools.
getCurrentCacheSize() - Method in interface org.apache.camel.FluentProducerTemplate
Gets an approximated size of the current cached resources in the backing cache pools.
getCurrentCacheSize() - Method in interface org.apache.camel.ProducerTemplate
Gets an approximated size of the current cached resources in the backing cache pools.
getDataFormatJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
Returns the data format information as JSON format.
getDataFormatName() - Method in interface org.apache.camel.spi.DataFormatName
The name of the data format
getDataFormatParameterJsonSchema(String) - Method in interface org.apache.camel.CatalogCamelContext
Returns the JSON schema representation of the DataFormat parameters for the given data format name.
getDataFormatProperties() - Method in class org.apache.camel.spi.RestConfiguration
Gets additional options on data format level
getDataFormatResolver() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the current data format resolver
getDataType() - Method in interface org.apache.camel.spi.DataTypeAware
Get the data type of the message.
getDeadLetterUri() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailureEvent
 
getDeadLetterUri() - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
Gets the dead letter channel
getDebugger() - Method in interface org.apache.camel.CamelContext
Gets the current Debugger
getDefaultCipherSuites() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
 
getDefaultCipherSuites() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
 
getDefaultCipherSuitesFilter() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
 
getDefaultEndpoint() - Method in interface org.apache.camel.FluentProducerTemplate
Get the default endpoint to use if none is specified
getDefaultEndpoint() - Method in interface org.apache.camel.ProducerTemplate
Get the default endpoint to use if none is specified
getDefaultFactoryFinder() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the default FactoryFinder which will be used for the loading the factory class from META-INF
getDefaultSecureSocketProcotolFilter() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
 
getDefaultThreadPoolProfile() - Method in interface org.apache.camel.spi.ExecutorServiceManager
Gets the default thread pool profile
getDeferServiceFactory() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the DeferServiceFactory to use.
getDelayer() - Method in interface org.apache.camel.RuntimeConfiguration
Gets the delay value
getDelegate() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
 
getDelegate() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
 
getDelegate() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
 
getDescription() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
A human readable description of the error in plain english
getDescription() - Method in interface org.apache.camel.Route
Gets the route description (if any has been configured).
getDescription() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Optional description about this rest service.
getDescriptionText() - Method in interface org.apache.camel.NamedNode
Returns the description text or null if there is no description text associated with this node
getDetail(ComponentVerifierExtension.VerificationError.Attribute) - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
Get a single detail for a given attribute
getDetail(String) - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
Get a single detail for a given attribute
getDetails() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
Details about the failed verification.
getDetails() - Method in interface org.apache.camel.health.HealthCheck.Result
An key/value combination of details.
getDirection() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry.Statistic
Whether the endpoint is used as input our output

The returned value can either be in or out

getDuration() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
The duration in millis the exchange has been inflight
getEipParameterJsonSchema(String) - Method in interface org.apache.camel.CatalogCamelContext
Returns the JSON schema representation of the EIP parameters for the given EIP name.
getElapsed() - Method in interface org.apache.camel.MessageHistory
Gets the elapsed time in millis processing the node took (this is 0 until the node processing is done)
getElapsed() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
The elapsed time in millis processing the exchange at the current node
getEndpoint(String) - Method in interface org.apache.camel.CamelContext
Resolves the given name to an Endpoint of the specified type.
getEndpoint(String, Map<String, Object>) - Method in interface org.apache.camel.CamelContext
Resolves the given name to an Endpoint of the specified type.
getEndpoint(String, Class<T>) - Method in interface org.apache.camel.CamelContext
Resolves the given name to an Endpoint of the specified type.
getEndpoint() - Method in interface org.apache.camel.cloud.ServiceHealth
The health enpoint exposed by the service.
getEndpoint() - Method in interface org.apache.camel.DelegateEndpoint
Gets the delegated Endpoint.
getEndpoint() - Method in interface org.apache.camel.EndpointAware
Gets the endpoint associated with an object.
getEndpoint(NormalizedEndpointUri) - Method in interface org.apache.camel.ExtendedCamelContext
Resolves the given name to an Endpoint of the specified type.
getEndpoint(NormalizedEndpointUri, Map<String, Object>) - Method in interface org.apache.camel.ExtendedCamelContext
Resolves the given name to an Endpoint of the specified type.
getEndpoint() - Method in exception org.apache.camel.ProxyInstantiationException
 
getEndpoint() - Method in interface org.apache.camel.Route
Gets the input endpoint for this route.
getEndpoint() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeSendingEvent
 
getEndpoint() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeSentEvent
 
getEndpointBaseUri() - Method in interface org.apache.camel.Endpoint
Returns the string representation of the base endpoint URI (without query parameters).
getEndpointKey() - Method in interface org.apache.camel.Endpoint
Returns a string key of this endpoint.
getEndpointMap() - Method in interface org.apache.camel.CamelContext
getEndpointProperties() - Method in class org.apache.camel.spi.RestConfiguration
Gets additional options on endpoint level
getEndpointPropertyConfigurer() - Method in interface org.apache.camel.Component
Gets the endpoint PropertyConfigurer.
getEndpointRegistry() - Method in interface org.apache.camel.CamelContext
getEndpointRuntimeStatisticsEnabled() - Method in interface org.apache.camel.spi.ManagementAgent
Gets whether endpoint runtime statistics is enabled
getEndpoints() - Method in interface org.apache.camel.CamelContext
Returns a new Collection of all of the endpoints from the EndpointRegistry
getEndpointsPerRoute(String, boolean) - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
Gets all the endpoint uris captured from the given route during runtime routing that are in-use of the routes.
getEndpointStatistics() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
Gets details about all the endpoint captured from the given route during runtime routing that are in-use of the routes.
getEndpointUri() - Method in interface org.apache.camel.Endpoint
Returns the string representation of the endpoint URI
getEndpointUriFactory(String) - Method in interface org.apache.camel.ExtendedCamelContext
Gets the EndpointUriFactory for the given component name.
getEndpointUrl() - Method in interface org.apache.camel.NamedRoute
Gets the route endpoint url.
getEndpointUtilizationStatistics() - Method in interface org.apache.camel.spi.ConsumerCache
Gets the endpoint statistics
getEndpointUtilizationStatistics() - Method in interface org.apache.camel.spi.ProducerCache
Gets the endpoint statistics
getError() - Method in class org.apache.camel.catalog.LanguageValidationResult
 
getError() - Method in interface org.apache.camel.health.HealthCheck.Result
An error associated to the result, used to provide the error associated to unhealthy services.
getErrorHandler() - Method in interface org.apache.camel.Channel
Gets the ErrorHandler this Channel uses.
getErrorHandler() - Method in interface org.apache.camel.spi.ErrorHandlerAware
Gets the error handler
getErrorHandlerExecutorService() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the default shared thread pool for error handlers which leverages this for asynchronous redelivery tasks.
getErrorHandlerFactory() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the default error handler builder which is inherited by the routes
getErrorHandlerFactory() - Method in interface org.apache.camel.Route
 
getErrorHandlerHandled() - Method in interface org.apache.camel.ExtendedExchange
Whether the exchange has been handled by the error handler.
getErrorHandlers(ErrorHandlerFactory) - Method in interface org.apache.camel.Route
Gets the error handlers
getErrors() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.Result
Collection of errors happened for the verification.
getEventDrivenProcessors() - Method in interface org.apache.camel.Route
This method retrieves the event driven Processors on this route context.
getEventFactory() - Method in interface org.apache.camel.spi.ManagementStrategy
Gets the event factory
getEventNotifiers() - Method in interface org.apache.camel.spi.ManagementStrategy
Gets the event notifiers.
getException() - Method in interface org.apache.camel.Exchange
Returns the exception associated with this exchange
getException(Class<T>) - Method in interface org.apache.camel.Exchange
Returns the exception associated with this exchange.
getException() - Method in interface org.apache.camel.spi.RouteError
Gets the error.
getExceptionMessage(Throwable) - Static method in exception org.apache.camel.FailedToCreateRouteException
 
getExchange() - Method in exception org.apache.camel.CamelExchangeException
Returns the exchange which caused the exception
getExchange() - Method in exception org.apache.camel.ExpectedBodyTypeException
 
getExchange() - Method in exception org.apache.camel.ExpressionEvaluationException
 
getExchange() - Method in interface org.apache.camel.Message
Returns the exchange this message is related to
getExchange() - Method in exception org.apache.camel.RuntimeExchangeException
Returns the exchange which caused the exception

Can be null

getExchange() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.AwaitThread
The exchange being processed by the other thread.
getExchange() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeEvent
 
getExchange() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
The exchange being inflight
getExchangeFormatter() - Method in interface org.apache.camel.spi.Tracer
To use a custom exchange formatter for formatting the output of the Exchange in the trace logs.
getExchangeId() - Method in interface org.apache.camel.Exchange
Returns the exchange id (unique)
getExchanges() - Method in interface org.apache.camel.spi.BrowsableEndpoint
Return the exchanges available on this endpoint
getExclude() - Method in class org.apache.camel.support.jsse.FilterParameters
Returns a live copy of the list of patterns to exclude.
getExcludePatterns() - Method in class org.apache.camel.support.jsse.FilterParameters
Returns a list of compiled Patterns based on the values of the exclude list.
getExcludeRoutes() - Method in interface org.apache.camel.spi.SupervisingRouteController
 
getExcludes() - Method in class org.apache.camel.support.jsse.FilterParameters.Patterns
 
getExecutorService() - Method in interface org.apache.camel.ExecutorServiceAware
Gets the executor service
getExecutorServiceManager() - Method in interface org.apache.camel.CamelContext
Gets the current ExecutorServiceManager
getExecutorServiceRef() - Method in interface org.apache.camel.ExecutorServiceAware
Gets the reference to lookup in the Registry for the executor service to be used.
getExhaustedRoutes() - Method in interface org.apache.camel.spi.SupervisingRouteController
Return the list of routes that have failed all attempts to startup and are now exhausted.
getExpectedBodyType() - Method in exception org.apache.camel.ExpectedBodyTypeException
 
getExpression() - Method in exception org.apache.camel.ExpressionEvaluationException
 
getExpression() - Method in exception org.apache.camel.ExpressionIllegalSyntaxException
 
getExpressionFactory() - Method in interface org.apache.camel.spi.ExpressionFactoryAware
getExpressionText() - Method in interface org.apache.camel.spi.ExpressionResultTypeAware
Gets the expression or predicate as text
getExtension(Class<T>) - Method in interface org.apache.camel.CamelContext
Gets the extension of the given type.
getExtension(Class<T>) - Method in interface org.apache.camel.Component
Gets the extension of the given type.
getFactoryFinder(String) - Method in interface org.apache.camel.ExtendedCamelContext
Gets the FactoryFinder which will be used for the loading the factory class from META-INF in the given path
getFactoryFinderResolver() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the factory finder resolver to use
getFailedCounter() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
Number of failed attempts during type conversion
getFailureHandler() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailureEvent
 
getFailureThreshold() - Method in class org.apache.camel.health.HealthCheckConfiguration
 
getFile() - Method in interface org.apache.camel.WrappedFile
Gets the file.
getFileName() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
 
getFrom() - Method in class org.apache.camel.spi.Transformer
Get 'from' data type.
getFromEndpoint() - Method in interface org.apache.camel.Exchange
Returns the endpoint which originated this message exchange if a consumer on an endpoint created the message exchange, otherwise this property will be null
getFromRouteId() - Method in interface org.apache.camel.Exchange
Returns the route id which originated this message exchange if a route consumer on an endpoint created the message exchange, otherwise this property will be null
getFromRouteId() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
The id of the route where the exchange originates (started)
getFromType() - Method in exception org.apache.camel.NoTypeConversionAvailableException
Returns the required from type.
getFromType() - Method in exception org.apache.camel.TypeConversionException
Returns the required from type.
getFromType() - Method in exception org.apache.camel.TypeConverterExistsException
 
getGlobalEndpointConfiguration() - Method in interface org.apache.camel.CamelContext
Gets the global endpoint configuration, where you can configure common endpoint options.
getGlobalOption(String) - Method in interface org.apache.camel.CamelContext
Gets the global option value that can be referenced in the camel context

Important: This has nothing to do with property placeholders, and is just a plain set of key/value pairs which are used to configure global options on CamelContext, such as a maximum debug logging length etc.

getGlobalOptions() - Method in interface org.apache.camel.CamelContext
Gets global options that can be referenced in the camel context.
getGroup(HealthCheck) - Static method in class org.apache.camel.health.HealthCheckHelper
Get the group of the given check or an empty string if the group is not set.
getGroup() - Method in interface org.apache.camel.Route
Gets the route group
getGroup() - Method in interface org.apache.camel.spi.HasGroup
Returns the group
getHeader(String) - Method in interface org.apache.camel.Message
Accesses a specific header
getHeader(String, Object) - Method in interface org.apache.camel.Message
Accesses a specific header
getHeader(String, Supplier<Object>) - Method in interface org.apache.camel.Message
Accesses a specific header
getHeader(String, Class<T>) - Method in interface org.apache.camel.Message
Returns a header associated with this message by name and specifying the type required
getHeader(String, Object, Class<T>) - Method in interface org.apache.camel.Message
Returns a header associated with this message by name and specifying the type required
getHeader(String, Supplier<Object>, Class<T>) - Method in interface org.apache.camel.Message
Returns a header associated with this message by name and specifying the type required
getHeaderFilterStrategy() - Method in interface org.apache.camel.spi.HeaderFilterStrategyAware
Gets the header filter strategy used
getHeaderName() - Method in exception org.apache.camel.NoSuchHeaderException
 
getHeaders() - Method in interface org.apache.camel.Message
Returns all of the headers associated with the message.
getHeadersMapFactory() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the HeadersMapFactory to use.
getHealth() - Method in interface org.apache.camel.cloud.ServiceDefinition
Gets the health.
getHistoryNodeId() - Method in interface org.apache.camel.ExtendedExchange
Gets the history node id (the current processor that will process the exchange)
getHistoryNodeLabel() - Method in interface org.apache.camel.ExtendedExchange
Gets the history node label (the current processor that will process the exchange)
getHitCounter() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
Number of successful conversions
getHits() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry.Statistic
Usage of the endpoint, such as how many messages it has received / sent to

This information is only available if ManagementStatisticsLevel is configured as ManagementStatisticsLevel.Extended.

getHost() - Method in interface org.apache.camel.cloud.ServiceDefinition
Gets the IP or hostname of the server hosting the service.
getHost() - Method in class org.apache.camel.spi.RestConfiguration
Gets the hostname to use by the REST consumer
getHostNameResolver() - Method in class org.apache.camel.spi.RestConfiguration
Gets the resolver to use for resolving hostname
getId() - Method in interface org.apache.camel.cloud.ServiceDefinition
Gets the service id.
getId() - Method in interface org.apache.camel.NamedNode
Gets the value of the id property.
getId() - Method in interface org.apache.camel.Route
Gets the route id
getId() - Method in interface org.apache.camel.spi.HasId
Returns the id
getId() - Method in class org.apache.camel.spi.ThreadPoolProfile
Gets the id of this profile
getIn() - Method in interface org.apache.camel.Exchange
Returns the inbound request message
getIn(Class<T>) - Method in interface org.apache.camel.Exchange
Returns the inbound request message as the given type
getInclude() - Method in class org.apache.camel.support.jsse.FilterParameters
Returns a live copy of the list of patterns to include.
getIncludeHostName() - Method in interface org.apache.camel.spi.ManagementAgent
Gets whether host name is included in MBean names.
getIncludePatterns() - Method in class org.apache.camel.support.jsse.FilterParameters
Returns a list of compiled Patterns based on the values of the include list.
getIncludeRoutes() - Method in interface org.apache.camel.spi.SupervisingRouteController
 
getIncludes() - Method in class org.apache.camel.support.jsse.FilterParameters.Patterns
 
getIndex() - Method in class org.apache.camel.catalog.LanguageValidationResult
 
getInflightRepository() - Method in interface org.apache.camel.CamelContext
Gets the inflight repository
getInitialDelay() - Method in interface org.apache.camel.spi.SupervisingRouteController
 
getInjector() - Method in interface org.apache.camel.CamelContext
Returns the injector used to instantiate objects by type
getInjector() - Method in interface org.apache.camel.spi.TypeConverterRegistry
Gets the injector
getInputs() - Method in interface org.apache.camel.spi.RouteStartupOrder
Gets the input to this route (often only one consumer)
getInputType() - Method in class org.apache.camel.spi.Contract
 
getInterceptEndpointFactory() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the current InterceptEndpointFactory
getInterceptStrategies() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the interceptor strategies
getInterceptStrategies() - Method in interface org.apache.camel.Route
This method retrieves the InterceptStrategy instances this route context.
getInternalProcessorFactory() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the current InternalProcessorFactory
getInternalRouteController() - Method in interface org.apache.camel.ExtendedCamelContext
Internal RouteController that are only used internally by Camel to perform basic route operations.
getInterval() - Method in class org.apache.camel.health.HealthCheckConfiguration
 
getInType() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Optional detail about input binding to a FQN class name.
getInvokedCounter() - Method in interface org.apache.camel.spi.BeanIntrospection
Number of times bean introspection has been invoked
getJsonDataFormat() - Method in class org.apache.camel.spi.RestConfiguration
Gets the name of the json data format.
getKeepAliveTime() - Method in class org.apache.camel.spi.ThreadPoolProfile
Gets the keep alive time for inactive threads
getKeyManagers() - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
getKeyPassword() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
 
getKeys() - Method in interface org.apache.camel.spi.AggregationRepository
Gets the keys currently in the repository.
getKeyStore() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
 
getKeyStore() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
 
getLabel() - Method in interface org.apache.camel.NamedNode
Returns a label to describe this node such as the expression if some kind of expression node
getLanguage() - Method in exception org.apache.camel.NoSuchLanguageException
 
getLanguageJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
Returns the language information as JSON format.
getLanguageNames() - Method in interface org.apache.camel.CamelContext
Deprecated.
not in use
getLanguageParameterJsonSchema(String) - Method in interface org.apache.camel.CatalogCamelContext
Returns the JSON schema representation of the Language parameters for the given language name.
getLanguageResolver() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the LanguageResolver to use.
getLastError() - Method in interface org.apache.camel.Route
Gets the last error.
getLeader() - Method in interface org.apache.camel.cluster.CamelClusterView
Provides the leader member if elected.
getLeft() - Method in interface org.apache.camel.BinaryPredicate
Gets the left hand side expression
getLenient() - Method in class org.apache.camel.catalog.EndpointValidationResult
 
getLenientProperties() - Method in class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
 
getLevel() - Method in class org.apache.camel.spi.CamelLogger
 
getLifecycleStrategies() - Method in interface org.apache.camel.CamelContext
Returns the lifecycle strategies used to handle lifecycle notifications
getLimit() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
Maximum number of endpoints to keep in the cache per route.
getLineNumber() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
 
getLoadStatisticsEnabled() - Method in interface org.apache.camel.spi.ManagementAgent
Gets whether load statistics is enabled
getLocalMember() - Method in interface org.apache.camel.cluster.CamelClusterView
Provides the local member.
getLocalProperties() - Method in interface org.apache.camel.spi.PropertiesComponent
Gets a list of properties that are local for the current thread only (ie thread local)
getLocalPropertiesAsMap() - Method in interface org.apache.camel.spi.PropertiesComponent
Gets a list of properties that are local for the current thread only (ie thread local)
getLocations() - Method in interface org.apache.camel.spi.PropertiesComponent
Gets the configured properties locations.
getLog() - Method in class org.apache.camel.spi.CamelLogger
 
getLoggingLevel() - Method in interface org.apache.camel.spi.BeanIntrospection
Logging level used for logging introspection usage.
getLogListeners() - Method in interface org.apache.camel.ExtendedCamelContext
Gets a list of LogListener (can be null if empty).
getMainJsonSchema() - Method in interface org.apache.camel.catalog.JSonSchemaResolver
Returns the camel-main json schema
getManagedObjectForCamelContext(CamelContext) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForCamelHealth(CamelContext, HealthCheckRegistry) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForClusterService(CamelContext, CamelClusterService) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForComponent(CamelContext, Component, String) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForConsumer(CamelContext, Consumer) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForDataFormat(CamelContext, DataFormat) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForEndpoint(CamelContext, Endpoint) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForEventNotifier(CamelContext, EventNotifier) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForProcessor(CamelContext, Processor, NamedNode, Route) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForProducer(CamelContext, Producer) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForRoute(CamelContext, Route) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForRouteController(CamelContext, RouteController) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForService(CamelContext, Service) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagedObjectForThreadPool(CamelContext, ThreadPoolExecutor, String, String, String, String) - Method in interface org.apache.camel.spi.ManagementObjectStrategy
 
getManagementAgent() - Method in interface org.apache.camel.spi.ManagementStrategy
Gets the management agent
getManagementInterceptStrategy() - Method in interface org.apache.camel.Route
Gets the special managed intercept strategy if any
getManagementMBeanAssembler() - Method in interface org.apache.camel.ExtendedCamelContext
Returns the management mbean assembler
getManagementName() - Method in interface org.apache.camel.CamelContext
Gets the name this CamelContext was registered in JMX.
getManagementNamePattern() - Method in interface org.apache.camel.spi.ManagementAgent
The naming pattern for creating the CamelContext management name.
getManagementNameStrategy() - Method in interface org.apache.camel.CamelContext
Gets the current management name strategy
getManagementObjectNameStrategy() - Method in interface org.apache.camel.spi.ManagementStrategy
Gets the naming strategy to use
getManagementObjectStrategy() - Method in interface org.apache.camel.spi.ManagementStrategy
Gets the object strategy to use
getManagementStrategy() - Method in interface org.apache.camel.CamelContext
Gets the management strategy
getMandatoryBody() - Method in interface org.apache.camel.Message
Returns the body of the message as a POJO

Notice if the message body is stream based then calling this method multiple times may lead to the stream not being able to be re-read again.

getMandatoryBody(Class<T>) - Method in interface org.apache.camel.Message
Returns the mandatory body as the specified type

Notice if the message body is stream based then calling this method multiple times may lead to the stream not being able to be re-read again.

getMarker() - Method in class org.apache.camel.spi.CamelLogger
 
getMask() - Method in interface org.apache.camel.spi.ManagementAgent
Whether to remove detected sensitive information (such as passwords) from MBean names and attributes.
getMaxDuration() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
The highest duration time in millis.
getMaximumCacheSize() - Method in interface org.apache.camel.ConsumerTemplate
Gets the maximum cache size used.
getMaximumCacheSize() - Method in interface org.apache.camel.FluentProducerTemplate
Gets the maximum cache size used in the backing cache pools.
getMaximumCacheSize() - Method in interface org.apache.camel.ProducerTemplate
Gets the maximum cache size used in the backing cache pools.
getMaximumCacheSize() - Method in interface org.apache.camel.spi.EndpointRegistry
Maximum number of entries to store in the dynamic registry
getMaximumCacheSize() - Method in interface org.apache.camel.spi.TransformerRegistry
Maximum number of entries to store in the dynamic registry
getMaximumCacheSize() - Method in interface org.apache.camel.spi.ValidatorRegistry
Maximum number of entries to store in the dynamic registry
getMaximumRedeliveries() - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
Gets the maximum redelivery attempts to do before a recovered Exchange is doomed as exhausted and moved to the dead letter channel.
getMaxPoolSize() - Method in class org.apache.camel.spi.ThreadPoolProfile
Gets the maximum pool size
getMaxQueueSize() - Method in class org.apache.camel.spi.ThreadPoolProfile
Gets the maximum number of tasks in the work queue.
getMBeanObjectDomainName() - Method in interface org.apache.camel.spi.ManagementAgent
Get domain name for Camel MBeans.
getMBeanServer() - Method in interface org.apache.camel.spi.ManagementAgent
Get the MBeanServer which hosts managed objects.
getMBeanServerDefaultDomain() - Method in interface org.apache.camel.spi.ManagementAgent
Gets the default domain on the MBean server
getMDCLoggingKeysPattern() - Method in interface org.apache.camel.CamelContext
Gets the pattern used for determine which custom MDC keys to propagate during message routing when the routing engine continues routing asynchronously for the given message.
getMeanDuration() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
The average duration time in millis.
getMembers() - Method in interface org.apache.camel.cluster.CamelClusterView
Provides the list of members of the cluster.
getMessage() - Method in interface org.apache.camel.Exchange
Returns the current message
getMessage(Class<T>) - Method in interface org.apache.camel.Exchange
Returns the current message as the given type
getMessage() - Method in interface org.apache.camel.health.HealthCheck.Result
A message associated to the result, used to provide more information for unhealthy services.
getMessage() - Method in interface org.apache.camel.MessageHistory
A read-only copy of the message at the point of this history (if this has been enabled).
getMessage() - Method in exception org.apache.camel.PropertyBindingException
 
getMessageHistoryFactory() - Method in interface org.apache.camel.CamelContext
Gets the current MessageHistoryFactory
getMessageId() - Method in interface org.apache.camel.Message
Returns the id of the message.
getMetadata() - Method in interface org.apache.camel.cloud.ServiceDefinition
Gets a key/value metadata associated with the service.
getMetadata() - Method in interface org.apache.camel.cloud.ServiceHealth
Gets a key/value metadata associated with the service.
getMetaData() - Method in interface org.apache.camel.health.HealthCheck
Return meta data associated with this HealthCheck.
getMethod() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Gets the HTTP method (GET, POST, PUT etc)
getMinDuration() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
The lowest duration time in millis.
getMissCounter() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
Number of attempts which cannot be converted as no suitable type converter exists
getModel() - Method in class org.apache.camel.spi.DataType
 
getModel() - Method in class org.apache.camel.spi.Transformer
Get a data model which is supported by this transformer.
getModelJAXBContextFactory() - Method in interface org.apache.camel.ExtendedCamelContext
Returns the JAXB Context factory used to create Models.
getModelJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
Returns the model information as JSON format.
getModelToXMLDumper() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the ModelToXMLDumper to be used.
getName() - Method in interface org.apache.camel.CamelContext
Gets the name (id) of the this CamelContext.
getName() - Method in interface org.apache.camel.cloud.ServiceDefinition
Gets the service name.
getName() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.Attribute
Bean style accessor to name; This is required for framework like Jackson using bean convention for object serialization.
getName() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.Code
Bean style accessor to name.
getName() - Method in exception org.apache.camel.NoSuchBeanException
 
getName() - Method in interface org.apache.camel.spi.CamelContextNameStrategy
Gets the name

The CamelContextNameStrategy.isFixedName() determines if the name can be re-calculated such as when using a counter, or the name is always fixed.

getName() - Method in class org.apache.camel.spi.DataType
 
getName() - Method in interface org.apache.camel.spi.ManagementNameStrategy
Gets the name

The ManagementNameStrategy.isFixedName() determines if the name can be re-calculated such as when using a counter, or the name is always fixed.

getName() - Method in interface org.apache.camel.spi.PropertiesFunction
Name of the function which is used as name: to let the properties component know its a function.
getName() - Method in interface org.apache.camel.spi.PropertiesSource
Name of properties source
getNamePattern() - Method in interface org.apache.camel.spi.ManagementNameStrategy
Gets the custom name pattern.
getNamespace() - Method in interface org.apache.camel.cluster.CamelClusterView
 
getNamespaces() - Method in interface org.apache.camel.cluster.CamelClusterService
Return the namespaces handled by this service.
getNamespaces() - Method in interface org.apache.camel.spi.NamespaceAware
Gets the XML Namespaces
getNameStrategy() - Method in interface org.apache.camel.CamelContext
Gets the current name strategy
getNextName() - Method in interface org.apache.camel.spi.CamelContextNameStrategy
Gets the next calculated name, if this strategy is not using fixed names.
getNextName() - Method in interface org.apache.camel.spi.ManagementNameStrategy
Gets the next calculated name, if this strategy is not using fixed names.
getNextProcessor() - Method in interface org.apache.camel.Channel
Gets the next Processor to route to (not wrapped)
getNode() - Method in interface org.apache.camel.MessageHistory
Gets the node at the point of this history.
getNodeId() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.AwaitThread
The id of the node from the route where the exchange was processed when the thread was set to block.
getNodeId() - Method in interface org.apache.camel.spi.InflightRepository.InflightExchange
The id of the node from the route where the exchange currently is being processed

Is null if message history is disabled.

getNodeIdFactory() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the node id factory
getNodePattern() - Method in interface org.apache.camel.spi.MessageHistoryFactory
An optional pattern to filter which nodes to trace in this message history.
getNoopCounter() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
Number of noop attempts (no type conversion was needed)
getNotConsumerOnly() - Method in class org.apache.camel.catalog.EndpointValidationResult
 
getNotProducerOnly() - Method in class org.apache.camel.catalog.EndpointValidationResult
 
getObjectName(Object) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForCamelContext(String, String) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForCamelContext(CamelContext) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForCamelHealth(CamelContext) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForClusterService(CamelContext, CamelClusterService) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForComponent(Component, String) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForConsumer(CamelContext, Consumer) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForDataFormat(CamelContext, DataFormat) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForEndpoint(Endpoint) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForEventNotifier(CamelContext, EventNotifier) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForProcessor(CamelContext, Processor, NamedNode) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForProducer(CamelContext, Producer) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForRoute(Route) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForRouteController(CamelContext, RouteController) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForService(CamelContext, Service) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForStep(CamelContext, Processor, NamedNode) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForThreadPool(CamelContext, ThreadPoolExecutor, String, String) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getObjectNameForTracer(CamelContext, Service) - Method in interface org.apache.camel.spi.ManagementObjectNameStrategy
 
getOnCompletions() - Method in interface org.apache.camel.Route
 
getOnException(String) - Method in interface org.apache.camel.Route
 
getOnExceptions() - Method in interface org.apache.camel.Route
 
getOnlyRegisterProcessorWithCustomId() - Method in interface org.apache.camel.spi.ManagementAgent
Whether to only register processors which has a custom id assigned.
getOperator() - Method in interface org.apache.camel.BinaryPredicate
Gets the operator
getOptionKey() - Method in exception org.apache.camel.PropertyBindingException
 
getOptionPrefix() - Method in exception org.apache.camel.PropertyBindingException
 
getOptionType(String, boolean) - Method in interface org.apache.camel.spi.PropertyConfigurerGetter
Gets the option class type.
getOptionValue(Object, String, boolean) - Method in interface org.apache.camel.spi.PropertyConfigurerGetter
Gets the property value
getOrder() - Method in interface org.apache.camel.cloud.ServiceRegistry
 
getOrder() - Method in interface org.apache.camel.cluster.CamelClusterService
 
getOrder() - Method in interface org.apache.camel.health.HealthCheck
 
getOrder() - Method in interface org.apache.camel.Ordered
Gets the order.
getOrder() - Method in interface org.apache.camel.spi.BulkTypeConverters
 
getOrder() - Method in interface org.apache.camel.spi.CamelContextCustomizer
 
getOrder() - Method in interface org.apache.camel.spi.ComponentCustomizer
 
getOrder() - Method in interface org.apache.camel.spi.DataFormatCustomizer
 
getOrder() - Method in interface org.apache.camel.spi.LanguageCustomizer
 
getOrElseProperty(Object, String, Object, boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
Gets the property or else returning the default value.
getOriginalEndpoint() - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
The original endpoint which was intercepted.
getOriginalInMessage() - Method in interface org.apache.camel.spi.UnitOfWork
Gets the original IN Message this Unit of Work was started with.
getOriginalUri() - Method in class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
 
getOtherJSonSchema(String) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
Returns the other (miscellaneous) information as JSON format.
getOut() - Method in interface org.apache.camel.Exchange
Deprecated.
getOut(Class<T>) - Method in interface org.apache.camel.Exchange
getOutput() - Method in interface org.apache.camel.Channel
Gets the wrapped output that at runtime should be delegated to.
getOutput() - Method in interface org.apache.camel.spi.ErrorHandlerRedeliveryCustomizer
Returns the output processor
getOutputType() - Method in class org.apache.camel.spi.Contract
 
getOutType() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Optional detail about output binding to a FQN class name.
getOwner() - Method in exception org.apache.camel.InvalidPropertyException
 
getPackageScanClassResolver() - Method in interface org.apache.camel.ExtendedCamelContext
Returns the package scanning class resolver
getPackageScanResourceResolver() - Method in interface org.apache.camel.ExtendedCamelContext
Returns the package scanning resource resolver
getParameterKeys() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError
A set of input parameter names which fails the verification.
getParent() - Method in class org.apache.camel.health.HealthCheckConfiguration
 
getParent() - Method in interface org.apache.camel.NamedNode
Returns the parent
getPassword() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
 
getPattern() - Method in interface org.apache.camel.Exchange
Returns the ExchangePattern (MEP) of this exchange.
getPattern(List<String>) - Method in class org.apache.camel.support.jsse.FilterParameters
Compiles Patterns for each expression in patternStrings.
getPatterns() - Method in class org.apache.camel.support.jsse.FilterParameters
Returns an immutable collection of compiled filter patterns based on the state of this instance at the time of invocation.
getPayload() - Method in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
Returns the payload of the meta data as a POJO.
getPayload(Class<T>) - Method in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
Returns the payload of the meta data as specified type.
getPendingExchangesSize() - Method in interface org.apache.camel.spi.ShutdownAware
Gets the number of pending exchanges.
getPhase() - Method in interface org.apache.camel.spi.RouteError
Gets the phase associated with the error.
getPolicyId() - Method in exception org.apache.camel.CamelAuthorizationException
 
getPoolSize() - Method in class org.apache.camel.spi.ThreadPoolProfile
Gets the core pool size (threads to keep minimum in pool)
getPort() - Method in interface org.apache.camel.cloud.ServiceDefinition
Gets the port number of the server hosting the service.
getPort() - Method in class org.apache.camel.spi.RestConfiguration
Gets the port to use by the REST consumer
getPrivateKey(String) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
 
getProcessor(String) - Method in interface org.apache.camel.CamelContext
Gets the processor from any of the routes which with the given id
getProcessor(String, Class<T>) - Method in interface org.apache.camel.CamelContext
Gets the processor from any of the routes which with the given id
getProcessor() - Method in interface org.apache.camel.Consumer
 
getProcessor() - Method in interface org.apache.camel.DelegateProcessor
Gets the delegated Processor.
getProcessor() - Method in interface org.apache.camel.Route
Gets the Processor
getProcessorFactory() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the current ProcessorFactory
getProducerApiDoc() - Method in class org.apache.camel.spi.RestConfiguration
Gets the location of the api document (swagger api) the REST producer will use to validate the REST uri and query parameters are valid accordingly to the api document.
getProducerComponent() - Method in class org.apache.camel.spi.RestConfiguration
Gets the name of the Camel component to use as the REST producer
getProduces() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Optional details about what media-types the REST service returns
getProperties() - Method in interface org.apache.camel.Exchange
Returns all of the properties associated with the exchange
getProperties() - Method in interface org.apache.camel.Route
This property map is used to associate information about the route.
getProperties(Object, Map<String, Object>, String) - Method in interface org.apache.camel.spi.BeanIntrospection
Will inspect the target for properties.
getProperties(Object, Map<String, Object>, String, boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
Will inspect the target for properties.
getProperties() - Method in class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
 
getPropertiesComponent() - Method in interface org.apache.camel.CamelContext
Returns the configured properties component or create one if none has been configured.
getProperty(String) - Method in interface org.apache.camel.Exchange
Returns a property associated with this exchange by name
getProperty(String, Object) - Method in interface org.apache.camel.Exchange
Deprecated.
getProperty(String, Class<T>) - Method in interface org.apache.camel.Exchange
Returns a property associated with this exchange by name and specifying the type required
getProperty(String, Object, Class<T>) - Method in interface org.apache.camel.Exchange
Returns a property associated with this exchange by name and specifying the type required
getProperty(String) - Method in interface org.apache.camel.spi.PropertiesSource
Gets the property with the name
getPropertyConfigurer(Object) - Method in interface org.apache.camel.spi.PropertyConfigurerAware
Gets the configurer.
getPropertyGetter(Class<?>, String, boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
Gets the getter method for the property.
getPropertyName() - Method in exception org.apache.camel.InvalidPropertyException
 
getPropertyName() - Method in exception org.apache.camel.NoSuchPropertyException
 
getPropertyName() - Method in exception org.apache.camel.PropertyBindingException
 
getPrototypeEndpoint(String) - Method in interface org.apache.camel.ExtendedCamelContext
Resolves the given name to an Endpoint of the specified type (scope is prototype).
getPrototypeEndpoint(NormalizedEndpointUri) - Method in interface org.apache.camel.ExtendedCamelContext
Resolves the given name to an Endpoint of the specified type (scope is prototype).
getProvider() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
 
getProvider() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
 
getProvider() - Method in class org.apache.camel.support.jsse.SecureRandomParameters
 
getProvider() - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
getProvider() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
 
getReactiveExecutor() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the ReactiveExecutor to use.
getRecoveryIntervalInMillis() - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
Gets the interval between recovery scans in millis.
getRegisterAlways() - Method in interface org.apache.camel.spi.ManagementAgent
Whether to always register mbeans.
getRegisterNewRoutes() - Method in interface org.apache.camel.spi.ManagementAgent
Whether to register mbeans when starting a new route

This option is default true.

getRegistry() - Method in interface org.apache.camel.CamelContext
Returns the registry used to lookup components by name and type such as SimpleRegistry, Spring ApplicationContext, JNDI, or the OSGi Service Registry.
getRegistry(Class<T>) - Method in interface org.apache.camel.CamelContext
Returns the registry used to lookup components by name and as the given type
getRejectedExecutionHandler() - Method in class org.apache.camel.spi.ThreadPoolProfile
Gets the handler for tasks which cannot be executed by the thread pool.
getRejectedPolicy() - Method in class org.apache.camel.spi.ThreadPoolProfile
Gets the policy for tasks which cannot be executed by the thread pool.
getRepository(String) - Method in interface org.apache.camel.health.HealthCheckRegistry
Returns the repository identified by the given id if available.
getResource() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
 
getResourcePath() - Method in interface org.apache.camel.spi.FactoryFinder
Gets the resource classpath.
getRestartException(String) - Method in interface org.apache.camel.spi.SupervisingRouteController
Gets the last exception that caused the route to not startup for the given route
getRestartingRoutes() - Method in interface org.apache.camel.spi.SupervisingRouteController
Return the list of routes that are currently under restarting by this controller.
getRestartingRouteState(String) - Method in interface org.apache.camel.spi.SupervisingRouteController
Gets the state of the backoff for the given route if its managed and under restarting.
getRestBindingJaxbDataFormatFactory() - Method in interface org.apache.camel.ExtendedCamelContext
getRestConfiguration() - Method in interface org.apache.camel.CamelContext
Gets the default REST configuration
getRestRegistry() - Method in interface org.apache.camel.CamelContext
Gets the RestRegistry to use
getResultType() - Method in interface org.apache.camel.spi.ExpressionResultTypeAware
Gets the result type
getRight() - Method in interface org.apache.camel.BinaryPredicate
Gets the right hand side expression
getRoute(String) - Method in interface org.apache.camel.CamelContext
Gets the route with the given id
getRoute() - Method in interface org.apache.camel.Channel
Gets the Route
getRoute() - Method in interface org.apache.camel.Route
Get the route type.
getRoute() - Method in interface org.apache.camel.RouteAware
Gets the Route
getRoute() - Method in interface org.apache.camel.spi.CamelEvent.RouteEvent
 
getRoute() - Method in interface org.apache.camel.spi.RouteStartupOrder
Gets the route
getRoute() - Method in interface org.apache.camel.spi.UnitOfWork
Gets the Route that this UnitOfWork currently is being routed through.
getRouteController() - Method in interface org.apache.camel.CamelContext
getRouteController() - Method in interface org.apache.camel.Route
Gets the RouteController for this route.
getRouteDescription() - Method in interface org.apache.camel.Route
Gets the route description
getRouteFactory() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the current RouteFactory
getRouteId() - Method in exception org.apache.camel.FailedToCreateRouteException
 
getRouteId() - Method in exception org.apache.camel.FailedToStartRouteException
 
getRouteId() - Method in interface org.apache.camel.MessageHistory
Gets the route id at the point of this history.
getRouteId() - Method in interface org.apache.camel.NamedRoute
Gets the route id.
getRouteId() - Method in interface org.apache.camel.Route
Gets the route id
getRouteId() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.AwaitThread
The id of the route where the exchange was processed when the thread was set to block.
getRouteId() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Gets the id of the route this rest service will be using.
getRouteId() - Method in interface org.apache.camel.spi.RouteIdAware
Gets the route id
getRouteId() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry.Statistic
The route id (if the endpoint is associated with a route)
getRouteMessage(String) - Static method in exception org.apache.camel.FailedToCreateRouteException
 
getRoutePolicyFactories() - Method in interface org.apache.camel.CamelContext
Gets the route policy factories
getRoutePolicyList() - Method in interface org.apache.camel.Route
Gets the route policy List
getRoutes() - Method in interface org.apache.camel.CamelContext
Returns the current routes in this CamelContext
getRoutesSize() - Method in interface org.apache.camel.CamelContext
Returns the total number of routes in this CamelContext
getRouteStartupLoggingLevel() - Method in interface org.apache.camel.spi.RouteController
Gets the logging level used for logging route startup activity.
getRouteStartupOrder() - Method in interface org.apache.camel.ExtendedCamelContext
Returns the order in which the route inputs was started.
getRouteStatus(String) - Method in interface org.apache.camel.spi.RouteController
Returns the current status of the given route
getRuntimeCamelCatalog() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the RuntimeCamelCatalog if available on the classpath.
getRuntimeEndpointRegistry() - Method in interface org.apache.camel.CamelContext
Gets the RuntimeEndpointRegistry to use, or null if none is in use.
getScheme() - Method in class org.apache.camel.spi.RestConfiguration
Gets the scheme to use by the REST consumer
getScheme() - Method in interface org.apache.camel.spi.SendDynamicAware
Gets the component name
getScope() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.Result
Scope of the verification.
getSecureRandom() - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
getSecureSocketProtocol() - Method in class org.apache.camel.support.jsse.SecureSocketProtocolsParameters
Returns a live reference to the list of secure socket protocol names.
getSecureSocketProtocol() - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
getSecureSocketProtocols() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Returns the explicitly configured secure socket protocol names for this configuration.
getSecureSocketProtocolsFilter() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Returns the optional secure socket protocol filter for this configuration.
getServerAliases(String, Principal[]) - Method in class org.apache.camel.support.jsse.AliasedX509ExtendedKeyManager
 
getServerParameters() - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
getService() - Method in interface org.apache.camel.spi.CamelEvent.ServiceEvent
 
getServiceChooser() - Method in interface org.apache.camel.cloud.ServiceChooserAware
getServiceDiscovery() - Method in interface org.apache.camel.cloud.ServiceDiscoveryAware
getServiceFilter() - Method in interface org.apache.camel.cloud.ServiceFilterAware
getServiceProperties() - Method in interface org.apache.camel.cloud.DiscoverableService
Get the service properties.
getServices(String) - Method in interface org.apache.camel.cloud.ServiceDiscovery
Gets the list of services.
getServices() - Method in interface org.apache.camel.ExtendedCamelContext
Returns an unmodifiable list of the services registered currently in this CamelContext.
getServices() - Method in interface org.apache.camel.Route
Returns the services for this particular route
getServices() - Method in interface org.apache.camel.spi.RouteStartupOrder
Gets the services to this route.
getSessionTimeout() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Returns the optional SSLSessionContext timeout time for SSLSessions in seconds.
getShortError() - Method in class org.apache.camel.catalog.LanguageValidationResult
 
getShortName() - Method in interface org.apache.camel.NamedNode
Returns a short name for this node which can be useful for ID generation or referring to related resources like images
getShutdownAwaitTermination() - Method in interface org.apache.camel.spi.ExecutorServiceManager
Gets the time to wait for thread pools to shutdown orderly, when invoking the ShutdownableService.shutdown() method.
getShutdownRoute() - Method in interface org.apache.camel.RuntimeConfiguration
Gets the option to use when shutting down the route.
getShutdownRunningTask() - Method in interface org.apache.camel.RuntimeConfiguration
Gets the ShutdownRunningTask option in use when shutting down a route.
getShutdownStrategy() - Method in interface org.apache.camel.CamelContext
Gets the current shutdown strategy.
getSNIHostNames() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
 
getSNIHostNames() - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
 
getSource() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextEvent
 
getSource() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeEvent
 
getSource() - Method in interface org.apache.camel.spi.CamelEvent
 
getSource() - Method in interface org.apache.camel.spi.CamelEvent.RouteEvent
 
getSource() - Method in interface org.apache.camel.spi.CamelEvent.ServiceEvent
 
getSource() - Method in interface org.apache.camel.spi.ConsumerCache
Gets the source which uses this cache
getSource() - Method in interface org.apache.camel.spi.ProducerCache
Gets the source which uses this cache
getSpoolCipher() - Method in interface org.apache.camel.spi.StreamCachingStrategy
 
getSpoolDirectory() - Method in interface org.apache.camel.spi.StreamCachingStrategy
 
getSpoolThreshold() - Method in interface org.apache.camel.spi.StreamCachingStrategy
 
getSpoolUsedHeapMemoryLimit() - Method in interface org.apache.camel.spi.StreamCachingStrategy
 
getSpoolUsedHeapMemoryThreshold() - Method in interface org.apache.camel.spi.StreamCachingStrategy
 
getSSLContextParameters() - Method in interface org.apache.camel.CamelContext
Gets the global SSL context parameters if configured.
getSSLEngineConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Returns the list of configurers to apply to an SSLEngine in order to fully configure it in compliance with the provided configuration options.
getSSLEngineConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
Returns the list of configurers to apply to an SSLEngine in order to fully configure it in compliance with the provided configuration options.
getSSLEngineConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
getSSLEngineConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
Returns the list of configurers to apply to an SSLEngine in order to fully configure it in compliance with the provided configuration options.
getSSLServerSocketFactoryConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Returns the list of configurers to apply to an SSLServerSocketFactory in order to fully configure it in compliance with the provided configuration options.
getSSLServerSocketFactoryConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
This class has no bearing on SSLServerSocketFactory instances and therefore provides no configurers for that purpose.
getSSLServerSocketFactoryConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
getSSLServerSocketFactorySSLServerSocketConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Returns the list of configurers to apply to an SSLServerSocket in order to fully configure it in compliance with the provided configuration options.
getSSLServerSocketFactorySSLServerSocketConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
 
getSSLSocketFactoryConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Returns the list of configurers to apply to an SSLSocketFactory in order to fully configure it in compliance with the provided configuration options.
getSSLSocketFactoryConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
getSSLSocketFactoryConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
This class has no bearing on SSLSocketFactory instances and therefore provides no configurers for that purpose.
getSSLSocketFactorySSLSocketConfigurers(SSLContext) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Returns the list of configurers to apply to an SSLSocket in order to fully configure it in compliance with the provided configuration options.
getStartDate() - Method in interface org.apache.camel.CamelContext
Gets the date and time Camel was started up.
getStartupOrder() - Method in interface org.apache.camel.Route
Gets the route startup order
getStartupOrder() - Method in interface org.apache.camel.spi.RouteStartupOrder
Get the order this route should be started.
getState() - Method in interface org.apache.camel.health.HealthCheck.Result
The state of the service.
getState() - Method in interface org.apache.camel.spi.Breakpoint
Gets the state of this break
getState() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Gets the state of the REST service (started, stopped, etc)
getState(K) - Method in interface org.apache.camel.spi.StateRepository
Gets the state value for the given key.
getStatistics() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
Gets the utilization statistics of this manager
getStatistics() - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
Gets the endpoint utilization statistics.
getStatistics() - Method in interface org.apache.camel.spi.StreamCachingStrategy
Gets the utilization statistics.
getStatistics() - Method in interface org.apache.camel.spi.TypeConverterRegistry
Gets the utilization statistics of this type converter registry
getStatisticsLevel() - Method in interface org.apache.camel.spi.ManagementAgent
§ Gets the statistics level
getStatus() - Method in interface org.apache.camel.CamelContextLifecycle
Get the status of this CamelContext
getStatus() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.Result
Result of the validation as status.
getStatus() - Method in interface org.apache.camel.StatefulService
Returns the current status
getStatus() - Method in class org.apache.camel.support.service.BaseService
 
getStepId() - Method in interface org.apache.camel.spi.CamelEvent.StepEvent
 
getStreamCachingStrategy() - Method in interface org.apache.camel.CamelContext
Gets the StreamCachingStrategy to use.
getSupportedCipherSuites() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
 
getSupportedCipherSuites() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
 
getSupportedExtensions() - Method in interface org.apache.camel.Component
Gets a list of supported extensions.
getTarget() - Method in exception org.apache.camel.PropertyBindingException
 
getterOrSetterShorthandName - Variable in class org.apache.camel.spi.BeanIntrospection.MethodInfo
 
getText() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
 
getText() - Method in class org.apache.camel.catalog.LanguageValidationResult
 
getThreadNamePattern() - Method in interface org.apache.camel.spi.ExecutorServiceManager
Gets the thread name pattern to use
getThreadPoolFactory() - Method in interface org.apache.camel.spi.ExecutorServiceManager
Gets the ThreadPoolFactory to use for creating the thread pools.
getThreadPoolProfile(String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Gets the thread pool profile by the given id
getThreadPoolSize() - Method in interface org.apache.camel.spi.SupervisingRouteController
 
getThreadsBlocked() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
Total number of threads that has been blocked
getThreadsInterrupted() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
Total number of threads that has been forced interrupted
getTime() - Method in interface org.apache.camel.MessageHistory
Gets the timestamp at the point of this history.
getTimeout() - Method in exception org.apache.camel.ExchangeTimedOutException
Return the timeout which expired in milliseconds
getTimeout() - Method in interface org.apache.camel.spi.ShutdownStrategy
Gets the timeout.
getTimeTaken() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeSentEvent
 
getTimeUnit() - Method in interface org.apache.camel.spi.ShutdownStrategy
Gets the time unit used
getTimeUnit() - Method in class org.apache.camel.spi.ThreadPoolProfile
Gets the time unit used for keep alive time
getTo() - Method in class org.apache.camel.spi.Transformer
Get 'to' data type.
getTotalDuration() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
The total duration time in millis.
getToType() - Method in exception org.apache.camel.NoTypeConversionAvailableException
Returns the required to type
getToType() - Method in exception org.apache.camel.TypeConversionException
Returns the required to type
getToType() - Method in exception org.apache.camel.TypeConverterExistsException
 
getTraceCounter() - Method in interface org.apache.camel.spi.Tracer
Number of traced messages
getTraceLabel() - Method in interface org.apache.camel.Traceable
Gets the trace label used for logging when tracing is enabled.
getTracePattern() - Method in interface org.apache.camel.spi.Tracer
Tracing pattern to match which node EIPs to trace.
getTracer() - Method in interface org.apache.camel.CamelContext
Gets the current Tracer
getTracingPattern() - Method in interface org.apache.camel.RuntimeConfiguration
Tracing pattern to match which node EIPs to trace.
getTransformerRegistry() - Method in interface org.apache.camel.CamelContext
getTrustManager() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
 
getTrustManagers() - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
getType() - Method in exception org.apache.camel.InvalidPayloadException
The expected type of the body
getType() - Method in exception org.apache.camel.InvalidPayloadRuntimeException
The expected type of the body
getType() - Method in exception org.apache.camel.NoSuchHeaderException
 
getType() - Method in exception org.apache.camel.NoSuchPropertyException
 
getType() - Method in exception org.apache.camel.ProxyInstantiationException
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextInitializedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextInitializingEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextResumedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextResumeFailureEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextResumingEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextRoutesStartedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextRoutesStartingEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextRoutesStoppedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextRoutesStoppingEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextStartedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextStartingEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextStartupFailureEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextStopFailureEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextStoppedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextStoppingEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextSuspendedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.CamelContextSuspendingEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeCompletedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeCreatedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailureHandledEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailureHandlingEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeRedeliveryEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeSendingEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeSentEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteAddedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteRemovedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteStartedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.RouteStoppedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.ServiceStartupFailureEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.ServiceStopFailureEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.StepCompletedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.StepFailedEvent
 
getType() - Method in interface org.apache.camel.spi.CamelEvent.StepStartedEvent
 
getType() - Method in class org.apache.camel.spi.Validator
Get 'from' data type.
getType() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
 
getTypeConverter() - Method in interface org.apache.camel.CamelContext
Returns the type converter used to coerce types from one type to another.
getTypeConverterExists() - Method in interface org.apache.camel.spi.TypeConverterRegistry
What should happen when attempting to add a duplicate type converter.
getTypeConverterExistsLoggingLevel() - Method in interface org.apache.camel.spi.TypeConverterRegistry
The logging level to use when logging that a type converter already exists when attempting to add a duplicate type converter.
getTypeConverterRegistry() - Method in interface org.apache.camel.CamelContext
Returns the type converter registry where type converters can be added or looked up
getUnitOfWork() - Method in interface org.apache.camel.Exchange
Returns the unit of work that this exchange belongs to; which may map to zero, one or more physical transactions
getUnitOfWorkFactory() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the UnitOfWorkFactory to use.
getUptime() - Method in interface org.apache.camel.CamelContext
Gets the uptime in a human readable format
getUptime() - Method in interface org.apache.camel.Route
Gets the uptime in a human readable format
getUptimeMillis() - Method in interface org.apache.camel.CamelContext
Gets the uptime in milli seconds
getUptimeMillis() - Method in interface org.apache.camel.Route
Gets the uptime in milliseconds
getUri() - Method in class org.apache.camel.catalog.EndpointValidationResult
 
getUri() - Method in exception org.apache.camel.FailedToCreateConsumerException
 
getUri() - Method in exception org.apache.camel.FailedToCreateProducerException
 
getUri() - Method in exception org.apache.camel.NoFactoryAvailableException
 
getUri() - Method in exception org.apache.camel.NoSuchEndpointException
 
getUri() - Method in exception org.apache.camel.ResolveEndpointFailedException
 
getUri() - Method in interface org.apache.camel.spi.NormalizedEndpointUri
Gets the normalized uri
getUri() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry.Statistic
The endpoint uri
getUri() - Method in class org.apache.camel.spi.SendDynamicAware.DynamicAwareEntry
 
getUriFactoryResolver() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the UriFactoryResolver to use.
getUriTemplate() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Gets the uri template
getUrl() - Method in exception org.apache.camel.LoadPropertiesException
 
getUrl() - Method in interface org.apache.camel.spi.RestRegistry.RestService
Gets the absolute url to the REST service (baseUrl + uriTemplate)
getUseHostIPAddress() - Method in interface org.apache.camel.spi.ManagementAgent
Gets whether host IP Address to be used instead of host name.
getUsePlatformMBeanServer() - Method in interface org.apache.camel.spi.ManagementAgent
Whether to use the platform MBean Server.
getUuidGenerator() - Method in interface org.apache.camel.CamelContext
Gets the current UuidGenerator
getValidatorRegistry() - Method in interface org.apache.camel.CamelContext
getValue() - Method in enum org.apache.camel.Category
Returns the string representation of this value
getValue() - Method in exception org.apache.camel.NoTypeConversionAvailableException
Returns the value which could not be converted
getValue() - Method in exception org.apache.camel.PropertyBindingException
 
getValue() - Method in interface org.apache.camel.StaticExpression
Gets the constant value
getValue() - Method in exception org.apache.camel.TypeConversionException
Returns the value which could not be converted
getVersion() - Method in interface org.apache.camel.CamelContext
Gets the version of the this CamelContext.
getView(String) - Method in interface org.apache.camel.cluster.CamelClusterService
Get a view of the cluster bound to a namespace creating it if needed.
getView(String) - Method in interface org.apache.camel.cluster.CamelPreemptiveClusterService
 
getWaitDuration() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.AwaitThread
Time in millis the thread has been blocked waiting for the signal.
getWrapped() - Method in interface org.apache.camel.spi.WrapAwareProcessor
Gets the wrapped Processor
getXmlDataFormat() - Method in class org.apache.camel.spi.RestConfiguration
Gets the name of the xml data format.
getXMLRoutesDefinitionLoader() - Method in interface org.apache.camel.ExtendedCamelContext
Gets the XMLRoutesDefinitionLoader to be used.
GlobalEndpointConfiguration - Interface in org.apache.camel
Global endpoint configurations which can be set as defaults when Camel creates new Endpoints.
GlobalSSLContextParametersSupplier - Interface in org.apache.camel.support.jsse
A global Supplier of SSLContextParameters to be used in Camel registry.
GROUP_NAME - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.GroupAttribute
Group name
GROUP_OPTIONS - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.GroupAttribute
Options for the group
GROUP_PROPERTY - Static variable in interface org.apache.camel.Route
 
GroupAware - Interface in org.apache.camel.spi
To allow objects to be injected with an group.
GROUPED_EXCHANGE - Static variable in interface org.apache.camel.Exchange
 

H

handleException(Throwable) - Method in interface org.apache.camel.spi.ExceptionHandler
Handles the given exception
handleException(String, Throwable) - Method in interface org.apache.camel.spi.ExceptionHandler
Handles the given exception
handleException(String, Exchange, Throwable) - Method in interface org.apache.camel.spi.ExceptionHandler
Handles the given exception
Handler - Annotation Type in org.apache.camel
Marks a method on a POJO as being the preferred method to invoke when Camel looks for methods to invoke using the BeanEndpoint.
handoverCompletions(Exchange) - Method in interface org.apache.camel.ExtendedExchange
Handover all the on completions from this exchange to the target exchange.
handoverCompletions() - Method in interface org.apache.camel.ExtendedExchange
Handover all the on completions from this exchange
handoverSynchronization(Exchange) - Method in interface org.apache.camel.spi.UnitOfWork
Handover all the registered synchronizations to the target Exchange.
handoverSynchronization(Exchange, Predicate<Synchronization>) - Method in interface org.apache.camel.spi.UnitOfWork
Handover all the registered synchronizations to the target Exchange.
HasCamelContext - Interface in org.apache.camel.spi
A simple marker interface for an object which holds a CamelContext
hasComponent(String) - Method in interface org.apache.camel.CamelContext
Is the given component already registered?
hasDataType() - Method in interface org.apache.camel.spi.DataTypeAware
Whether any data type has been configured
hasEndpoint(String) - Method in interface org.apache.camel.CamelContext
Is the given endpoint already registered in the EndpointRegistry
hasEndpoint(NormalizedEndpointUri) - Method in interface org.apache.camel.ExtendedCamelContext
Is the given endpoint already registered in the EndpointRegistry
hasGetterAndSetter - Variable in class org.apache.camel.spi.BeanIntrospection.MethodInfo
 
HasGroup - Interface in org.apache.camel.spi
A simple marker interface for an object which has belongs to a group Group which is useful for group related operation such as clustering, JMX style API
hashCode() - Method in class org.apache.camel.spi.Contract
 
hashCode() - Method in class org.apache.camel.spi.DataType
 
hashCode() - Method in class org.apache.camel.ValueHolder
 
hasHeaders() - Method in interface org.apache.camel.Message
Returns whether has any headers has been set.
HasId - Interface in org.apache.camel.spi
A simple marker interface for an object which has a unique ID which is useful for referring to objects in REST or JMX style APIs
hasNext() - Method in interface org.apache.camel.Navigate
Are there more outputs?

Important only invoke this once, as this method do not carry state, and is not intended to be used in a while loop, but used by a if statement instead.

hasOut() - Method in interface org.apache.camel.Exchange
Deprecated.
hasProperties() - Method in interface org.apache.camel.Exchange
Returns whether any properties has been set
hasService(Object) - Method in interface org.apache.camel.CamelContext
Has the given service already been added to this CamelContext?
hasService(Class<T>) - Method in interface org.apache.camel.CamelContext
Has the given service type already been added to this CamelContext?
hasServices(Class<T>) - Method in interface org.apache.camel.CamelContext
Has the given service type already been added to this CamelContext?
hasState() - Method in interface org.apache.camel.spi.CamelInternalProcessorAdvice
Whether this advice has state or not.
hasTimeoutOccurred() - Method in interface org.apache.camel.spi.ShutdownStrategy
Whether a timeout has occurred during a shutdown.
Header - Annotation Type in org.apache.camel
Marks a parameter as being a header on an inbound Message
HeaderFilterStrategy - Interface in org.apache.camel.spi
Interface to allow plug-able implementation to filter header to and from Camel message.
HeaderFilterStrategy.Direction - Enum in org.apache.camel.spi
The direction is either IN or OUT.
HeaderFilterStrategyAware - Interface in org.apache.camel.spi
An interface to represent an object which can make use of injected HeaderFilterStrategy.
Headers - Annotation Type in org.apache.camel
Marks a parameter as being an injection point of the headers of an inbound Message
HeadersMapFactory - Interface in org.apache.camel.spi
Factory to create the Map implementation to use for storing headers on Message.
HealthCheck - Interface in org.apache.camel.health
Health check
HealthCheck.Result - Interface in org.apache.camel.health
Response to an health check invocation.
HealthCheck.State - Enum in org.apache.camel.health
 
HealthCheckConfiguration - Class in org.apache.camel.health
Configuration for HealthCheck.
HealthCheckConfiguration() - Constructor for class org.apache.camel.health.HealthCheckConfiguration
 
HealthCheckConfiguration.Builder - Class in org.apache.camel.health
 
HealthCheckFilter - Interface in org.apache.camel.health
Health check filter definition.
HealthCheckHelper - Class in org.apache.camel.health
Helper for invoking HealthCheck's.
HealthCheckRegistry - Interface in org.apache.camel.health
A registry for health checks.
HealthCheckRepository - Interface in org.apache.camel.health
A repository for health checks.
HealthCheckResultBuilder - Class in org.apache.camel.health
A builder helper to create a HealthCheck result.
HIGHEST - Static variable in interface org.apache.camel.Ordered
The highest precedence
HTTP_BASE_URI - Static variable in interface org.apache.camel.Exchange
 
HTTP_CHARACTER_ENCODING - Static variable in interface org.apache.camel.Exchange
 
HTTP_CHUNKED - Static variable in interface org.apache.camel.Exchange
 
HTTP_CODE - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.HttpAttribute
The erroneous HTTP code that occurred
HTTP_HOST - Static variable in interface org.apache.camel.Exchange
 
HTTP_METHOD - Static variable in interface org.apache.camel.Exchange
 
HTTP_PATH - Static variable in interface org.apache.camel.Exchange
 
HTTP_PORT - Static variable in interface org.apache.camel.Exchange
 
HTTP_PROTOCOL_VERSION - Static variable in interface org.apache.camel.Exchange
 
HTTP_QUERY - Static variable in interface org.apache.camel.Exchange
 
HTTP_RAW_QUERY - Static variable in interface org.apache.camel.Exchange
 
HTTP_REDIRECT - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.HttpAttribute
If given as details, specifies that a redirect happened and the content of this detail is the redirect URL
HTTP_RESPONSE_CODE - Static variable in interface org.apache.camel.Exchange
 
HTTP_RESPONSE_TEXT - Static variable in interface org.apache.camel.Exchange
 
HTTP_SCHEME - Static variable in interface org.apache.camel.Exchange
 
HTTP_SERVLET_REQUEST - Static variable in interface org.apache.camel.Exchange
 
HTTP_SERVLET_RESPONSE - Static variable in interface org.apache.camel.Exchange
 
HTTP_TEXT - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.HttpAttribute
HTTP response's body
HTTP_URI - Static variable in interface org.apache.camel.Exchange
 
HTTP_URL - Static variable in interface org.apache.camel.Exchange
 

I

ID_PROPERTY - Static variable in interface org.apache.camel.Route
 
IdAware - Interface in org.apache.camel.spi
To allow objects to be injected with an id, such as EIP Processors which has been defined from Camel routes.
IdempotentRepository - Interface in org.apache.camel.spi
Access to a repository of Message IDs to implement the Idempotent Consumer pattern.
ILLEGAL_PARAMETER - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
A given parameter is illegal
ILLEGAL_PARAMETER_GROUP_COMBINATION - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
A combination of parameters is illegal.
ILLEGAL_PARAMETER_VALUE - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
A parameter value is not valid
include - Variable in class org.apache.camel.support.jsse.FilterParameters
 
INCOMPLETE_PARAMETER_GROUP - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
A group of parameters is not complete in order to be valid
InflightRepository - Interface in org.apache.camel.spi
A repository which tracks in flight Exchanges.
InflightRepository.InflightExchange - Interface in org.apache.camel.spi
Information about the inflight exchange.
init() - Method in interface org.apache.camel.CamelContextLifecycle
 
init(CamelContext) - Method in interface org.apache.camel.Expression
Initialize the expression with the given camel context
init(CamelContext) - Method in interface org.apache.camel.Predicate
Initialize the predicate with the given camel context
init() - Method in interface org.apache.camel.Service
Initialize the service
init() - Method in class org.apache.camel.support.service.BaseService
 
initChannel(Route, NamedNode, NamedNode, List<InterceptStrategy>, Processor, NamedRoute, boolean) - Method in interface org.apache.camel.Channel
Initializes the channel.
INITIALIZED - Static variable in class org.apache.camel.support.service.BaseService
 
INITIALIZING - Static variable in class org.apache.camel.support.service.BaseService
 
initService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
Initializes the given value if it's a Service or a collection of it.
initService(Object...) - Static method in class org.apache.camel.support.service.ServiceHelper
Initializes each element of the given services if services itself is not null, otherwise this method would return immediately.
Injector - Interface in org.apache.camel.spi
A pluggable strategy for creating and possibly dependency injecting objects which could be implemented using straight forward reflection or using Spring or CDI to perform dependency injection.
inMemory() - Method in interface org.apache.camel.StreamCache
Whether this StreamCache is in memory only or spooled to persistent storage such as files.
InOnly - Annotation Type in org.apache.camel
Marks methods as being ExchangePattern.InOnly for one way asynchronous invocation when using Bean Integration or Spring Remoting to overload the default value which is ExchangePattern.InOut for request/reply if no annotations are used.
InOut - Annotation Type in org.apache.camel
Marks a method as being ExchangePattern.InOut when a class or interface has been annotated with InOnly when using Bean Integration or Spring Remoting.
INTERCEPT_SEND_TO_ENDPOINT_WHEN_MATCHED - Static variable in interface org.apache.camel.Exchange
 
INTERCEPTED_ENDPOINT - Static variable in interface org.apache.camel.Exchange
 
InterceptEndpointFactory - Interface in org.apache.camel.spi
A factory to create Endpoint which are intercepted.
InterceptSendToEndpoint - Interface in org.apache.camel.spi
This is an endpoint when sending to it, is intercepted and is routed in a detour, with the following flow: before, send to original endpoint (can be skipped), after (optional).
InterceptStrategy - Interface in org.apache.camel.spi
The purpose of this interface is to allow an implementation to wrap processors in a route with interceptors.
INTERNAL - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
Internal error while performing the verification
InternalProcessor - Interface in org.apache.camel.spi
Internal Processor that Camel routing engine used during routing for cross cutting functionality such as: Execute UnitOfWork Keeping track which route currently is being routed Execute RoutePolicy Gather JMX performance statics Tracing Debugging Message History Stream Caching Transformer ...
InternalProcessorFactory - Interface in org.apache.camel.spi
A factory used internally by Camel to create Processor and other internal building blocks.
interrupt(String) - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
To interrupt an exchange which may seem as stuck, to force the exchange to continue, allowing any blocking thread to be released.
interrupt(Exchange) - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
To interrupt an exchange which may seem as stuck, to force the exchange to continue, allowing any blocking thread to be released.
INTERRUPTED - Static variable in interface org.apache.camel.Exchange
Deprecated.
interval(Duration) - Method in class org.apache.camel.health.HealthCheckConfiguration.Builder
 
interval(String) - Method in class org.apache.camel.health.HealthCheckConfiguration.Builder
 
interval(long) - Method in class org.apache.camel.health.HealthCheckConfiguration.Builder
 
InvalidPayloadException - Exception in org.apache.camel
Is thrown if the payload from the exchange could not be retrieved because of being null, wrong class type etc.
InvalidPayloadException(Exchange, Class<?>) - Constructor for exception org.apache.camel.InvalidPayloadException
 
InvalidPayloadException(Exchange, Class<?>, Message) - Constructor for exception org.apache.camel.InvalidPayloadException
 
InvalidPayloadException(Exchange, Class<?>, Message, Throwable) - Constructor for exception org.apache.camel.InvalidPayloadException
 
InvalidPayloadRuntimeException - Exception in org.apache.camel
Runtime version of the InvalidPayloadException.
InvalidPayloadRuntimeException(Exchange, Class<?>) - Constructor for exception org.apache.camel.InvalidPayloadRuntimeException
 
InvalidPayloadRuntimeException(Exchange, Class<?>, Throwable) - Constructor for exception org.apache.camel.InvalidPayloadRuntimeException
 
InvalidPayloadRuntimeException(Exchange, Class<?>, Message) - Constructor for exception org.apache.camel.InvalidPayloadRuntimeException
 
InvalidPayloadRuntimeException(Exchange, Class<?>, Message, Throwable) - Constructor for exception org.apache.camel.InvalidPayloadRuntimeException
 
InvalidPropertyException - Exception in org.apache.camel
An exception caused when an invalid property name is used on an object
InvalidPropertyException(Object, String) - Constructor for exception org.apache.camel.InvalidPropertyException
 
InvalidPropertyException(Object, String, Class<?>) - Constructor for exception org.apache.camel.InvalidPropertyException
 
invoke(CamelContext) - Static method in class org.apache.camel.health.HealthCheckHelper
Invokes the checks and returns a collection of results.
invoke(CamelContext, Function<HealthCheck, Map<String, Object>>) - Static method in class org.apache.camel.health.HealthCheckHelper
Invokes the checks and returns a collection of results.
invoke(CamelContext, HealthCheckFilter) - Static method in class org.apache.camel.health.HealthCheckHelper
Invokes the checks and returns a collection of results.
invoke(CamelContext, Function<HealthCheck, Map<String, Object>>, HealthCheckFilter) - Static method in class org.apache.camel.health.HealthCheckHelper
Invokes the checks and returns a collection of results.
invoke(CamelContext, String, Map<String, Object>) - Static method in class org.apache.camel.health.HealthCheckHelper
Invoke a check by id.
invokeLiveness(CamelContext) - Static method in class org.apache.camel.health.HealthCheckHelper
Invokes the liveness checks and returns a collection of results.
InvokeOnHeader - Annotation Type in org.apache.camel.spi
Marks a method as being invoked for a specific header value.
InvokeOnHeaders - Annotation Type in org.apache.camel.spi
Marks a method as being invoked for a specific header value.
invokeReadiness(CamelContext) - Static method in class org.apache.camel.health.HealthCheckHelper
Invokes the readiness checks and returns a collection of results.
isAccepted() - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
 
isAllowUseOriginalMessage() - Method in interface org.apache.camel.RuntimeConfiguration
Gets whether access to the original message from Camel's error handler, or from UnitOfWork.getOriginalInMessage() is allowed.
isAnySpoolRules() - Method in interface org.apache.camel.spi.StreamCachingStrategy
 
isApiContextListing() - Method in class org.apache.camel.spi.RestConfiguration
 
isApiVendorExtension() - Method in class org.apache.camel.spi.RestConfiguration
 
isAutoStartup() - Method in interface org.apache.camel.Route
Gets whether the route should automatically start when Camel starts.
isAutoStartup() - Method in interface org.apache.camel.RuntimeConfiguration
Gets whether the object should automatically start when Camel starts.
isAutowiredEnabled() - Method in interface org.apache.camel.GlobalEndpointConfiguration
 
isAutowiredEnabled() - Method in interface org.apache.camel.RuntimeConfiguration
Whether autowiring is enabled.
isBacklogTracing() - Method in interface org.apache.camel.RuntimeConfiguration
Returns whether backlog tracing is enabled.
isBatchAllowed() - Method in interface org.apache.camel.BatchConsumer
Whether processing the batch is still allowed.
isBeforeAfterProcess() - Method in interface org.apache.camel.spi.UnitOfWork
Whether the unit of work should call the before/after process methods or not.
isBridgeErrorHandler() - Method in interface org.apache.camel.GlobalEndpointConfiguration
 
isBuild() - Method in class org.apache.camel.support.service.BaseService
 
isCaseInsensitive() - Method in interface org.apache.camel.spi.HeadersMapFactory
Whether the created Map are case insensitive or not.
isCaseInsensitiveHeaders() - Method in interface org.apache.camel.RuntimeConfiguration
Whether to use case sensitive or insensitive headers.
isClientRequestValidation() - Method in class org.apache.camel.spi.RestConfiguration
 
isCopyMessage() - Method in interface org.apache.camel.spi.MessageHistoryFactory
Whether to make a copy of the message in the MessageHistory.
isDeadLetterChannel() - Method in interface org.apache.camel.spi.CamelEvent.ExchangeFailureEvent
 
isDebugging() - Method in interface org.apache.camel.RuntimeConfiguration
Returns whether debugging is enabled.
isDefaultOrExtended() - Method in enum org.apache.camel.ManagementStatisticsLevel
 
isDefaultProfile() - Method in class org.apache.camel.spi.ThreadPoolProfile
Whether this profile is the default profile (there can only be one).
isDisabled() - Method in interface org.apache.camel.cluster.CamelPreemptiveClusterView
Check if the view is disabled.
isDisabled() - Method in interface org.apache.camel.spi.EventNotifier
Checks whether notification is disabled for all events
isDynamic(String) - Method in interface org.apache.camel.spi.EndpointRegistry
Whether the given endpoint is stored in the dynamic cache
isDynamic(String) - Method in interface org.apache.camel.spi.TransformerRegistry
Whether the given transformer is stored in the dynamic cache
isDynamic(DataType, DataType) - Method in interface org.apache.camel.spi.TransformerRegistry
Whether the given Transformer is stored in the dynamic cache
isDynamic(DataType) - Method in interface org.apache.camel.spi.ValidatorRegistry
Whether the given Validator is stored in the dynamic cache
isEmpty() - Method in class org.apache.camel.spi.Contract
 
isEmpty() - Method in class org.apache.camel.spi.ThreadPoolProfile
 
isEnableCORS() - Method in class org.apache.camel.spi.RestConfiguration
To specify whether to enable CORS which means Camel will automatic include CORS in the HTTP headers in the response.
isEnabled() - Method in class org.apache.camel.health.HealthCheckConfiguration
 
isEnabled() - Method in interface org.apache.camel.health.HealthCheckRegistry
Whether Health Check is enabled globally
isEnabled() - Method in interface org.apache.camel.health.HealthCheckRepository
Set if the checks associated to this repository is enabled or not.
isEnabled(LoggingLevel) - Method in enum org.apache.camel.LoggingLevel
Is the given logging level equal or higher than the current level.
isEnabled() - Method in interface org.apache.camel.spi.CamelBeanPostProcessor
 
isEnabled(String, Component) - Method in interface org.apache.camel.spi.ComponentCustomizer
Checks whether this customizer should be applied to the given Component.
isEnabled(String, DataFormat) - Method in interface org.apache.camel.spi.DataFormatCustomizer
Checks whether this customizer should be applied to the given DataFormat.
isEnabled(String) - Method in interface org.apache.camel.spi.EndpointUriFactory
Checks whether this factory supports the given component name
isEnabled(CamelEvent) - Method in interface org.apache.camel.spi.EventNotifier
Checks whether notification for the given event is enabled.
isEnabled(String, Language) - Method in interface org.apache.camel.spi.LanguageCustomizer
Checks whether this customizer should be applied to the given Language.
isEnabled() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
Whether gathering runtime usage is enabled or not.
isEnabled() - Method in interface org.apache.camel.spi.StreamCachingStrategy
 
isEnabled() - Method in interface org.apache.camel.spi.Tracer
Whether the tracer is enabled
isErrorHandlerHandled() - Method in interface org.apache.camel.ExtendedExchange
Whether the exchange has been handled by the error handler.
isErrorHandlerHandledSet() - Method in interface org.apache.camel.ExtendedExchange
Whether the error handler handled flag has been set.
isEventNotificationApplicable() - Method in interface org.apache.camel.ExtendedCamelContext
Whether exchange event notification is applicable (possible).
isEventNotifierEnabled() - Method in interface org.apache.camel.FluentProducerTemplate
Whether the EventNotifier should be used by this ProducerTemplate to send events about the Exchange being sent.
isEventNotifierEnabled() - Method in interface org.apache.camel.ProducerTemplate
Whether the EventNotifier should be used by this ProducerTemplate to send events about the Exchange being sent.
isEventNotifierEnabled() - Method in interface org.apache.camel.spi.ProducerCache
Whether EventNotifier is enabled
isExtended() - Method in enum org.apache.camel.ManagementStatisticsLevel
 
isExtendedStatistics() - Method in interface org.apache.camel.spi.BeanIntrospection
Whether to gather extended statistics for introspection usage.
isExternalRedelivered() - Method in interface org.apache.camel.Exchange
Returns true if this exchange is an external initiated redelivered message (such as a JMS broker).
isFailed() - Method in interface org.apache.camel.Exchange
Returns true if this exchange failed due to either an exception or fault
isFixedName() - Method in interface org.apache.camel.spi.CamelContextNameStrategy
Whether the name will be fixed, or allow re-calculation such as by using an unique counter.
isFixedName() - Method in interface org.apache.camel.spi.ManagementNameStrategy
Whether the name will be fixed, or allow re-calculation such as by using an unique counter.
isGetter - Variable in class org.apache.camel.spi.BeanIntrospection.MethodInfo
 
isHealthy() - Method in interface org.apache.camel.cloud.ServiceHealth
States if the service is healthy or not
isIgnoreCamelContextEvents() - Method in interface org.apache.camel.spi.EventNotifier
 
isIgnoreExchangeCompletedEvent() - Method in interface org.apache.camel.spi.EventNotifier
 
isIgnoreExchangeCreatedEvent() - Method in interface org.apache.camel.spi.EventNotifier
 
isIgnoreExchangeEvents() - Method in interface org.apache.camel.spi.EventNotifier
 
isIgnoreExchangeFailedEvents() - Method in interface org.apache.camel.spi.EventNotifier
 
isIgnoreExchangeRedeliveryEvents() - Method in interface org.apache.camel.spi.EventNotifier
 
isIgnoreExchangeSendingEvents() - Method in interface org.apache.camel.spi.EventNotifier
 
isIgnoreExchangeSentEvents() - Method in interface org.apache.camel.spi.EventNotifier
 
isIgnoreRouteEvents() - Method in interface org.apache.camel.spi.EventNotifier
 
isIgnoreServiceEvents() - Method in interface org.apache.camel.spi.EventNotifier
 
isIgnoreStepEvents() - Method in interface org.apache.camel.spi.EventNotifier
 
isInCapable() - Method in enum org.apache.camel.ExchangePattern
Return true if there can be an IN message
isInflightBrowseEnabled() - Method in interface org.apache.camel.spi.InflightRepository
Whether the inflight repository should allow browsing each inflight exchange.
isInit() - Method in class org.apache.camel.support.service.BaseService
 
isInitialized() - Method in enum org.apache.camel.ServiceStatus
 
isInitializing() - Method in enum org.apache.camel.ServiceStatus
 
isInstanceOf(Map<String, Object>) - Method in interface org.apache.camel.spi.HeadersMapFactory
Whether the given Map implementation is created by this factory?
isInterrupted() - Method in interface org.apache.camel.ExtendedExchange
Whether the exchange was interrupted (InterruptException) during routing.
isInterruptThreadsWhileStopping() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
Whether to interrupt any blocking threads during stopping.
isJavaType() - Method in class org.apache.camel.spi.DataType
 
isLazyStartProducer() - Method in interface org.apache.camel.GlobalEndpointConfiguration
 
isLeader() - Method in interface org.apache.camel.cluster.CamelClusterMember
 
isLeader(String) - Method in interface org.apache.camel.cluster.CamelClusterService
Check if the service is the leader on the given namespace.
isLenientProperties() - Method in interface org.apache.camel.Endpoint
Should all properties be known or does the endpoint allow unknown options?

lenient = false means that the endpoint should validate that all given options is known and configured properly.

isLenientProperties() - Method in interface org.apache.camel.spi.EndpointUriFactory
Whether the endpoint is lenient or not.
isLenientProperties() - Method in interface org.apache.camel.spi.SendDynamicAware
Whether the endpoint is lenient or not.
isLightweight() - Method in interface org.apache.camel.ExtendedCamelContext
Whether to run in lightweight mode which triggers some optimizations and memory reduction.
isLiveness() - Method in interface org.apache.camel.health.HealthCheck
Whether this health check can be used for liveness checks
isLoadTypeConverters() - Method in interface org.apache.camel.CamelContext
Whether to load custom type converters by scanning classpath.
isLocal() - Method in interface org.apache.camel.cluster.CamelClusterMember
 
isLogExhaustedMessageBody() - Method in interface org.apache.camel.RuntimeConfiguration
Returns whether to log exhausted message body with message history.
isLogInflightExchangesOnTimeout() - Method in interface org.apache.camel.spi.ShutdownStrategy
Whether to log information about the inflight Exchanges which are still running during a shutdown which didn't complete without the given timeout.
isLogMask() - Method in interface org.apache.camel.RuntimeConfiguration
Gets whether security mask for Logging is enabled or not.
isManaged(Object) - Method in interface org.apache.camel.spi.ManagementStrategy
Determines if an object or name is managed.
isManagedName(Object) - Method in interface org.apache.camel.spi.ManagementStrategy
Determines if an object or name is managed.
isMessageHistory() - Method in interface org.apache.camel.RuntimeConfiguration
Returns whether message history is enabled
isMultipleConsumersSupported() - Method in interface org.apache.camel.MultipleConsumersSupport
Are multiple consumers supported?
isNew() - Method in class org.apache.camel.support.service.BaseService
 
isNotifyEvent() - Method in interface org.apache.camel.ExtendedExchange
Whether the exchange is currently used as event notification.
isOnlyDynamicQueryParameters() - Method in interface org.apache.camel.spi.SendDynamicAware
Whether only the query parameters can be dynamic and the context-path must be static.
isOutCapable() - Method in enum org.apache.camel.ExchangePattern
Return true if there can be an OUT message
isReadiness() - Method in interface org.apache.camel.health.HealthCheck
Whether this health check can be used for readiness checks
isRedeliveryExhausted() - Method in interface org.apache.camel.ExtendedExchange
Whether the exchange has exhausted (attempted all) its redeliveries and still failed.
isRegistered(ObjectName) - Method in interface org.apache.camel.spi.ManagementAgent
Is the given object registered
isRemoveSpoolDirectoryWhenStopping() - Method in interface org.apache.camel.spi.StreamCachingStrategy
 
isRethrowException() - Method in exception org.apache.camel.VetoCamelContextStartException
Whether to rethrow this exception when starting CamelContext, to cause an exception to be thrown from the start method.
isRollbackOnly() - Method in interface org.apache.camel.Exchange
Returns true if this exchange is marked for rollback
isRollbackOnlyLast() - Method in interface org.apache.camel.Exchange
Returns true if this exchange is marked for rollback (only last transaction section)
isRouteStop() - Method in interface org.apache.camel.Exchange
Returns true if this exchange is marked to stop and not continue routing.
isRunAllowed() - Method in interface org.apache.camel.CamelContextLifecycle
Helper methods so the CamelContext knows if it should keep running.
isRunAllowed() - Method in interface org.apache.camel.StatefulService
Helper methods so the service knows if it should keep running.
isRunAllowed() - Method in class org.apache.camel.support.service.BaseService
 
isSchedulerStarted() - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
Whether the scheduler has been started.
isSetter - Variable in class org.apache.camel.spi.BeanIntrospection.MethodInfo
 
isSetupRoutes() - Method in interface org.apache.camel.ExtendedCamelContext
Indicates whether current thread is setting up route(s) as part of starting Camel from spring/blueprint.
isShutdown() - Method in class org.apache.camel.support.service.BaseService
 
isShutdownNowOnTimeout() - Method in interface org.apache.camel.spi.ShutdownStrategy
Whether to force shutdown of all consumers when a timeout occurred.
isShutdownRoutesInReverseOrder() - Method in interface org.apache.camel.spi.ShutdownStrategy
Whether to shutdown routes in reverse order than they where started.
IsSingleton - Interface in org.apache.camel
Used for defining if a given class is singleton or not.
isSingleton() - Method in interface org.apache.camel.IsSingleton
Whether this class supports being singleton or not.
isSingletonProducer() - Method in interface org.apache.camel.Endpoint
Whether this endpoint creates singleton producers
isSkip() - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
Whether to skip sending to the original endpoint.
isSkipBindingOnErrorCode() - Method in class org.apache.camel.spi.RestConfiguration
Whether to skip binding output if there is a custom HTTP error code, and instead use the response body as-is.
isStartable() - Method in enum org.apache.camel.ServiceStatus
 
isStarted() - Method in interface org.apache.camel.CamelContextLifecycle
Whether the CamelContext is started
isStarted() - Method in enum org.apache.camel.ServiceStatus
 
isStarted() - Method in interface org.apache.camel.StatefulService
Whether the service is started
isStarted() - Method in class org.apache.camel.support.service.BaseService
 
isStarted(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
Is the given service starting or already started?
isStarting() - Method in interface org.apache.camel.CamelContextLifecycle
Whether the CamelContext is starting
isStarting() - Method in enum org.apache.camel.ServiceStatus
 
isStarting() - Method in interface org.apache.camel.StatefulService
Whether the service is starting
isStarting() - Method in class org.apache.camel.support.service.BaseService
 
isStartingOrStarted() - Method in class org.apache.camel.support.service.BaseService
Is the service in progress of being suspended or already suspended
isStartingRoutes() - Method in interface org.apache.camel.spi.RouteController
Indicates whether current thread is starting route(s).
isStatic(String) - Method in interface org.apache.camel.spi.EndpointRegistry
Whether the given endpoint is stored in the static cache
isStatic(String) - Method in interface org.apache.camel.spi.TransformerRegistry
Whether the given transformer is stored in the static cache
isStatic(DataType, DataType) - Method in interface org.apache.camel.spi.TransformerRegistry
Whether the given transformer is stored in the static cache
isStatic(DataType) - Method in interface org.apache.camel.spi.ValidatorRegistry
Whether the given Validator is stored in the static cache
isStatisticsEnabled() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
Whether statistics is enabled.
isStatisticsEnabled() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
Whether statistics is enabled.
isStatisticsEnabled() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
Whether statistics is enabled.
isStoppable() - Method in enum org.apache.camel.ServiceStatus
 
isStopped() - Method in interface org.apache.camel.CamelContextLifecycle
Whether the CamelContext is stopped
isStopped() - Method in enum org.apache.camel.ServiceStatus
 
isStopped() - Method in interface org.apache.camel.StatefulService
Whether the service is stopped
isStopped() - Method in class org.apache.camel.support.service.BaseService
 
isStopped(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
Is the given service stopping or already stopped?
isStopping() - Method in interface org.apache.camel.CamelContextLifecycle
Whether the CamelContext is stopping
isStopping() - Method in enum org.apache.camel.ServiceStatus
 
isStopping() - Method in interface org.apache.camel.StatefulService
Whether the service is stopping
isStopping() - Method in class org.apache.camel.support.service.BaseService
 
isStoppingOrStopped() - Method in class org.apache.camel.support.service.BaseService
Is the service in progress of being stopped or already stopped
isStreamCaching() - Method in interface org.apache.camel.RuntimeConfiguration
Returns whether stream cache is enabled
isSuccess() - Method in class org.apache.camel.catalog.EndpointValidationResult
 
isSuccess() - Method in class org.apache.camel.catalog.LanguageValidationResult
 
isSuppressLoggingOnTimeout() - Method in interface org.apache.camel.spi.ShutdownStrategy
Whether Camel should try to suppress logging during shutdown and timeout was triggered, meaning forced shutdown is happening.
isSuspendable() - Method in enum org.apache.camel.ServiceStatus
 
isSuspended() - Method in interface org.apache.camel.CamelContextLifecycle
Whether the CamelContext is suspended
isSuspended() - Method in enum org.apache.camel.ServiceStatus
 
isSuspended() - Method in class org.apache.camel.support.service.BaseService
 
isSuspended(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
Is the given service suspending or already suspended?
isSuspended() - Method in interface org.apache.camel.SuspendableService
Tests whether the service is suspended or not.
isSuspending() - Method in interface org.apache.camel.CamelContextLifecycle
Whether the CamelContext is suspending
isSuspending() - Method in enum org.apache.camel.ServiceStatus
 
isSuspending() - Method in interface org.apache.camel.StatefulService
Whether the service is suspending
isSuspending() - Method in class org.apache.camel.support.service.BaseService
 
isSuspendingOrSuspended() - Method in class org.apache.camel.support.service.BaseService
Is the service in progress of being suspended or already suspended
isThreadedAsyncMode() - Method in interface org.apache.camel.ProducerTemplate
Reports if async* methods will dispath processing from the calling thread (false) or through executor (true).
isTraceBeforeAndAfterRoute() - Method in interface org.apache.camel.spi.Tracer
Whether to include tracing of before/after routes to trace the input and responses of routes.
isTracing() - Method in interface org.apache.camel.RuntimeConfiguration
Returns whether tracing enabled To use tracing then this must be enabled on startup to be installed in the CamelContext.
isTransacted() - Method in interface org.apache.camel.Exchange
Returns true if this exchange is transacted
isTransacted() - Method in interface org.apache.camel.spi.UnitOfWork
Are we transacted?
isTransactedBy(Object) - Method in interface org.apache.camel.spi.UnitOfWork
Are we already transacted by the given transaction key?
isTypeConverterStatisticsEnabled() - Method in interface org.apache.camel.CamelContext
Whether or not type converter statistics is enabled.
isUnhealthy() - Method in interface org.apache.camel.spi.RouteError
Whether the route is regarded as unhealthy.
isUnhealthyOnExhausted() - Method in interface org.apache.camel.spi.SupervisingRouteController
Whether to mark the route as unhealthy (down) when all restarting attempts (backoff) have failed and the route is not successfully started and the route manager is giving up.
isUseBreadcrumb() - Method in interface org.apache.camel.CamelContext
Whether or not breadcrumb is enabled.
isUseDataType() - Method in interface org.apache.camel.CamelContext
Whether to enable using data type on Camel messages.
isUseGlobalSslContextParameters() - Method in interface org.apache.camel.SSLContextParametersAware
Determine if the implementing object is using global SSL context parameters.
isUseMDCLogging() - Method in interface org.apache.camel.CamelContext
Whether or not MDC logging is being enabled.
isUseRecovery() - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
Whether or not recovery is enabled or not
isUseXForwardHeaders() - Method in class org.apache.camel.spi.RestConfiguration
WWhether to use X-Forward headers to set host etc.
isValidateInput() - Method in class org.apache.camel.spi.Contract
 
isValidateOutput() - Method in class org.apache.camel.spi.Contract
 
isVetoStarted() - Method in interface org.apache.camel.CamelContext
If CamelContext during the start procedure was vetoed, and therefore causing Camel to not start.

J

JAVA_TYPE - Static variable in interface org.apache.camel.component.extension.MetaDataExtension.MetaData
 
JAVA_TYPE_PREFIX - Static variable in class org.apache.camel.spi.DataType
 
JDK_SERVICE - Static variable in annotation type org.apache.camel.spi.annotations.ServiceFactory
 
JdkService - Annotation Type in org.apache.camel.spi.annotations
 
JSonSchemaResolver - Interface in org.apache.camel.catalog
Pluggable resolver to load JSON schema files for components, data formats, languages etc.
JsseParameters - Class in org.apache.camel.support.jsse
Base class that provides optional integration with core Camel capabilities.
JsseParameters() - Constructor for class org.apache.camel.support.jsse.JsseParameters
 

K

KeyManagersParameters - Class in org.apache.camel.support.jsse
A representation of configuration options for creating and loading KeyManager instance(s).
KeyManagersParameters() - Constructor for class org.apache.camel.support.jsse.KeyManagersParameters
 
keyPassword - Variable in class org.apache.camel.support.jsse.KeyManagersParameters
The optional password for recovering keys in the key store.
keyStore - Variable in class org.apache.camel.support.jsse.KeyManagersParameters
The key store configuration used to create the KeyStoreParameters that the KeyManagers produced by this object's configuration expose.
keyStore - Variable in class org.apache.camel.support.jsse.TrustManagersParameters
The key store configuration used to create the KeyStoreParameters that the TrustManagers produced by this object's configuration expose.
KeyStoreParameters - Class in org.apache.camel.support.jsse
A representation of configuration options for creating and loading a KeyStore instance.
KeyStoreParameters() - Constructor for class org.apache.camel.support.jsse.KeyStoreParameters
 

L

Language - Annotation Type in org.apache.camel.spi.annotations
 
Language - Interface in org.apache.camel.spi
Represents a language to be used for Expression or Predicate instances
LANGUAGE_SCRIPT - Static variable in interface org.apache.camel.Exchange
 
LanguageCustomizer - Interface in org.apache.camel.spi
To apply custom configurations to Language instances.
LanguageCustomizer.Builder<T extends Language> - Class in org.apache.camel.spi
A fluent builder to create a LanguageCustomizer instance.
LanguageCustomizer.Policy - Interface in org.apache.camel.spi
Used as additional filer mechanism to control if customizers need to be applied or not.
LanguageResolver - Interface in org.apache.camel.spi
A pluggable strategy for resolving different languages in a loosely coupled manner
LanguageValidationResult - Class in org.apache.camel.catalog
Validation result of parsing a language expression or predicate
LanguageValidationResult(String) - Constructor for class org.apache.camel.catalog.LanguageValidationResult
 
leadershipChanged(CamelClusterView, Optional<CamelClusterMember>) - Method in interface org.apache.camel.cluster.CamelClusterEventListener.Leadership
Notify a change in the leadership for a particular cluster.
length() - Method in interface org.apache.camel.StreamCache
Gets the length of the cached stream.
LifecycleStrategy - Interface in org.apache.camel.spi
Strategy for lifecycle notifications.
listAllRestServices() - Method in interface org.apache.camel.spi.RestRegistry
List all REST services from this registry.
load(TypeConverterRegistry) - Method in interface org.apache.camel.spi.TypeConverterLoader
A pluggable strategy to load type converters into a registry from some kind of mechanism
LoadablePropertiesSource - Interface in org.apache.camel.spi
A source for properties that can be loaded all at once during initialization, such as loading .properties files.
loadAllResourcesAsURL(String) - Method in interface org.apache.camel.spi.ClassResolver
Loads the given resources as a URL from all bundles/classloaders
loadProperties() - Method in interface org.apache.camel.spi.LoadablePropertiesSource
Loads the properties from the source
loadProperties(Predicate<String>) - Method in interface org.apache.camel.spi.LoadablePropertiesSource
Loads the properties from the source filtering them out according to a predicate.
loadProperties() - Method in interface org.apache.camel.spi.PropertiesComponent
Loads the properties from the default locations and sources.
loadProperties(Predicate<String>) - Method in interface org.apache.camel.spi.PropertiesComponent
Loads the properties from the default locations and sources filtering them out according to a predicate.
loadPropertiesAsMap() - Method in interface org.apache.camel.spi.PropertiesComponent
Loads the properties from the default locations and sources.
loadPropertiesAsMap(Predicate<String>) - Method in interface org.apache.camel.spi.PropertiesComponent
Loads the properties from the default locations and sources filtering them out according to a predicate.
LoadPropertiesException - Exception in org.apache.camel
Represents a failure to open a Properties file at a given URL
LoadPropertiesException(URL, Exception) - Constructor for exception org.apache.camel.LoadPropertiesException
 
loadResourceAsStream(String) - Method in interface org.apache.camel.spi.ClassResolver
Loads the given resource as a stream
loadResourceAsURL(String) - Method in interface org.apache.camel.spi.ClassResolver
Loads the given resource as a URL
loadResourcesAsURL(String) - Method in interface org.apache.camel.spi.ClassResolver
Loads the given resources as a URL from the current bundle/classloader
loadRestsDefinition(CamelContext, InputStream) - Method in interface org.apache.camel.spi.XMLRoutesDefinitionLoader
Loads from XML into rests.
loadRoutesDefinition(CamelContext, InputStream) - Method in interface org.apache.camel.spi.XMLRoutesDefinitionLoader
Loads from XML into routes.
loadRouteTemplatesDefinition(CamelContext, InputStream) - Method in interface org.apache.camel.spi.XMLRoutesDefinitionLoader
Loads from XML into route templates.
lock - Variable in class org.apache.camel.support.service.BaseService
 
log(String, LoggingLevel) - Method in class org.apache.camel.spi.CamelLogger
 
log(String) - Method in class org.apache.camel.spi.CamelLogger
Logs the message with checking the CamelLogger.shouldLog() method first.
log(String, Throwable, LoggingLevel) - Method in class org.apache.camel.spi.CamelLogger
 
log(String, Throwable) - Method in class org.apache.camel.spi.CamelLogger
 
log(Logger, LoggingLevel, String) - Static method in class org.apache.camel.spi.CamelLogger
 
log(Logger, LoggingLevel, Marker, String) - Static method in class org.apache.camel.spi.CamelLogger
 
log(Logger, LoggingLevel, String, Throwable) - Static method in class org.apache.camel.spi.CamelLogger
 
log(Logger, LoggingLevel, Marker, String, Throwable) - Static method in class org.apache.camel.spi.CamelLogger
 
LOG_DEBUG_BODY_MAX_CHARS - Static variable in interface org.apache.camel.Exchange
 
LOG_DEBUG_BODY_STREAMS - Static variable in interface org.apache.camel.Exchange
 
LOG_EIP_NAME - Static variable in interface org.apache.camel.Exchange
 
LoggingLevel - Enum in org.apache.camel
Used to configure the logging levels
LogListener - Interface in org.apache.camel.spi
An event listener SPI for logging.
lookup(String) - Static method in class org.apache.camel.ExchangeConstantProvider
 
lookup(Class<?>, Class<?>) - Method in interface org.apache.camel.spi.BulkTypeConverters
Performs a lookup for a given type converter.
lookup(Class<?>, Class<?>) - Method in interface org.apache.camel.spi.TypeConverterRegistry
Performs a lookup for a given type converter.
lookupByName(String) - Method in interface org.apache.camel.spi.BeanRepository
Looks up a bean in the registry based purely on name, returning the bean or null if it could not be found.
lookupByNameAndType(String, Class<T>) - Method in interface org.apache.camel.spi.BeanRepository
Looks up a bean in the registry, returning the bean or null if it could not be found.
LOOP_INDEX - Static variable in interface org.apache.camel.Exchange
 
LOOP_SIZE - Static variable in interface org.apache.camel.Exchange
 
LOWEST - Static variable in interface org.apache.camel.Ordered
The lowest precedence

M

ManagementAgent - Interface in org.apache.camel.spi
Camel JMX service agent
ManagementInterceptStrategy - Interface in org.apache.camel.spi
 
ManagementInterceptStrategy.InstrumentationProcessor<T> - Interface in org.apache.camel.spi
 
ManagementMBeanAssembler - Interface in org.apache.camel.spi
An assembler to assemble a RequiredModelMBean which can be used to register the object in JMX.
ManagementNameStrategy - Interface in org.apache.camel.spi
Strategy for assigning the name part of the ObjectName for a managed CamelContext.
ManagementObjectNameStrategy - Interface in org.apache.camel.spi
Strategy for computing ObjectName names for the various beans that Camel register for management.
ManagementObjectStrategy - Interface in org.apache.camel.spi
Strategy for creating the managed object for the various beans Camel register for management.
ManagementStatisticsLevel - Enum in org.apache.camel
Level of granularity for performance statistics enabled
ManagementStrategy - Interface in org.apache.camel.spi
Strategy for management.
ManagementStrategyFactory - Interface in org.apache.camel.spi
Service Factory for ManagementStrategy
manageObject(Object) - Method in interface org.apache.camel.spi.ManagementStrategy
Adds a managed object allowing the ManagementStrategy implementation to record or expose the object as it sees fit.
manageProcessor(NamedNode) - Method in interface org.apache.camel.spi.ManagementStrategy
Filter whether the processor should be managed or not.
mandatoryConvertTo(Class<?>, Class<T>, Exchange, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
Converts the value to the specified type in the context of an exchange

Used when conversion requires extra information from the current exchange (such as encoding).

mandatoryConvertTo(Class<T>, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
 
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
 
mandatoryConvertTo(Class<T>, Object) - Method in interface org.apache.camel.TypeConverter
Converts the value to the specified type
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in interface org.apache.camel.TypeConverter
Converts the value to the specified type in the context of an exchange

Used when conversion requires extra information from the current exchange (such as encoding).

marshal(Exchange, Object, OutputStream) - Method in interface org.apache.camel.spi.DataFormat
Marshals the object to the given Stream.
MaskingFormatter - Interface in org.apache.camel.spi
A plugin used to mask a log String, for example security information like password or passphrase.
matches(ServiceDefinition) - Method in interface org.apache.camel.cloud.ServiceDefinition
Check if a service definition matches.
matches(Exchange) - Method in interface org.apache.camel.Predicate
Evaluates the predicate on the message exchange and returns true if this exchange matches the predicate
matches(Class<?>) - Method in interface org.apache.camel.spi.PackageScanFilter
Does the given class match
matchesOneOf(String, List<Pattern>) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Returns true if and only if the value is matched by one or more of the supplied patterns.
matchesReturningFailureMessage(Exchange) - Method in interface org.apache.camel.BinaryPredicate
Evaluates the predicate on the message exchange and returns null if this exchange matches the predicate.
matchEvent(Exchange, CamelEvent.ExchangeEvent) - Method in interface org.apache.camel.spi.Condition
Does the condition match
matchProcess(Exchange, Processor, NamedNode) - Method in interface org.apache.camel.spi.Condition
Does the condition match
maxCapacity() - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
Maximum number of elements that we can have information about
MAXIMUM_CACHE_POOL_SIZE - Static variable in interface org.apache.camel.Exchange
 
MAXIMUM_ENDPOINT_CACHE_SIZE - Static variable in interface org.apache.camel.Exchange
 
MAXIMUM_SIMPLE_CACHE_SIZE - Static variable in interface org.apache.camel.Exchange
 
MAXIMUM_TRANSFORMER_CACHE_SIZE - Static variable in interface org.apache.camel.Exchange
 
MAXIMUM_VALIDATOR_CACHE_SIZE - Static variable in interface org.apache.camel.Exchange
 
MDC_BREADCRUMB_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
 
MDC_CAMEL_CONTEXT_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
 
MDC_CORRELATION_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
 
MDC_EXCHANGE_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
 
MDC_MESSAGE_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
 
MDC_ROUTE_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
 
MDC_STEP_ID - Static variable in interface org.apache.camel.spi.UnitOfWork
 
MDC_TRANSACTION_KEY - Static variable in interface org.apache.camel.spi.UnitOfWork
 
memberAdded(CamelClusterView, CamelClusterMember) - Method in interface org.apache.camel.cluster.CamelClusterEventListener.Membership
Notify a change (addition) in the cluster composition.
memberRemoved(CamelClusterView, CamelClusterMember) - Method in interface org.apache.camel.cluster.CamelClusterEventListener.Membership
Notify a change (removal) in the cluster composition.
message() - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
message(String) - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
Message - Interface in org.apache.camel
Implements the Message pattern and represents an inbound or outbound message as part of an Exchange.
MESSAGE_HISTORY - Static variable in interface org.apache.camel.Exchange
 
MESSAGE_HISTORY_HEADER_FORMAT - Static variable in interface org.apache.camel.Exchange
 
MESSAGE_HISTORY_OUTPUT_FORMAT - Static variable in interface org.apache.camel.Exchange
 
MessageHistory - Interface in org.apache.camel
Represents the history of a Camel Message how it was routed by the Camel routing engine.
MessageHistoryFactory - Interface in org.apache.camel.spi
A factory to create MessageHistory instances.
meta(Map<String, Object>) - Method in interface org.apache.camel.component.extension.MetaDataExtension
 
Metadata - Annotation Type in org.apache.camel.spi
Meta data for EIPs, components, data formats and other Camel concepts

For example to associate labels to Camel components

MetaDataExtension - Interface in org.apache.camel.component.extension
 
MetaDataExtension.MetaData - Interface in org.apache.camel.component.extension
 
method - Variable in class org.apache.camel.spi.BeanIntrospection.MethodInfo
 
MethodInfo() - Constructor for class org.apache.camel.spi.BeanIntrospection.MethodInfo
 
methods - Variable in class org.apache.camel.spi.BeanIntrospection.ClassInfo
 
MISS_VALUE - Static variable in interface org.apache.camel.TypeConverter
 
MISSING_PARAMETER - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
A mandatory parameter is missing
mock(String, boolean) - Method in interface org.apache.camel.spi.MockSendToEndpointStrategyFactory
Mock sending to endpoint
MockSendToEndpointStrategyFactory - Interface in org.apache.camel.spi
Factory for intercepting sending to endpoint pattern and sending to mock component.
ModelJAXBContextFactory - Interface in org.apache.camel.spi
Factory to abstract the creation of the Model's javax.xml.bind.JAXBContext.
ModelReifierFactory - Interface in org.apache.camel.spi
Factory that uses reifiers to build an entity from a given model.
ModelToXMLDumper - Interface in org.apache.camel.spi
SPI for dumping model definitions into XML representation.
MULTICAST_COMPLETE - Static variable in interface org.apache.camel.Exchange
 
MULTICAST_INDEX - Static variable in interface org.apache.camel.Exchange
 
MultipleConsumersSupport - Interface in org.apache.camel
Endpoint can optionally implement this interface to indicate whether or not it supports multiple consumers.

N

name() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.Attribute
Name of the attribute.
name() - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.Code
Name of the code.
NamedNode - Interface in org.apache.camel
Represents a node in the routes which is identified by an id.
NamedRoute - Interface in org.apache.camel
Represents a node in the routes which is identified as a route.
NamespaceAware - Interface in org.apache.camel.spi
Represents an object which is aware of the namespaces in which its used such as XPath and XQuery type expressions so that the current namespace context can be injected
Navigate<T> - Interface in org.apache.camel
Implementations support navigating a graph where you can traverse forward and each next returns a List of outputs of type T that can contain 0..n nodes.
navigate() - Method in interface org.apache.camel.Route
Returns a navigator to navigate this route by navigating all the Processors.
NEW - Static variable in class org.apache.camel.support.service.BaseService
 
newCachedThreadPool(Object, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Deprecated.
newCachedThreadPool(ThreadFactory) - Method in interface org.apache.camel.spi.ThreadPoolFactory
Deprecated.
newDefaultScheduledThreadPool(Object, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a new scheduled thread pool using the default thread pool profile.
newDefaultThreadPool(Object, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a new thread pool using the default thread pool profile.
newFixedThreadPool(Object, String, int) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a new fixed thread pool (the pool will not grow or shrink but has a fixed number of threads constantly).
newInstance(CamelContext) - Method in interface org.apache.camel.cloud.ServiceFactory
Creates an instance of a service.
newInstance() - Method in interface org.apache.camel.spi.DataFormatFactory
Creates a new DataFormat instance.
newInstance(String) - Method in interface org.apache.camel.spi.FactoryFinder
Creates a new class instance using the key to lookup
newInstance(String, Class<T>) - Method in interface org.apache.camel.spi.FactoryFinder
Creates a new class instance using the key to lookup
newInstance(Class<T>) - Method in interface org.apache.camel.spi.Injector
Instantiates a new instance of the given type; possibly injecting values into the object in the process (bean post processing)
newInstance(Class<T>, String) - Method in interface org.apache.camel.spi.Injector
Instantiates a new instance of the given type by using the factory method (this will not perform bean post processing)
newInstance(Class<T>, boolean) - Method in interface org.apache.camel.spi.Injector
Instantiates a new instance of the given type; possibly injecting values into the object in the process (bean post processing if enabled)
newJAXBContext() - Method in interface org.apache.camel.spi.ModelJAXBContextFactory
Creates a new javax.xml.bind.JAXBContext used for loading the Camel model
newMap() - Method in interface org.apache.camel.spi.HeadersMapFactory
Creates a new empty Map
newMap(Map<String, Object>) - Method in interface org.apache.camel.spi.HeadersMapFactory
Creates a new Map and copies over all the content from the existing map.
newMessageHistory(String, NamedNode, long, Exchange) - Method in interface org.apache.camel.spi.MessageHistoryFactory
Creates a new MessageHistory
newProxyClient(ObjectName, Class<T>) - Method in interface org.apache.camel.spi.ManagementAgent
Creates a new proxy client
newScheduledThreadPool(Object, String, int) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a new scheduled thread pool.
newScheduledThreadPool(Object, String, ThreadPoolProfile) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a new scheduled thread pool using a profile
newScheduledThreadPool(Object, String, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a new scheduled thread pool using a profile id
newScheduledThreadPool(ThreadPoolProfile, ThreadFactory) - Method in interface org.apache.camel.spi.ThreadPoolFactory
Create a scheduled thread pool using the given thread pool profile
newSingleThreadExecutor(Object, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a new single-threaded thread pool.
newSingleThreadScheduledExecutor(Object, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a new single-threaded thread pool.
newThread(String, Runnable) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a new daemon thread with the given name.
newThreadPool(Object, String, ThreadPoolProfile) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a new thread pool using the given profile
newThreadPool(Object, String, String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a new thread pool using using the given profile id
newThreadPool(Object, String, int, int) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a new thread pool.
newThreadPool(ThreadPoolProfile, ThreadFactory) - Method in interface org.apache.camel.spi.ThreadPoolFactory
Create a thread pool using the given thread pool profile
next() - Method in interface org.apache.camel.Navigate
Next group of outputs

Important only invoke this once, as this method do not carry state, and is not intended to be used in a while loop, but used by a if statement instead.

NodeIdFactory - Interface in org.apache.camel.spi
Factory to generate unique ids for model nodes.
nodeProcessingDone() - Method in interface org.apache.camel.MessageHistory
Used for signalling that processing of the node is done.
NoFactoryAvailableException - Exception in org.apache.camel
Thrown if no factory resource is available for the given URI
NoFactoryAvailableException(String) - Constructor for exception org.apache.camel.NoFactoryAvailableException
 
NoFactoryAvailableException(String, Throwable) - Constructor for exception org.apache.camel.NoFactoryAvailableException
 
none() - Static method in interface org.apache.camel.spi.ComponentCustomizer.Policy
A simple deny-all policy.
none() - Static method in interface org.apache.camel.spi.DataFormatCustomizer.Policy
A simple deny-all policy.
none() - Static method in interface org.apache.camel.spi.LanguageCustomizer.Policy
A simple deny-all policy.
NonManagedService - Interface in org.apache.camel
A marker to indicate the Service should not be registered in JMX for management.
NormalizedEndpointUri - Interface in org.apache.camel.spi
An Uri which has been normalized.
normalizeUri(String) - Method in interface org.apache.camel.ExtendedCamelContext
Normalizes the given uri.
NoSuchBeanException - Exception in org.apache.camel
A runtime exception if a given bean could not be found in the Registry
NoSuchBeanException(String) - Constructor for exception org.apache.camel.NoSuchBeanException
 
NoSuchBeanException(String, String) - Constructor for exception org.apache.camel.NoSuchBeanException
 
NoSuchBeanException(String, Throwable) - Constructor for exception org.apache.camel.NoSuchBeanException
 
NoSuchBeanException(String, String, Throwable) - Constructor for exception org.apache.camel.NoSuchBeanException
 
NoSuchEndpointException - Exception in org.apache.camel
A runtime exception thrown if a routing processor such as a recipient list is unable to resolve an Endpoint from a URI.
NoSuchEndpointException(String) - Constructor for exception org.apache.camel.NoSuchEndpointException
 
NoSuchEndpointException(String, String) - Constructor for exception org.apache.camel.NoSuchEndpointException
 
NoSuchHeaderException - Exception in org.apache.camel
An exception caused when a mandatory header is not available on a message Exchange
NoSuchHeaderException(Exchange, String, Class<?>) - Constructor for exception org.apache.camel.NoSuchHeaderException
 
NoSuchLanguageException - Exception in org.apache.camel
A runtime exception thrown if an attempt is made to resolve an unknown language definition.
NoSuchLanguageException(String) - Constructor for exception org.apache.camel.NoSuchLanguageException
 
NoSuchPropertyException - Exception in org.apache.camel
An exception caused when a mandatory property is not available on a message Exchange
NoSuchPropertyException(Exchange, String, Class<?>) - Constructor for exception org.apache.camel.NoSuchPropertyException
 
notify(CamelEvent) - Method in interface org.apache.camel.spi.EventNotifier
Notifies the given event
notify(CamelEvent) - Method in interface org.apache.camel.spi.ManagementStrategy
Management events provide a single model for capturing information about execution points in the application code.
NOTIFY_EVENT - Static variable in interface org.apache.camel.Exchange
Deprecated.
NotifyBuilderMatcher - Interface in org.apache.camel.spi
Allows to be used in combination with NotifyBuilder as external predicate implementations to compute if the exchange matches.
notifyBuilderMatches() - Method in interface org.apache.camel.spi.NotifyBuilderMatcher
Whether the predicate matches
notifyBuilderOnExchange(Exchange) - Method in interface org.apache.camel.spi.NotifyBuilderMatcher
When an exchange was received
notifyBuilderReset() - Method in interface org.apache.camel.spi.NotifyBuilderMatcher
Reset state
notifyContextCreated(CamelContext) - Static method in class org.apache.camel.spi.CamelContextTracker
 
notifyContextDestroyed(CamelContext) - Static method in class org.apache.camel.spi.CamelContextTracker
 
NoTypeConversionAvailableException - Exception in org.apache.camel
An exception thrown if a value could not be converted to the required type
NoTypeConversionAvailableException(Object, Class<?>) - Constructor for exception org.apache.camel.NoTypeConversionAvailableException
 
NoTypeConversionAvailableException(Object, Class<?>, Throwable) - Constructor for exception org.apache.camel.NoTypeConversionAvailableException
 

O

oldest(String) - Method in interface org.apache.camel.spi.InflightRepository
Gets the oldest InflightRepository.InflightExchange that are currently inflight that started from the given route.
on(HealthCheck) - Static method in class org.apache.camel.health.HealthCheckResultBuilder
 
ON_COMPLETION - Static variable in interface org.apache.camel.Exchange
 
onAfterRoute(Route, Exchange) - Method in interface org.apache.camel.spi.SynchronizationRouteAware
Invoked after the Exchange has been routed by the given route.
onBeforeRoute(Route, Exchange) - Method in interface org.apache.camel.spi.SynchronizationRouteAware
Invoked before the Exchange is being routed by the given route.
OnCamelContextEvent - Interface in org.apache.camel.spi
Marker interface used to make it easy to discover CamelContext related event handlers from the registry.
onCamelContextFullyStarted(CamelContext, boolean) - Method in interface org.apache.camel.StartupListener
Callback invoked when the CamelContext has been fully started.
OnCamelContextInitialized - Interface in org.apache.camel.spi
Notification on an initialized a CamelContext.
OnCamelContextInitializing - Interface in org.apache.camel.spi
Notification on initializing a CamelContext.
OnCamelContextStart - Interface in org.apache.camel.spi
Notification on starting a CamelContext.
OnCamelContextStarted - Interface in org.apache.camel.spi
Notification on a started CamelContext.
onCamelContextStarted(CamelContext, boolean) - Method in interface org.apache.camel.StartupListener
Callback invoked when the CamelContext is about to be fully started (not started yet).
OnCamelContextStarting - Interface in org.apache.camel.spi
Notification on starting a CamelContext.
onCamelContextStarting(CamelContext, boolean) - Method in interface org.apache.camel.StartupListener
Callback invoked when the CamelContext is being started.
OnCamelContextStop - Interface in org.apache.camel.spi
Notification on stopping a CamelContext.
OnCamelContextStopped - Interface in org.apache.camel.spi
Notification on a stopped CamelContext.
OnCamelContextStopping - Interface in org.apache.camel.spi
Notification on stopping a CamelContext.
onComplete(Exchange) - Method in interface org.apache.camel.spi.Synchronization
Called when the processing of the message exchange is complete
onCompletion(Exchange) - Method in interface org.apache.camel.AggregationStrategy
The aggregated Exchange has completed Important: This method must not throw any exceptions.
onComponentAdd(String, Component) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on adding an Component.
onComponentRemove(String, Component) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on removing an Component.
onContextInitialized(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on initialized CamelContext.
onContextInitialized(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextInitialized
 
onContextInitializing(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on initializing a CamelContext.
onContextInitializing(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextInitializing
 
onContextStart(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
onContextStart(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextStart
 
onContextStarted(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on started CamelContext.
onContextStarted(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextStarted
 
onContextStarting(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on starting a CamelContext.
onContextStarting(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextStarting
 
onContextStop(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
onContextStop(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextStop
 
onContextStopped(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on stopped CamelContext.
onContextStopped(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextStopped
 
onContextStopping(CamelContext) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on stopping a CamelContext.
onContextStopping(CamelContext) - Method in interface org.apache.camel.spi.OnCamelContextStopping
 
onDataFormatCreated(String, DataFormat) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on DataFormat being resolved from the Registry
onEndpointAdd(Endpoint) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on adding an Endpoint.
onEndpointRemove(Endpoint) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on removing an Endpoint.
onEvent(Exchange, CamelEvent.ExchangeEvent, NamedNode) - Method in interface org.apache.camel.spi.Breakpoint
Callback invoked when the breakpoint was hit and any of the Exchange events occurred.
onEvent(Exchange, CamelEvent.ExchangeEvent) - Method in interface org.apache.camel.spi.Debugger
Callback invoked when an Exchange is being processed which allows implementators to notify breakpoints.
onExchangeBegin(Route, Exchange) - Method in interface org.apache.camel.spi.RoutePolicy
Callback invoked when an Exchange is started being routed on the given Route
onExchangeDone(Route, Exchange) - Method in interface org.apache.camel.spi.RoutePolicy
Callback invoked when an Exchange is done being routed, where it started from the given Route

Notice this callback is invoked when the Exchange is done and the Route is the route where the Exchange was started.

onFailure(Exchange) - Method in interface org.apache.camel.spi.Synchronization
Called when the processing of the message exchange has failed for some reason.
onHit(String) - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
Callback when an endpoint is being utilizated by an Processor EIP such as sending a message to a dynamic endpoint.
onInit() - Method in interface org.apache.camel.PollingConsumerPollingStrategy
Callback invoked when the consumer is initialized such as when the PollingConsumer starts.
onInit(Route) - Method in interface org.apache.camel.spi.RoutePolicy
Callback invoked when the Route is being initialized
onInit(Consumer) - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
Initializes this ScheduledPollConsumerScheduler with the associated Consumer.
onLanguageCreated(String, Language) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on a Language instance being resolved.
onLog(Exchange, CamelLogger, String) - Method in interface org.apache.camel.spi.LogListener
Invoked right before Log component or Log EIP logs.
onOptimisticLockFailure(Exchange, Exchange) - Method in interface org.apache.camel.AggregationStrategy
onRemove(Route) - Method in interface org.apache.camel.spi.RoutePolicy
Callback invoked when the Route is being removed from CamelContext
onResume(Route) - Method in interface org.apache.camel.spi.RoutePolicy
Callback invoked when the Route is being resumed
onRouteContextCreate(Route) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on creating Route(s).
onRoutesAdd(Collection<Route>) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on adding Route(s).
onRoutesRemove(Collection<Route>) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on removing Route(s).
onServiceAdd(CamelContext, Service, Route) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on adding a Service.
onServiceRemove(CamelContext, Service, Route) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on removing a Service.
onStart(Route) - Method in interface org.apache.camel.spi.RoutePolicy
Callback invoked when the Route is being started
onStartingServices(List<Service>) - Method in interface org.apache.camel.Route
A strategy callback allowing special initialization when services are starting.
onStop(Route) - Method in interface org.apache.camel.spi.RoutePolicy
Callback invoked when the Route is being stopped
onSuspend(Route) - Method in interface org.apache.camel.spi.RoutePolicy
Callback invoked when the Route is being suspended
onThreadPoolAdd(CamelContext, ThreadPoolExecutor, String, String, String, String) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on adding a thread pool.
onThreadPoolRemove(CamelContext, ThreadPoolExecutor) - Method in interface org.apache.camel.spi.LifecycleStrategy
Notification on removing a thread pool.
onTimer() - Method in interface org.apache.camel.TimerListener
Notification invoked.
open() - Method in class org.apache.camel.spi.CamelContextTracker
Opens the tracker to start tracking when new CamelContext is created or destroyed.
OptimisticLockingAggregationRepository - Interface in org.apache.camel.spi
A specialized AggregationRepository which also supports optimistic locking.
OptimisticLockingAggregationRepository.OptimisticLockingException - Exception in org.apache.camel.spi
Exception used by an AggregationRepository to indicate that an optimistic update error has occurred and that the operation should be retried by the caller.
OptimisticLockingException() - Constructor for exception org.apache.camel.spi.OptimisticLockingAggregationRepository.OptimisticLockingException
 
Ordered - Interface in org.apache.camel
Interface to be implemented by objects that should be orderable, such as with a Collection.
org.apache.camel - package org.apache.camel
The core Camel API.
org.apache.camel.catalog - package org.apache.camel.catalog
Camel Catalog API
org.apache.camel.cloud - package org.apache.camel.cloud
Camel cloud
org.apache.camel.cluster - package org.apache.camel.cluster
Camel Cluster support
org.apache.camel.component.extension - package org.apache.camel.component.extension
Component extension
org.apache.camel.health - package org.apache.camel.health
Camel Health Check support
org.apache.camel.spi - package org.apache.camel.spi
Service Provider Interfaces used by the Camel runtime which are plugin strategies.
org.apache.camel.spi.annotations - package org.apache.camel.spi.annotations
 
org.apache.camel.support.jsse - package org.apache.camel.support.jsse
A collection of utility classes for configuring a JSSE SSLContext and other JSSE classes.
org.apache.camel.support.service - package org.apache.camel.support.service
 
OVERRULE_FILE_NAME - Static variable in interface org.apache.camel.Exchange
 

P

PackageScanClassResolver - Interface in org.apache.camel.spi
A resolver that can find classes based on package scanning.
PackageScanFilter - Interface in org.apache.camel.spi
Filter that can be used with the PackageScanClassResolver resolver.
PackageScanResourceResolver - Interface in org.apache.camel.spi
A resolver that can find resources based on package scanning.
parameters(String) - Method in interface org.apache.camel.spi.RouteTemplateParameterSource
The parameters for the given route
parent(String) - Method in class org.apache.camel.health.HealthCheckConfiguration.Builder
 
PARENT_PROPERTY - Static variable in interface org.apache.camel.Route
 
PARENT_UNIT_OF_WORK - Static variable in interface org.apache.camel.Exchange
 
parsePropertyValue(String) - Method in class org.apache.camel.support.jsse.JsseParameters
Parses the value using the Camel Property Placeholder capabilities if a context is provided.
parsePropertyValues(List<String>) - Method in class org.apache.camel.support.jsse.JsseParameters
Parses the values using the Camel Property Placeholder capabilities if a context is provided.
parseUri(String) - Method in interface org.apache.camel.spi.PropertiesComponent
Parses the input text and resolve all property placeholders from within the text.
password - Variable in class org.apache.camel.support.jsse.KeyStoreParameters
The optional password for reading/opening/verifying the key store.
Pattern - Annotation Type in org.apache.camel
Marks a method as having a specific kind of ExchangePattern for use with Bean Integration or Spring Remoting to overload the default value which is ExchangePattern.InOut for request/reply if no annotations are used.
Patterns(List<Pattern>, List<Pattern>) - Constructor for class org.apache.camel.support.jsse.FilterParameters.Patterns
 
Policy - Interface in org.apache.camel.spi
A strategy capable of applying interceptors to a processor.
PollingConsumer - Interface in org.apache.camel
Represents a Polling Consumer where the caller polls for messages when it is ready.
PollingConsumerPollingStrategy - Interface in org.apache.camel
Strategy that allows Consumers to influence the PollingConsumer.
PollingConsumerPollStrategy - Interface in org.apache.camel.spi
Strategy for a PollingConsumer when polling an Endpoint.
pop() - Method in interface org.apache.camel.spi.ClaimCheckRepository
Pops the repository and returns the latest.
popRoute() - Method in interface org.apache.camel.spi.UnitOfWork
When finished being routed under the current Route it should be removed.
postInitChannel() - Method in interface org.apache.camel.Channel
Post initializes the channel.
postProcessAfterInitialization(Object, String) - Method in interface org.apache.camel.spi.CamelBeanPostProcessor
Apply this post processor to the given new bean instance after any bean initialization callbacks (like afterPropertiesSet or a custom init-method).
postProcessBeforeInitialization(Object, String) - Method in interface org.apache.camel.spi.CamelBeanPostProcessor
Apply this post processor to the given new bean instance before any bean initialization callbacks (like afterPropertiesSet or a custom init-method).
preComplete(Exchange, Exchange) - Method in interface org.apache.camel.AggregationStrategy
Determines if the aggregation should complete the current group, and start a new group, or the aggregation should continue using the current group.
Predicate - Interface in org.apache.camel
Evaluates a binary predicate on the message exchange.
PREFIX_TOKEN - Static variable in interface org.apache.camel.spi.PropertiesComponent
The prefix token.
prepare(Exchange, String, String) - Method in interface org.apache.camel.spi.SendDynamicAware
Prepares for using optimised dynamic to by parsing the uri and returning an entry of details that are used for creating the pre and post processors, and the static uri.
prepareShutdown(boolean, boolean) - Method in interface org.apache.camel.spi.ShutdownPrepared
Prepares for stop/shutdown.
process(Exchange, AsyncCallback) - Method in interface org.apache.camel.AsyncProcessor
Processes the message exchange.
process(String, ServiceLoadBalancerFunction<T>) - Method in interface org.apache.camel.cloud.ServiceLoadBalancer
 
process(Exchange) - Method in interface org.apache.camel.Processor
Processes the message exchange
process(AsyncProcessor, Exchange) - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
Process the given exchange sychronously.
process(Exchange) - Method in interface org.apache.camel.spi.SharedInternalProcessor
 
process(Exchange, AsyncCallback, AsyncProcessor, Processor) - Method in interface org.apache.camel.spi.SharedInternalProcessor
Asynchronous API
process(Exchange, AsyncProcessor, Processor) - Method in interface org.apache.camel.spi.SharedInternalProcessor
Synchronous API
processAsync(Exchange) - Method in interface org.apache.camel.AsyncProcessor
 
processBatch(Queue<Object>) - Method in interface org.apache.camel.BatchConsumer
Processes the list of Exchange objects in a batch.
Processor - Interface in org.apache.camel
A processor is used to implement the Event Driven Consumer and Message Translator patterns and to process message exchanges.
ProcessorFactory - Interface in org.apache.camel.spi
A factory to create Processor based on the definition.
Produce - Annotation Type in org.apache.camel
Marks a field or property as being a producer to an Endpoint either via its URI or via the name of the endpoint reference which is then resolved in a registry such as the Spring Application Context.
Producer - Interface in org.apache.camel
Provides a channel on which clients can create and invoke message exchanges on an Endpoint
ProducerCache - Interface in org.apache.camel.spi
Cache containing created Producer.
ProducerCache.AsyncProducerCallback - Interface in org.apache.camel.spi
Callback for sending a exchange message to a endpoint using an AsyncProcessor capable producer.
ProducerTemplate - Interface in org.apache.camel
Template for working with Camel and sending Message instances in an Exchange to an Endpoint.
PropertiesComponent - Interface in org.apache.camel.spi
Component for property placeholders and loading properties from sources (such as .properties file from classpath or file system)
PropertiesFunction - Interface in org.apache.camel.spi
A function that is applied instead of looking up a property placeholder.
PropertiesSource - Interface in org.apache.camel.spi
A source for properties.
PropertyBindingException - Exception in org.apache.camel
Error binding property to a bean.
PropertyBindingException(Object, String, Object) - Constructor for exception org.apache.camel.PropertyBindingException
 
PropertyBindingException(Object, String, Object, Throwable) - Constructor for exception org.apache.camel.PropertyBindingException
 
PropertyBindingException(Object, Throwable) - Constructor for exception org.apache.camel.PropertyBindingException
 
PropertyBindingException(Object, String, Object, String, String, Throwable) - Constructor for exception org.apache.camel.PropertyBindingException
 
PropertyConfigurer - Interface in org.apache.camel.spi
A marker interface to identify the object as being configurable via a configurer class.
PropertyConfigurerAware - Interface in org.apache.camel.spi
An interface to represent an object which is capable of configuring via PropertyConfigurer.
PropertyConfigurerGetter - Interface in org.apache.camel.spi
A marker interface to identify the object as being a configurer which can provide details about the options the configurer supports.
PropertyInject - Annotation Type in org.apache.camel
Used to indicate an injection point of a property placeholder into a POJO.
propertyNames() - Method in interface org.apache.camel.spi.EndpointUriFactory
Returns all the names this endpoint supports.
provider - Variable in class org.apache.camel.support.jsse.KeyManagersParameters
The optional provider identifier for the KeyManagerFactory used to create the KeyManagers represented by this object's configuration.
provider - Variable in class org.apache.camel.support.jsse.KeyStoreParameters
The optional provider identifier for instantiating the key store.
provider - Variable in class org.apache.camel.support.jsse.SecureRandomParameters
The optional provider identifier for the SecureRandom factory method used to create the SecureRandom represented by this object's configuration.
provider - Variable in class org.apache.camel.support.jsse.TrustManagersParameters
The optional provider identifier for the TrustManagerFactory used to create the TrustManagers represented by this object's configuration.
ProxyInstantiationException - Exception in org.apache.camel
Exception indicating a failure while trying to create a proxy of a given type and on a given endpoint
ProxyInstantiationException(Class<?>, Endpoint, Throwable) - Constructor for exception org.apache.camel.ProxyInstantiationException
 
purge() - Method in interface org.apache.camel.spi.ConsumerCache
Purges this cache
purge() - Method in interface org.apache.camel.spi.EndpointRegistry
Purges the cache (removes endpoints from the dynamic cache)
purge() - Method in interface org.apache.camel.spi.ProducerCache
Purges this cache
purge() - Method in interface org.apache.camel.spi.TransformerRegistry
Purges the cache (removes transformers from the dynamic cache)
purge() - Method in interface org.apache.camel.spi.ValidatorRegistry
Purges the cache (removes validators from the dynamic cache)
push(Exchange) - Method in interface org.apache.camel.spi.ClaimCheckRepository
Pushes the exchange on top of the repository.
pushRoute(Route) - Method in interface org.apache.camel.spi.UnitOfWork
Pushes the Route that this UnitOfWork currently is being routed through.
put(K, V, long) - Method in interface org.apache.camel.TimeoutMap
Adds the key value pair into the map such that some time after the given timeout the entry will be evicted
putIfAbsent(K, V, long) - Method in interface org.apache.camel.TimeoutMap
Adds the key value pair into the map if the specified key is not already associated with a value such that some time after the given timeout the entry will be evicted.

Q

query(CamelContext, String, Map<String, Object>) - Static method in class org.apache.camel.health.HealthCheckHelper
Query the status of a check by id.

R

ReactiveExecutor - Interface in org.apache.camel.spi
SPI to plugin different reactive engines in the Camel routing engine.
reason(Exchange, String) - Static method in exception org.apache.camel.NoSuchHeaderException
 
reason(Exchange, String) - Static method in exception org.apache.camel.NoSuchPropertyException
 
receive(String) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response

Important: See ConsumerTemplate.doneUoW(Exchange)

receive(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response.
receive(String, long) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response or the timeout occurs

Important: See ConsumerTemplate.doneUoW(Exchange)

receive(Endpoint, long) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response or the timeout occurs

Important: See ConsumerTemplate.doneUoW(Exchange)

receive() - Method in interface org.apache.camel.PollingConsumer
Waits until a message is available and then returns it.
receive(long) - Method in interface org.apache.camel.PollingConsumer
Attempts to receive a message exchange, waiting up to the given timeout to expire if a message is not yet available.
receive(Endpoint) - Method in interface org.apache.camel.spi.ConsumerCache
Waits until a message is available and then returns it.
receive(Endpoint, long) - Method in interface org.apache.camel.spi.ConsumerCache
Attempts to receive a message exchange, waiting up to the given timeout to expire if a message is not yet available.
receiveBody(String) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response
receiveBody(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response
receiveBody(String, long) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response or the timeout occurs
receiveBody(Endpoint, long) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response or the timeout occurs
receiveBody(String, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response
receiveBody(Endpoint, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response
receiveBody(String, long, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response or the timeout occurs
receiveBody(Endpoint, long, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, waiting until there is a response or the timeout occurs
receiveBodyNoWait(String) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, not waiting for a response if non exists.
receiveBodyNoWait(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, not waiting for a response if non exists.
receiveBodyNoWait(String, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, not waiting for a response if non exists.
receiveBodyNoWait(Endpoint, Class<T>) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, not waiting for a response if non exists.
RECEIVED_TIMESTAMP - Static variable in interface org.apache.camel.Exchange
 
receiveNoWait(String) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, not waiting for a response if non exists.
receiveNoWait(Endpoint) - Method in interface org.apache.camel.ConsumerTemplate
Receives from the endpoint, not waiting for a response if non exists.
receiveNoWait() - Method in interface org.apache.camel.PollingConsumer
Attempts to receive a message exchange immediately without waiting and returning null if a message exchange is not available yet.
receiveNoWait(Endpoint) - Method in interface org.apache.camel.spi.ConsumerCache
Attempts to receive a message exchange immediately without waiting and returning null if a message exchange is not available yet.
RECIPIENT_LIST_ENDPOINT - Static variable in interface org.apache.camel.Exchange
 
RecipientList - Annotation Type in org.apache.camel
Indicates that this method is to be used as a Dynamic Recipient List routing the incoming message to one or more endpoints.
recover(CamelContext, String) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
Recovers the exchange with the given exchange id
RecoverableAggregationRepository - Interface in org.apache.camel.spi
A specialized AggregationRepository which also supports recovery.
REDELIVERED - Static variable in interface org.apache.camel.Exchange
 
REDELIVERY_COUNTER - Static variable in interface org.apache.camel.Exchange
 
REDELIVERY_DELAY - Static variable in interface org.apache.camel.Exchange
 
REDELIVERY_EXHAUSTED - Static variable in interface org.apache.camel.Exchange
Deprecated.
REDELIVERY_MAX_COUNTER - Static variable in interface org.apache.camel.Exchange
 
register(ServiceDefinition) - Method in interface org.apache.camel.cloud.ServiceRegistry
Register the service definition.
register(Object) - Method in interface org.apache.camel.health.HealthCheckRegistry
register(Object, ObjectName) - Method in interface org.apache.camel.spi.ManagementAgent
Registers object with management infrastructure with a specific name.
register(Object, ObjectName, boolean) - Method in interface org.apache.camel.spi.ManagementAgent
Registers object with management infrastructure with a specific name.
registerEndpoint(String, Endpoint) - Method in interface org.apache.camel.spi.EndpointStrategy
Register the endpoint.
registerEndpointCallback(EndpointStrategy) - Method in interface org.apache.camel.ExtendedCamelContext
Registers a callback to allow you to do custom logic when an Endpoint is about to be registered to the EndpointRegistry.
registerThreadPoolProfile(ThreadPoolProfile) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Registers the given thread pool profile
Registry - Interface in org.apache.camel.spi
Represents a BeanRepository which may also be capable of binding beans to its repository.
ReifierStrategy - Class in org.apache.camel.spi
Strategy for reifiers.
ReifierStrategy() - Constructor for class org.apache.camel.spi.ReifierStrategy
 
releasePollingConsumer(Endpoint, PollingConsumer) - Method in interface org.apache.camel.spi.ConsumerCache
Releases an acquired polling consumer back after usage.
releaseProducer(Endpoint, AsyncProducer) - Method in interface org.apache.camel.spi.ProducerCache
Releases an acquired producer back after usage.
releaseView(CamelClusterView) - Method in interface org.apache.camel.cluster.CamelClusterService
Release a view if it has no references.
remove(CamelContext, String, Exchange) - Method in interface org.apache.camel.spi.AggregationRepository
Removes the exchange with the given correlation key, which should happen when an Exchange is completed

Important: This method is not invoked if only one exchange was completed, and therefore the exchange does not need to be added to a repository, as its completed immediately.

remove(String) - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
To remove an endpoint from tracking information about its utilization
remove(String) - Method in interface org.apache.camel.spi.IdempotentRepository
Removes the key from the repository.
remove(Exchange, String) - Method in interface org.apache.camel.spi.IdempotentRepository
Removes the key from the repository.
remove(Exchange) - Method in interface org.apache.camel.spi.InflightRepository
Removes the exchange from the inflight registry to the total counter
remove(Exchange, String) - Method in interface org.apache.camel.spi.InflightRepository
Removes the exchange from the inflight registry removing association to the given route
remove(CamelContext, String, Exchange) - Method in interface org.apache.camel.spi.OptimisticLockingAggregationRepository
Removes the given Exchange when both the supplied key and Exchange are present in the repository.
remove(K) - Method in interface org.apache.camel.TimeoutMap
Removes the object with the given key
removeBreakpoint(Breakpoint) - Method in interface org.apache.camel.spi.Debugger
Removes the given breakpoint
removeComponent(String) - Method in interface org.apache.camel.CamelContext
Removes a previously added component.
removeEndpoint(Endpoint) - Method in interface org.apache.camel.CamelContext
Removes the endpoint from the EndpointRegistry.
removeEndpoints(String) - Method in interface org.apache.camel.CamelContext
Removes all endpoints with the given URI from the EndpointRegistry.
removeEventListener(CamelClusterEventListener) - Method in interface org.apache.camel.cluster.CamelClusterView
Remove the event listener.
removeEventNotifier(EventNotifier) - Method in interface org.apache.camel.spi.ManagementStrategy
Removes the event notifier
removeFilter(PackageScanFilter) - Method in interface org.apache.camel.spi.PackageScanClassResolver
Removes the filter
removeHeader(String) - Method in interface org.apache.camel.Message
Removes the named header from this message
removeHeaders(String) - Method in interface org.apache.camel.Message
Removes the headers from this message
removeHeaders(String, String...) - Method in interface org.apache.camel.Message
Removes the headers from this message that match the given pattern, except for the ones matching one or more excludePatterns
removeProperties(String) - Method in interface org.apache.camel.Exchange
Remove all of the properties associated with the exchange matching a specific pattern
removeProperties(String, String...) - Method in interface org.apache.camel.Exchange
Removes the properties from this exchange that match the given pattern, except for the ones matching one ore more excludePatterns
removeProperty(String) - Method in interface org.apache.camel.Exchange
Removes the given property on the exchange
removeRestService(Consumer) - Method in interface org.apache.camel.spi.RestRegistry
Removes the REST service from the registry
removeRoute(String) - Method in interface org.apache.camel.CamelContext
Removes the given route (the route must be stopped before it can be removed).
removeRoute(Route) - Method in interface org.apache.camel.ExtendedCamelContext
Internal API for removing routes.
removeRoute(String) - Method in interface org.apache.camel.spi.InflightRepository
Removes the route from the in flight registry.
removeService(Object) - Method in interface org.apache.camel.CamelContext
Removes a service from this CamelContext.
removeSynchronization(Synchronization) - Method in interface org.apache.camel.spi.UnitOfWork
Removes a synchronization hook
removeTypeConverter(Class<?>, Class<?>) - Method in interface org.apache.camel.spi.TypeConverterRegistry
Removes the type converter
request() - Method in interface org.apache.camel.FluentProducerTemplate
Send to an endpoint (InOut) returning any result output body.
request(Class<T>) - Method in interface org.apache.camel.FluentProducerTemplate
Send to an endpoint (InOut).
request(Endpoint, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied processor Uses an ExchangePattern.InOut message exchange pattern.
request(String, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied processor Uses an ExchangePattern.InOut message exchange pattern.
requestBody(Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint and returns the result content Uses an ExchangePattern.InOut message exchange pattern.
requestBody(Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint and returns the result content Uses an ExchangePattern.InOut message exchange pattern.
requestBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body.
requestBody(Endpoint, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body.
requestBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body.
requestBody(String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body.
requestBodyAndHeader(Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint and returns the result content Uses an ExchangePattern.InOut message exchange pattern.
requestBodyAndHeader(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body.
requestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body.
requestBodyAndHeader(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body.
requestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body.
requestBodyAndHeaders(String, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values.
requestBodyAndHeaders(String, Object, Map<String, Object>, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values.
requestBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values.
requestBodyAndHeaders(Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint and returns the result content Uses an ExchangePattern.InOut message exchange pattern.
requestBodyAndHeaders(Endpoint, Object, Map<String, Object>, Class<T>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values.
reset() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
Reset the counters
reset() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
Reset the statistic counters
reset() - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
Reset the counters
reset() - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
Reset the counters
reset() - Method in interface org.apache.camel.StreamCache
Resets the StreamCache for a new stream consumption.
resetCounters() - Method in interface org.apache.camel.spi.BeanIntrospection
Reset the statistics counters.
resetTraceCounter() - Method in interface org.apache.camel.spi.Tracer
Reset trace counter
resolve(CamelContext) - Method in interface org.apache.camel.EndpointConsumerResolver
Resolves this object as an endpoint.
resolve(CamelContext, Class<T>) - Method in interface org.apache.camel.EndpointConsumerResolver
Resolves this object as an endpoint.
resolve(CamelContext) - Method in interface org.apache.camel.EndpointProducerResolver
Resolves this object as an endpoint.
resolve(CamelContext, Class<T>) - Method in interface org.apache.camel.EndpointProducerResolver
Resolves this object as an endpoint.
resolveBootstrapFactoryFinder(ClassResolver) - Method in interface org.apache.camel.spi.FactoryFinderResolver
Creates a new bootstrap factory finder using a default resource path.
resolveBootstrapFactoryFinder(ClassResolver, String) - Method in interface org.apache.camel.spi.FactoryFinderResolver
Creates a new factory finder.
resolveById(String) - Method in interface org.apache.camel.health.HealthCheckRegistry
resolveClass(String) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveClass(String, Class<T>) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveClass(String, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveClass(String, Class<T>, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveComponent(String, CamelContext) - Method in interface org.apache.camel.spi.ComponentResolver
Attempts to resolve the component for the given URI
resolveDataFormat(String) - Method in interface org.apache.camel.CamelContext
Resolve an existing data format, or creates a new by the given its name
resolveDefaultFactoryFinder(ClassResolver) - Method in interface org.apache.camel.spi.FactoryFinderResolver
Creates a new default factory finder using a default resource path.
ResolveEndpointFailedException - Exception in org.apache.camel
A runtime exception thrown if an Endpoint cannot be resolved via URI
ResolveEndpointFailedException(String, Throwable) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
 
ResolveEndpointFailedException(String, String) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
 
ResolveEndpointFailedException(String) - Constructor for exception org.apache.camel.ResolveEndpointFailedException
 
resolveFactory(String, CamelContext) - Method in interface org.apache.camel.spi.UriFactoryResolver
Resolves the given EndpointUriFactory.
resolveFactoryFinder(ClassResolver, String) - Method in interface org.apache.camel.spi.FactoryFinderResolver
Creates a new factory finder.
resolveLanguage(String) - Method in interface org.apache.camel.CamelContext
Resolves a language for creating expressions
resolveLanguage(String, CamelContext) - Method in interface org.apache.camel.spi.LanguageResolver
Resolves the given language.
resolveManagementName(String, String, boolean) - Method in interface org.apache.camel.spi.ManagementNameStrategy
Creates a new management name with the given pattern.
resolveMandatoryClass(String) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveMandatoryClass(String, Class<T>) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveMandatoryClass(String, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveMandatoryClass(String, Class<T>, ClassLoader) - Method in interface org.apache.camel.spi.ClassResolver
Resolves the given class by its name
resolveNames(CamelContext) - Method in interface org.apache.camel.spi.ComponentNameResolver
Discovers which components are available on the classpath.
resolveProperty(String) - Method in interface org.apache.camel.spi.PropertiesComponent
Looks up the property with the given key
resolvePropertyConfigurer(String, CamelContext) - Method in interface org.apache.camel.spi.ConfigurerResolver
Resolves the given configurer.
resolvePropertyPlaceholders(String) - Method in interface org.apache.camel.CamelContext
Parses the given text and resolve any property placeholders - using {{key}}.
resolveRawParameterValues() - Method in interface org.apache.camel.spi.SendDynamicAware
Whether to traverses the given parameters, and resolve any parameter values which uses the RAW token syntax: key=RAW(value).
resolveResource(String) - Method in class org.apache.camel.support.jsse.JsseParameters
Attempts to loads a resource using a number of different approaches.
resolveStaticUri(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in interface org.apache.camel.spi.SendDynamicAware
Resolves the static part of the uri that are used for creating a single Endpoint and Producer that will be reused for processing the optimised toD.
resolveThreadName(String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Creates a full thread name
resolveTransformer(String) - Method in interface org.apache.camel.CamelContext
Resolve a transformer given a scheme
resolveTransformer(DataType, DataType) - Method in interface org.apache.camel.CamelContext
Resolve a transformer given from/to data type.
resolveTransformer(K) - Method in interface org.apache.camel.spi.TransformerRegistry
Lookup a Transformer in the registry which supports the transformation for the data types represented by the key.
resolveValidator(DataType) - Method in interface org.apache.camel.CamelContext
Resolve a validator given from/to data type.
resolveValidator(K) - Method in interface org.apache.camel.spi.ValidatorRegistry
Lookup a Validator in the registry which supports the validation for the data type represented by the key.
resource - Variable in class org.apache.camel.support.jsse.KeyStoreParameters
The optional file path, class path resource, or URL of the resource used to load the key store.
RESOURCE_PATH - Static variable in interface org.apache.camel.spi.ConfigurerResolver
 
RESPONSE_FROM_FALLBACK - Static variable in interface org.apache.camel.spi.CircuitBreakerConstants
 
RESPONSE_REJECTED - Static variable in interface org.apache.camel.spi.CircuitBreakerConstants
 
RESPONSE_SHORT_CIRCUITED - Static variable in interface org.apache.camel.spi.CircuitBreakerConstants
 
RESPONSE_SUCCESSFUL_EXECUTION - Static variable in interface org.apache.camel.spi.CircuitBreakerConstants
 
RESPONSE_TIMED_OUT - Static variable in interface org.apache.camel.spi.CircuitBreakerConstants
 
REST_HTTP_QUERY - Static variable in interface org.apache.camel.Exchange
 
REST_HTTP_URI - Static variable in interface org.apache.camel.Exchange
 
REST_PROPERTY - Static variable in interface org.apache.camel.Route
 
RestApiConsumerFactory - Interface in org.apache.camel.spi
Allows SPI to plugin a RestApiConsumerFactory that creates the Camel Consumer responsible for handling incoming HTTP GET requests from clients that request to access the REST API documentation.
RestApiProcessorFactory - Interface in org.apache.camel.spi
Allows SPI to plugin a RestApiProcessorFactory that creates the Camel Processor responsible for servicing and generating the REST API documentation.
RestBindingJaxbDataFormatFactory - Interface in org.apache.camel.spi
SPI for setting up XML data format (JAXB) for rest-dsl.
RestConfiguration - Class in org.apache.camel.spi
Configuration use by RestConsumerFactory and RestApiConsumerFactory for Camel components to support the Camel rest DSL.
RestConfiguration() - Constructor for class org.apache.camel.spi.RestConfiguration
 
RestConfiguration.RestBindingMode - Enum in org.apache.camel.spi
 
RestConfiguration.RestHostNameResolver - Enum in org.apache.camel.spi
 
RestConsumerFactory - Interface in org.apache.camel.spi
Allows SPI to plugin a RestConsumerFactory that creates the Camel Consumer responsible for handling incoming HTTP requests from clients that request to access REST services which has been created using the rest-dsl.
RestProducerFactory - Interface in org.apache.camel.spi
Allows SPI to plugin a RestProducerFactory that creates the Camel Producer responsible for performing HTTP requests to call a remote REST service.
RestRegistry - Interface in org.apache.camel.spi
A registry of all REST services running within the CamelContext which have been defined and created using the Rest DSL.
RestRegistry.RestService - Interface in org.apache.camel.spi
Details about the REST service
RestRegistryFactory - Interface in org.apache.camel.spi
A factory for RestRegistry.
resume() - Method in interface org.apache.camel.CamelContextLifecycle
Resumes the CamelContext.
resume() - Method in class org.apache.camel.support.service.BaseService
Important: You should override the lifecycle methods that start with do, eg BaseService.doStart(), BaseService.doStop(), etc.
resume() - Method in interface org.apache.camel.SuspendableService
Resumes the service.
resumeRoute(String) - Method in interface org.apache.camel.spi.RouteController
Resumes the given route if it has been previously suspended

If the route does not support suspension the route will be started instead

resumeService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
Resumes the given service.
resumeServices(Collection<?>) - Static method in class org.apache.camel.support.service.ServiceHelper
Resumes each element of the given services if services itself is not null, otherwise this method would return immediately.
retrieveGlobalSslContextParameters() - Method in interface org.apache.camel.SSLContextParametersAware
Returns the global SSLContextParameters if enabled on the implementing object, null otherwise.
REUSE_SCRIPT_ENGINE - Static variable in interface org.apache.camel.Exchange
 
rollback(Consumer, Endpoint, int, Exception) - Method in interface org.apache.camel.spi.PollingConsumerPollStrategy
Called when poll failed
ROLLBACK_ONLY - Static variable in interface org.apache.camel.Exchange
Deprecated.
ROLLBACK_ONLY_LAST - Static variable in interface org.apache.camel.Exchange
Deprecated.
RollbackExchangeException - Exception in org.apache.camel
Exception used for forcing an Exchange to be rolled back.
RollbackExchangeException(Exchange) - Constructor for exception org.apache.camel.RollbackExchangeException
 
RollbackExchangeException(Exchange, Throwable) - Constructor for exception org.apache.camel.RollbackExchangeException
 
RollbackExchangeException(String, Exchange) - Constructor for exception org.apache.camel.RollbackExchangeException
 
RollbackExchangeException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.RollbackExchangeException
 
Route - Interface in org.apache.camel
A Route defines the processing used on an inbound message exchange from a specific Endpoint within a CamelContext.
ROUTE_STOP - Static variable in interface org.apache.camel.Exchange
Deprecated.
RouteAware - Interface in org.apache.camel
An interface to represent an object which wishes to be injected with a Route such as Consumer which is the consumer for a route.
RouteController - Interface in org.apache.camel.spi
Controller for managing the lifecycle of all the Route's.
RouteError - Interface in org.apache.camel.spi
 
RouteError.Phase - Enum in org.apache.camel.spi
 
RouteFactory - Interface in org.apache.camel.spi
A factory to create Route
RouteIdAware - Interface in org.apache.camel.spi
To allow objects to be injected with the route id

This allows access to the route id of the processor at runtime, to know which route its associated with.

routeIds() - Method in interface org.apache.camel.spi.RouteTemplateParameterSource
Gets the route ids as a set.
RoutePolicy - Interface in org.apache.camel.spi
Policy for a Route which allows controlling the route at runtime.
RoutePolicyFactory - Interface in org.apache.camel.spi
A factory to create RoutePolicy and assign to routes automatic.
RoutesBuilder - Interface in org.apache.camel
A routes builder is capable of building routes using the builder and model classes.
RouteStartupOrder - Interface in org.apache.camel.spi
Information about a route to be started where we want to control the order in which they are started by CamelContext.
RouteTemplateParameterSource - Interface in org.apache.camel.spi
Source for parameters used when creating routes from route templates.
RoutingSlip - Annotation Type in org.apache.camel
Indicates that this method is to be used as a Routing Slip routing the incoming message through a series of processing steps.
run() - Method in interface org.apache.camel.AsyncCallback
Optimized for the reactive executor engine to be able to schedule this callback in its engine.
RuntimeCamelCatalog - Interface in org.apache.camel.catalog
Runtime catalog which limited API needed by components that supports ComponentVerifierExtension or SendDynamicAware.
RuntimeCamelException - Exception in org.apache.camel
Base class for all Camel unchecked exceptions.
RuntimeCamelException() - Constructor for exception org.apache.camel.RuntimeCamelException
 
RuntimeCamelException(String) - Constructor for exception org.apache.camel.RuntimeCamelException
 
RuntimeCamelException(String, Throwable) - Constructor for exception org.apache.camel.RuntimeCamelException
 
RuntimeCamelException(Throwable) - Constructor for exception org.apache.camel.RuntimeCamelException
 
RuntimeConfiguration - Interface in org.apache.camel
Various runtime configuration options used by CamelContext and Route for cross cutting functions such as tracing, delayer, stream cache and the like.
RuntimeEndpointRegistry - Interface in org.apache.camel.spi
A registry which listen for runtime usage of Endpoint during routing in Camel.
RuntimeEndpointRegistry.Statistic - Interface in org.apache.camel.spi
Statistics gathered about the endpoint.
RuntimeExchangeException - Exception in org.apache.camel
A runtime exception caused by a specific message Exchange
RuntimeExchangeException(String, Exchange) - Constructor for exception org.apache.camel.RuntimeExchangeException
 
RuntimeExchangeException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.RuntimeExchangeException
 
RuntimeExpressionException - Exception in org.apache.camel
Thrown if an expression evaluation fails
RuntimeExpressionException(String) - Constructor for exception org.apache.camel.RuntimeExpressionException
 
RuntimeExpressionException(String, Throwable) - Constructor for exception org.apache.camel.RuntimeExpressionException
 
RuntimeExpressionException(Throwable) - Constructor for exception org.apache.camel.RuntimeExpressionException
 
RuntimeTransformException - Exception in org.apache.camel
Thrown if a message transformation fails
RuntimeTransformException(String) - Constructor for exception org.apache.camel.RuntimeTransformException
 
RuntimeTransformException(String, Throwable) - Constructor for exception org.apache.camel.RuntimeTransformException
 
RuntimeTransformException(Throwable) - Constructor for exception org.apache.camel.RuntimeTransformException
 

S

SAGA_LONG_RUNNING_ACTION - Static variable in interface org.apache.camel.Exchange
 
SAXPARSER_FACTORY - Static variable in interface org.apache.camel.Exchange
 
scan(CamelContext) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
Scans the repository for Exchanges to be recovered
scanTypeConverters() - Method in interface org.apache.camel.spi.AnnotationScanTypeConverters
Scan for Converter classes and add those as type converters.
schedule(Runnable) - Method in interface org.apache.camel.spi.ReactiveExecutor
Schedules the task to be run (fairly)
ScheduledPollConsumerScheduler - Interface in org.apache.camel.spi
A pluggable scheduler for org.apache.camel.support.ScheduledPollConsumer consumers.
scheduleMain(Runnable) - Method in interface org.apache.camel.spi.ReactiveExecutor
Schedules the task to be prioritized and run asap
SCHEDULER_POLLED_MESSAGES - Static variable in interface org.apache.camel.Exchange
 
scheduleSync(Runnable) - Method in interface org.apache.camel.spi.ReactiveExecutor
Schedules the task to run synchronously (current thread)
scheduleTask(Runnable) - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
Schedules the task to run.
secretPropertyNames() - Method in interface org.apache.camel.spi.EndpointUriFactory
Returns the names of the secret properties this endpoin supports.
SecureRandomParameters - Class in org.apache.camel.support.jsse
 
SecureRandomParameters() - Constructor for class org.apache.camel.support.jsse.SecureRandomParameters
 
SecureSocketProtocolsParameters - Class in org.apache.camel.support.jsse
Represents a list of TLS/SSL cipher suite names.
SecureSocketProtocolsParameters() - Constructor for class org.apache.camel.support.jsse.SecureSocketProtocolsParameters
 
select(Collection<ServiceRegistry>) - Method in interface org.apache.camel.cloud.ServiceRegistry.Selector
Select a specific ServiceRegistry instance among a collection.
select(Collection<CamelClusterService>) - Method in interface org.apache.camel.cluster.CamelClusterService.Selector
Select a specific CamelClusterService instance among a collection.
send() - Method in interface org.apache.camel.FluentProducerTemplate
Send to an endpoint (InOnly)
send(Exchange) - Method in interface org.apache.camel.ProducerTemplate
Sends the exchange to the default endpoint

Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange using Exchange.getException().
send(Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to the default endpoint using a supplied processor

Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange using Exchange.getException().
send(String, Exchange) - Method in interface org.apache.camel.ProducerTemplate
Sends the exchange to the given endpoint

Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange using Exchange.getException().

send(String, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied processor

Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange using Exchange.getException().

send(String, ExchangePattern, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied processor

Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange using Exchange.getException().

send(Endpoint, Exchange) - Method in interface org.apache.camel.ProducerTemplate
Sends the exchange to the given endpoint

Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange using Exchange.getException().

send(Endpoint, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied processor

Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange using Exchange.getException().

send(Endpoint, ExchangePattern, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied processor

Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange using Exchange.getException().

send(Endpoint, ExchangePattern, Processor, Processor) - Method in interface org.apache.camel.ProducerTemplate
Sends an exchange to an endpoint using a supplied processor

Notice: that if the processing of the exchange failed with an Exception it is not thrown from this method, but you can access it from the returned exchange using Exchange.getException().

send(Endpoint, Exchange, Processor) - Method in interface org.apache.camel.spi.ProducerCache
Sends the exchange to the given endpoint.
sendBody(Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBody(Endpoint, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBody(String, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBody(Endpoint, ExchangePattern, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint with the given ExchangePattern returning any result output body

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBody(String, ExchangePattern, Object) - Method in interface org.apache.camel.ProducerTemplate
Send the body to an endpoint returning any result output body

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeader(Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint with a specified header and header value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeader(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified header and header value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeader(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified header and header value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeader(Endpoint, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified header and header value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeader(String, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified header and header value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeaders(Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint with the specified headers and header values

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeaders(String, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeaders(String, ExchangePattern, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndHeaders(Endpoint, ExchangePattern, Object, Map<String, Object>) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with the specified headers and header values

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndProperty(Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to the default endpoint with a specified property and property value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndProperty(String, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified property and property value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndProperty(Endpoint, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified property and property value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndProperty(Endpoint, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified property and property value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

sendBodyAndProperty(String, ExchangePattern, Object, String, Object) - Method in interface org.apache.camel.ProducerTemplate
Sends the body to an endpoint with a specified property and property value

Notice: that if the processing of the exchange failed with an Exception it is thrown from this method as a CamelExecutionException with the caused exception wrapped.

SendDynamic - Annotation Type in org.apache.camel.spi.annotations
 
SendDynamicAware - Interface in org.apache.camel.spi
Used for components that can optimise the usage of org.apache.camel.processor.SendDynamicProcessor (toD) to reuse a static Endpoint and Producer that supports using headers to provide the dynamic parts.
SendDynamicAware.DynamicAwareEntry - Class in org.apache.camel.spi
An entry of detailed information from the recipient uri, which allows the SendDynamicAware implementation to prepare pre- and post- processor and the static uri to be used for the optimised dynamic to.
Service - Interface in org.apache.camel
Represents the core lifecycle API for services which can be initialized, started and stopped
SERVICE_CALL_CONTEXT_PATH - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
 
SERVICE_CALL_SCHEME - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
 
SERVICE_CALL_URI - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
 
SERVICE_HOST - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
 
SERVICE_META - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
 
SERVICE_META_HOST - Static variable in interface org.apache.camel.cloud.ServiceDefinition
 
SERVICE_META_ID - Static variable in interface org.apache.camel.cloud.ServiceDefinition
 
SERVICE_META_NAME - Static variable in interface org.apache.camel.cloud.ServiceDefinition
 
SERVICE_META_PATH - Static variable in interface org.apache.camel.cloud.ServiceDefinition
 
SERVICE_META_PORT - Static variable in interface org.apache.camel.cloud.ServiceDefinition
 
SERVICE_META_PREFIX - Static variable in interface org.apache.camel.cloud.ServiceDefinition
 
SERVICE_META_PROTOCOL - Static variable in interface org.apache.camel.cloud.ServiceDefinition
 
SERVICE_META_ZONE - Static variable in interface org.apache.camel.cloud.ServiceDefinition
 
SERVICE_NAME - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
 
SERVICE_PORT - Static variable in interface org.apache.camel.cloud.ServiceCallConstants
 
ServiceCallConstants - Interface in org.apache.camel.cloud
 
ServiceChooser - Interface in org.apache.camel.cloud
Allows SPIs to implement custom Service Chooser.
ServiceChooserAware - Interface in org.apache.camel.cloud
An interface to represent an object which wishes to be injected with a ServiceChooser
ServiceChooserFactory - Interface in org.apache.camel.cloud
A factory to create ServiceChooser
ServiceDefinition - Interface in org.apache.camel.cloud
Represents a Service.
ServiceDiscovery - Interface in org.apache.camel.cloud
Allows SPIs to implement custom Service Discovery.
ServiceDiscoveryAware - Interface in org.apache.camel.cloud
An interface to represent an object which wishes to be injected with a ServiceDiscovery
ServiceDiscoveryFactory - Interface in org.apache.camel.cloud
A factory to create ServiceDiscovery
ServiceExpressionFactory - Interface in org.apache.camel.cloud
A factory to create Expression
ServiceFactory<T> - Interface in org.apache.camel.cloud
 
ServiceFactory - Annotation Type in org.apache.camel.spi.annotations
 
ServiceFilter - Interface in org.apache.camel.cloud
Allows SPIs to implement custom Service Filter.
ServiceFilterAware - Interface in org.apache.camel.cloud
An interface to represent an object which wishes to be injected with a ServiceFilter
ServiceFilterFactory - Interface in org.apache.camel.cloud
A factory to create ServiceFilter
ServiceHealth - Interface in org.apache.camel.cloud
 
ServiceHelper - Class in org.apache.camel.support.service
A collection of helper methods for working with Service objects.
ServiceLoadBalancer - Interface in org.apache.camel.cloud
Represents a Load Balancer.
ServiceLoadBalancerFactory - Interface in org.apache.camel.cloud
A factory to create LoadBalancer
ServiceLoadBalancerFunction<T> - Interface in org.apache.camel.cloud
Represents a load balancer function to be executed by the LoadBalancer.
ServiceRegistry - Interface in org.apache.camel.cloud
 
ServiceRegistry.Selector - Interface in org.apache.camel.cloud
A selector used to pick up a service among a list.
ServiceStatus - Enum in org.apache.camel
Represents the status of a Service instance
ServiceSupport - Class in org.apache.camel.support.service
A useful base class which ensures that a service is only initialized once and provides some helper methods for enquiring of its status.
ServiceSupport() - Constructor for class org.apache.camel.support.service.ServiceSupport
 
setAcceptableSchemes(String) - Method in interface org.apache.camel.spi.PackageScanClassResolver
To specify a set of accepted schemas to use for loading resources as URL connections (besides http and https schemas)
setAcceptableSchemes(String) - Method in interface org.apache.camel.spi.PackageScanResourceResolver
To specify a set of accepted schemas to use for loading resources as URL connections (besides http and https schemas)
setAccepted(boolean) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
 
setAfter(Processor) - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
Sets the processor (optional) for routing after sending to the original endpoint.
setAlgorithm(String) - Method in class org.apache.camel.support.jsse.KeyManagersParameters
Sets optional algorithm name for the KeyManagerFactory used to create the KeyManagers represented by this object's configuration.
setAlgorithm(String) - Method in class org.apache.camel.support.jsse.SecureRandomParameters
Sets the Random Number Generator (RNG) algorithm identifier for the SecureRandom factory method used to create the SecureRandom represented by this object's configuration.
setAlgorithm(String) - Method in class org.apache.camel.support.jsse.TrustManagersParameters
Sets optional algorithm name for the TrustManagerFactory used to create the TrustManagers represented by this object's configuration.
setAllowCoreThreadTimeOut(Boolean) - Method in class org.apache.camel.spi.ThreadPoolProfile
Sets whether to allow core threads to timeout
setAllowUseOriginalMessage(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Sets whether to allow access to the original message from Camel's error handler, or from UnitOfWork.getOriginalInMessage().
setAnnotationBasedProcessorFactory(AnnotationBasedProcessorFactory) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom AnnotationBasedProcessorFactory to use.
setAnySpoolRules(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy
Sets whether if just any of the StreamCachingStrategy.SpoolRule rules returns true then StreamCachingStrategy.shouldSpoolCache(long) returns true.
setApiComponent(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets the name of the Camel component to use as the REST API (such as swagger or openapi)
setApiContextIdPattern(String) - Method in class org.apache.camel.spi.RestConfiguration
Optional CamelContext id pattern to only allow Rest APIs from rest services within CamelContext's which name matches the pattern.
setApiContextListing(boolean) - Method in class org.apache.camel.spi.RestConfiguration
Sets whether listing of all available CamelContext's with REST services in the JVM is enabled.
setApiContextPath(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets a leading API context-path the REST API services will be using.
setApiContextRouteId(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets the route id to use for the route that services the REST API.
setApiHost(String) - Method in class org.apache.camel.spi.RestConfiguration
To use an specific hostname for the API documentation (eg swagger)

This can be used to override the generated host with this configured hostname

setApiProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
Sets additional options on api level
setApiVendorExtension(boolean) - Method in class org.apache.camel.spi.RestConfiguration
Whether vendor extension is enabled in the Rest APIs.
setApplicationContextClassLoader(ClassLoader) - Method in interface org.apache.camel.CamelContext
Sets the application CamelContext class loader
setAsyncProcessorAwaitManager(AsyncProcessorAwaitManager) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom AsyncProcessor await manager.
setAutoStartup(Boolean) - Method in interface org.apache.camel.Route
Sets whether the route should automatically start when Camel starts.
setAutoStartup(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Sets whether the object should automatically start when Camel starts.
setAutowiredEnabled(boolean) - Method in interface org.apache.camel.GlobalEndpointConfiguration
Whether autowiring is enabled.
setAutowiredEnabled(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Whether autowiring is enabled.
setBacklogTracing(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Sets whether backlog tracing is enabled or not (default is disabled).
setBackOffDelay(long) - Method in interface org.apache.camel.spi.SupervisingRouteController
Backoff delay in millis when restarting a route that failed to startup.
setBackOffMaxAttempts(long) - Method in interface org.apache.camel.spi.SupervisingRouteController
Backoff maximum number of attempts to restart a route that failed to startup.
setBackOffMaxDelay(long) - Method in interface org.apache.camel.spi.SupervisingRouteController
Backoff maximum delay in millis when restarting a route that failed to startup.
setBackOffMaxElapsedTime(long) - Method in interface org.apache.camel.spi.SupervisingRouteController
Backoff maximum elapsed time in millis, after which the backoff should be considered exhausted and no more attempts should be made.
setBackOffMultiplier(double) - Method in interface org.apache.camel.spi.SupervisingRouteController
Backoff multiplier to use for exponential backoff.
setBeanIntrospection(BeanIntrospection) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom BeanIntrospection.
setBefore(Processor) - Method in interface org.apache.camel.spi.InterceptSendToEndpoint
Sets the processor for routing in a detour before sending to the original endpoint.
setBindingMode(RestConfiguration.RestBindingMode) - Method in class org.apache.camel.spi.RestConfiguration
Sets the binding mode to be used by the REST consumer
setBindingMode(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets the binding mode to be used by the REST consumer
setBody(Object) - Method in interface org.apache.camel.Message
Sets the body of the message
setBody(Object, Class<T>) - Method in interface org.apache.camel.Message
Sets the body of the message as a specific type
setBody(Object, DataType) - Method in interface org.apache.camel.spi.DataTypeAware
Set the message body with data type.
setBootstrapConfigurerResolver(ConfigurerResolver) - Method in interface org.apache.camel.ExtendedCamelContext
sets the bootstrap ConfigurerResolver to use.
setBootstrapFactoryFinder(FactoryFinder) - Method in interface org.apache.camel.ExtendedCamelContext
Sets the bootstrap FactoryFinder which will be used for the loading the factory class from META-INF.
setBridgeErrorHandler(boolean) - Method in interface org.apache.camel.GlobalEndpointConfiguration
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.
setBufferSize(int) - Method in interface org.apache.camel.spi.StreamCachingStrategy
Sets the buffer size to use when allocating in-memory buffers used for in-memory stream caches.
setCamelContext(CamelContext) - Method in interface org.apache.camel.CamelContextAware
Injects the CamelContext
setCamelContext(CamelContext) - Method in interface org.apache.camel.Endpoint
Sets the camel context.
setCamelContext(CamelContext) - Method in class org.apache.camel.spi.Transformer
 
setCamelContext(CamelContext) - Method in class org.apache.camel.spi.Validator
 
setCamelContext(CamelContext) - Method in class org.apache.camel.support.jsse.JsseParameters
Sets the optional CamelContext used for integration with core capabilities such as Camel Property Placeholders and ClassResolver.
setCaseInsensitiveHeaders(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Whether to use case sensitive or insensitive headers.
setCertAlias(String) - Method in class org.apache.camel.support.jsse.SSLContextParameters
An optional certificate alias to use.
setCipherSuite(List<String>) - Method in class org.apache.camel.support.jsse.CipherSuitesParameters
Sets the cipher suite.
setCipherSuites(CipherSuitesParameters) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Sets the optional explicitly configured cipher suites for this configuration.
setCipherSuitesFilter(FilterParameters) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Sets the optional cipher suite filter for this JSSE configuration.
setClassLoader(ClassLoader) - Method in interface org.apache.camel.catalog.JSonSchemaResolver
Sets an extra class loader to use first for loading resources.
setClassResolver(ClassResolver) - Method in interface org.apache.camel.CamelContext
Sets the class resolver to be use
setClientAuthentication(String) - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
Sets the configuration options for server-side client-authentication requirements.
setClientParameters(SSLContextClientParameters) - Method in class org.apache.camel.support.jsse.SSLContextParameters
The optional configuration options to be applied purely to the client side settings of the SSLContext.
setClientRequestValidation(boolean) - Method in class org.apache.camel.spi.RestConfiguration
Whether to enable validation of the client request to check whether the Content-Type and Accept headers from the client is supported by the Rest-DSL configuration of its consumes/produces settings.
setComponent(Component) - Method in interface org.apache.camel.ComponentAware
Injects the Component
setComponent(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets the name of the Camel component to use as the REST consumer
setComponentNameResolver(ComponentNameResolver) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom ComponentNameResolver to use.
setComponentProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
Sets additional options on component level
setComponentResolver(ComponentResolver) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom ComponentResolver to use.
setConfigurations(Map<String, HealthCheckConfiguration>) - Method in interface org.apache.camel.health.HealthCheckRepository
Configurations for health checks based on their ids
setConfigurerResolver(ConfigurerResolver) - Method in interface org.apache.camel.ExtendedCamelContext
Sets the ConfigurerResolver to use.
setConsumerProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
Sets additional options on consumer level
setContentTypeHeader(boolean) - Method in interface org.apache.camel.spi.DataFormatContentTypeHeader
Whether the data format should set the Content-Type header with the type from the data format if the data format is capable of doing so.
setContextPath(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets a leading context-path the REST services will be using.
setCopyMessage(boolean) - Method in interface org.apache.camel.spi.MessageHistoryFactory
Sets whether to make a copy of the message in the MessageHistory.
setCorsHeaders(Map<String, String>) - Method in class org.apache.camel.spi.RestConfiguration
Sets the CORS headers to use if CORS has been enabled.
setCounter(Object) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy.InstrumentationProcessor
 
setDataFormatProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
Sets additional options on data format level
setDataFormatResolver(DataFormatResolver) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom data format resolver
setDataType(DataType) - Method in interface org.apache.camel.spi.DataTypeAware
Set the data type of the message.
setDeadLetterUri(String) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
Sets an optional dead letter channel which exhausted recovered Exchange should be send to.
setDebugger(Debugger) - Method in interface org.apache.camel.CamelContext
Sets a custom Debugger
setDebugging(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Sets whether debugging (will use backlog if no custom debugger has been configured) is enabled or not (default is disabled).
setDefaultEndpoint(Endpoint) - Method in interface org.apache.camel.FluentProducerTemplate
Sets the default endpoint to use if none is specified
setDefaultEndpoint(Endpoint) - Method in interface org.apache.camel.ProducerTemplate
Sets the default endpoint to use if none is specified
setDefaultEndpointUri(String) - Method in interface org.apache.camel.FluentProducerTemplate
Sets the default endpoint uri to use if none is specified
setDefaultEndpointUri(String) - Method in interface org.apache.camel.ProducerTemplate
Sets the default endpoint uri to use if none is specified
setDefaultProfile(Boolean) - Method in class org.apache.camel.spi.ThreadPoolProfile
Sets whether this profile is the default profile (there can only be one).
setDefaultThreadPoolProfile(ThreadPoolProfile) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Sets the default thread pool profile
setDeferServiceFactory(DeferServiceFactory) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom DeferServiceFactory to use.
setDelayer(Long) - Method in interface org.apache.camel.RuntimeConfiguration
Sets a delay value in millis that a message is delayed at every step it takes in the route path, slowing the process down to better observe what is occurring

Is disabled by default

setDisabled(boolean) - Method in interface org.apache.camel.cluster.CamelPreemptiveClusterView
Enable or disables a view.
setEnableCORS(boolean) - Method in class org.apache.camel.spi.RestConfiguration
To specify whether to enable CORS which means Camel will automatic include CORS in the HTTP headers in the response.
setEnabled(boolean) - Method in class org.apache.camel.health.HealthCheckConfiguration
Set if the check associated to this configuration is enabled or not.
setEnabled(boolean) - Method in interface org.apache.camel.health.HealthCheckRegistry
Whether Health Check is enabled globally
setEnabled(boolean) - Method in interface org.apache.camel.health.HealthCheckRepository
Set if the checks associated to this repository is enabled or not.
setEnabled(boolean) - Method in interface org.apache.camel.spi.CamelBeanPostProcessor
Can be used to turn off bean post processing.
setEnabled(boolean) - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
Sets whether gathering runtime usage is enabled or not.
setEnabled(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy
Sets whether the stream caching is enabled.
setEnabled(boolean) - Method in interface org.apache.camel.spi.Tracer
Whether the tracer is enabled
setEncoding(String) - Method in interface org.apache.camel.spi.PropertiesComponent
Encoding to use when loading properties file from the file system or classpath.
setEndpointProperties(Map<String, Object>) - Method in class org.apache.camel.spi.RestConfiguration
Sets additional options on endpoint level
setEndpointRuntimeStatisticsEnabled(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
Sets whether endpoint runtime statistics is enabled (gathers runtime usage of each incoming and outgoing endpoints).
setError(String) - Method in class org.apache.camel.catalog.LanguageValidationResult
 
setErrorHandler(Processor) - Method in interface org.apache.camel.Channel
Sets the ErrorHandler this Channel uses.
setErrorHandler(Processor) - Method in interface org.apache.camel.spi.ErrorHandlerAware
Sets the error handler
setErrorHandlerFactory(ErrorHandlerFactory) - Method in interface org.apache.camel.ExtendedCamelContext
Sets the default error handler builder which is inherited by the routes
setErrorHandlerFactory(ErrorHandlerFactory) - Method in interface org.apache.camel.Route
 
setErrorHandlerHandled(Boolean) - Method in interface org.apache.camel.ExtendedExchange
Used to signal that this exchange has been handled by the error handler.
setEventFactory(EventFactory) - Method in interface org.apache.camel.spi.ManagementStrategy
Sets the event factory to use
setEventNotificationApplicable(boolean) - Method in interface org.apache.camel.ExtendedCamelContext
Used as internal optimization in Camel to flag whether exchange event notification is applicable or not.
setEventNotifierEnabled(boolean) - Method in interface org.apache.camel.FluentProducerTemplate
Sets whether the EventNotifier should be used by this ProducerTemplate to send events about the Exchange being sent.
setEventNotifierEnabled(boolean) - Method in interface org.apache.camel.ProducerTemplate
Sets whether the EventNotifier should be used by this ProducerTemplate to send events about the Exchange being sent.
setEventNotifierEnabled(boolean) - Method in interface org.apache.camel.spi.ProducerCache
Sets whether EventNotifier is enabled
setException(Throwable) - Method in interface org.apache.camel.Exchange
Sets the exception associated with this exchange

Camel will wrap Throwable into Exception type to accommodate for the Exchange.getException() method returning a plain Exception type.

setExchangeFormatter(ExchangeFormatter) - Method in interface org.apache.camel.spi.Tracer
To use a custom exchange formatter for formatting the output of the Exchange in the trace logs.
setExchangeId(String) - Method in interface org.apache.camel.Exchange
Set the exchange id
setExcludeRoutes(String) - Method in interface org.apache.camel.spi.SupervisingRouteController
Pattern for filtering routes to be excluded as supervised.
setExecutorService(ExecutorService) - Method in interface org.apache.camel.ExecutorServiceAware
Sets the executor service to be used.
setExecutorService(ExecutorService) - Method in interface org.apache.camel.ProducerTemplate
Sets a custom executor service to use for async messaging.
setExecutorServiceManager(ExecutorServiceManager) - Method in interface org.apache.camel.CamelContext
setExecutorServiceRef(String) - Method in interface org.apache.camel.ExecutorServiceAware
Sets a reference to lookup in the Registry for the executor service to be used.
setExtendedStatistics(boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
Whether to gather extended statistics for introspection usage.
setExtension(Class<T>, T) - Method in interface org.apache.camel.CamelContext
Allows to install custom extensions to the Camel context.
setFactoryFinderResolver(FactoryFinderResolver) - Method in interface org.apache.camel.ExtendedCamelContext
Sets the factory finder resolver to use.
setFailureThreshold(int) - Method in class org.apache.camel.health.HealthCheckConfiguration
Set the number of failure before reporting the service as un-healthy.
setFileName(String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
 
setFrom(String) - Method in class org.apache.camel.spi.Transformer
Set 'from' data type.
setFromEndpoint(Endpoint) - Method in interface org.apache.camel.ExtendedExchange
Sets the endpoint which originated this message exchange.
setFromRouteId(String) - Method in interface org.apache.camel.ExtendedExchange
Sets the route id which originated this message exchange.
setGeneratedId(String) - Method in interface org.apache.camel.spi.IdAware
Sets the id which has been auto generated
setGlobalOptions(Map<String, String>) - Method in interface org.apache.camel.CamelContext
Sets global options that can be referenced in the camel context

Important: This has nothing to do with property placeholders, and is just a plain set of key/value pairs which are used to configure global options on CamelContext, such as a maximum debug logging length etc.

setGroup(String) - Method in interface org.apache.camel.spi.GroupAware
Sets the group
setHeader(String, Object) - Method in interface org.apache.camel.Message
Sets a header on the message
setHeaderFilterStrategy(HeaderFilterStrategy) - Method in interface org.apache.camel.spi.HeaderFilterStrategyAware
Sets the header filter strategy to use
setHeaders(Map<String, Object>) - Method in interface org.apache.camel.Message
Set all the headers associated with this message

Important: If you want to copy headers from another Message to this Message, then use getHeaders().putAll(other) to copy the headers, where other is the other headers.

setHeadersMapFactory(HeadersMapFactory) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom HeadersMapFactory to be used.
setHistoryNodeId(String) - Method in interface org.apache.camel.ExtendedExchange
Sets the history node id (the current processor that will process the exchange)
setHistoryNodeLabel(String) - Method in interface org.apache.camel.ExtendedExchange
Sets the history node label (the current processor that will process the exchange)
setHost(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets the hostname to use by the REST consumer
setHostNameResolver(RestConfiguration.RestHostNameResolver) - Method in class org.apache.camel.spi.RestConfiguration
Sets the resolver to use for resolving hostname
setHostNameResolver(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets the resolver to use for resolving hostname
setId(String) - Method in interface org.apache.camel.spi.IdAware
Sets the id
setId(String) - Method in class org.apache.camel.spi.ThreadPoolProfile
Sets the id of this profile
setIgnoreCamelContextEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
 
setIgnoreExchangeCompletedEvent(boolean) - Method in interface org.apache.camel.spi.EventNotifier
 
setIgnoreExchangeCreatedEvent(boolean) - Method in interface org.apache.camel.spi.EventNotifier
 
setIgnoreExchangeEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
 
setIgnoreExchangeFailedEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
 
setIgnoreExchangeRedeliveryEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
 
setIgnoreExchangeSendingEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
 
setIgnoreExchangeSentEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
 
setIgnoreMissingLocation(boolean) - Method in interface org.apache.camel.spi.PropertiesComponent
Whether to silently ignore if a location cannot be located, such as a properties file not found.
setIgnoreRouteEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
 
setIgnoreServiceEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
 
setIgnoreStepEvents(boolean) - Method in interface org.apache.camel.spi.EventNotifier
 
setIn(Message) - Method in interface org.apache.camel.Exchange
Sets the inbound message instance
setIncludeHostName(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
Sets whether to include host name in the ManagementObjectNameStrategy.
setIncludeRoutes(String) - Method in interface org.apache.camel.spi.SupervisingRouteController
Pattern for filtering routes to be included as supervised.
setIndex(int) - Method in class org.apache.camel.catalog.LanguageValidationResult
 
setInflightBrowseEnabled(boolean) - Method in interface org.apache.camel.spi.InflightRepository
Whether the inflight repository should allow browsing each inflight exchange.
setInflightRepository(InflightRepository) - Method in interface org.apache.camel.CamelContext
Sets a custom inflight repository to use
setInitialDelay(long) - Method in interface org.apache.camel.spi.SupervisingRouteController
Initial delay in milli seconds before the route controller starts, after CamelContext has been started.
setInitialProperties(Properties) - Method in interface org.apache.camel.spi.PropertiesComponent
Sets initial properties which will be added before any property locations are loaded.
setInjector(Injector) - Method in interface org.apache.camel.CamelContext
Sets the injector to use
setInjector(Injector) - Method in interface org.apache.camel.spi.TypeConverterRegistry
Sets the injector to be used for creating new instances during type conversions.
setInputType(String) - Method in class org.apache.camel.spi.Contract
Set the input data type.
setInputType(Class<?>) - Method in class org.apache.camel.spi.Contract
Set the input data type with Java class.
setInterceptEndpointFactory(InterceptEndpointFactory) - Method in interface org.apache.camel.ExtendedCamelContext
setInternalProcessorFactory(InternalProcessorFactory) - Method in interface org.apache.camel.ExtendedCamelContext
setInterruptable(boolean) - Method in interface org.apache.camel.ExtendedExchange
To control whether the exchange can accept being interrupted currently.
setInterrupted(boolean) - Method in interface org.apache.camel.ExtendedExchange
Used to signal that this exchange was interrupted (InterruptException) during routing.
setInterruptThreadsWhileStopping(boolean) - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
Sets whether to interrupt any blocking threads during stopping.
setInterval(long) - Method in class org.apache.camel.health.HealthCheckConfiguration
Set the check interval in milli seconds.
setJsonDataFormat(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets a custom json data format to be used

Important: This option is only for setting a custom name of the data format, not to refer to an existing data format instance.

setKeepAliveTime(Long) - Method in class org.apache.camel.spi.ThreadPoolProfile
Sets the keep alive time for inactive threads
setKeyManagers(KeyManagersParameters) - Method in class org.apache.camel.support.jsse.SSLContextParameters
Sets the optional key manager configuration for creating the KeyManagers used in constructing an SSLContext.
setKeyPassword(String) - Method in class org.apache.camel.support.jsse.KeyManagersParameters
Sets the optional password for recovering keys in the key store.
setKeyStore(KeyStoreParameters) - Method in class org.apache.camel.support.jsse.KeyManagersParameters
Sets the key store configuration used to create the KeyStore that the KeyManagers produced by this object's configuration expose.
setKeyStore(KeyStoreParameters) - Method in class org.apache.camel.support.jsse.TrustManagersParameters
Sets the key store configuration used to create the KeyStoreParameters that the TrustManagers produced by this object's configuration expose.
setLanguageResolver(LanguageResolver) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom LanguageResolver to use.
setLastError(RouteError) - Method in interface org.apache.camel.Route
Sets the last error.
setLazyStartProducer(boolean) - Method in interface org.apache.camel.GlobalEndpointConfiguration
Whether the producer should be started lazy (on the first message).
setLevel(LoggingLevel) - Method in class org.apache.camel.spi.CamelLogger
 
setLightweight(boolean) - Method in interface org.apache.camel.ExtendedCamelContext
Whether to run in lightweight mode which triggers some optimizations and memory reduction.
setLimit(int) - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
Sets the maximum number of endpoints to keep in the cache per route.
setLineNumber(int) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
 
setLoadStatisticsEnabled(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
Sets whether load statistics is enabled (gathers load statistics using a background thread per CamelContext).
setLoadTypeConverters(Boolean) - Method in interface org.apache.camel.CamelContext
Whether to load custom type converters by scanning classpath.
setLocalProperties(Properties) - Method in interface org.apache.camel.spi.PropertiesComponent
Sets a special list of local properties (ie thread local) that take precedence and will use first, if a property exist.
setLocation(String) - Method in interface org.apache.camel.spi.PropertiesComponent
A list of locations to load properties.
setLog(Logger) - Method in class org.apache.camel.spi.CamelLogger
 
setLogExhaustedMessageBody(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Sets whether to log exhausted message body with message history.
setLoggingLevel(LoggingLevel) - Method in interface org.apache.camel.spi.BeanIntrospection
Logging level used for logging introspection usage.
setLogInflightExchangesOnTimeout(boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
Sets whether to log information about the inflight Exchanges which are still running during a shutdown which didn't complete without the given timeout.
setLogMask(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Sets whether security mask for Logging is enabled or not (default is disabled).
setLogName(String) - Method in class org.apache.camel.spi.CamelLogger
 
setManagementAgent(ManagementAgent) - Method in interface org.apache.camel.spi.ManagementStrategy
Sets the management agent to use
setManagementInterceptStrategy(ManagementInterceptStrategy) - Method in interface org.apache.camel.Route
Sets a special intercept strategy for management.
setManagementName(String) - Method in interface org.apache.camel.CamelContext
Sets the name this CamelContext will be registered in JMX.
setManagementNamePattern(String) - Method in interface org.apache.camel.spi.ManagementAgent
The naming pattern for creating the CamelContext management name.
setManagementNameStrategy(ManagementNameStrategy) - Method in interface org.apache.camel.CamelContext
Sets a custom management name strategy
setManagementObjectNameStrategy(ManagementObjectNameStrategy) - Method in interface org.apache.camel.spi.ManagementStrategy
Sets the naming strategy to use
setManagementObjectStrategy(ManagementObjectStrategy) - Method in interface org.apache.camel.spi.ManagementStrategy
Sets the object strategy to use
setManagementStrategy(ManagementStrategy) - Method in interface org.apache.camel.CamelContext
Sets the management strategy to use
setMarker(Marker) - Method in class org.apache.camel.spi.CamelLogger
 
setMarker(String) - Method in class org.apache.camel.spi.CamelLogger
 
setMask(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
Whether to remove detected sensitive information (such as passwords) from MBean names and attributes.
setMaximumCacheSize(int) - Method in interface org.apache.camel.ConsumerTemplate
Sets a custom maximum cache size.
setMaximumCacheSize(int) - Method in interface org.apache.camel.FluentProducerTemplate
Sets a custom maximum cache size to use in the backing cache pools.
setMaximumCacheSize(int) - Method in interface org.apache.camel.ProducerTemplate
Sets a custom maximum cache size to use in the backing cache pools.
setMaximumRedeliveries(int) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
Sets an optional limit of the number of redelivery attempt of recovered Exchange should be attempted, before its exhausted.
setMaxMessagesPerPoll(int) - Method in interface org.apache.camel.BatchConsumer
Sets a maximum number of messages as a limit to poll at each polling.
setMaxPoolSize(Integer) - Method in class org.apache.camel.spi.ThreadPoolProfile
Sets the maximum pool size
setMaxQueueSize(Integer) - Method in class org.apache.camel.spi.ThreadPoolProfile
Sets the maximum number of tasks in the work queue.
setMBeanObjectDomainName(String) - Method in interface org.apache.camel.spi.ManagementAgent
Sets the object domain name
setMBeanServer(MBeanServer) - Method in interface org.apache.camel.spi.ManagementAgent
Sets a custom mbean server to use
setMBeanServerDefaultDomain(String) - Method in interface org.apache.camel.spi.ManagementAgent
Sets the default domain on the MBean server
setMDCLoggingKeysPattern(String) - Method in interface org.apache.camel.CamelContext
Sets the pattern used for determine which custom MDC keys to propagate during message routing when the routing engine continues routing asynchronously for the given message.
setMessage(Message) - Method in interface org.apache.camel.Exchange
Replace the current message instance.
setMessageHistory(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Sets whether message history is enabled or not (default is disabled).
setMessageHistoryFactory(MessageHistoryFactory) - Method in interface org.apache.camel.CamelContext
Sets a custom MessageHistoryFactory
setMessageId(String) - Method in interface org.apache.camel.Message
Sets the id of the message
setModel(String) - Method in class org.apache.camel.spi.Transformer
Set data model.
setModelJAXBContextFactory(ModelJAXBContextFactory) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom JAXB Context factory to be used
setModelToXMLDumper(ModelToXMLDumper) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom ModelToXMLDumper to be used.
setName(String) - Method in interface org.apache.camel.ExtendedCamelContext
Sets the name (id) of the this context.
setNamePattern(String) - Method in interface org.apache.camel.spi.ManagementNameStrategy
Sets a custom name pattern, which will be used instead of any default patterns.
setNamespaces(Map<String, String>) - Method in interface org.apache.camel.spi.NamespaceAware
Injects the XML Namespaces of prefix -> uri mappings
setNameStrategy(CamelContextNameStrategy) - Method in interface org.apache.camel.CamelContext
Sets a custom name strategy
setNodeIdFactory(NodeIdFactory) - Method in interface org.apache.camel.ExtendedCamelContext
Uses a custom node id factory when generating auto assigned ids to the nodes in the route definitions
setNodePattern(String) - Method in interface org.apache.camel.spi.MessageHistoryFactory
An optional pattern to filter which nodes to trace in this message history.
setNotifyEvent(boolean) - Method in interface org.apache.camel.ExtendedExchange
Sets whether the exchange is currently used as event notification and if so then this should not generate additional events.
setOnCompletion(String, Processor) - Method in interface org.apache.camel.Route
 
setOnException(String, Processor) - Method in interface org.apache.camel.Route
 
setOnlyRegisterProcessorWithCustomId(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
Whether to only register processors which has a custom id assigned.
setOut(Message) - Method in interface org.apache.camel.Exchange
setOutputType(String) - Method in class org.apache.camel.spi.Contract
Set the output data type.
setOutputType(Class<?>) - Method in class org.apache.camel.spi.Contract
Set the output data type with Java class.
setOverrideProperties(Properties) - Method in interface org.apache.camel.spi.PropertiesComponent
Sets a special list of override properties that take precedence and will use first, if a property exist.
setPackageScanClassResolver(PackageScanClassResolver) - Method in interface org.apache.camel.ExtendedCamelContext
Sets the package scanning class resolver to use
setPackageScanResourceResolver(PackageScanResourceResolver) - Method in interface org.apache.camel.ExtendedCamelContext
Sets the package scanning resource resolver to use
setParent(String) - Method in class org.apache.camel.health.HealthCheckConfiguration
The id of the health check such as routes or registry (can use * as wildcard)
setParentUnitOfWork(UnitOfWork) - Method in interface org.apache.camel.spi.UnitOfWork
Sets the parent unit of work.
setPassword(String) - Method in class org.apache.camel.support.jsse.KeyStoreParameters
Set the optional password for reading/opening/verifying the key store.
setPattern(ExchangePattern) - Method in interface org.apache.camel.Exchange
Allows the ExchangePattern (MEP) of this exchange to be customized.
setPoolSize(Integer) - Method in class org.apache.camel.spi.ThreadPoolProfile
Sets the core pool size (threads to keep minimum in pool)
setPort(int) - Method in class org.apache.camel.spi.RestConfiguration
Sets the port to use by the REST consumer
setProcessor(Processor) - Method in interface org.apache.camel.Route
Sets the Processor
setProcessor(Processor) - Method in interface org.apache.camel.spi.ManagementInterceptStrategy.InstrumentationProcessor
 
setProcessorFactory(ProcessorFactory) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom ProcessorFactory
setProducerApiDoc(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets the location of the api document (swagger api) the REST producer will use to validate the REST uri and query parameters are valid accordingly to the api document.
setProducerComponent(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets the name of the Camel component to use as the REST producer
setProperties(Map<String, Object>) - Method in interface org.apache.camel.ExtendedExchange
Sets the properties on the exchange
setPropertiesComponent(PropertiesComponent) - Method in interface org.apache.camel.CamelContext
Sets a custom properties component to be used.
setProperty(String, Object) - Method in interface org.apache.camel.Exchange
Sets a property on the exchange
setProperty(CamelContext, Object, String, Object) - Method in interface org.apache.camel.spi.BeanIntrospection
This method supports three modes to set a property: 1.
setProperty(CamelContext, TypeConverter, Object, String, Object, String, boolean, boolean, boolean) - Method in interface org.apache.camel.spi.BeanIntrospection
This method supports three modes to set a property: 1.
setProvider(String) - Method in class org.apache.camel.support.jsse.KeyManagersParameters
Sets the optional provider identifier for the KeyManagerFactory used to create the KeyManagers represented by this object's configuration.
setProvider(String) - Method in class org.apache.camel.support.jsse.KeyStoreParameters
Sets the optional provider identifier for instantiating the key store.
setProvider(String) - Method in class org.apache.camel.support.jsse.SecureRandomParameters
Sets the optional provider identifier for the SecureRandom factory method used to create the SecureRandom represented by this object's configuration.
setProvider(String) - Method in class org.apache.camel.support.jsse.SSLContextParameters
Sets the optional provider identifier to use when constructing an SSLContext.
setProvider(String) - Method in class org.apache.camel.support.jsse.TrustManagersParameters
Sets the optional provider identifier for the TrustManagerFactory used to create the TrustManagers represented by this object's configuration.
setReactiveExecutor(ReactiveExecutor) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom ReactiveExecutor to be used.
setRecoveryInterval(long, TimeUnit) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
Sets the interval between recovery scans
setRecoveryInterval(long) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
Sets the interval between recovery scans
setRedeliveryExhausted(boolean) - Method in interface org.apache.camel.ExtendedExchange
Used to signal that this exchange has exhausted (attempted all) its redeliveries and still failed.
setRegisterAlways(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
Whether to always register mbeans.
setRegisterNewRoutes(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
Whether to register mbeans when starting a new route

This option is default true.

setRegistry(Registry) - Method in interface org.apache.camel.ExtendedCamelContext
Sets the registry Camel should use for looking up beans by name or type.
setRejectedPolicy(ThreadPoolRejectedPolicy) - Method in class org.apache.camel.spi.ThreadPoolProfile
Sets the handler for tasks which cannot be executed by the thread pool.
setRemoveSpoolDirectoryWhenStopping(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy
Whether to remove the temporary directory when stopping.
setResource(String) - Method in class org.apache.camel.support.jsse.KeyStoreParameters
Sets the optional file path, class path resource, or URL of the resource used to load the key store.
setRestBindingJaxbDataFormatFactory(RestBindingJaxbDataFormatFactory) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom RestBindingJaxbDataFormatFactory to be used.
setRestConfiguration(RestConfiguration) - Method in interface org.apache.camel.CamelContext
Sets a custom RestConfiguration
setRestRegistry(RestRegistry) - Method in interface org.apache.camel.CamelContext
Sets a custom RestRegistry to use.
setRollbackOnly(boolean) - Method in interface org.apache.camel.Exchange
Sets whether to mark this exchange for rollback
setRollbackOnlyLast(boolean) - Method in interface org.apache.camel.Exchange
Sets whether to mark this exchange for rollback (only last transaction section)
setRoute(Route) - Method in interface org.apache.camel.RouteAware
Injects the Route
setRouteController(RouteController) - Method in interface org.apache.camel.CamelContext
Sets a custom RouteController to use
setRouteController(RouteController) - Method in interface org.apache.camel.Route
Sets the RouteController for this route.
setRouteFactory(RouteFactory) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom RouteFactory
setRouteId(String) - Method in interface org.apache.camel.spi.RouteIdAware
Sets the route id
setRouteOnAdvices(Route) - Method in interface org.apache.camel.spi.InternalProcessor
 
setRouteStartupLoggingLevel(LoggingLevel) - Method in interface org.apache.camel.spi.RouteController
Sets the logging level used for logging route startup activity.
setRouteStop(boolean) - Method in interface org.apache.camel.Exchange
Sets whether this exchange is marked to stop and not continue routing.
setRuntimeCamelCatalog(RuntimeCamelCatalog) - Method in interface org.apache.camel.ExtendedCamelContext
Sets the RuntimeCamelCatalog to use.
setRuntimeEndpointRegistry(RuntimeEndpointRegistry) - Method in interface org.apache.camel.CamelContext
Sets a custom RuntimeEndpointRegistry to use.
setScheme(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets the scheme to use by the REST consumer
setScheme(String) - Method in interface org.apache.camel.spi.SendDynamicAware
Sets the component name.
setSecureRandom(SecureRandomParameters) - Method in class org.apache.camel.support.jsse.SSLContextParameters
Sets the optional secure random configuration options to use for constructing the SecureRandom used in the creation of an SSLContext.
setSecureSocketProtocol(List<String>) - Method in class org.apache.camel.support.jsse.SecureSocketProtocolsParameters
Sets the list of secure socket protocol names.
setSecureSocketProtocol(String) - Method in class org.apache.camel.support.jsse.SSLContextParameters
Sets the optional protocol for the secure sockets created by the SSLContext represented by this instance's configuration.
setSecureSocketProtocols(SecureSocketProtocolsParameters) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Sets the explicitly configured secure socket protocol names for this configuration.
setSecureSocketProtocolsFilter(FilterParameters) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Sets the optional secure socket protocol filter for this JSSE configuration.
setServerParameters(SSLContextServerParameters) - Method in class org.apache.camel.support.jsse.SSLContextParameters
The optional configuration options to be applied purely to the server side settings of the SSLContext.
setServiceChooser(ServiceChooser) - Method in interface org.apache.camel.cloud.ServiceChooserAware
Injects the ServiceChooser
setServiceDiscovery(ServiceDiscovery) - Method in interface org.apache.camel.cloud.ServiceDiscoveryAware
Injects the ServiceDiscovery
setServiceFilter(ServiceFilter) - Method in interface org.apache.camel.cloud.ServiceFilterAware
Injects the ServiceFilter
setSessionTimeout(String) - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters
Sets the optional SSLSessionContext timeout time for SSLSessions in seconds.
setShortError(String) - Method in class org.apache.camel.catalog.LanguageValidationResult
 
setShutdownAwaitTermination(long) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Sets the time to wait for thread pools to shutdown orderly, when invoking the ShutdownableService.shutdown() method.
setShutdownNowOnTimeout(boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
Sets whether to force shutdown of all consumers when a timeout occurred and thus not all consumers was shutdown within that period.
setShutdownRoute(ShutdownRoute) - Method in interface org.apache.camel.RuntimeConfiguration
Sets the ShutdownRoute option for routes.
setShutdownRoutesInReverseOrder(boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
Sets whether routes should be shutdown in reverse or the same order as they where started.
setShutdownRunningTask(ShutdownRunningTask) - Method in interface org.apache.camel.RuntimeConfiguration
Sets the ShutdownRunningTask option to use when shutting down a route.
setShutdownStrategy(ShutdownStrategy) - Method in interface org.apache.camel.CamelContext
Sets a custom shutdown strategy
setSkipBindingOnErrorCode(boolean) - Method in class org.apache.camel.spi.RestConfiguration
Whether to skip binding output if there is a custom HTTP error code, and instead use the response body as-is.
setSniHostName(String) - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
 
setSpoolCipher(String) - Method in interface org.apache.camel.spi.StreamCachingStrategy
Sets a cipher name to use when spooling to disk to write with encryption.
setSpoolDirectory(File) - Method in interface org.apache.camel.spi.StreamCachingStrategy
Sets the spool (temporary) directory to use for overflow and spooling to disk.
setSpoolDirectory(String) - Method in interface org.apache.camel.spi.StreamCachingStrategy
 
setSpoolThreshold(long) - Method in interface org.apache.camel.spi.StreamCachingStrategy
Threshold in bytes when overflow to disk is activated.
setSpoolUsedHeapMemoryLimit(StreamCachingStrategy.SpoolUsedHeapMemoryLimit) - Method in interface org.apache.camel.spi.StreamCachingStrategy
Sets what the upper bounds should be when StreamCachingStrategy.setSpoolUsedHeapMemoryThreshold(int) is in use.
setSpoolUsedHeapMemoryThreshold(int) - Method in interface org.apache.camel.spi.StreamCachingStrategy
Sets a percentage (1-99) of used heap memory threshold to activate spooling to disk.
setSSLContextParameters(SSLContextParameters) - Method in interface org.apache.camel.CamelContext
Sets the global SSL context parameters.
setStartupOrder(Integer) - Method in interface org.apache.camel.Route
Sets the route startup order
setState(K, V) - Method in interface org.apache.camel.spi.StateRepository
Sets the state value for the given key.
setStatisticsEnabled(boolean) - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager.Statistics
Sets whether statistics is enabled.
setStatisticsEnabled(boolean) - Method in interface org.apache.camel.spi.StreamCachingStrategy.Statistics
Sets whether statistics is enabled.
setStatisticsEnabled(boolean) - Method in interface org.apache.camel.spi.TypeConverterRegistry.Statistics
Sets whether statistics is enabled.
setStatisticsLevel(ManagementStatisticsLevel) - Method in interface org.apache.camel.spi.ManagementAgent
Sets the statistics level

Default is ManagementStatisticsLevel.Default

The level can be set to Extended to gather additional information

setStreamCaching(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Sets whether stream caching is enabled or not (default is disabled).
setStreamCachingStrategy(StreamCachingStrategy) - Method in interface org.apache.camel.CamelContext
Sets a custom StreamCachingStrategy to use.
setSuppressLoggingOnTimeout(boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
Whether Camel should try to suppress logging during shutdown and timeout was triggered, meaning forced shutdown is happening.
setText(String) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
 
setThreadedAsyncMode(boolean) - Method in interface org.apache.camel.ProducerTemplate
Reports if async* methods will dispath processing from the calling thread (false) or through executor (true).
setThreadNamePattern(String) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Sets the thread name pattern used for creating the full thread name.
setThreadPoolFactory(ThreadPoolFactory) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Sets a custom ThreadPoolFactory to use
setThreadPoolSize(int) - Method in interface org.apache.camel.spi.SupervisingRouteController
The number of threads used by the scheduled thread pool that are used for restarting routes.
setTimeout(long) - Method in interface org.apache.camel.spi.ShutdownStrategy
Set an timeout to wait for the shutdown to complete.
setTimeUnit(TimeUnit) - Method in interface org.apache.camel.spi.ShutdownStrategy
Set the time unit to use
setTimeUnit(TimeUnit) - Method in class org.apache.camel.spi.ThreadPoolProfile
Sets the time unit used for keep alive time
setTo(String) - Method in class org.apache.camel.spi.Transformer
Set 'to' data type.
setTraceBeforeAndAfterRoute(boolean) - Method in interface org.apache.camel.spi.Tracer
Whether to include tracing of before/after routes to trace the input and responses of routes.
setTracePattern(String) - Method in interface org.apache.camel.spi.Tracer
Tracing pattern to match which node EIPs to trace.
setTracer(Tracer) - Method in interface org.apache.camel.CamelContext
Sets a custom Tracer
setTracing(Boolean) - Method in interface org.apache.camel.RuntimeConfiguration
Sets whether tracing is enabled or not (default is disabled).
setTracingPattern(String) - Method in interface org.apache.camel.RuntimeConfiguration
Tracing pattern to match which node EIPs to trace.
setTransacted(boolean) - Method in interface org.apache.camel.ExtendedExchange
Sets whether the exchange is routed in a transaction.
setTrustManager(TrustManager) - Method in class org.apache.camel.support.jsse.TrustManagersParameters
To use a existing configured trust manager instead of using TrustManagerFactory to get the TrustManager.
setTrustManagers(TrustManagersParameters) - Method in class org.apache.camel.support.jsse.SSLContextParameters
Sets the optional trust manager configuration for creating the TrustManagers used in constructing an SSLContext.
setType(String) - Method in class org.apache.camel.spi.Validator
Set data type.
setType(String) - Method in class org.apache.camel.support.jsse.KeyStoreParameters
Sets the type of the key store to create and load.
setTypeConverterExists(TypeConverterExists) - Method in interface org.apache.camel.spi.TypeConverterRegistry
What should happen when attempting to add a duplicate type converter.
setTypeConverterExistsLoggingLevel(LoggingLevel) - Method in interface org.apache.camel.spi.TypeConverterRegistry
The logging level to use when logging that a type converter already exists when attempting to add a duplicate type converter.
setTypeConverterRegistry(TypeConverterRegistry) - Method in interface org.apache.camel.CamelContext
Configures the type converter registry to use, where type converters can be added or looked up.
setTypeConverterStatisticsEnabled(Boolean) - Method in interface org.apache.camel.CamelContext
Sets whether or not type converter statistics is enabled.
setUnhealthyOnExhausted(boolean) - Method in interface org.apache.camel.spi.SupervisingRouteController
Whether to mark the route as unhealthy (down) when all restarting attempts (backoff) have failed and the route is not successfully started and the route manager is giving up.
setUnitOfWork(UnitOfWork) - Method in interface org.apache.camel.ExtendedExchange
Sets the unit of work that this exchange belongs to; which may map to zero, one or more physical transactions
setUnitOfWorkFactory(UnitOfWorkFactory) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom UnitOfWorkFactory to use.
setupJaxb(CamelContext, RestConfiguration, String, Class<?>, String, Class<?>, DataFormat, DataFormat) - Method in interface org.apache.camel.spi.RestBindingJaxbDataFormatFactory
Setup XML data format
setupManagement(Map<String, Object>) - Method in interface org.apache.camel.ExtendedCamelContext
Setup management according to whether JMX is enabled or disabled.
setupManagement(CamelContext, ManagementStrategy, LifecycleStrategy) - Method in interface org.apache.camel.spi.ManagementStrategyFactory
Setup the management on the CamelContext.
setupRoutes(boolean) - Method in interface org.apache.camel.ExtendedCamelContext
Method to signal to CamelContext that the process to initialize setup routes is in progress.
setUriFactoryResolver(UriFactoryResolver) - Method in interface org.apache.camel.ExtendedCamelContext
Sets the UriFactoryResolver to use.
setUseBreadcrumb(Boolean) - Method in interface org.apache.camel.CamelContext
Set whether breadcrumb is enabled.
setUseDataType(Boolean) - Method in interface org.apache.camel.CamelContext
Whether to enable using data type on Camel messages.
setUseGlobalSslContextParameters(boolean) - Method in interface org.apache.camel.SSLContextParametersAware
Enable usage of global SSL context parameters.
setUseHostIPAddress(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
Sets whether to use host IP Address
setUseMDCLogging(Boolean) - Method in interface org.apache.camel.CamelContext
Set whether MDC is enabled.
setUsePlatformMBeanServer(Boolean) - Method in interface org.apache.camel.spi.ManagementAgent
Whether to use the platform MBean Server.
setUseRecovery(boolean) - Method in interface org.apache.camel.spi.RecoverableAggregationRepository
Sets whether or not recovery is enabled
setUseXForwardHeaders(boolean) - Method in class org.apache.camel.spi.RestConfiguration
WWhether to use X-Forward headers to set host etc.
setUuidGenerator(UuidGenerator) - Method in interface org.apache.camel.CamelContext
Sets a custom UuidGenerator (should only be set once)
setValidateInput(boolean) - Method in class org.apache.camel.spi.Contract
Whether to validate the input
setValidateOutput(boolean) - Method in class org.apache.camel.spi.Contract
Whether to validate the output
setValue(Object) - Method in interface org.apache.camel.StaticExpression
Sets the constant value
setXmlDataFormat(String) - Method in class org.apache.camel.spi.RestConfiguration
Sets a custom xml data format to be used.
setXMLRoutesDefinitionLoader(XMLRoutesDefinitionLoader) - Method in interface org.apache.camel.ExtendedCamelContext
Sets a custom XMLRoutesDefinitionLoader to be used.
SharedInternalProcessor - Interface in org.apache.camel.spi
A Shared (thread safe) internal Processor that Camel routing engine used during routing for cross cutting functionality such as: Execute UnitOfWork Keeping track which route currently is being routed Execute RoutePolicy Gather JMX performance statics Tracing Debugging Message History Stream Caching Transformer ...
shouldLog() - Method in class org.apache.camel.spi.CamelLogger
 
shouldLog(Logger, LoggingLevel) - Static method in class org.apache.camel.spi.CamelLogger
 
shouldSpoolCache(long) - Method in interface org.apache.camel.spi.StreamCachingStrategy
Determines if the stream should be spooled or not.
shouldSpoolCache(long) - Method in interface org.apache.camel.spi.StreamCachingStrategy.SpoolRule
Determines if the stream should be spooled or not.
shouldTrace(NamedNode) - Method in interface org.apache.camel.spi.Tracer
Whether or not to trace the given processor definition.
shutdown() - Method in interface org.apache.camel.CamelContextLifecycle
Shutdown the CamelContext, which means it cannot be started again.
shutdown() - Method in interface org.apache.camel.ShutdownableService
Shutdown the service, which means it cannot be started again.
shutdown(ExecutorService) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Shutdown the given executor service (not graceful).
shutdown(CamelContext, List<RouteStartupOrder>) - Method in interface org.apache.camel.spi.ShutdownStrategy
Shutdown the routes
shutdown(CamelContext, List<RouteStartupOrder>, long, TimeUnit) - Method in interface org.apache.camel.spi.ShutdownStrategy
Shutdown the routes using a specified timeout instead of the default timeout values
shutdown(CamelContext, RouteStartupOrder, long, TimeUnit, boolean) - Method in interface org.apache.camel.spi.ShutdownStrategy
Shutdown the route using a specified timeout instead of the default timeout values and supports abortAfterTimeout mode
SHUTDOWN - Static variable in class org.apache.camel.support.service.BaseService
 
shutdown() - Method in class org.apache.camel.support.service.BaseService
Important: You should override the lifecycle methods that start with do, eg BaseService.doStart(), BaseService.doStop(), etc.
ShutdownableService - Interface in org.apache.camel
A Service which is capable of being shut down.
ShutdownAware - Interface in org.apache.camel.spi
Allows Consumer to fine grained control on shutdown which mostly have to cater for in-memory based components.
shutdownForced(CamelContext, List<RouteStartupOrder>) - Method in interface org.apache.camel.spi.ShutdownStrategy
Shutdown the routes, forcing shutdown being more aggressive, if timeout occurred.
shutdownGraceful(ExecutorService) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Shutdown the given executor service graceful at first, and then aggressively if the await termination timeout was hit.
shutdownGraceful(ExecutorService, long) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Shutdown the given executor service graceful at first, and then aggressively if the await termination timeout was hit.
shutdownNow(ExecutorService) - Method in interface org.apache.camel.spi.ExecutorServiceManager
Shutdown now the given executor service aggressively.
ShutdownPrepared - Interface in org.apache.camel.spi
Allows a Service to prepare for shutdown.
ShutdownRoute - Enum in org.apache.camel
Represents the options available when shutting down routes.
ShutdownRunningTask - Enum in org.apache.camel
Represents the kind of options for what to do with the current task when shutting down.
ShutdownStrategy - Interface in org.apache.camel.spi
Pluggable shutdown strategy executed during shutdown of Camel and the active routes.
SHUTTING_DOWN - Static variable in class org.apache.camel.support.service.BaseService
 
SimpleExecutorService - Interface in org.apache.camel.spi
Marker interface to signal that a ExecutorService is simple and tasks are either only submitted via ExecutorService.submit(Runnable) or executed via Executor.execute(Runnable) methods.
size() - Method in interface org.apache.camel.spi.AsyncProcessorAwaitManager
Number of threads that are blocked waiting for other threads to trigger the callback when they are done processing the exchange.
size() - Method in interface org.apache.camel.spi.BulkTypeConverters
Number of type converters included
size() - Method in interface org.apache.camel.spi.ConsumerCache
Returns the current size of the cache
size() - Method in interface org.apache.camel.spi.EndpointUtilizationStatistics
Current number of endpoints we have information about
size() - Method in interface org.apache.camel.spi.InflightRepository
Current size of inflight exchanges.
size(String) - Method in interface org.apache.camel.spi.InflightRepository
Current size of inflight exchanges which are from the given route.
size() - Method in interface org.apache.camel.spi.ProducerCache
Returns the current size of the cache
size() - Method in interface org.apache.camel.spi.RestRegistry
Number of rest services in the registry.
size() - Method in interface org.apache.camel.spi.RuntimeEndpointRegistry
Number of endpoints currently in the cache.
size() - Method in interface org.apache.camel.spi.TypeConverterRegistry
Number of type converters in the registry.
size() - Method in interface org.apache.camel.TimeoutMap
Returns the size of the map
SKIP_GZIP_ENCODING - Static variable in interface org.apache.camel.Exchange
 
SKIP_WWW_FORM_URLENCODED - Static variable in interface org.apache.camel.Exchange
 
SLIP_ENDPOINT - Static variable in interface org.apache.camel.Exchange
 
SLIP_PRODUCER - Static variable in interface org.apache.camel.Exchange
 
SOAP_ACTION - Static variable in interface org.apache.camel.Exchange
 
SPLIT_COMPLETE - Static variable in interface org.apache.camel.Exchange
 
SPLIT_INDEX - Static variable in interface org.apache.camel.Exchange
 
SPLIT_SIZE - Static variable in interface org.apache.camel.Exchange
 
SSLContextClientParameters - Class in org.apache.camel.support.jsse
Configuration model for client side JSSE options.
SSLContextClientParameters() - Constructor for class org.apache.camel.support.jsse.SSLContextClientParameters
 
SSLContextDecorator(BaseSSLContextParameters.SSLContextSpiDecorator) - Constructor for class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextDecorator
 
SSLContextParameters - Class in org.apache.camel.support.jsse
Represents SSLContext configuration options used in instantiating an SSLContext instance.
SSLContextParameters() - Constructor for class org.apache.camel.support.jsse.SSLContextParameters
 
SSLContextParametersAware - Interface in org.apache.camel
Indicates that an object is able to use the global SSLContextParameters if configured.
SSLContextServerParameters - Class in org.apache.camel.support.jsse
 
SSLContextServerParameters() - Constructor for class org.apache.camel.support.jsse.SSLContextServerParameters
 
SSLContextSpiDecorator(SSLContext, List<BaseSSLContextParameters.Configurer<SSLEngine>>, List<BaseSSLContextParameters.Configurer<SSLSocketFactory>>, List<BaseSSLContextParameters.Configurer<SSLServerSocketFactory>>) - Constructor for class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextSpiDecorator
 
SSLServerSocketFactoryDecorator(SSLServerSocketFactory, List<BaseSSLContextParameters.Configurer<SSLServerSocket>>) - Constructor for class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLServerSocketFactoryDecorator
 
SSLSocketFactoryDecorator(SSLSocketFactory, List<BaseSSLContextParameters.Configurer<SSLSocket>>) - Constructor for class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLSocketFactoryDecorator
 
start() - Method in interface org.apache.camel.CamelContextLifecycle
Starts the CamelContext (important: the start method is not blocked, see more details here).
start() - Method in interface org.apache.camel.Service
Starts the service
start() - Method in class org.apache.camel.support.service.BaseService
Important: You should override the lifecycle methods that start with do, eg BaseService.doStart(), BaseService.doStop(), etc.
startAllRoutes() - Method in interface org.apache.camel.spi.RouteController
Starts all the routes which currently is not started.
STARTED - Static variable in class org.apache.camel.support.service.BaseService
 
STARTING - Static variable in class org.apache.camel.support.service.BaseService
 
startRoute(String) - Method in interface org.apache.camel.spi.RouteController
Starts the given route if it has been previously stopped
startScheduler() - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
Starts the scheduler.
startService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
Starts the given value if it's a Service or a collection of it.
startService(Object...) - Static method in class org.apache.camel.support.service.ServiceHelper
Starts each element of the given services if services itself is not null, otherwise this method would return immediately.
startSingleStepExchange(String, Breakpoint) - Method in interface org.apache.camel.spi.Debugger
Starts the single step debug mode for the given exchange
StartupListener - Interface in org.apache.camel
Allows objects to be notified when CamelContext has almost done all work when starting.
startView(String) - Method in interface org.apache.camel.cluster.CamelClusterService
Force start of the view associated to the give namespace.
state() - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
state(HealthCheck.State) - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
StatefulService - Interface in org.apache.camel
A Service which has all the lifecycle events and offers details about its current state.
StateRepository<K,V> - Interface in org.apache.camel.spi
This StateRepository holds a set of key/value pairs for defining a particular state of a component.
StaticExpression - Interface in org.apache.camel
Marked if the Expression or Predicate is based from a constant value (ie is static).
StaticService - Interface in org.apache.camel
Marker for indicating the Service is a static service (only one instance per CamelContext).
staticSize() - Method in interface org.apache.camel.spi.EndpointRegistry
Number of endpoints in the static registry.
staticSize() - Method in interface org.apache.camel.spi.TransformerRegistry
Number of transformers in the static registry.
staticSize() - Method in interface org.apache.camel.spi.ValidatorRegistry
Number of validators in the static registry.
status - Variable in class org.apache.camel.support.service.BaseService
 
STEP_ID - Static variable in interface org.apache.camel.Exchange
 
stop() - Method in interface org.apache.camel.CamelContextLifecycle
Stop and shutdown the CamelContext (will stop all routes/components/endpoints etc and clear internal state/cache).
stop() - Method in interface org.apache.camel.Service
Stops the service
stop() - Method in class org.apache.camel.support.service.BaseService
Important: You should override the lifecycle methods that start with do, eg BaseService.doStart(), BaseService.doStop(), etc.
stopAndShutdownService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
Stops and shutdowns the given service, rethrowing the first exception caught.
stopAndShutdownServices(Object...) - Static method in class org.apache.camel.support.service.ServiceHelper
Stops and shutdowns each element of the given services if services itself is not null, otherwise this method would return immediately.
stopAndShutdownServices(Collection<?>) - Static method in class org.apache.camel.support.service.ServiceHelper
Stops and shutdowns each element of the given services if services itself is not null, otherwise this method would return immediately.
STOPPED - Static variable in class org.apache.camel.support.service.BaseService
 
STOPPING - Static variable in class org.apache.camel.support.service.BaseService
 
stopRoute(String) - Method in interface org.apache.camel.spi.RouteController
Stops the given route using ShutdownStrategy.
stopRoute(String, long, TimeUnit) - Method in interface org.apache.camel.spi.RouteController
Stops the given route using ShutdownStrategy with a specified timeout.
stopRoute(String, long, TimeUnit, boolean) - Method in interface org.apache.camel.spi.RouteController
Stops the given route using ShutdownStrategy with a specified timeout and optional abortAfterTimeout mode.
stopService(Object...) - Static method in class org.apache.camel.support.service.ServiceHelper
Stops each element of the given services if services itself is not null, otherwise this method would return immediately.
stopService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
Stops the given value, rethrowing the first exception caught.
stopService(Collection<?>) - Static method in class org.apache.camel.support.service.ServiceHelper
Stops each element of the given services if services itself is not null, otherwise this method would return immediately.
stopSingleStepExchange(String) - Method in interface org.apache.camel.spi.Debugger
Stops the single step debug mode for the given exchange.
stopView(String) - Method in interface org.apache.camel.cluster.CamelClusterService
Force stop of the view associated to the give namespace.
stream() - Method in interface org.apache.camel.health.HealthCheckRegistry
Returns a sequential Stream with the known HealthCheck as its source.
stream() - Method in interface org.apache.camel.health.HealthCheckRepository
Returns a sequential Stream with the known HealthCheck as its source.
STREAM_CACHE_UNIT_OF_WORK - Static variable in interface org.apache.camel.Exchange
 
StreamCache - Interface in org.apache.camel
Tagging interface to indicate that a type is capable of caching the underlying data stream.
StreamCacheException - Exception in org.apache.camel
 
StreamCacheException(Object, Throwable) - Constructor for exception org.apache.camel.StreamCacheException
 
StreamCachingStrategy - Interface in org.apache.camel.spi
Strategy for using stream caching.
StreamCachingStrategy.SpoolRule - Interface in org.apache.camel.spi
Rule for determine if stream caching should be spooled to disk or kept in-memory.
StreamCachingStrategy.SpoolUsedHeapMemoryLimit - Enum in org.apache.camel.spi
Used for selecting if the memory limit is committed or maximum heap memory setting.
StreamCachingStrategy.Statistics - Interface in org.apache.camel.spi
Utilization statistics of stream caching.
SUFFIX_TOKEN - Static variable in interface org.apache.camel.spi.PropertiesComponent
The suffix token.
suggestEndpointOptions(Set<String>, String) - Method in interface org.apache.camel.catalog.SuggestionStrategy
Provides a list of valid option names for a did you mean function.
SuggestionStrategy - Interface in org.apache.camel.catalog
Strategy to provide suggestions for unknown endpoint options
summaryErrorMessage(boolean) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
A human readable summary of the validation errors.
summaryErrorMessage(boolean, boolean, boolean) - Method in class org.apache.camel.catalog.ConfigurationPropertiesValidationResult
A human readable summary of the validation errors.
summaryErrorMessage(boolean) - Method in class org.apache.camel.catalog.EndpointValidationResult
A human readable summary of the validation errors.
summaryErrorMessage(boolean, boolean, boolean) - Method in class org.apache.camel.catalog.EndpointValidationResult
A human readable summary of the validation errors.
supervising() - Method in interface org.apache.camel.spi.RouteController
Enables supervising RouteController.
SupervisingRouteController - Interface in org.apache.camel.spi
A supervising capable RouteController that delays the startup of the routes after the camel context startup and takes control of starting the routes in a safe manner.
supportsAutoWiring() - Method in interface org.apache.camel.spi.Injector
Whether the injector supports creating new instances using auto-wiring.
supportsSuspension() - Method in interface org.apache.camel.Route
Whether or not the route supports suspension (suspend and resume)
suspend() - Method in interface org.apache.camel.CamelContextLifecycle
Suspends the CamelContext.
suspend() - Method in interface org.apache.camel.spi.Breakpoint
Suspend this breakpoint
suspend(CamelContext, List<RouteStartupOrder>) - Method in interface org.apache.camel.spi.ShutdownStrategy
Suspends the routes
suspend(CamelContext, List<RouteStartupOrder>, long, TimeUnit) - Method in interface org.apache.camel.spi.ShutdownStrategy
Suspends the routes using a specified timeout instead of the default timeout values
suspend() - Method in class org.apache.camel.support.service.BaseService
Important: You should override the lifecycle methods that start with do, eg BaseService.doStart(), BaseService.doStop(), etc.
suspend() - Method in interface org.apache.camel.SuspendableService
Suspends the service.
Suspendable - Interface in org.apache.camel
Marker interface to indicate a custom component has custom implementation for suspending the SuspendableService service.
SuspendableService - Interface in org.apache.camel
A Service which is also capable of suspending and resuming.
suspendAllBreakpoints() - Method in interface org.apache.camel.spi.Debugger
Suspends all breakpoints.
SUSPENDED - Static variable in class org.apache.camel.support.service.BaseService
 
SUSPENDING - Static variable in class org.apache.camel.support.service.BaseService
 
suspendRoute(String) - Method in interface org.apache.camel.spi.RouteController
Suspends the given route using ShutdownStrategy.
suspendRoute(String, long, TimeUnit) - Method in interface org.apache.camel.spi.RouteController
Suspends the given route using ShutdownStrategy with a specified timeout.
suspendService(Object) - Static method in class org.apache.camel.support.service.ServiceHelper
Suspends the given service.
suspendServices(Collection<?>) - Static method in class org.apache.camel.support.service.ServiceHelper
Suspends each element of the given services if services itself is not null, otherwise this method would return immediately.
Synchronization - Interface in org.apache.camel.spi
Provides a hook for custom Processor or Component instances to respond to completed or failed processing of an Exchange rather like Spring's TransactionSynchronization
SynchronizationRouteAware - Interface in org.apache.camel.spi
An extended Synchronization which is route aware.
SynchronizationVetoable - Interface in org.apache.camel.spi
A vetoable Synchronization.

T

TEMPLATE_ID - Static variable in interface org.apache.camel.spi.RouteTemplateParameterSource
 
TEMPLATE_PROPERTY - Static variable in interface org.apache.camel.Route
 
test(HealthCheck) - Method in interface org.apache.camel.health.HealthCheckFilter
Determine if the given HealthCheck has to be filtered out.
test(Object) - Static method in interface org.apache.camel.IsSingleton
Test if the given instance is a singleton or not.
test(CamelContext) - Method in interface org.apache.camel.spi.CamelContextTracker.Filter
 
ThreadPoolFactory - Interface in org.apache.camel.spi
Creates ExecutorService and ScheduledExecutorService objects that work with a thread pool for a given ThreadPoolProfile and ThreadFactory.
ThreadPoolProfile - Class in org.apache.camel.spi
A profile which defines thread pool settings.
ThreadPoolProfile() - Constructor for class org.apache.camel.spi.ThreadPoolProfile
Creates a new thread pool profile, with no id set.
ThreadPoolProfile(String) - Constructor for class org.apache.camel.spi.ThreadPoolProfile
Creates a new thread pool profile
timeout(Exchange, int, int, long) - Method in interface org.apache.camel.AggregationStrategy
A timeout occurred.
TimeoutMap<K,V> - Interface in org.apache.camel
Represents a map of values which timeout after a period of inactivity.
TimeoutMap.Listener<K,V> - Interface in org.apache.camel
 
TimeoutMap.Listener.Type - Enum in org.apache.camel
 
timeoutMapEvent(TimeoutMap.Listener.Type, K, V) - Method in interface org.apache.camel.TimeoutMap.Listener
Callback when the map changes content
TIMER_COUNTER - Static variable in interface org.apache.camel.Exchange
 
TIMER_FIRED_TIME - Static variable in interface org.apache.camel.Exchange
 
TIMER_NAME - Static variable in interface org.apache.camel.Exchange
 
TIMER_PERIOD - Static variable in interface org.apache.camel.Exchange
 
TIMER_TIME - Static variable in interface org.apache.camel.Exchange
 
TimerListener - Interface in org.apache.camel
Listener for receiving timer events.
to(String) - Method in interface org.apache.camel.FluentProducerTemplate
Endpoint to send to
to(EndpointProducerResolver) - Method in interface org.apache.camel.FluentProducerTemplate
Endpoint to send to
to(Endpoint) - Method in interface org.apache.camel.FluentProducerTemplate
Endpoint to send to
TO_ENDPOINT - Static variable in interface org.apache.camel.Exchange
 
toF(String, Object...) - Method in interface org.apache.camel.FluentProducerTemplate
Endpoint to send to.
toString() - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
toString() - Method in class org.apache.camel.spi.CamelLogger
 
toString() - Method in class org.apache.camel.spi.Contract
 
toString() - Method in class org.apache.camel.spi.DataType
 
toString() - Method in class org.apache.camel.spi.ThreadPoolProfile
 
toString() - Method in class org.apache.camel.spi.Transformer
 
toString() - Method in class org.apache.camel.spi.Validator
 
toString() - Method in class org.apache.camel.support.jsse.BaseSSLContextParameters.SSLContextDecorator
 
toString() - Method in class org.apache.camel.support.jsse.CipherSuitesParameters
 
toString() - Method in class org.apache.camel.support.jsse.FilterParameters.Patterns
 
toString() - Method in class org.apache.camel.support.jsse.FilterParameters
 
toString() - Method in class org.apache.camel.support.jsse.KeyManagersParameters
 
toString() - Method in class org.apache.camel.support.jsse.KeyStoreParameters
 
toString() - Method in class org.apache.camel.support.jsse.SecureRandomParameters
 
toString() - Method in class org.apache.camel.support.jsse.SecureSocketProtocolsParameters
 
toString() - Method in class org.apache.camel.support.jsse.SSLContextClientParameters
 
toString() - Method in class org.apache.camel.support.jsse.SSLContextParameters
 
toString() - Method in class org.apache.camel.support.jsse.SSLContextServerParameters
 
toString() - Method in class org.apache.camel.support.jsse.TrustManagersParameters
 
TRACE_EVENT - Static variable in interface org.apache.camel.Exchange
 
TRACE_EVENT_EXCHANGE - Static variable in interface org.apache.camel.Exchange
 
TRACE_EVENT_NODE_ID - Static variable in interface org.apache.camel.Exchange
 
TRACE_EVENT_TIMESTAMP - Static variable in interface org.apache.camel.Exchange
 
Traceable - Interface in org.apache.camel
Traceable processors allowing easier tracing using constructed labels to help identify the processor and where it's defined in the route model.
traceAfterNode(NamedNode, Exchange) - Method in interface org.apache.camel.spi.Tracer
Trace after the given node
traceAfterRoute(Route, Exchange) - Method in interface org.apache.camel.spi.Tracer
Trace after the route (eg output from route)
traceBeforeNode(NamedNode, Exchange) - Method in interface org.apache.camel.spi.Tracer
Trace before the given node
traceBeforeRoute(NamedRoute, Exchange) - Method in interface org.apache.camel.spi.Tracer
Trace before the route (eg input to route)
Tracer - Interface in org.apache.camel.spi
SPI for tracing messages.
TRACING_HEADER_FORMAT - Static variable in interface org.apache.camel.Exchange
 
TRACING_OUTPUT_FORMAT - Static variable in interface org.apache.camel.Exchange
 
TransactedPolicy - Interface in org.apache.camel.spi
A marker for defining the policy to be used for applying transaction to routes.
TRANSFER_ENCODING - Static variable in interface org.apache.camel.Exchange
 
transform(Message, DataType, DataType) - Method in class org.apache.camel.spi.Transformer
Perform data transformation with specified from/to type.
Transformer - Class in org.apache.camel.spi
Transformer performs message transformation according to the declared data type.
Transformer() - Constructor for class org.apache.camel.spi.Transformer
 
TransformerRegistry<K> - Interface in org.apache.camel.spi
Registry to cache transformers in memory.
trustManager - Variable in class org.apache.camel.support.jsse.TrustManagersParameters
To use a existing configured trust manager instead of using TrustManagerFactory to get the TrustManager.
TrustManagersParameters - Class in org.apache.camel.support.jsse
 
TrustManagersParameters() - Constructor for class org.apache.camel.support.jsse.TrustManagersParameters
 
TRY_ROUTE_BLOCK - Static variable in interface org.apache.camel.Exchange
 
tryConvertTo(Class<?>, Class<T>, Exchange, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
Tries to convert the value to the specified type, returning null if not possible to convert.
tryConvertTo(Class<T>, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
 
tryConvertTo(Class<T>, Exchange, Object) - Method in interface org.apache.camel.spi.BulkTypeConverters
 
tryConvertTo(Class<T>, Object) - Method in interface org.apache.camel.TypeConverter
Tries to convert the value to the specified type, returning null if not possible to convert.
tryConvertTo(Class<T>, Exchange, Object) - Method in interface org.apache.camel.TypeConverter
Tries to convert the value to the specified type in the context of an exchange, returning null if not possible to convert.
trySetCamelContext(T, CamelContext) - Static method in interface org.apache.camel.CamelContextAware
Set the CamelContext context if the object is an instance of CamelContextAware.
trySetComponent(T, Component) - Static method in interface org.apache.camel.Component
Set the Component context if the component is an instance of ComponentAware.
type - Variable in class org.apache.camel.support.jsse.KeyStoreParameters
The optional type of the key store to load.
TypeConversionException - Exception in org.apache.camel
Exception when failing during type conversion.
TypeConversionException(Object, Class<?>, Throwable) - Constructor for exception org.apache.camel.TypeConversionException
 
TypeConverter - Interface in org.apache.camel
A pluggable strategy to be able to convert objects to different types such as to and from String, InputStream/OutputStream, Reader/Writer, Document, byte[], ByteBuffer etc
TypeConverterExists - Enum in org.apache.camel
What to do if attempting to add a duplicate type converter
TypeConverterExistsException - Exception in org.apache.camel
Exception when failing to add type converters due there is already an existing type converter.
TypeConverterExistsException(Class<?>, Class<?>) - Constructor for exception org.apache.camel.TypeConverterExistsException
 
TypeConverterLoader - Interface in org.apache.camel.spi
A pluggable strategy to load type converters into a TypeConverterRegistry from some kind of mechanism.
TypeConverterLoaderException - Exception in org.apache.camel
Exception when failing to load type converters.
TypeConverterLoaderException(String) - Constructor for exception org.apache.camel.TypeConverterLoaderException
 
TypeConverterLoaderException(String, Throwable) - Constructor for exception org.apache.camel.TypeConverterLoaderException
 
TypeConverterRegistry - Interface in org.apache.camel.spi
Registry for type converters.
TypeConverterRegistry.Statistics - Interface in org.apache.camel.spi
Utilization statistics of the this registry.
TypeConverters - Interface in org.apache.camel
A tagging interface to mark this class implements type converters using the Converter annotations.

U

UNIT_OF_WORK_EXHAUSTED - Static variable in interface org.apache.camel.Exchange
 
UNIT_OF_WORK_PROCESS_SYNC - Static variable in interface org.apache.camel.Exchange
Deprecated.
UNIT_OF_WORK_PROCESS_SYNC is not in use and will be removed in future Camel release
UnitOfWork - Interface in org.apache.camel.spi
An object representing the unit of work processing an Exchange which allows the use of Synchronization hooks.
UnitOfWorkFactory - Interface in org.apache.camel.spi
Factory to create UnitOfWork.
unknown() - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
UNKNOWN_PARAMETER - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
A given parameter is not known to the component
unmanageObject(Object) - Method in interface org.apache.camel.spi.ManagementStrategy
Removes the managed object.
unmarshal(Exchange, InputStream) - Method in interface org.apache.camel.spi.DataFormat
Unmarshals the given stream into an object.
unregister(Object) - Method in interface org.apache.camel.health.HealthCheckRegistry
unregister(ObjectName) - Method in interface org.apache.camel.spi.ManagementAgent
Unregisters object based upon registered name
unscheduleTask() - Method in interface org.apache.camel.spi.ScheduledPollConsumerScheduler
Attempts to unschedules the last task which was scheduled.
UNSUPPORTED - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
The verification is not supported
UNSUPPORTED_COMPONENT - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
The requested Component is not supported
UNSUPPORTED_SCOPE - Static variable in interface org.apache.camel.component.extension.ComponentVerifierExtension.VerificationError.StandardCode
The requested ComponentVerifierExtension.Scope is not supported
unwrap(Class<T>) - Method in interface org.apache.camel.cluster.CamelClusterService
Access the underlying concrete CamelClusterService implementation to provide access to further features.
unwrap(Class<T>) - Method in interface org.apache.camel.cluster.CamelClusterView
Access the underlying concrete CamelClusterView implementation to provide access to further features.
unwrap(Class<T>) - Method in interface org.apache.camel.component.extension.ComponentExtension
Access the underlying concrete ComponentExtension implementation to provide access to further features.
unwrap(Object) - Method in interface org.apache.camel.spi.BeanRepository
Strategy to wrap the value to be stored in the registry.
up() - Method in class org.apache.camel.health.HealthCheckResultBuilder
 
UriEndpoint - Annotation Type in org.apache.camel.spi
Represents an annotated Camel Endpoint which can have its properties (and the properties on its consumer) injected from the Camel URI path and its query parameters
UriFactoryResolver - Interface in org.apache.camel.spi
A pluggable strategy for resolving different URI factories in a loosely coupled manner.
UriParam - Annotation Type in org.apache.camel.spi
Represents an injection point of a Camel Uri parameter value on an Endpoint or Consumer, usually configured via a URI style query parameter in a URI
UriParams - Annotation Type in org.apache.camel.spi
Used to annotate a nested configuration parameter type (such as a nested Configuration object) which can then be used on a Component, Endpoint and/or Consumer and then be configured via Camel URI query arguments.
UriPath - Annotation Type in org.apache.camel.spi
Represents an injection point of a Camel Uri path value (the remaining part of a Camel URI without any query arguments)
useRawUri() - Method in interface org.apache.camel.Component
Whether to use raw or encoded uri, when creating endpoints.
UuidGenerator - Interface in org.apache.camel.spi
Generator to generate UUID strings.

V

validate(Message, DataType) - Method in class org.apache.camel.spi.Validator
Perform data validation with specified type.
validateProperties(String, Map<String, String>) - Method in interface org.apache.camel.catalog.RuntimeCamelCatalog
Validates the properties for the given scheme against component and endpoint

This API is needed by ComponentVerifierExtension.

ValidationException - Exception in org.apache.camel
The base class for any validation exception, such as org.apache.camel.processor.validation.SchemaValidationException so that it is easy to treat all validation errors in a similar way irrespective of the particular validation technology used.
ValidationException(Exchange, String) - Constructor for exception org.apache.camel.ValidationException
 
ValidationException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.ValidationException
 
Validator - Class in org.apache.camel.spi
Validator performs message content validation according to the declared data type.
Validator() - Constructor for class org.apache.camel.spi.Validator
 
ValidatorRegistry<K> - Interface in org.apache.camel.spi
Registry to cache validators in memory.
ValueHolder<V> - Class in org.apache.camel
Holder object for a given value.
ValueHolder(V) - Constructor for class org.apache.camel.ValueHolder
 
valueOf(String) - Static method in enum org.apache.camel.BeanScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.Category
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.component.extension.ComponentVerifierExtension.Result.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.component.extension.ComponentVerifierExtension.Scope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.ExchangePattern
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.health.HealthCheck.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.LoggingLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.ManagementStatisticsLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.ServiceStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.ShutdownRoute
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.ShutdownRunningTask
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.spi.Breakpoint.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.spi.CamelEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.spi.HeaderFilterStrategy.Direction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.spi.RestConfiguration.RestBindingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.spi.RestConfiguration.RestHostNameResolver
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.spi.RouteError.Phase
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.spi.StreamCachingStrategy.SpoolUsedHeapMemoryLimit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.support.jsse.ClientAuthentication
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.TimeoutMap.Listener.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.TypeConverterExists
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.WaitForTaskToComplete
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.camel.BeanScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.Category
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.component.extension.ComponentVerifierExtension.Result.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.component.extension.ComponentVerifierExtension.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.ExchangePattern
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.health.HealthCheck.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.LoggingLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.ManagementStatisticsLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.ServiceStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.ShutdownRoute
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.ShutdownRunningTask
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.spi.Breakpoint.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.spi.CamelEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.spi.HeaderFilterStrategy.Direction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.spi.RestConfiguration.RestBindingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.spi.RestConfiguration.RestHostNameResolver
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.spi.RouteError.Phase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.spi.StreamCachingStrategy.SpoolUsedHeapMemoryLimit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.support.jsse.ClientAuthentication
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.TimeoutMap.Listener.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.TypeConverterExists
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.WaitForTaskToComplete
Returns an array containing the constants of this enum type, in the order they are declared.
verify(ComponentVerifierExtension.Scope, Map<String, Object>) - Method in interface org.apache.camel.component.extension.ComponentVerifierExtension
Verify the given parameters against a provided scope.
VetoCamelContextStartException - Exception in org.apache.camel
An exception to veto starting CamelContext.
VetoCamelContextStartException(String, CamelContext) - Constructor for exception org.apache.camel.VetoCamelContextStartException
 
VetoCamelContextStartException(String, CamelContext, boolean) - Constructor for exception org.apache.camel.VetoCamelContextStartException
 
VetoCamelContextStartException(String, Throwable, CamelContext) - Constructor for exception org.apache.camel.VetoCamelContextStartException
 
VetoCamelContextStartException(String, Throwable, CamelContext, boolean) - Constructor for exception org.apache.camel.VetoCamelContextStartException
 

W

WaitForTaskToComplete - Enum in org.apache.camel
Represent the kinds of options for wait for tasks to complete.
warmUp() - Method in interface org.apache.camel.Route
Callback preparing the route to be started, by warming up the route.
withBody(Object) - Method in interface org.apache.camel.FluentProducerTemplate
Set the message body
withBodyAs(Object, Class<?>) - Method in interface org.apache.camel.FluentProducerTemplate
Set the message body after converting it to the given type
withCondition(BiPredicate<String, Component>) - Method in class org.apache.camel.spi.ComponentCustomizer.Builder
 
withCondition(BiPredicate<String, DataFormat>) - Method in class org.apache.camel.spi.DataFormatCustomizer.Builder
 
withCondition(BiPredicate<String, Language>) - Method in class org.apache.camel.spi.LanguageCustomizer.Builder
 
withExchange(Exchange) - Method in interface org.apache.camel.FluentProducerTemplate
Set the exchange to use for send.
withExchange(Supplier<Exchange>) - Method in interface org.apache.camel.FluentProducerTemplate
Set the exchangeSupplier which will be invoke to get the exchange to be used for send.
withHeader(String, Object) - Method in interface org.apache.camel.FluentProducerTemplate
Set the header
withOrder(int) - Method in class org.apache.camel.spi.ComponentCustomizer.Builder
 
withOrder(int) - Method in class org.apache.camel.spi.DataFormatCustomizer.Builder
 
withOrder(int) - Method in class org.apache.camel.spi.LanguageCustomizer.Builder
 
withProcessor(Processor) - Method in interface org.apache.camel.FluentProducerTemplate
Set the processor to use for send/request.
withProcessor(Supplier<Processor>) - Method in interface org.apache.camel.FluentProducerTemplate
Set the processorSupplier which will be invoke to get the processor to be used for send/request.
withTemplateCustomizer(Consumer<ProducerTemplate>) - Method in interface org.apache.camel.FluentProducerTemplate
To customize the producer template for advanced usage like to set the executor service to use.
wrap(Route, Processor) - Method in interface org.apache.camel.spi.Policy
Wraps any applicable interceptors around the given processor.
wrap(Object) - Method in interface org.apache.camel.spi.Registry
Strategy to wrap the value to be stored in the registry.
WrapAwareProcessor - Interface in org.apache.camel.spi
An interface to represent an object which wraps a Processor.
wrapCamelExecutionException(Exchange, Throwable) - Static method in exception org.apache.camel.CamelExecutionException
Wraps the caused exception in a CamelExecutionException if its not already such an exception.
WrappedFile<T> - Interface in org.apache.camel
Wraps a file.
wrapProcessorInInterceptors(CamelContext, NamedNode, Processor, Processor) - Method in interface org.apache.camel.spi.InterceptStrategy
Give implementor an opportunity to wrap the target processor in a route.
wrapRuntimeCamelException(Throwable) - Static method in exception org.apache.camel.RuntimeCamelException
Wraps the caused exception in a RuntimeCamelException if its not already such an exception.
wrapRuntimeException(Throwable) - Static method in exception org.apache.camel.RuntimeCamelException
Wraps the caused exception in a RuntimeCamelException if its not already a runtime exception.
writeTo(OutputStream) - Method in interface org.apache.camel.StreamCache
Writes the stream to the given output

X

XMLRoutesDefinitionLoader - Interface in org.apache.camel.spi
SPI for loading routes/rests from XML input streams and parsing this to model definition classes.
XSLT_ERROR - Static variable in interface org.apache.camel.Exchange
 
XSLT_FATAL_ERROR - Static variable in interface org.apache.camel.Exchange
 
XSLT_FILE_NAME - Static variable in interface org.apache.camel.Exchange
 
XSLT_WARNING - Static variable in interface org.apache.camel.Exchange
 
A B C D E F G H I J K L M N O P Q R S T U V W X 
Skip navigation links

Apache Camel