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

A

AbstractCamelCatalog - Class in org.apache.camel.runtimecatalog.impl
Base class for both the runtime RuntimeCamelCatalog from camel-core and the complete CamelCatalog from camel-catalog.
AbstractCamelCatalog() - Constructor for class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
AbstractCamelContext - Class in org.apache.camel.impl.engine
Represents the context used to configure routes and the policies to use.
AbstractCamelContext() - Constructor for class org.apache.camel.impl.engine.AbstractCamelContext
Creates the CamelContext using DefaultRegistry as registry.
AbstractCamelContext(Registry) - Constructor for class org.apache.camel.impl.engine.AbstractCamelContext
Creates the CamelContext using the given registry
AbstractCamelContext(boolean) - Constructor for class org.apache.camel.impl.engine.AbstractCamelContext
 
AbstractCamelContext.Initialization - Enum in org.apache.camel.impl.engine
 
AbstractContextEvent - Class in org.apache.camel.impl.event
Base class for CamelContext events.
AbstractContextEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.AbstractContextEvent
 
AbstractDynamicRegistry<K,V> - Class in org.apache.camel.impl.engine
Base implementation for TransformerRegistry, ValidatorRegistry and EndpointRegistry.
AbstractDynamicRegistry(CamelContext, int) - Constructor for class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
AbstractExchangeEvent - Class in org.apache.camel.impl.event
Base class for Exchange events.
AbstractExchangeEvent(Exchange) - Constructor for class org.apache.camel.impl.event.AbstractExchangeEvent
 
AbstractHealthCheck - Class in org.apache.camel.impl.health
 
AbstractHealthCheck(String) - Constructor for class org.apache.camel.impl.health.AbstractHealthCheck
 
AbstractHealthCheck(String, String) - Constructor for class org.apache.camel.impl.health.AbstractHealthCheck
 
AbstractHealthCheck(String, String, Map<String, Object>) - Constructor for class org.apache.camel.impl.health.AbstractHealthCheck
 
AbstractListAggregationStrategy<V> - Class in org.apache.camel.processor.aggregate
Aggregate all exchanges into a List of values defined by the AbstractListAggregationStrategy.getValue(Exchange) call.
AbstractListAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.AbstractListAggregationStrategy
 
AbstractLocationPropertiesSource - Class in org.apache.camel.component.properties
Base class for LoadablePropertiesSource which can load properties from a source such as classpath or file system.
AbstractLocationPropertiesSource(PropertiesComponent, PropertiesLocation) - Constructor for class org.apache.camel.component.properties.AbstractLocationPropertiesSource
 
AbstractRouteEvent - Class in org.apache.camel.impl.event
Base class for CamelContext events.
AbstractRouteEvent(Route) - Constructor for class org.apache.camel.impl.event.AbstractRouteEvent
 
AbstractStepEvent - Class in org.apache.camel.impl.event
Base class for step events.
AbstractStepEvent(Exchange, String) - Constructor for class org.apache.camel.impl.event.AbstractStepEvent
 
accept(TokenType) - Method in class org.apache.camel.language.simple.BaseSimpleParser
Accept the given token.
acceptableSchemes - Variable in class org.apache.camel.impl.engine.BasePackageScanResolver
 
acceptAndAddNode(SimpleNode) - Method in interface org.apache.camel.language.simple.ast.Block
Whether to accept and add the given node in this block.
acceptAndAddNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.DoubleQuoteStart
 
acceptAndAddNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.SimpleFunctionStart
 
acceptAndAddNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.SingleQuoteStart
 
acceptClass(Class<?>) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
acceptClass(Class<?>) - Method in class org.apache.camel.impl.converter.FastAnnotationTypeConverterLoader
 
acceptLeft(SimpleNode) - Method in class org.apache.camel.language.simple.ast.UnaryExpression
Accepts the left node to this operator
acceptLeftNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.BinaryExpression
 
acceptLeftNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.LogicalExpression
 
acceptRightNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.BinaryExpression
 
acceptRightNode(SimpleNode) - Method in class org.apache.camel.language.simple.ast.LogicalExpression
 
acquire(Endpoint) - Method in class org.apache.camel.impl.engine.ServicePool
Tries to acquire the service with the given key
acquirePollingConsumer(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
Acquires a pooled PollingConsumer which you must release back again after usage using the DefaultConsumerCache.releasePollingConsumer(org.apache.camel.Endpoint, org.apache.camel.PollingConsumer) method.
acquireProducer(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
activate() - Method in class org.apache.camel.processor.interceptor.BreakpointSupport
 
activateAllBreakpoints() - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
adapt(Class<T>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
add(String, Exchange) - Method in class org.apache.camel.impl.engine.DefaultClaimCheckRepository
 
add(Exchange) - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
add(Exchange, String) - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
add(CamelContext, String, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
add(CamelContext, String, Exchange) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
addAdvice(CamelInternalProcessorAdvice<?>) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
addAdvice(CamelInternalProcessorAdvice<?>) - Method in class org.apache.camel.processor.CamelInternalProcessor
Adds an CamelInternalProcessorAdvice advice to the list of advices to execute by this internal processor.
addBlacklistedRoute(String) - Method in class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
addBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
addBreakpoint(Breakpoint) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
addBreakpoint(Breakpoint, Condition...) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
addChild(SimpleNode) - Method in class org.apache.camel.language.simple.ast.CompositeNodes
 
addClassLoader(ClassLoader) - Method in class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
addClassLoader(ClassLoader) - Method in class org.apache.camel.impl.engine.BasePackageScanResolver
 
addComponent(String, Component) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addConditionalBreakpoint(String, String, String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
addEndpoint(String, Endpoint) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addEndpointToRegistry(String, Endpoint) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
Strategy to add the given endpoint to the internal endpoint registry
addErrorHandler(ErrorHandlerFactory, NamedNode) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
addErrorHandler(Processor) - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
 
addErrorHandlerFactoryReference(ErrorHandlerFactory, ErrorHandlerFactory) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
addEvaluator(PerformanceCounterEvaluator<ManagedRouteMBean>) - Method in class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
addEventDrivenProcessor(Processor) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
addEventNotifier(EventNotifier) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
addExceptionPolicy(ExceptionPolicyKey, ExceptionPolicy) - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
 
addFallbackTypeConverter(TypeConverter, boolean) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
addFilter(PackageScanFilter) - Method in class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
addFilter(PackageScanFilter) - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
 
addFilter(SupervisingRouteController.Filter) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
Add a filter used to determine the routes to supervise.
addFilter(PackageScanFilter) - Method in class org.apache.camel.impl.scan.CompositePackageScanFilter
 
addFunction(PropertiesFunction) - Method in class org.apache.camel.component.properties.PropertiesComponent
Registers the PropertiesFunction as a function to this component.
addHalfOpenTimer(Route) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
addIfMatching(PackageScanFilter, String, Set<Class<?>>) - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
Add the class designated by the fully qualified class name provided to the set of resolved classes if and only if it is approved by the Test supplied.
addInterceptStrategy(InterceptStrategy) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addInterceptStrategy(InterceptStrategy) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
addLifecycleStrategy(LifecycleStrategy) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addLocation(PropertiesLocation) - Method in class org.apache.camel.component.properties.PropertiesComponent
 
addLocation(String) - Method in class org.apache.camel.component.properties.PropertiesComponent
 
addLogListener(LogListener) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addMetaData(String, Object) - Method in class org.apache.camel.impl.health.AbstractHealthCheck
 
addMethod(Object, Method, Endpoint, String) - Method in class org.apache.camel.impl.engine.SubscribeMethodProcessor
 
addNewExchangeProcessor(Processor) - Method in class org.apache.camel.processor.WireTapProcessor
 
addParentType(Class<?>) - Method in class org.apache.camel.impl.scan.AssignableToPackageScanFilter
 
addProcessor(AsyncProcessor) - Method in interface org.apache.camel.processor.loadbalancer.LoadBalancer
Adds a new processor to the load balancer
addProcessor(AsyncProcessor) - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
addPropertiesSource(PropertiesSource) - Method in class org.apache.camel.component.properties.PropertiesComponent
 
addProperty(String, Object) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
addRepository(HealthCheckRepository) - Method in class org.apache.camel.impl.health.DefaultHealthCheckRegistry
 
addRestConfiguration(RestConfiguration) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addRoute(Route) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addRoute(String) - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
addRouteEvaluator(String, PerformanceCounterEvaluator<ManagedRouteMBean>) - Method in class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
addRoutePolicyFactory(RoutePolicyFactory) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addRoutes(RoutesBuilder) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addService(Object) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addService(Object, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addService(Object, boolean, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addService(Service) - Method in class org.apache.camel.impl.engine.DefaultRoute
 
addService(Service) - Method in class org.apache.camel.impl.engine.DeferServiceStartupListener
 
addServices(List<Service>) - Method in class org.apache.camel.impl.engine.DefaultRoute
Strategy method to allow derived classes to lazily load services for the route
addServices(List<Service>) - Method in class org.apache.camel.impl.engine.EventDrivenConsumerRoute
Factory method to lazily create the complete list of services required for this route such as adding the processor or consumer
addSingleStepBreakpoint(Breakpoint) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
addSingleStepBreakpoint(Breakpoint, Condition...) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
addSpoolRule(StreamCachingStrategy.SpoolRule) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
addStartupListener(StartupListener) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
addStateChangeListener(BiConsumer<HealthCheck.State, HealthCheck>) - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
addSynchronization(Synchronization) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
addText(String) - Method in class org.apache.camel.language.simple.ast.LiteralExpression
 
addText(String) - Method in interface org.apache.camel.language.simple.ast.LiteralNode
Adds the given text to this model.
addToClassMap(String, DefaultFactoryFinder.ClassSupplier) - Method in class org.apache.camel.impl.engine.DefaultFactoryFinder
 
addTypeConverter(Class<?>, Class<?>, TypeConverter) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
addTypeConverters(TypeConverters) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
after(Exchange, StopWatch) - Method in class org.apache.camel.processor.CamelInternalProcessor.BacklogDebuggerAdvice
 
after(Exchange, Object) - Method in class org.apache.camel.processor.CamelInternalProcessor.BacklogTracerAdvice
 
after(Exchange, StopWatch) - Method in class org.apache.camel.processor.CamelInternalProcessor.DebuggerAdvice
 
after(Exchange, Object) - Method in class org.apache.camel.processor.CamelInternalProcessor.DelayerAdvice
 
after(Exchange, MessageHistory) - Method in class org.apache.camel.processor.CamelInternalProcessor.MessageHistoryAdvice
 
after(Exchange, Object) - Method in class org.apache.camel.processor.CamelInternalProcessor.RouteInflightRepositoryAdvice
 
after(Exchange, Object) - Method in class org.apache.camel.processor.CamelInternalProcessor.RouteLifecycleAdvice
 
after(Exchange, Object) - Method in class org.apache.camel.processor.CamelInternalProcessor.RoutePolicyAdvice
 
after(Exchange, StreamCache) - Method in class org.apache.camel.processor.CamelInternalProcessor.StreamCachingAdvice
 
after(Exchange, Object) - Method in class org.apache.camel.processor.CamelInternalProcessor.TracingAdvice
 
after(Exchange, UnitOfWork) - Method in class org.apache.camel.processor.CamelInternalProcessor.UnitOfWorkProcessorAdvice
 
after(Exchange, Object) - Method in class org.apache.camel.processor.ContractAdvice
 
after(Exchange, Map<String, Object>) - Method in class org.apache.camel.processor.RestBindingAdvice
 
after(String, String) - Static method in class org.apache.camel.runtimecatalog.impl.CatalogHelper
Returns the string after the given token
afterProcess(Processor, Exchange, AsyncCallback, boolean) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
afterProcess(Processor, Exchange, AsyncCallback, boolean) - Method in class org.apache.camel.impl.engine.MDCUnitOfWork
 
afterProcess(Exchange, Processor, NamedNode, long) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
afterProcess(Exchange, Processor, NamedNode, long) - Method in class org.apache.camel.processor.interceptor.BreakpointSupport
 
afterProcess(Exchange, Processor, NamedNode, long) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
afterRoute(Exchange, Route) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
afterSend(ProcessorExchangePair, StopWatch) - Method in class org.apache.camel.processor.MulticastProcessor
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AbstractListAggregationStrategy
This method will aggregate the old and new exchange and return the result.
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.GroupedExchangeAggregationStrategy
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.GroupedMessageAggregationStrategy
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
aggregate(Exchange, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategy
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
aggregate(Exchange, Exchange) - Method in class org.apache.camel.processor.ClaimCheckAggregationStrategy
 
aggregate() - Method in class org.apache.camel.processor.MulticastProcessor.MulticastState
 
AGGREGATE_OPTIMISTIC_LOCKING_EXECUTOR - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
AGGREGATE_TIMEOUT_CHECKER - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
AggregateController - Interface in org.apache.camel.processor.aggregate
A controller which allows controlling a AggregateProcessor from an external source, such as Java API or JMX.
AggregateProcessor - Class in org.apache.camel.processor.aggregate
An implementation of the Aggregator pattern where a batch of messages are processed (up to a maximum amount or until some timeout is reached) and messages for the same correlation key are combined together using some kind of AggregationStrategy (by default the latest message is used) to compress many message exchanges into a smaller number of exchanges.
AggregateProcessor(CamelContext, AsyncProcessor, Expression, AggregationStrategy, ExecutorService, boolean) - Constructor for class org.apache.camel.processor.aggregate.AggregateProcessor
 
AggregateProcessorStatistics - Interface in org.apache.camel.processor.aggregate
Various statistics of the aggregator
AggregationStrategyBeanAdapter - Class in org.apache.camel.processor.aggregate
An AggregationStrategy that adapts to a POJO.
AggregationStrategyBeanAdapter(Object) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
Creates this adapter.
AggregationStrategyBeanAdapter(Class<?>) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
Creates this adapter.
AggregationStrategyBeanAdapter(Object, String) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
Creates this adapter.
AggregationStrategyBeanAdapter(Class<?>, String) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
Creates this adapter.
AggregationStrategyBeanInfo - Class in org.apache.camel.processor.aggregate
Class information about the POJO method to call when using the AggregationStrategyBeanAdapter.
AggregationStrategyBeanInfo(Class<?>, Method) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyBeanInfo
 
AggregationStrategyMethodInfo - Class in org.apache.camel.processor.aggregate
Method information about the POJO method to call when using the AggregationStrategyBeanAdapter.
AggregationStrategyMethodInfo(Method, List<AggregationStrategyParameterInfo>, List<AggregationStrategyParameterInfo>) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyMethodInfo
 
AggregationStrategyParameterInfo - Class in org.apache.camel.processor.aggregate
Parameter information to be used for method invocation.
AggregationStrategyParameterInfo(int, Class<?>, Expression) - Constructor for class org.apache.camel.processor.aggregate.AggregationStrategyParameterInfo
 
allowEscape - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
allowNull() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
allowNull() - Method in class org.apache.camel.impl.converter.InstanceMethodFallbackTypeConverter
 
allowNull() - Method in class org.apache.camel.impl.converter.InstanceMethodTypeConverter
 
allowNull() - Method in class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
 
allowNull() - Method in class org.apache.camel.impl.converter.StaticMethodTypeConverter
 
allowOptimisedComponents - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
allowRedeliveryWhileStopping - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
allowRedeliveryWhileStopping(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Controls whether to allow redelivery while stopping/shutting down a route that uses error handling.
AnnotatedWithAnyPackageScanFilter - Class in org.apache.camel.impl.scan
Package scan filter for testing if a given class is annotated with any of the annotations.
AnnotatedWithAnyPackageScanFilter(Set<Class<? extends Annotation>>) - Constructor for class org.apache.camel.impl.scan.AnnotatedWithAnyPackageScanFilter
 
AnnotatedWithAnyPackageScanFilter(Set<Class<? extends Annotation>>, boolean) - Constructor for class org.apache.camel.impl.scan.AnnotatedWithAnyPackageScanFilter
 
AnnotatedWithPackageScanFilter - Class in org.apache.camel.impl.scan
Package scan filter for testing if a given class is annotated with a certain annotation.
AnnotatedWithPackageScanFilter(Class<? extends Annotation>) - Constructor for class org.apache.camel.impl.scan.AnnotatedWithPackageScanFilter
 
AnnotatedWithPackageScanFilter(Class<? extends Annotation>, boolean) - Constructor for class org.apache.camel.impl.scan.AnnotatedWithPackageScanFilter
 
AnnotationTypeConverterLoader - Class in org.apache.camel.impl.converter
A class which will auto-discover Converter objects and methods to pre-load the TypeConverterRegistry of converters on startup.
AnnotationTypeConverterLoader(PackageScanClassResolver) - Constructor for class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
apply(String) - Method in class org.apache.camel.component.properties.EnvPropertiesFunction
 
apply(String) - Method in interface org.apache.camel.component.properties.PropertiesFunction
Applies the function
apply(String) - Method in class org.apache.camel.component.properties.ServiceHostPropertiesFunction
 
apply(String) - Method in class org.apache.camel.component.properties.ServicePortPropertiesFunction
 
apply(String) - Method in class org.apache.camel.component.properties.ServicePropertiesFunction
 
apply(String) - Method in class org.apache.camel.component.properties.SysPropertiesFunction
 
apply(Route) - Method in class org.apache.camel.impl.engine.SupervisingRouteControllerFilters.BlackList
 
ArrayTypeConverter - Class in org.apache.camel.impl.converter
A type converter which is used to convert to and from array types particularly for derived types of array component types and dealing with primitive array types.
ArrayTypeConverter() - Constructor for class org.apache.camel.impl.converter.ArrayTypeConverter
 
asEndpointUri(String, Map<String, String>, boolean) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
asEndpointUriXml(String, Map<String, String>, boolean) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
asOperator(String) - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType
 
asOperator(String) - Static method in enum org.apache.camel.language.simple.types.LogicalOperatorType
 
asOperator(String) - Static method in enum org.apache.camel.language.simple.types.UnaryOperatorType
 
AssignableToPackageScanFilter - Class in org.apache.camel.impl.scan
Package scan filter for testing if a given class is assignable to another class.
AssignableToPackageScanFilter() - Constructor for class org.apache.camel.impl.scan.AssignableToPackageScanFilter
 
AssignableToPackageScanFilter(Class<?>) - Constructor for class org.apache.camel.impl.scan.AssignableToPackageScanFilter
 
AssignableToPackageScanFilter(Set<Class<?>>) - Constructor for class org.apache.camel.impl.scan.AssignableToPackageScanFilter
 
asyncCallback(String, Exchange, Synchronization) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncCallback(String, Processor, Synchronization) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncCallback(Endpoint, Exchange, Synchronization) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncCallback(Endpoint, Processor, Synchronization) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncCallback(Endpoint, ExchangePattern, Object, Synchronization) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncCallbackRequestBody(String, Object, Synchronization) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncCallbackRequestBody(Endpoint, Object, Synchronization) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncCallbackSendBody(String, Object, Synchronization) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncCallbackSendBody(Endpoint, Object, Synchronization) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncDelayedRedelivery - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
asyncDelayedRedelivery() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Allow asynchronous delayed redelivery.
asyncDispatchExchange(Endpoint, AsyncProducer, Processor, Exchange, AsyncCallback) - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
AsyncProcessorTypeConverter - Class in org.apache.camel.impl.converter
A simple converter that can convert any Processor to an AsyncProcessor.
AsyncProcessorTypeConverter() - Constructor for class org.apache.camel.impl.converter.AsyncProcessorTypeConverter
 
asyncRequest() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
asyncRequest(Class<T>) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
asyncRequest(Endpoint, Processor, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBody(String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBody(String, Object, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBody(Endpoint, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBody(Endpoint, Object, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBody(Endpoint, Processor, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBody(Endpoint, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBody(Endpoint, Processor, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBodyAndHeader(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBodyAndHeaders(String, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncRequestBodyAndHeaders(Endpoint, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncSend() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
asyncSend(Endpoint, ExchangePattern, Processor, Processor, CompletableFuture<Exchange>) - Method in class org.apache.camel.impl.engine.DefaultProducerCache
Deprecated.
asyncSend(String, Exchange) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncSend(String, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncSend(Endpoint, Exchange) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncSend(Endpoint, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncSend(Endpoint, ExchangePattern, Processor, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncSendBody(String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncSendBody(Endpoint, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
asyncSendExchange(Endpoint, ExchangePattern, Processor, Processor, Exchange, CompletableFuture<Exchange>) - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
asyncSendExchange(Endpoint, ExchangePattern, Processor, Processor, Exchange) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
attemptCounter - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
await(Exchange, CountDownLatch) - Method in class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
 
awaitManager - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
awaitTermination(ExecutorService, long) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 

B

BacklogDebugger - Class in org.apache.camel.processor.interceptor
A Debugger that has easy debugging functionality which can be used from JMX with ManagedBacklogDebuggerMBean.
BacklogDebuggerAdvice(BacklogDebugger, Processor, NamedNode) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.BacklogDebuggerAdvice
 
BacklogTracer - Class in org.apache.camel.processor.interceptor
A tracer used for message tracing, storing a copy of the message details in a backlog.
BacklogTracerAdvice(BacklogTracer, NamedNode, NamedRoute, boolean) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.BacklogTracerAdvice
 
backOffMultiplier - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
backOffMultiplier(double) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Enables exponential backoff and sets the multiplier used to increase the delay between redeliveries
BaseExecutorServiceManager - Class in org.apache.camel.impl.engine
Base ExecutorServiceManager which can be used for implementations
BaseExecutorServiceManager(CamelContext) - Constructor for class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
BasePackageScanResolver - Class in org.apache.camel.impl.engine
Base class for package scan resolvers.
BasePackageScanResolver() - Constructor for class org.apache.camel.impl.engine.BasePackageScanResolver
 
BaseRouteService - Class in org.apache.camel.impl.engine
Represents the runtime objects for a given route so that it can be stopped independently of other routes
BaseRouteService(Route) - Constructor for class org.apache.camel.impl.engine.BaseRouteService
 
BaseSimpleNode - Class in org.apache.camel.language.simple.ast
Base class for SimpleNode nodes.
BaseSimpleNode(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.BaseSimpleNode
 
BaseSimpleParser - Class in org.apache.camel.language.simple
Base class for Simple language parser.
BaseSimpleParser(String, boolean) - Constructor for class org.apache.camel.language.simple.BaseSimpleParser
 
BaseTypeConverterRegistry - Class in org.apache.camel.impl.converter
Base implementation of a type converter registry used for type converters in Camel.
BaseTypeConverterRegistry(CamelContext, PackageScanClassResolver, Injector, FactoryFinder) - Constructor for class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
BaseTypeConverterRegistry.FallbackTypeConverter - Class in org.apache.camel.impl.converter
Represents a fallback type converter
BeanProcessorFactoryResolver - Class in org.apache.camel.impl.engine
Factory resolver to find the BeanProcessorFactory from the classpath in camel-bean.
BeanProcessorFactoryResolver() - Constructor for class org.apache.camel.impl.engine.BeanProcessorFactoryResolver
 
BeanProxyFactoryResolver - Class in org.apache.camel.impl.engine
Factory resolver to find the BeanProxyFactory from the classpath in camel-bean.
BeanProxyFactoryResolver() - Constructor for class org.apache.camel.impl.engine.BeanProxyFactoryResolver
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.BacklogDebuggerAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.BacklogTracerAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.DebuggerAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.DelayerAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.MessageHistoryAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.RouteInflightRepositoryAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.RouteLifecycleAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.RoutePolicyAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.StreamCachingAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.TracingAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.UnitOfWorkProcessorAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.ContractAdvice
 
before(Exchange) - Method in class org.apache.camel.processor.RestBindingAdvice
 
before(String, String) - Static method in class org.apache.camel.runtimecatalog.impl.CatalogHelper
Returns the string before the given token
beforeProcess(Processor, Exchange, AsyncCallback) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
beforeProcess(Processor, Exchange, AsyncCallback) - Method in class org.apache.camel.impl.engine.MDCUnitOfWork
 
beforeProcess(Exchange, Processor, NamedNode) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
beforeProcess(Exchange, Processor, NamedNode) - Method in class org.apache.camel.processor.interceptor.BreakpointSupport
 
beforeProcess(Exchange, Processor, NamedNode) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
beforeRoute(Exchange, Route) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
beforeSend(ProcessorExchangePair) - Method in class org.apache.camel.processor.MulticastProcessor
 
begin() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
beginStep(Exchange, CamelSagaStep) - Method in class org.apache.camel.impl.saga.InMemorySagaCoordinator
 
beginTransactedBy(Object) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
beginTransactedBy(Object) - Method in class org.apache.camel.impl.engine.MDCUnitOfWork
 
between(String, String, String) - Static method in class org.apache.camel.runtimecatalog.impl.CatalogHelper
Returns the string between the given tokens
BinaryExpression - Class in org.apache.camel.language.simple.ast
Represents a binary expression in the AST.
BinaryExpression(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.BinaryExpression
 
binaryOperator() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
BinaryOperatorType - Enum in org.apache.camel.language.simple.types
Types of binary operators supported
BinaryOperatorType.ParameterType - Enum in org.apache.camel.language.simple.types
Parameter types a binary operator supports on the right hand side.
bindDataFormats() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
bindToRegistrySupported() - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
Whether support for the annotation BindToRegistry is supported.
BlackList(String) - Constructor for class org.apache.camel.impl.engine.SupervisingRouteControllerFilters.BlackList
 
BlackList(Collection<String>) - Constructor for class org.apache.camel.impl.engine.SupervisingRouteControllerFilters.BlackList
 
Block - Interface in org.apache.camel.language.simple.ast
A model which is a block, containing other nodes.
BlockEnd - Interface in org.apache.camel.language.simple.ast
Marks an end of a block.
BlockStart - Interface in org.apache.camel.language.simple.ast
Marks a start of a block.
Body() - Constructor for class org.apache.camel.support.dump.MessageDump.Body
 
bodyOgnlExpression(String, String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns the expression for the exchanges inbound message body converted to the given type and invoking methods on the converted body defined in a simple OGNL notation
bodyOgnlExpression(String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns the expression for the exchanges inbound message body invoking methods defined in a simple OGNL notation
booleanValue() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
BreakpointSupport - Class in org.apache.camel.processor.interceptor
A support class for Breakpoint implementations to use as base class.
BreakpointSupport() - Constructor for class org.apache.camel.processor.interceptor.BreakpointSupport
 
browse() - Method in class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
 
browse() - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
browse(String) - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
browse(int, boolean) - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
browse(String, int, boolean) - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
build() - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 

C

cache(Exchange) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
cacheClass(Class<?>) - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
cacheExpression(Expression) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns an expression that caches the evaluation of another expression and returns the cached value, to avoid re-evaluating the expression.
cacheSize - Variable in class org.apache.camel.processor.RoutingSlip
 
cacheSize - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
CachingInjector<T> - Class in org.apache.camel.impl.converter
A caching proxy
CachingInjector(TypeConverterRegistry, Class<T>) - Constructor for class org.apache.camel.impl.converter.CachingInjector
 
calculateDelay(Exchange) - Method in class org.apache.camel.processor.Delayer
 
calculateDelay(Exchange) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
calculateRedeliverDelayUsingPattern(String, int) - Static method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Calculates the delay using the delay pattern
calculateRedeliveryDelay(long, int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Calculates the new redelivery delay based on the last one
call() - Method in class org.apache.camel.impl.health.AbstractHealthCheck
 
call(Map<String, Object>) - Method in class org.apache.camel.impl.health.AbstractHealthCheck
 
call(String) - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
call(String, Map<String, Object>) - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
callback(AsyncCallback) - Method in class org.apache.camel.impl.engine.DefaultReactiveExecutor
 
camelContext - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
camelContext - Variable in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
camelContext - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
camelContext - Variable in class org.apache.camel.processor.RoutingSlip
 
camelContext - Variable in class org.apache.camel.processor.saga.SagaProcessor
 
camelContext(CamelContext) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
camelContext - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
camelContext - Variable in class org.apache.camel.processor.SendProcessor
 
CamelContextJSonSchemaResolver - Class in org.apache.camel.runtimecatalog.impl
Uses runtime CamelContext to resolve the JSon schema files.
CamelContextJSonSchemaResolver(CamelContext) - Constructor for class org.apache.camel.runtimecatalog.impl.CamelContextJSonSchemaResolver
 
camelContextOgnlExpression(String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns the expression for the exchanges camelContext invoking methods defined in a simple OGNL notation
CamelContextResumedEvent - Class in org.apache.camel.impl.event
 
CamelContextResumedEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.CamelContextResumedEvent
 
CamelContextResumeFailureEvent - Class in org.apache.camel.impl.event
 
CamelContextResumeFailureEvent(CamelContext, Throwable) - Constructor for class org.apache.camel.impl.event.CamelContextResumeFailureEvent
 
CamelContextResumingEvent - Class in org.apache.camel.impl.event
 
CamelContextResumingEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.CamelContextResumingEvent
 
CamelContextRoutesStartedEvent - Class in org.apache.camel.impl.event
 
CamelContextRoutesStartedEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.CamelContextRoutesStartedEvent
 
CamelContextRoutesStartingEvent - Class in org.apache.camel.impl.event
 
CamelContextRoutesStartingEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.CamelContextRoutesStartingEvent
 
CamelContextRoutesStoppedEvent - Class in org.apache.camel.impl.event
 
CamelContextRoutesStoppedEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.CamelContextRoutesStoppedEvent
 
CamelContextRoutesStoppingEvent - Class in org.apache.camel.impl.event
 
CamelContextRoutesStoppingEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.CamelContextRoutesStoppingEvent
 
CamelContextStartedEvent - Class in org.apache.camel.impl.event
 
CamelContextStartedEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.CamelContextStartedEvent
 
CamelContextStartingEvent - Class in org.apache.camel.impl.event
 
CamelContextStartingEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.CamelContextStartingEvent
 
CamelContextStartupFailureEvent - Class in org.apache.camel.impl.event
 
CamelContextStartupFailureEvent(CamelContext, Throwable) - Constructor for class org.apache.camel.impl.event.CamelContextStartupFailureEvent
 
CamelContextStatDump - Class in org.apache.camel.support.dump
A model of a CamelContext stat dump from ManagedCamelContextMBean.dumpRoutesStatsAsXml(boolean, boolean).
CamelContextStatDump() - Constructor for class org.apache.camel.support.dump.CamelContextStatDump
 
CamelContextStopFailureEvent - Class in org.apache.camel.impl.event
 
CamelContextStopFailureEvent(CamelContext, Throwable) - Constructor for class org.apache.camel.impl.event.CamelContextStopFailureEvent
 
CamelContextStoppedEvent - Class in org.apache.camel.impl.event
 
CamelContextStoppedEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.CamelContextStoppedEvent
 
CamelContextStoppingEvent - Class in org.apache.camel.impl.event
 
CamelContextStoppingEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.CamelContextStoppingEvent
 
CamelContextSuspendedEvent - Class in org.apache.camel.impl.event
 
CamelContextSuspendedEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.CamelContextSuspendedEvent
 
CamelContextSuspendingEvent - Class in org.apache.camel.impl.event
 
CamelContextSuspendingEvent(CamelContext) - Constructor for class org.apache.camel.impl.event.CamelContextSuspendingEvent
 
CamelConverter - Class in org.apache.camel.converter
Some useful converters for Camel APIs such as to convert a Predicate or Expression to a Processor
CamelConverterLoader - Class in org.apache.camel.converter
Source code generated by org.apache.camel:apt
CamelConverterLoader() - Constructor for class org.apache.camel.converter.CamelConverterLoader
 
CamelInternalProcessor - Class in org.apache.camel.processor
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 ...
CamelInternalProcessor() - Constructor for class org.apache.camel.processor.CamelInternalProcessor
 
CamelInternalProcessor(Processor) - Constructor for class org.apache.camel.processor.CamelInternalProcessor
 
CamelInternalProcessor.BacklogDebuggerAdvice - Class in org.apache.camel.processor
Advice to execute the BacklogDebugger if enabled.
CamelInternalProcessor.BacklogTracerAdvice - Class in org.apache.camel.processor
Advice to execute the BacklogTracer if enabled.
CamelInternalProcessor.ChildUnitOfWorkProcessorAdvice - Class in org.apache.camel.processor
Advice when an EIP uses the shareUnitOfWork functionality.
CamelInternalProcessor.DebuggerAdvice - Class in org.apache.camel.processor
Advice to execute when using custom debugger.
CamelInternalProcessor.DelayerAdvice - Class in org.apache.camel.processor
Advice for delaying
CamelInternalProcessor.MessageHistoryAdvice - Class in org.apache.camel.processor
Advice when Message History has been enabled.
CamelInternalProcessor.RouteInflightRepositoryAdvice - Class in org.apache.camel.processor
Advice to keep the InflightRepository up to date.
CamelInternalProcessor.RouteLifecycleAdvice - Class in org.apache.camel.processor
Advice to invoke callbacks for before and after routing.
CamelInternalProcessor.RoutePolicyAdvice - Class in org.apache.camel.processor
Advice to execute any RoutePolicy a route may have been configured with.
CamelInternalProcessor.StreamCachingAdvice - Class in org.apache.camel.processor
Advice for StreamCachingStrategy
CamelInternalProcessor.TracingAdvice - Class in org.apache.camel.processor
Advice for tracing
CamelInternalProcessor.UnitOfWorkProcessorAdvice - Class in org.apache.camel.processor
Advice to inject new UnitOfWork to the Exchange if needed, and as well to ensure the UnitOfWork is done and stopped.
CamelPostProcessorHelper - Class in org.apache.camel.impl.engine
A helper class for Camel based injector or post processing hooks which can be reused by both the Spring, Guice and Blueprint support.
CamelPostProcessorHelper() - Constructor for class org.apache.camel.impl.engine.CamelPostProcessorHelper
 
CamelPostProcessorHelper(CamelContext) - Constructor for class org.apache.camel.impl.engine.CamelPostProcessorHelper
 
camelPostProcessorHelper - Variable in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
canPostProcessBean(Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
canPreComplete() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
canSetCamelContext(Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
CatalogHelper - Class in org.apache.camel.runtimecatalog.impl
 
catchClauses - Variable in class org.apache.camel.processor.TryProcessor
 
catches(Exchange, Throwable) - Method in class org.apache.camel.processor.CatchProcessor
Returns with the exception that is caught by this processor.
CatchProcessor - Class in org.apache.camel.processor
A processor which catches exceptions.
CatchProcessor(List<Class<? extends Throwable>>, Processor, Predicate, Predicate) - Constructor for class org.apache.camel.processor.CatchProcessor
 
changeOutput(Processor) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
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.
CHECK_ENABLED - Static variable in class org.apache.camel.impl.health.AbstractHealthCheck
 
CHECK_GROUP - Static variable in class org.apache.camel.impl.health.AbstractHealthCheck
 
CHECK_ID - Static variable in class org.apache.camel.impl.health.AbstractHealthCheck
 
checkException(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
childProcessor(Processor) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
ChildUnitOfWorkProcessorAdvice(RouteContext, UnitOfWork) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.ChildUnitOfWorkProcessorAdvice
 
ChoiceProcessor - Class in org.apache.camel.processor
Implements a Choice structure where one or more predicates are used which if they are true their processors are used, with a default otherwise clause used if none match.
ChoiceProcessor(List<FilterProcessor>, Processor) - Constructor for class org.apache.camel.processor.ChoiceProcessor
 
chooseProcessor(AsyncProcessor[], Exchange) - Method in class org.apache.camel.processor.loadbalancer.QueueLoadBalancer
 
chooseProcessor(AsyncProcessor[], Exchange) - Method in class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
 
chooseProcessor(AsyncProcessor[], Exchange) - Method in class org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer
 
chooseProcessor(AsyncProcessor[], Exchange) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
chooseProcessor(AsyncProcessor[], Exchange) - Method in class org.apache.camel.processor.loadbalancer.WeightedRandomLoadBalancer
 
chooseProcessor(AsyncProcessor[], Exchange) - Method in class org.apache.camel.processor.loadbalancer.WeightedRoundRobinLoadBalancer
 
ClaimCheckAggregationStrategy - Class in org.apache.camel.processor
Default AggregationStrategy used by the ClaimCheckProcessor EIP.
ClaimCheckAggregationStrategy() - Constructor for class org.apache.camel.processor.ClaimCheckAggregationStrategy
 
ClaimCheckProcessor - Class in org.apache.camel.processor
ClaimCheck EIP implementation.
ClaimCheckProcessor() - Constructor for class org.apache.camel.processor.ClaimCheckProcessor
 
ClasspathPropertiesSource - Class in org.apache.camel.component.properties
 
ClasspathPropertiesSource(PropertiesComponent, PropertiesLocation) - Constructor for class org.apache.camel.component.properties.ClasspathPropertiesSource
 
cleanUp() - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
cleanUp() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
Cleanup the cache (purging stale entries)
cleanUp() - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
cleanUp() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
cleanUp() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
cleanUp() - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
cleanUp() - Method in class org.apache.camel.impl.engine.ServicePool
 
clear() - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
clear() - Method in class org.apache.camel.impl.engine.DefaultClaimCheckRepository
 
clear() - Method in class org.apache.camel.impl.engine.DefaultEndpointUtilizationStatistics
 
clear() - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
clear() - Method in class org.apache.camel.impl.engine.MDCUnitOfWork
Clears information put on the MDC by this MDCUnitOfWork
clear() - Method in class org.apache.camel.language.simple.BaseSimpleParser
Clears the parser state, which means it can be used for parsing a new input.
clear() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
Clear the idempotent repository
clear() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
clearAll() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
clearBody() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
clearCache() - Method in class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
clearCache() - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
clearCache() - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
 
clearClosedCorrelationKeysCache() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Clear all the closed correlation keys stored in the cache
clearHeaders() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
closeCircuit(Route) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
ClosedCorrelationKeyException - Exception in org.apache.camel.processor.aggregate
The correlation key has been closed and the Exchange cannot be aggregated.
ClosedCorrelationKeyException(String, Exchange) - Constructor for exception org.apache.camel.processor.aggregate.ClosedCorrelationKeyException
 
ClosedCorrelationKeyException(String, Exchange, Throwable) - Constructor for exception org.apache.camel.processor.aggregate.ClosedCorrelationKeyException
 
collateExpression(String, int) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns an iterator to collate (iterate) the given expression
CollectionConverter - Class in org.apache.camel.converter
Some core java.util Collection based Type Converters
CollectionConverterLoader - Class in org.apache.camel.converter
Source code generated by org.apache.camel:apt
CollectionConverterLoader() - Constructor for class org.apache.camel.converter.CollectionConverterLoader
 
collisionAvoidanceFactor - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
collisionAvoidancePercent(double) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Enables collision avoidance and sets the percentage used
commit() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
commit(Consumer, Endpoint, int) - Method in class org.apache.camel.impl.engine.LimitedPollingConsumerPollStrategy
 
comparator() - Method in class org.apache.camel.processor.resequencer.Sequence
Returns this sequence's comparator.
compare(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
compensate() - Method in class org.apache.camel.impl.saga.InMemorySagaCoordinator
 
complete() - Method in class org.apache.camel.impl.saga.InMemorySagaCoordinator
 
COMPLETED_BY_CONSUMER - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
COMPLETED_BY_FORCE - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
COMPLETED_BY_INTERVAL - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
COMPLETED_BY_PREDICATE - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
COMPLETED_BY_SIZE - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
COMPLETED_BY_STRATEGY - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
COMPLETED_BY_TIMEOUT - Static variable in class org.apache.camel.processor.aggregate.AggregateProcessor
 
completionMode - Variable in class org.apache.camel.processor.saga.SagaProcessor
 
completionMode(SagaCompletionMode) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
componentJSonSchema(String) - Method in class org.apache.camel.runtimecatalog.impl.DefaultRuntimeCamelCatalog
 
CompositeNodes - Class in org.apache.camel.language.simple.ast
A node which contains other nodes.
CompositeNodes(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.CompositeNodes
 
CompositePackageScanFilter - Class in org.apache.camel.impl.scan
CompositePackageScanFilter allows multiple PackageScanFilters to be composed into a single filter.
CompositePackageScanFilter() - Constructor for class org.apache.camel.impl.scan.CompositePackageScanFilter
 
CompositePackageScanFilter(Set<PackageScanFilter>) - Constructor for class org.apache.camel.impl.scan.CompositePackageScanFilter
 
configureExchange(Exchange, ExchangePattern, Endpoint) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
configureExchange(Exchange, ExchangePattern) - Method in class org.apache.camel.processor.SendProcessor
 
configureExchange(Exchange, ExchangePattern) - Method in class org.apache.camel.processor.WireTapProcessor
 
configureProperties(Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
confirm(CamelContext, String) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
constant(Object) - Static method in class org.apache.camel.language.constant.ConstantLanguage
 
ConstantLanguage - Class in org.apache.camel.language.constant
A language for constant expressions.
ConstantLanguage() - Constructor for class org.apache.camel.language.constant.ConstantLanguage
 
consumerInjection(Method, Object, String) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
 
contains(String) - Method in class org.apache.camel.impl.engine.DefaultClaimCheckRepository
 
containsKey(Object) - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
containsSynchronization(Synchronization) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
containsValue(Object) - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
context - Variable in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
ContextHealthCheck - Class in org.apache.camel.impl.health
 
ContextHealthCheck() - Constructor for class org.apache.camel.impl.health.ContextHealthCheck
 
continueProcessing(Exchange, String, Logger) - Static method in class org.apache.camel.processor.PipelineHelper
Should we continue processing the exchange?
continueProcessing(Exchange, AsyncProcessor) - Method in class org.apache.camel.processor.SharedCamelInternalProcessor
Strategy to determine if we should continue processing the Exchange.
continueRouting(Iterator<AsyncProcessor>, Exchange) - Method in class org.apache.camel.processor.Pipeline
 
continueRouting(Iterator<Processor>, Exchange) - Method in class org.apache.camel.processor.TryProcessor
 
ContractAdvice - Class in org.apache.camel.processor
A CamelInternalProcessorAdvice which applies Transformer and Validator according to the data type Contract.
ContractAdvice(Contract) - Constructor for class org.apache.camel.processor.ContractAdvice
 
convertBeanToEndpoint(String, Object) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
Strategy method for attempting to convert the bean from a Registry to an endpoint using some kind of transformation or wrapper
ConvertBodyProcessor - Class in org.apache.camel.processor
A processor which converts the payload of the input message to be of the given type

If the conversion fails an InvalidPayloadException is thrown.

ConvertBodyProcessor(Class<?>) - Constructor for class org.apache.camel.processor.ConvertBodyProcessor
 
ConvertBodyProcessor(Class<?>, String) - Constructor for class org.apache.camel.processor.ConvertBodyProcessor
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.ArrayTypeConverter
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.AsyncProcessorTypeConverter
 
convertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.EnumTypeConverter
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.FutureTypeConverter
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.InstanceMethodFallbackTypeConverter
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.InstanceMethodTypeConverter
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.StaticMethodTypeConverter
 
convertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.ToStringTypeConverter
 
copy() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
copyExchangeStrategy(Processor, Exchange) - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
Strategy method to copy the exchange before sending to another endpoint.
countDown(Exchange, CountDownLatch) - Method in class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
 
counter - Variable in class org.apache.camel.processor.SendProcessor
 
covertToByteBuffer(InputStream) - Static method in class org.apache.camel.converter.IOConverter
 
create(CamelContext, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategyFactory
 
createAggregateExecutorService(String) - Method in class org.apache.camel.processor.MulticastProcessor
Strategy to create the thread pool for the aggregator background task which waits for and aggregates completed tasks when running in parallel mode.
createAggregationStrategy() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
createAsyncProcessorAwaitManager() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createAsyncProducer() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
createBeanIntrospection() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createBeanPostProcessor() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createBeanProcessorFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createBeanProxyFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createBodyAndHeaderProcessor(Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
createBodyAndHeaders(Object, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
createBodyAndPropertyProcessor(Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
createCamelContextNameStrategy() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createCamelContextResumedEvent(CamelContext) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextResumeFailureEvent(CamelContext, Throwable) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextResumingEvent(CamelContext) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextRoutesStartedEvent(CamelContext) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextRoutesStartingEvent(CamelContext) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextRoutesStoppedEvent(CamelContext) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextRoutesStoppingEvent(CamelContext) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextStartedEvent(CamelContext) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextStartingEvent(CamelContext) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextStartupFailureEvent(CamelContext, Throwable) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextStopFailureEvent(CamelContext, Throwable) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextStoppedEvent(CamelContext) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextStoppingEvent(CamelContext) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextSuspendedEvent(CamelContext) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createCamelContextSuspendingEvent(CamelContext) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createChildProcessor(RouteContext, NamedNode, boolean) - Method in class org.apache.camel.impl.engine.DefaultProcessorFactory
 
createChildProcessor(RouteContext, NamedNode, boolean) - Method in class org.apache.camel.impl.engine.TypedProcessorFactory
 
createChildUnitOfWork(Exchange) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
createClassResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createCompletionFunction(Synchronization) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
createComponentResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createConsumer(Processor) - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
createConsumerTemplate() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createConsumerTemplate(int) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createConvertBodyProcessor(Class<?>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
createDataFormat(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createDataFormat(String, CamelContext) - Method in class org.apache.camel.impl.engine.DefaultDataFormatResolver
 
createDataFormatResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createDebugger(CamelContext) - Static method in class org.apache.camel.processor.interceptor.BacklogDebugger
Creates a new backlog debugger.
createDefaultExceptionPolicyStrategy() - Static method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
Creates the default exception policy strategy to use.
createDynamicRouter(CamelContext, DynamicRouter) - Method in class org.apache.camel.impl.engine.DefaultAnnotationBasedProcessorFactory
 
createEndpoint(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
A pluggable strategy to allow an endpoint to be created without requiring a component to be its factory, such as for looking up the URI inside some Registry
createEndpointRegistry(Map<EndpointKey, Endpoint>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createErrorHandler(RouteContext, Exchange, Processor) - Method in class org.apache.camel.processor.MulticastProcessor
 
createErrorHandler(RouteContext, Exchange, AsyncProcessor, Endpoint) - Method in class org.apache.camel.processor.RoutingSlip
 
createErrorHandlerExecutorService() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createExceptionIterable(Throwable) - Method in class org.apache.camel.processor.errorhandler.DefaultExceptionPolicyStrategy
Strategy method creating the iterator to walk the exception in the order Camel should use for find the ExceptionPolicyKey should be used.
createExchange() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
createExchange(ExchangePattern) - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
createExchangeCompletedEvent(Exchange) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createExchangeCreatedEvent(Exchange) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createExchangeFailedEvent(Exchange) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createExchangeFailureHandledEvent(Exchange, Processor, boolean, String) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createExchangeFailureHandlingEvent(Exchange, Processor, boolean, String) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createExchangeRedeliveryEvent(Exchange, int) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createExchangeSendingEvent(Exchange, Endpoint) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createExchangeSentEvent(Exchange, Endpoint, long) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createExecutorServiceManager() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createExpression(String) - Method in class org.apache.camel.language.constant.ConstantLanguage
 
createExpression(String) - Method in class org.apache.camel.language.header.HeaderLanguage
 
createExpression(String) - Method in class org.apache.camel.language.property.ExchangePropertyLanguage
 
createExpression(String) - Method in class org.apache.camel.language.ref.RefLanguage
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.BinaryExpression
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.CompositeNodes
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.DoubleQuoteEnd
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.DoubleQuoteStart
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.LiteralExpression
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.LogicalExpression
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.NullExpression
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.SimpleFunctionEnd
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.SimpleFunctionExpression
Creates a Camel Expression based on this model.
createExpression(String, boolean) - Method in class org.apache.camel.language.simple.ast.SimpleFunctionExpression
Creates a Camel Expression based on this model.
createExpression(String) - Method in class org.apache.camel.language.simple.ast.SimpleFunctionStart
 
createExpression(String) - Method in interface org.apache.camel.language.simple.ast.SimpleNode
Creates a Camel Expression based on this model.
createExpression(String) - Method in class org.apache.camel.language.simple.ast.SingleQuoteEnd
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.SingleQuoteStart
 
createExpression(String) - Method in class org.apache.camel.language.simple.ast.UnaryExpression
 
createExpression(String) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
createExpression(String, Class<?>) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
createExpression() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
Creates a tokenize expression.
createExpression(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
createFactoryFinder(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createFactoryFinderResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createFluentProducerTemplate() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createFluentProducerTemplate(int) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createHeadersMapFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createId(NamedNode) - Method in class org.apache.camel.impl.engine.DefaultNodeIdFactory
 
createInflightRepository() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createInjectionConsumerTemplate(String, String, String) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
Factory method to create a ConsumerTemplate to be injected into a POJO
createInjectionFluentProducerTemplate(String, String, String, Object) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
Factory method to create a FluentProducerTemplate to be injected into a POJO
createInjectionPollingConsumer(Endpoint, Object, String) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
Factory method to create a started PollingConsumer to be injected into a POJO
createInjectionProducer(Endpoint, Object, String) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
A Factory method to create a started Producer to be injected into a POJO
createInjectionProducerTemplate(String, String, String, Object) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
Factory method to create a ProducerTemplate to be injected into a POJO
createInjector() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createInstance(Class<T>) - Method in class org.apache.camel.impl.converter.CachingInjector
 
createLanguageResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createLifecycle(CamelContext) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategyFactory
 
createLogger() - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
createManagementNameStrategy() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createManagementObjectNameStrategy(String) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
createManagementObjectStrategy() - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
createMessageHistoryFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createMethodInfo() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanInfo
 
createModelJAXBContextFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createNodeIdFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createPackageScanClassResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createPackageScanResourceResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createPollingConsumer() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
createPollingConsumerServicePool() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createPredicate(String) - Method in class org.apache.camel.language.constant.ConstantLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.header.HeaderLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.property.ExchangePropertyLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.ref.RefLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.simple.SimpleLanguage
 
createPredicate(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
createProcessor(RouteContext, NamedNode) - Method in class org.apache.camel.impl.engine.DefaultProcessorFactory
 
createProcessor(CamelContext, String, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultProcessorFactory
 
createProcessor(RouteContext, NamedNode) - Method in class org.apache.camel.impl.engine.TypedProcessorFactory
 
createProcessor(CamelContext, String, Map<String, Object>) - Method in class org.apache.camel.impl.engine.TypedProcessorFactory
 
createProcessorExchangePair(int, Processor, Exchange, RouteContext) - Method in class org.apache.camel.processor.MulticastProcessor
Creates the ProcessorExchangePair which holds the processor and exchange to be send out.
createProcessorExchangePair(int, Endpoint, Producer, Exchange, ExchangePattern) - Method in class org.apache.camel.processor.RecipientListProcessor
This logic is similar to MulticastProcessor but we have to return a RecipientProcessorExchangePair instead
createProcessorExchangePairs(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
 
createProcessorExchangePairs(Exchange) - Method in class org.apache.camel.processor.RecipientListProcessor
 
createProcessorExchangePairs(Exchange) - Method in class org.apache.camel.processor.Splitter
 
createProcessorFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createProducer(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultDeferServiceFactory
 
createProducer() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
createProducerServicePool() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createProducerTemplate() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createProducerTemplate(int) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createPropertiesComponent() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createProxyInstantiationRuntimeException(Class<?>, Endpoint, Exception) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
 
createQueryString(Map<String, String>, String, boolean) - Static method in class org.apache.camel.runtimecatalog.impl.URISupport
Assembles a query from the given map.
createReactiveExecutor() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createRecipientList(CamelContext, RecipientList) - Method in class org.apache.camel.impl.engine.DefaultAnnotationBasedProcessorFactory
 
createRedeliveryPolicy(CamelContext, RedeliveryPolicy) - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
Allows an exception handler to create a new redelivery policy for this exception type
createRegistry() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createResourceExchange(Exchange, ExchangePattern) - Method in class org.apache.camel.processor.Enricher
Creates a new DefaultExchange instance from the given exchange.
createRestRegistry() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createRestRegistryFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createRouteAddedEvent(Route) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createRouteController() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createRoutePolicy(CamelContext, String, NamedNode) - Method in class org.apache.camel.impl.engine.DurationRoutePolicyFactory
 
createRouteRemovedEvent(Route) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createRouteStartedEvent(Route) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createRouteStoppedEvent(Route) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createRoutingSlip(CamelContext, RoutingSlip) - Method in class org.apache.camel.impl.engine.DefaultAnnotationBasedProcessorFactory
 
createRoutingSlipIterator(Exchange, Expression) - Method in class org.apache.camel.processor.DynamicRouter
 
createRoutingSlipIterator(Exchange, Expression) - Method in class org.apache.camel.processor.RoutingSlip
Creates the route slip iterator to be used.
createServiceStartupFailureEvent(CamelContext, Object, Throwable) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createServiceStopFailureEvent(CamelContext, Object, Throwable) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createSet(Expression, boolean, boolean) - Static method in class org.apache.camel.processor.Resequencer
 
createSet(Comparator<? super Exchange>, boolean, boolean) - Static method in class org.apache.camel.processor.Resequencer
 
createSetBodyProcessor(Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
createShutdownStrategy() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createStepCompletedEvent(Exchange, String) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createStepFailedEvent(Exchange, String) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createStepStartedEvent(Exchange, String) - Method in class org.apache.camel.impl.event.DefaultEventFactory
 
createStreamCachingStrategy() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createThreadFactory(String, boolean) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
createTracer() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createTracer(CamelContext) - Static method in class org.apache.camel.processor.interceptor.BacklogTracer
Creates a new backlog tracer.
createTransformerRegistry() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createTypeConversionException(Exchange, Class<?>, Object, Throwable) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
createTypeConverter() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createTypeConverterRegistry() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createUnitOfWork(Exchange) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWorkFactory
 
createUnitOfWork(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.ChildUnitOfWorkProcessorAdvice
 
createUnitOfWork(Exchange) - Method in class org.apache.camel.processor.CamelInternalProcessor.UnitOfWorkProcessorAdvice
 
createUnitOfWorkFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createUnitOfWorkProcessor(RouteContext, Processor, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Strategy to create the unit of work to be used for the sub route
createUuidGenerator() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
createValidatorRegistry() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
currentSystemTime() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
customExchangeFormatter - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
customResolveManagementName(String, String) - Method in class org.apache.camel.impl.engine.DefaultManagementNameStrategy
Strategy to do any custom resolution of the name
customResolveManagementName(String) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
customResourceLocator(URL) - Method in class org.apache.camel.impl.engine.BasePackageScanResolver
 

D

DATAFORMAT_RESOURCE_PATH - Static variable in class org.apache.camel.impl.engine.DefaultDataFormatResolver
 
dataFormatJSonSchema(String) - Method in class org.apache.camel.runtimecatalog.impl.DefaultRuntimeCamelCatalog
 
DataFormatTransformer - Class in org.apache.camel.impl.transformer
A Transformer implementation which leverages DataFormat to perform transformation.
DataFormatTransformer(CamelContext) - Constructor for class org.apache.camel.impl.transformer.DataFormatTransformer
 
dateExpression(String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
dateExpression(String, String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
dateExpression(String, String, String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
DateTimeConverter - Class in org.apache.camel.converter
Date and time related converters.
DateTimeConverterLoader - Class in org.apache.camel.converter
Source code generated by org.apache.camel:apt
DateTimeConverterLoader() - Constructor for class org.apache.camel.converter.DateTimeConverterLoader
 
deadLetter - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
DeadLetterChannel - Class in org.apache.camel.processor.errorhandler
Implements a Dead Letter Channel after attempting to redeliver the message using the RedeliveryPolicy
DeadLetterChannel(CamelContext, Processor, CamelLogger, Processor, RedeliveryPolicy, ExceptionPolicyStrategy, Processor, String, boolean, boolean, boolean, Predicate, ScheduledExecutorService, Processor, Processor) - Constructor for class org.apache.camel.processor.errorhandler.DeadLetterChannel
Creates the dead letter channel.
deadLetterHandleNewException - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
deadLetterUri - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
DebuggerAdvice(Debugger, Processor, NamedNode) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.DebuggerAdvice
 
decrement() - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
 
decrementSum() - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
DEFAULT_BATCH_SIZE - Static variable in class org.apache.camel.processor.Resequencer
 
DEFAULT_BATCH_TIMEOUT - Static variable in class org.apache.camel.processor.Resequencer
 
DEFAULT_MAX_RETRY_ATTEMPTS - Static variable in class org.apache.camel.impl.saga.InMemorySagaService
 
DEFAULT_RETRY_DELAY_IN_MILLISECONDS - Static variable in class org.apache.camel.impl.saga.InMemorySagaService
 
DefaultAggregateController - Class in org.apache.camel.processor.aggregate
A default AggregateController that offers Java and JMX API.
DefaultAggregateController() - Constructor for class org.apache.camel.processor.aggregate.DefaultAggregateController
 
DefaultAnnotationBasedProcessorFactory - Class in org.apache.camel.impl.engine
 
DefaultAnnotationBasedProcessorFactory() - Constructor for class org.apache.camel.impl.engine.DefaultAnnotationBasedProcessorFactory
 
DefaultAsyncProcessorAwaitManager - Class in org.apache.camel.impl.engine
 
DefaultAsyncProcessorAwaitManager() - Constructor for class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
 
DefaultBacklogTracerEventMessage - Class in org.apache.camel.processor.interceptor
An event message holding the traced message by the BacklogTracer.
DefaultBacklogTracerEventMessage(long, Date, String, String, String, String) - Constructor for class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
DefaultBeanIntrospection - Class in org.apache.camel.impl.engine
 
DefaultBeanIntrospection() - Constructor for class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
DefaultCamelBeanPostProcessor - Class in org.apache.camel.impl.engine
A bean post processor which implements the Bean Integration features in Camel.
DefaultCamelBeanPostProcessor() - Constructor for class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
DefaultCamelBeanPostProcessor(CamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
DefaultCamelContextNameStrategy - Class in org.apache.camel.impl.engine
A default name strategy which auto assigns a name using a prefix-counter pattern.
DefaultCamelContextNameStrategy() - Constructor for class org.apache.camel.impl.engine.DefaultCamelContextNameStrategy
 
DefaultCamelContextNameStrategy(String) - Constructor for class org.apache.camel.impl.engine.DefaultCamelContextNameStrategy
 
DefaultChannel - Class in org.apache.camel.processor.channel
DefaultChannel is the default Channel.
DefaultChannel() - Constructor for class org.apache.camel.processor.channel.DefaultChannel
 
DefaultClaimCheckRepository - Class in org.apache.camel.impl.engine
The default ClaimCheckRepository implementation that is an in-memory storage.
DefaultClaimCheckRepository() - Constructor for class org.apache.camel.impl.engine.DefaultClaimCheckRepository
 
DefaultClassResolver - Class in org.apache.camel.impl.engine
Default class resolver that uses regular class loader to load classes.
DefaultClassResolver() - Constructor for class org.apache.camel.impl.engine.DefaultClassResolver
 
DefaultClassResolver(CamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultClassResolver
 
defaultCompletionMode() - Static method in enum org.apache.camel.processor.saga.SagaCompletionMode
 
DefaultComponentResolver - Class in org.apache.camel.impl.engine
The default implementation of ComponentResolver which tries to find components by using the URI scheme prefix and searching for a file of the URI scheme name in the META-INF/services/org/apache/camel/component/ directory on the classpath.
DefaultComponentResolver() - Constructor for class org.apache.camel.impl.engine.DefaultComponentResolver
 
DefaultConsumerCache - Class in org.apache.camel.impl.engine
Cache containing created Consumer.
DefaultConsumerCache(Object, CamelContext, int) - Constructor for class org.apache.camel.impl.engine.DefaultConsumerCache
 
DefaultConsumerTemplate - Class in org.apache.camel.impl.engine
Default implementation of ConsumerTemplate.
DefaultConsumerTemplate(CamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
DefaultDataFormatResolver - Class in org.apache.camel.impl.engine
Default data format resolver
DefaultDataFormatResolver() - Constructor for class org.apache.camel.impl.engine.DefaultDataFormatResolver
 
DefaultDebugger - Class in org.apache.camel.processor.interceptor
The default implementation of the Debugger.
DefaultDebugger() - Constructor for class org.apache.camel.processor.interceptor.DefaultDebugger
 
DefaultDebugger(CamelContext) - Constructor for class org.apache.camel.processor.interceptor.DefaultDebugger
 
DefaultDeferServiceFactory - Class in org.apache.camel.impl.engine
 
DefaultDeferServiceFactory() - Constructor for class org.apache.camel.impl.engine.DefaultDeferServiceFactory
 
DefaultEndpointRegistry - Class in org.apache.camel.impl.engine
Default implementation of EndpointRegistry
DefaultEndpointRegistry(CamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultEndpointRegistry
 
DefaultEndpointRegistry(CamelContext, Map<EndpointKey, Endpoint>) - Constructor for class org.apache.camel.impl.engine.DefaultEndpointRegistry
 
DefaultEndpointUtilizationStatistics - Class in org.apache.camel.impl.engine
 
DefaultEndpointUtilizationStatistics(int) - Constructor for class org.apache.camel.impl.engine.DefaultEndpointUtilizationStatistics
 
DefaultErrorHandler - Class in org.apache.camel.processor.errorhandler
Default error handler
DefaultErrorHandler(CamelContext, Processor, CamelLogger, Processor, RedeliveryPolicy, ExceptionPolicyStrategy, Predicate, ScheduledExecutorService, Processor, Processor) - Constructor for class org.apache.camel.processor.errorhandler.DefaultErrorHandler
Creates the default error handler.
DefaultEventFactory - Class in org.apache.camel.impl.event
Default implementation of the EventFactory.
DefaultEventFactory() - Constructor for class org.apache.camel.impl.event.DefaultEventFactory
 
DefaultExceptionPolicyStrategy - Class in org.apache.camel.processor.errorhandler
The default strategy used in Camel to resolve the ExceptionPolicyKey that should handle the thrown exception.
DefaultExceptionPolicyStrategy() - Constructor for class org.apache.camel.processor.errorhandler.DefaultExceptionPolicyStrategy
 
DefaultExchangeComparator - Class in org.apache.camel.processor.resequencer
Compares elements of an Exchange sequence by comparing long values returned by this comparator's expression.
DefaultExchangeComparator() - Constructor for class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
DefaultFactoryFinder - Class in org.apache.camel.impl.engine
Default factory finder.
DefaultFactoryFinder(ClassResolver, String) - Constructor for class org.apache.camel.impl.engine.DefaultFactoryFinder
 
DefaultFactoryFinder.ClassSupplier - Interface in org.apache.camel.impl.engine
 
DefaultFactoryFinderResolver - Class in org.apache.camel.impl.engine
Default factory finder.
DefaultFactoryFinderResolver() - Constructor for class org.apache.camel.impl.engine.DefaultFactoryFinderResolver
 
DefaultFluentProducerTemplate - Class in org.apache.camel.impl.engine
 
DefaultFluentProducerTemplate(CamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
DefaultGlobalEndpointConfiguration - Class in org.apache.camel.impl.engine
 
DefaultGlobalEndpointConfiguration() - Constructor for class org.apache.camel.impl.engine.DefaultGlobalEndpointConfiguration
 
DefaultHeadersMapFactory - Class in org.apache.camel.impl.engine
Default HeadersMapFactory which uses the CaseInsensitiveMap.
DefaultHeadersMapFactory() - Constructor for class org.apache.camel.impl.engine.DefaultHeadersMapFactory
 
DefaultHealthCheckRegistry - Class in org.apache.camel.impl.health
 
DefaultHealthCheckRegistry() - Constructor for class org.apache.camel.impl.health.DefaultHealthCheckRegistry
 
DefaultHealthCheckRegistry(CamelContext) - Constructor for class org.apache.camel.impl.health.DefaultHealthCheckRegistry
 
DefaultHealthCheckService - Class in org.apache.camel.impl.health
 
DefaultHealthCheckService() - Constructor for class org.apache.camel.impl.health.DefaultHealthCheckService
 
DefaultHealthCheckService(CamelContext) - Constructor for class org.apache.camel.impl.health.DefaultHealthCheckService
 
DefaultInflightRepository - Class in org.apache.camel.impl.engine
Default InflightRepository.
DefaultInflightRepository() - Constructor for class org.apache.camel.impl.engine.DefaultInflightRepository
 
DefaultInjector - Class in org.apache.camel.impl.engine
A default implementation of Injector which just uses reflection to instantiate new objects using their zero argument constructor, and then performing bean post processing using CamelBeanPostProcessor.
DefaultInjector(CamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultInjector
 
DefaultInterceptSendToEndpoint - Class in org.apache.camel.impl.engine
This is an endpoint when sending to it, is intercepted and is routed in a detour (before and optionally after).
DefaultInterceptSendToEndpoint(Endpoint, boolean) - Constructor for class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
Intercepts sending to the given endpoint
DefaultLanguageResolver - Class in org.apache.camel.impl.engine
Default language resolver that looks for language factories in META-INF/services/org/apache/camel/language/ and language resolvers in META-INF/services/org/apache/camel/language/resolver/.
DefaultLanguageResolver() - Constructor for class org.apache.camel.impl.engine.DefaultLanguageResolver
 
defaultManagementName(String) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
DefaultManagementNameStrategy - Class in org.apache.camel.impl.engine
Default implementation of ManagementNameStrategy

This implementation will by default use a name pattern as #name# and in case of a clash, then the pattern will fallback to be using the counter as #name#-#counter#.

DefaultManagementNameStrategy(CamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultManagementNameStrategy
 
DefaultManagementNameStrategy(CamelContext, String, String) - Constructor for class org.apache.camel.impl.engine.DefaultManagementNameStrategy
 
DefaultManagementStrategy - Class in org.apache.camel.impl.engine
A default management strategy that does not manage.
DefaultManagementStrategy() - Constructor for class org.apache.camel.impl.engine.DefaultManagementStrategy
 
DefaultManagementStrategy(CamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultManagementStrategy
 
DefaultManagementStrategy(CamelContext, ManagementAgent) - Constructor for class org.apache.camel.impl.engine.DefaultManagementStrategy
 
DefaultManagementStrategyFactory - Class in org.apache.camel.impl.engine
Factory for creating non JMX ManagementStrategy.
DefaultManagementStrategyFactory() - Constructor for class org.apache.camel.impl.engine.DefaultManagementStrategyFactory
 
DefaultMessageHistoryFactory - Class in org.apache.camel.impl.engine
 
DefaultMessageHistoryFactory() - Constructor for class org.apache.camel.impl.engine.DefaultMessageHistoryFactory
 
DefaultNodeIdFactory - Class in org.apache.camel.impl.engine
Default id factory.
DefaultNodeIdFactory() - Constructor for class org.apache.camel.impl.engine.DefaultNodeIdFactory
 
DefaultPackageScanClassResolver - Class in org.apache.camel.impl.engine
Default implement of PackageScanClassResolver
DefaultPackageScanClassResolver() - Constructor for class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
 
DefaultPackageScanResourceResolver - Class in org.apache.camel.impl.engine
Default implement of PackageScanResourceResolver
DefaultPackageScanResourceResolver() - Constructor for class org.apache.camel.impl.engine.DefaultPackageScanResourceResolver
 
DefaultProcessorFactory - Class in org.apache.camel.impl.engine
Default ProcessorFactory that supports using 3rd party Camel components to implement the EIP Processor.
DefaultProcessorFactory() - Constructor for class org.apache.camel.impl.engine.DefaultProcessorFactory
 
DefaultProducerCache - Class in org.apache.camel.impl.engine
Default implementation of ProducerCache.
DefaultProducerCache(Object, CamelContext, int) - Constructor for class org.apache.camel.impl.engine.DefaultProducerCache
 
DefaultProducerTemplate - Class in org.apache.camel.impl.engine
Template (named like Spring's TransactionTemplate & JmsTemplate et al) for working with Camel and sending Message instances in an Exchange to an Endpoint.
DefaultProducerTemplate(CamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultProducerTemplate
 
DefaultProducerTemplate(CamelContext, ExecutorService) - Constructor for class org.apache.camel.impl.engine.DefaultProducerTemplate
 
DefaultProducerTemplate(CamelContext, Endpoint) - Constructor for class org.apache.camel.impl.engine.DefaultProducerTemplate
 
DefaultPropertiesLookup - Class in org.apache.camel.component.properties
Default PropertiesLookup which lookup properties from a Properties with all existing properties.
DefaultPropertiesLookup(PropertiesComponent) - Constructor for class org.apache.camel.component.properties.DefaultPropertiesLookup
 
DefaultPropertiesParser - Class in org.apache.camel.component.properties
A parser to parse a string which contains property placeholders.
DefaultPropertiesParser() - Constructor for class org.apache.camel.component.properties.DefaultPropertiesParser
 
DefaultPropertiesParser(PropertiesComponent) - Constructor for class org.apache.camel.component.properties.DefaultPropertiesParser
 
DefaultReactiveExecutor - Class in org.apache.camel.impl.engine
Default ReactiveExecutor.
DefaultReactiveExecutor() - Constructor for class org.apache.camel.impl.engine.DefaultReactiveExecutor
 
DefaultRoute - Class in org.apache.camel.impl.engine
Default implementation of Route.
DefaultRoute(RouteContext, Endpoint) - Constructor for class org.apache.camel.impl.engine.DefaultRoute
 
DefaultRoute(RouteContext, Endpoint, Service...) - Constructor for class org.apache.camel.impl.engine.DefaultRoute
 
DefaultRouteContext - Class in org.apache.camel.impl.engine
The context used to activate new routing rules
DefaultRouteContext(CamelContext, NamedNode, String) - Constructor for class org.apache.camel.impl.engine.DefaultRouteContext
 
DefaultRouteController - Class in org.apache.camel.impl.engine
 
DefaultRouteController() - Constructor for class org.apache.camel.impl.engine.DefaultRouteController
 
DefaultRouteController(AbstractCamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultRouteController
 
DefaultRouteError - Class in org.apache.camel.impl.engine
 
DefaultRouteError(RouteError.Phase, Throwable) - Constructor for class org.apache.camel.impl.engine.DefaultRouteError
 
DefaultRouteStartupOrder - Class in org.apache.camel.impl.engine
Default implementation of RouteStartupOrder.
DefaultRouteStartupOrder(int, Route, BaseRouteService) - Constructor for class org.apache.camel.impl.engine.DefaultRouteStartupOrder
 
DefaultRuntimeCamelCatalog - Class in org.apache.camel.runtimecatalog.impl
Default RuntimeCamelCatalog.
DefaultRuntimeCamelCatalog(CamelContext) - Constructor for class org.apache.camel.runtimecatalog.impl.DefaultRuntimeCamelCatalog
Creates the RuntimeCamelCatalog without caching enabled.
DefaultRuntimeCamelCatalog(CamelContext, boolean) - Constructor for class org.apache.camel.runtimecatalog.impl.DefaultRuntimeCamelCatalog
Creates the RuntimeCamelCatalog
DefaultRuntimeEndpointRegistry - Class in org.apache.camel.impl.engine
 
DefaultRuntimeEndpointRegistry() - Constructor for class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
DefaultShutdownStrategy - Class in org.apache.camel.impl.engine
Default ShutdownStrategy which uses graceful shutdown.
DefaultShutdownStrategy() - Constructor for class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
DefaultShutdownStrategy(CamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
DefaultStreamCachingStrategy - Class in org.apache.camel.impl.engine
Default implementation of StreamCachingStrategy
DefaultStreamCachingStrategy() - Constructor for class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
DefaultTracer - Class in org.apache.camel.impl.engine
Default Tracer implementation that will log traced messages to the logger named org.apache.camel.Tracing.
DefaultTracer() - Constructor for class org.apache.camel.impl.engine.DefaultTracer
 
DefaultTransformerRegistry - Class in org.apache.camel.impl.engine
Default implementation of TransformerRegistry.
DefaultTransformerRegistry(CamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultTransformerRegistry
 
DefaultTypeConverter - Class in org.apache.camel.impl.converter
Default implementation of a type converter registry used for type converters in Camel.
DefaultTypeConverter(PackageScanClassResolver, Injector, FactoryFinder, boolean) - Constructor for class org.apache.camel.impl.converter.DefaultTypeConverter
 
DefaultTypeConverter(CamelContext, PackageScanClassResolver, Injector, FactoryFinder, boolean) - Constructor for class org.apache.camel.impl.converter.DefaultTypeConverter
 
DefaultUnitOfWork - Class in org.apache.camel.impl.engine
The default implementation of UnitOfWork
DefaultUnitOfWork(Exchange) - Constructor for class org.apache.camel.impl.engine.DefaultUnitOfWork
 
DefaultUnitOfWork(Exchange, Logger) - Constructor for class org.apache.camel.impl.engine.DefaultUnitOfWork
 
DefaultUnitOfWorkFactory - Class in org.apache.camel.impl.engine
Default UnitOfWorkFactory
DefaultUnitOfWorkFactory() - Constructor for class org.apache.camel.impl.engine.DefaultUnitOfWorkFactory
 
DefaultUuidGenerator - Class in org.apache.camel.impl.engine
Default UuidGenerator optimized for Camel usage.
DefaultUuidGenerator(String) - Constructor for class org.apache.camel.impl.engine.DefaultUuidGenerator
 
DefaultUuidGenerator() - Constructor for class org.apache.camel.impl.engine.DefaultUuidGenerator
 
DefaultValidatorRegistry - Class in org.apache.camel.impl.engine
Default implementation of ValidatorRegistry.
DefaultValidatorRegistry(CamelContext) - Constructor for class org.apache.camel.impl.engine.DefaultValidatorRegistry
 
defensiveCopyExchangeIfNeeded(Exchange) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Performs a defensive copy of the exchange if needed
DeferProducer - Class in org.apache.camel.impl.engine
A Producer that defers being started, until CamelContext has been started, this ensures that the producer is able to adapt to changes that may otherwise occur during starting CamelContext.
DeferProducer(Endpoint) - Constructor for class org.apache.camel.impl.engine.DeferProducer
 
DeferServiceStartupListener - Class in org.apache.camel.impl.engine
A StartupListener that defers starting Services, until as late as possible during the startup process of CamelContext.
DeferServiceStartupListener() - Constructor for class org.apache.camel.impl.engine.DeferServiceStartupListener
 
deferShutdown(ShutdownRunningTask) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
deferShutdown(ShutdownRunningTask) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
deferShutdown(ShutdownRunningTask) - Method in class org.apache.camel.processor.WireTapProcessor
 
deferStartService(Object, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
delay(long, Exchange) - Method in class org.apache.camel.processor.DelayProcessorSupport
Delays the given time before continuing.
Delayer - Class in org.apache.camel.processor
A Delayer which delays processing the exchange until the correct amount of time has elapsed using an expression to determine the delivery time.
Delayer(CamelContext, Processor, Expression, ScheduledExecutorService, boolean) - Constructor for class org.apache.camel.processor.Delayer
 
DelayerAdvice(long) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.DelayerAdvice
 
delayPattern - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
delayPattern(String) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the delay pattern with delay intervals.
DelayProcessorSupport - Class in org.apache.camel.processor
A useful base class for any processor which provides some kind of throttling or delayed processing.
DelayProcessorSupport(CamelContext, Processor) - Constructor for class org.apache.camel.processor.DelayProcessorSupport
 
DelayProcessorSupport(CamelContext, Processor, ScheduledExecutorService, boolean) - Constructor for class org.apache.camel.processor.DelayProcessorSupport
 
delimiter(String) - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategy
Set delimiter used for joining aggregated String
deliver() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Delivers all elements which are currently ready to deliver.
deliverNext() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Attempts to deliver a single element from the head of the resequencer queue (sequence).
deliverToFailureProcessor(Processor, boolean, Exchange) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
All redelivery attempts failed so move the exchange to the dead letter queue
deliverToOnRedeliveryProcessor() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
Gives an optional configured redelivery processor a chance to process before the Exchange will be redelivered.
destination - Variable in class org.apache.camel.processor.SendProcessor
 
destinationExchangePattern - Variable in class org.apache.camel.processor.SendProcessor
 
determineIfRedeliveryIsEnabled(CamelContext) - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
determineIfRedeliveryIsEnabled() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Determines if redelivery is enabled by checking if any of the redelivery policy settings may allow redeliveries.
determineRedeliveryDelay(Exchange, RedeliveryPolicy, long, int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Determines the redelivery delay time by first inspecting the Message header Exchange.REDELIVERY_DELAY and if not present, defaulting to RedeliveryPolicy.calculateRedeliveryDelay(long, int)
disableBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
disableDebugger() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
disableJMX() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
disableRedelivery() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Disables redelivery by setting maximum redeliveries to 0.
DistributionRatio - Class in org.apache.camel.processor.loadbalancer
 
DistributionRatio(int) - Constructor for class org.apache.camel.processor.loadbalancer.DistributionRatio
 
distributionRatioSum - Variable in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
doAddService(T) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
doAddService(T, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
doAddService(T, boolean, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
doAggregate(AtomicReference<Exchange>, Exchange, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Aggregate the Exchange with the current result.
doAggregationComplete(String, List<Exchange>, String, Exchange, Exchange, boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doAggregationRepositoryAdd(CamelContext, String, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doAsyncSendExchange(Endpoint, Processor, Processor, Exchange, CompletableFuture<Exchange>) - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
doCall(HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.impl.health.AbstractHealthCheck
Invoke the health check.
doCall(HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.impl.health.ContextHealthCheck
 
doCall(HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.impl.health.RouteHealthCheck
 
doCompensate() - Method in class org.apache.camel.impl.saga.InMemorySagaCoordinator
 
doComplete() - Method in class org.apache.camel.impl.saga.InMemorySagaCoordinator
 
doConvertTo(Class<?>, Exchange, Object, boolean, boolean) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
doConvertTo(Class<?>, Exchange, Object, boolean) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
doConvertTo(Class<T>, Exchange, Object) - Static method in class org.apache.camel.impl.converter.EnumTypeConverter
 
doCreateChildProcessor(RouteContext, T, boolean) - Method in class org.apache.camel.impl.engine.TypedProcessorFactory
 
doCreateProcessor(RouteContext, T) - Method in class org.apache.camel.impl.engine.TypedProcessorFactory
 
doDelay(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
doDone(Exchange, Exchange, Iterable<ProcessorExchangePair>, AsyncCallback, boolean, boolean) - Method in class org.apache.camel.processor.MulticastProcessor
Common work which must be done when we are done multicasting.
doDone(Exchange, boolean) - Method in class org.apache.camel.processor.MulticastProcessor.MulticastState
 
doFinalize(Function<CamelSagaStep, Optional<Endpoint>>, String) - Method in class org.apache.camel.impl.saga.InMemorySagaCoordinator
 
doFind(String, ClassLoader, Set<InputStream>, String) - Method in class org.apache.camel.impl.engine.DefaultPackageScanResourceResolver
 
doGetProcessors() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
doGetProducer(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
doGetRouteScopedServices(List<Service>) - Method in class org.apache.camel.impl.engine.BaseRouteService
Gather all other kind of route scoped services from the given route, except error handler
doInAsyncProducer(Endpoint, Exchange, AsyncCallback, ProducerCache.AsyncProducerCallback) - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
doInit() - Method in class org.apache.camel.component.properties.AbstractLocationPropertiesSource
 
doInit() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
doInit() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
doInit() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
doInit() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
doInOptimisticLock(Exchange, String, AsyncCallback, int) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doLoadJarClassEntries(InputStream, String) - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
Loads all the class entries from the JAR.
doLookup(Class<?>, Class<?>, boolean) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
done(Exchange) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
done(boolean) - Method in class org.apache.camel.impl.engine.EventNotifierCallback
 
done(Exchange) - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer.State
 
done() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
doneUoW(Exchange) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
doParseExpression() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
 
doParsePredicate() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
doProcess(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doProcess(Exchange, String, AsyncCallback) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doProcess(Processor, Exchange) - Static method in class org.apache.camel.processor.OnCompletionProcessor
Processes the exchange by the processors
doProcess(Exchange, AsyncCallback, Iterator<AsyncProcessor>, boolean) - Method in class org.apache.camel.processor.Pipeline
 
doResume() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
doResume() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
doShutdown() - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
doShutdown() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
doShutdown() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
doShutdown(CamelContext, List<RouteStartupOrder>, long, TimeUnit, boolean, boolean, boolean) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
doShutdown() - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
doShutdown() - Method in class org.apache.camel.impl.engine.SubscribeMethodProcessor
 
doShutdown() - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
doShutdown() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doShutdown() - Method in class org.apache.camel.processor.channel.DefaultChannel
 
doShutdown() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
doShutdown() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
doShutdown() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
doShutdown() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
doShutdown() - Method in class org.apache.camel.processor.MulticastProcessor
 
doShutdown() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
doShutdown() - Method in class org.apache.camel.processor.PollEnricher
 
doShutdown() - Method in class org.apache.camel.processor.RecipientList
 
doShutdown() - Method in class org.apache.camel.processor.RecipientListProcessor
 
doShutdown() - Method in class org.apache.camel.processor.RoutingSlip
 
doShutdown() - Method in class org.apache.camel.processor.SendProcessor
 
doShutdown() - Method in class org.apache.camel.processor.ThreadsProcessor
 
doShutdown() - Method in class org.apache.camel.processor.Throttler
 
doShutdown() - Method in class org.apache.camel.processor.WireTapProcessor
 
doShutdownRoute(String, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
doStart() - Method in class org.apache.camel.component.properties.AbstractLocationPropertiesSource
 
doStart() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
doStart() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
doStart() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
doStart() - Method in class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
doStart() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
doStart() - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
doStart() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultMessageHistoryFactory
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultPackageScanResourceResolver
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultReactiveExecutor
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
doStart() - Method in class org.apache.camel.impl.engine.DefaultTracer
 
doStart() - Method in class org.apache.camel.impl.engine.DeferProducer
 
doStart() - Method in class org.apache.camel.impl.engine.FileStateRepository
 
doStart() - Method in class org.apache.camel.impl.engine.MemoryStateRepository
 
doStart() - Method in class org.apache.camel.impl.engine.ServicePool
 
doStart() - Method in class org.apache.camel.impl.engine.SubscribeMethodProcessor
 
doStart() - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
doStart() - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
doStart() - Method in class org.apache.camel.impl.saga.InMemorySagaService
 
doStart() - Method in class org.apache.camel.impl.transformer.DataFormatTransformer
 
doStart() - Method in class org.apache.camel.impl.transformer.ProcessorTransformer
 
doStart() - Method in class org.apache.camel.impl.validator.ProcessorValidator
 
doStart() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doStart() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
doStart() - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
doStart() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
doStart() - Method in class org.apache.camel.processor.channel.DefaultChannel
 
doStart() - Method in class org.apache.camel.processor.ChoiceProcessor
 
doStart() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
doStart() - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
doStart() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
doStart() - Method in class org.apache.camel.processor.Enricher
 
doStart() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
doStart() - Method in class org.apache.camel.processor.EventNotifierProducer
 
doStart() - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
doStart() - Method in class org.apache.camel.processor.FilterProcessor
 
doStart() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
doStart() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
doStart() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
doStart() - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
doStart() - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
 
doStart() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
doStart() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerConsumer
 
doStart() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
doStart() - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
doStart() - Method in class org.apache.camel.processor.LogProcessor
 
doStart() - Method in class org.apache.camel.processor.MethodCallProcessor
 
doStart() - Method in class org.apache.camel.processor.MulticastProcessor
 
doStart() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
doStart() - Method in class org.apache.camel.processor.Pipeline
 
doStart() - Method in class org.apache.camel.processor.PollEnricher
 
doStart() - Method in class org.apache.camel.processor.RecipientList
 
doStart() - Method in class org.apache.camel.processor.RecipientListProcessor
 
doStart() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
doStart() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
doStart() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
doStart() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
doStart() - Method in class org.apache.camel.processor.Resequencer
 
doStart() - Method in class org.apache.camel.processor.RollbackProcessor
 
doStart() - Method in class org.apache.camel.processor.RoutingSlip
 
doStart() - Method in class org.apache.camel.processor.ScriptProcessor
 
doStart() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
doStart() - Method in class org.apache.camel.processor.SendProcessor
 
doStart() - Method in class org.apache.camel.processor.SetBodyProcessor
 
doStart() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
doStart() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
doStart() - Method in class org.apache.camel.processor.SortProcessor
 
doStart() - Method in class org.apache.camel.processor.StopProcessor
 
doStart() - Method in class org.apache.camel.processor.StreamResequencer
 
doStart() - Method in class org.apache.camel.processor.ThreadsProcessor
 
doStart() - Method in class org.apache.camel.processor.Throttler
 
doStart() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
doStart() - Method in class org.apache.camel.processor.TransformProcessor
 
doStart() - Method in class org.apache.camel.processor.TryProcessor
 
doStart() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
doStart() - Method in class org.apache.camel.processor.WireTapProcessor
 
doStart() - Method in class org.apache.camel.processor.WrapProcessor
 
doStart() - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
doStartCamel() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
doStartEagerServices() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
doStartManagementStrategy() - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
doStartOrResumeRoutes(Map<String, BaseRouteService>, boolean, boolean, boolean, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
Starts or resumes the routes
doStartStandardServices() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
doStop() - Method in class org.apache.camel.component.properties.AbstractLocationPropertiesSource
 
doStop() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
doStop() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
doStop() - Method in class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
doStop() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
doStop() - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
doStop() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultMessageHistoryFactory
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultPackageScanResourceResolver
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultReactiveExecutor
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
doStop() - Method in class org.apache.camel.impl.engine.DefaultTracer
 
doStop() - Method in class org.apache.camel.impl.engine.DeferProducer
 
doStop() - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
 
doStop() - Method in class org.apache.camel.impl.engine.FileStateRepository
 
doStop() - Method in class org.apache.camel.impl.engine.MemoryStateRepository
 
doStop() - Method in class org.apache.camel.impl.engine.ServicePool
 
doStop() - Method in class org.apache.camel.impl.engine.SubscribeMethodProcessor
 
doStop() - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
doStop() - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
doStop() - Method in class org.apache.camel.impl.saga.InMemorySagaService
 
doStop() - Method in class org.apache.camel.impl.transformer.DataFormatTransformer
 
doStop() - Method in class org.apache.camel.impl.transformer.ProcessorTransformer
 
doStop() - Method in class org.apache.camel.impl.validator.ProcessorValidator
 
doStop() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
doStop() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
doStop() - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
doStop() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
doStop() - Method in class org.apache.camel.processor.channel.DefaultChannel
 
doStop() - Method in class org.apache.camel.processor.ChoiceProcessor
 
doStop() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
doStop() - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
doStop() - Method in class org.apache.camel.processor.Enricher
 
doStop() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
doStop() - Method in class org.apache.camel.processor.EventNotifierProducer
 
doStop() - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
doStop() - Method in class org.apache.camel.processor.FilterProcessor
 
doStop() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
doStop() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
doStop() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
doStop() - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
doStop() - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
 
doStop() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
doStop() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerConsumer
 
doStop() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
doStop() - Method in class org.apache.camel.processor.LogProcessor
 
doStop() - Method in class org.apache.camel.processor.MethodCallProcessor
 
doStop() - Method in class org.apache.camel.processor.MulticastProcessor
 
doStop() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
doStop() - Method in class org.apache.camel.processor.Pipeline
 
doStop() - Method in class org.apache.camel.processor.PollEnricher
 
doStop() - Method in class org.apache.camel.processor.RecipientList
 
doStop() - Method in class org.apache.camel.processor.RecipientListProcessor
 
doStop() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
doStop() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
doStop() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
doStop() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
doStop() - Method in class org.apache.camel.processor.Resequencer
 
doStop() - Method in class org.apache.camel.processor.RollbackProcessor
 
doStop() - Method in class org.apache.camel.processor.RoutingSlip
 
doStop() - Method in class org.apache.camel.processor.ScriptProcessor
 
doStop() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
doStop() - Method in class org.apache.camel.processor.SendProcessor
 
doStop() - Method in class org.apache.camel.processor.SetBodyProcessor
 
doStop() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
doStop() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
doStop() - Method in class org.apache.camel.processor.SortProcessor
 
doStop() - Method in class org.apache.camel.processor.StopProcessor
 
doStop() - Method in class org.apache.camel.processor.StreamResequencer
 
doStop() - Method in class org.apache.camel.processor.ThreadsProcessor
 
doStop() - Method in class org.apache.camel.processor.Throttler
 
doStop() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
doStop() - Method in class org.apache.camel.processor.TransformProcessor
 
doStop() - Method in class org.apache.camel.processor.TryProcessor
 
doStop() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
doStop() - Method in class org.apache.camel.processor.WireTapProcessor
 
doStop() - Method in class org.apache.camel.processor.WrapProcessor
 
doStop() - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
doSuspend() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
doSuspend() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
doubleQuotedLiteralText() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
doubleQuotedLiteralWithFunctionsText() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
DoubleQuoteEnd - Class in org.apache.camel.language.simple.ast
Ends a block enclosed by double quotes
DoubleQuoteEnd(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.DoubleQuoteEnd
 
DoubleQuoteStart - Class in org.apache.camel.language.simple.ast
Starts a block enclosed by double quotes
DoubleQuoteStart(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.DoubleQuoteStart
 
doWarmUp() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
dumpAllTracedMessages() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
dumpAllTracedMessagesAsXml() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
dumpState() - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
dumpTrace(String) - Method in class org.apache.camel.impl.engine.DefaultTracer
 
dumpTracedMessages(String) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
dumpTracedMessagesAsXml(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
dumpTracedMessagesAsXml(String) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
DurationConverter - Class in org.apache.camel.converter
Converters for java.time.Duration.
DurationConverterLoader - Class in org.apache.camel.converter
Source code generated by org.apache.camel:apt
DurationConverterLoader() - Constructor for class org.apache.camel.converter.DurationConverterLoader
 
DurationRoutePolicy - Class in org.apache.camel.impl.engine
RoutePolicy which executes for a duration and then triggers an action.
DurationRoutePolicy() - Constructor for class org.apache.camel.impl.engine.DurationRoutePolicy
 
DurationRoutePolicy(CamelContext, String) - Constructor for class org.apache.camel.impl.engine.DurationRoutePolicy
 
DurationRoutePolicyFactory - Class in org.apache.camel.impl.engine
RoutePolicyFactory which executes for a duration and then triggers an action.
DurationRoutePolicyFactory() - Constructor for class org.apache.camel.impl.engine.DurationRoutePolicyFactory
 
dynamicAware - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
dynamicMap - Variable in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
DynamicRouter - Class in org.apache.camel.processor
Implements a Dynamic Router pattern where the destination(s) is computed at runtime.
DynamicRouter(CamelContext) - Constructor for class org.apache.camel.processor.DynamicRouter
 
DynamicRouter(CamelContext, Expression, String) - Constructor for class org.apache.camel.processor.DynamicRouter
 
dynamicSize() - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 

E

enableBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
enableDebugger() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
encode(String) - Static method in class org.apache.camel.runtimecatalog.impl.UnsafeUriCharactersEncoder
 
encode(String, BitSet) - Static method in class org.apache.camel.runtimecatalog.impl.UnsafeUriCharactersEncoder
 
encode(String, boolean) - Static method in class org.apache.camel.runtimecatalog.impl.UnsafeUriCharactersEncoder
 
encode(String, BitSet, boolean) - Static method in class org.apache.camel.runtimecatalog.impl.UnsafeUriCharactersEncoder
 
encodeHttpURI(String) - Static method in class org.apache.camel.runtimecatalog.impl.UnsafeUriCharactersEncoder
 
encodeHttpURI(String, boolean) - Static method in class org.apache.camel.runtimecatalog.impl.UnsafeUriCharactersEncoder
 
endpointComponentName(String) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
EndpointKey - Class in org.apache.camel.impl.engine
Key used in DefaultEndpointRegistry in AbstractCamelContext, to ensure a consistent lookup.
EndpointKey(String) - Constructor for class org.apache.camel.impl.engine.EndpointKey
 
EndpointKey(String, boolean) - Constructor for class org.apache.camel.impl.engine.EndpointKey
Optimized when the uri is already normalized.
endpointLenientProperties(String) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
endpointProperties(String) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
endTransactedBy(Object) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
endTransactedBy(Object) - Method in class org.apache.camel.impl.engine.MDCUnitOfWork
 
Enricher - Class in org.apache.camel.processor
A content enricher that enriches input data by first obtaining additional data from a resource represented by an endpoint producer and second by aggregating input data and additional data.
Enricher(Expression) - Constructor for class org.apache.camel.processor.Enricher
 
entrySet() - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
EnumTypeConverter - Class in org.apache.camel.impl.converter
A type converter which is used to convert from String to enum type
EnumTypeConverter() - Constructor for class org.apache.camel.impl.converter.EnumTypeConverter
 
ENVIRONMENT_VARIABLES_MODE_FALLBACK - Static variable in class org.apache.camel.component.properties.PropertiesComponent
Check OS environment variables if not resolvable in the specified properties.
ENVIRONMENT_VARIABLES_MODE_NEVER - Static variable in class org.apache.camel.component.properties.PropertiesComponent
Never check OS environment variables.
ENVIRONMENT_VARIABLES_MODE_OVERRIDE - Static variable in class org.apache.camel.component.properties.PropertiesComponent
Check OS environment variables first, before trying the specified properties.
EnvPropertiesFunction - Class in org.apache.camel.component.properties
A PropertiesFunction that lookup the property value from OS environment variables.
EnvPropertiesFunction() - Constructor for class org.apache.camel.component.properties.EnvPropertiesFunction
 
equals(Object) - Method in class org.apache.camel.component.properties.PropertiesLocation
 
equals(Object) - Method in class org.apache.camel.impl.health.AbstractHealthCheck
 
equals(Object) - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
 
equals(Object) - Method in class org.apache.camel.runtimecatalog.impl.Pair
 
ErrorHandler - Interface in org.apache.camel.processor
An interface used to represent an error handler
errorHandler - Variable in class org.apache.camel.processor.RoutingSlip
 
ErrorHandlerSupport - Class in org.apache.camel.processor.errorhandler
Support class for ErrorHandler implementations.
ErrorHandlerSupport() - Constructor for class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
 
evaluate(Exchange) - Method in class org.apache.camel.language.simple.SimpleExpressionBuilder.KeyedOgnlExpressionAdapter
 
EvaluateExpressionProcessor - Class in org.apache.camel.processor
A Processor which evaluates an Expression and stores the result as a property on the Exchange with the key Exchange.EVALUATE_EXPRESSION_RESULT.
EvaluateExpressionProcessor(Expression) - Constructor for class org.apache.camel.processor.EvaluateExpressionProcessor
 
evaluators() - Method in class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
evaluators(String) - Method in class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
EventDrivenConsumerRoute - Class in org.apache.camel.impl.engine
A DefaultRoute which starts with an Event Driven Consumer

Use the API from CamelContext to control the lifecycle of a route, such as starting and stopping using the RouteController.startRoute(String) and RouteController.stopRoute(String) methods.

EventDrivenConsumerRoute(RouteContext, Endpoint, Processor) - Constructor for class org.apache.camel.impl.engine.EventDrivenConsumerRoute
 
EventNotifierCallback - Class in org.apache.camel.impl.engine
Helper class to notify on exchange sending events in async engine
EventNotifierCallback(AsyncCallback, Exchange, Endpoint) - Constructor for class org.apache.camel.impl.engine.EventNotifierCallback
 
EventNotifierProducer - Class in org.apache.camel.processor
Ensures a Producer do send EventNotifier notifications when sending.
EventNotifierProducer(Producer) - Constructor for class org.apache.camel.processor.EventNotifierProducer
The producer which should be executed and emit EventNotifier notifications.
ExceptionFailureStatistics - Class in org.apache.camel.processor.loadbalancer
Statistics about exception failures for load balancers that reacts on exceptions
ExceptionFailureStatistics() - Constructor for class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
exceptionPolicies - Variable in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
 
exceptionPolicy - Variable in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
 
ExceptionPolicy - Class in org.apache.camel.processor.errorhandler
 
ExceptionPolicy(String, String, boolean, boolean, boolean, Predicate, Predicate, Predicate, Processor, Processor, String, Map<ExceptionPolicy.RedeliveryOption, String>, List<String>) - Constructor for class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
ExceptionPolicy.RedeliveryOption - Enum in org.apache.camel.processor.errorhandler
 
ExceptionPolicyKey - Class in org.apache.camel.processor.errorhandler
Exception policy key is a compound key for storing: route id + exception class + when => exception type.
ExceptionPolicyKey(String, Class<? extends Throwable>, Predicate) - Constructor for class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
Key for exception clause
ExceptionPolicyStrategy - Interface in org.apache.camel.processor.errorhandler
A strategy to determine which ExceptionPolicyKey should handle the thrown exception.
ExchangeCompletedEvent - Class in org.apache.camel.impl.event
 
ExchangeCompletedEvent(Exchange) - Constructor for class org.apache.camel.impl.event.ExchangeCompletedEvent
 
ExchangeCreatedEvent - Class in org.apache.camel.impl.event
Event after an Exchange has been created.
ExchangeCreatedEvent(Exchange) - Constructor for class org.apache.camel.impl.event.ExchangeCreatedEvent
 
exchangeExceptionOgnlExpression(String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns the expression for the exchanges exception invoking methods defined in a simple OGNL notation
ExchangeFailedEvent - Class in org.apache.camel.impl.event
 
ExchangeFailedEvent(Exchange) - Constructor for class org.apache.camel.impl.event.ExchangeFailedEvent
 
ExchangeFailureHandledEvent - Class in org.apache.camel.impl.event
 
ExchangeFailureHandledEvent(Exchange, Processor, boolean, String) - Constructor for class org.apache.camel.impl.event.ExchangeFailureHandledEvent
 
ExchangeFailureHandlingEvent - Class in org.apache.camel.impl.event
 
ExchangeFailureHandlingEvent(Exchange, Processor, boolean, String) - Constructor for class org.apache.camel.impl.event.ExchangeFailureHandlingEvent
 
exchangeFormatter - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
exchangeFormatterRef - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
exchangeFormatterRef(String) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the reference of the instance of ExchangeFormatter to generate the log message from exchange.
exchangeOgnlExpression(String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns the expression for the exchange invoking methods defined in a simple OGNL notation
ExchangePatternProcessor - Class in org.apache.camel.processor
Processor to set ExchangePattern on the Exchange.
ExchangePatternProcessor() - Constructor for class org.apache.camel.processor.ExchangePatternProcessor
 
ExchangePatternProcessor(ExchangePattern) - Constructor for class org.apache.camel.processor.ExchangePatternProcessor
 
exchangeProperty(String) - Static method in class org.apache.camel.language.property.ExchangePropertyLanguage
 
ExchangePropertyLanguage - Class in org.apache.camel.language.property
A language for exchange property expressions.
ExchangePropertyLanguage() - Constructor for class org.apache.camel.language.property.ExchangePropertyLanguage
 
ExchangeRedeliveryEvent - Class in org.apache.camel.impl.event
 
ExchangeRedeliveryEvent(Exchange, int) - Constructor for class org.apache.camel.impl.event.ExchangeRedeliveryEvent
 
ExchangeSendingEvent - Class in org.apache.camel.impl.event
Event for before sending an Exchange to an Endpoint.
ExchangeSendingEvent(Exchange, Endpoint) - Constructor for class org.apache.camel.impl.event.ExchangeSendingEvent
 
ExchangeSentEvent - Class in org.apache.camel.impl.event
Event for after an Exchange has been sent to an Endpoint.
ExchangeSentEvent(Exchange, Endpoint, long) - Constructor for class org.apache.camel.impl.event.ExchangeSentEvent
 
exchangesFailed(long) - Static method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators
 
ExchangesFailed(long) - Constructor for class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.ExchangesFailed
 
exchangesInflight(long) - Static method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators
 
ExchangesInflight(long) - Constructor for class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.ExchangesInflight
 
executeFromQueue() - Method in class org.apache.camel.impl.engine.DefaultReactiveExecutor
 
executorService - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
expect(TokenType) - Method in class org.apache.camel.language.simple.BaseSimpleParser
Expect a given token
expectAndAcceptMore(TokenType) - Method in class org.apache.camel.language.simple.BaseSimpleParser
Expect and accept a given number of tokens in sequence.
ExplicitCamelContextNameStrategy - Class in org.apache.camel.impl.engine
Strategy to used an explicit (fixed) name for CamelContext.
ExplicitCamelContextNameStrategy(String) - Constructor for class org.apache.camel.impl.engine.ExplicitCamelContextNameStrategy
 
exponentialBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
expression - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
expression(String) - Static method in class org.apache.camel.language.simple.SimpleLanguage
Creates a new Expression.
expression - Variable in class org.apache.camel.processor.RoutingSlip
 
expression - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
ExpressionResultComparator - Interface in org.apache.camel.processor.resequencer
A SequenceElementComparator that compares Exchanges based on the result of an expression evaluation.
externalRedeliveries(long) - Static method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators
 
ExternalRedeliveries(long) - Constructor for class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.ExternalRedeliveries
 
extractFutureBody(Future<?>, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
extractFutureBody(Future<?>, long, TimeUnit, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
extractProperties(Map<String, Object>, String) - Static method in class org.apache.camel.runtimecatalog.impl.URISupport
 
extractResultBody(Exchange) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
Extracts the body from the given result.
extractResultBody(Exchange) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
extractResultBody(Exchange, ExchangePattern) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 

F

factoryFinder - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
failedCounter - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
FailOverLoadBalancer - Class in org.apache.camel.processor.loadbalancer
This FailOverLoadBalancer will failover to use next processor when an exception occurred

This implementation mirrors the logic from the Pipeline in the async variation as the failover load balancer is a specialized pipeline.

FailOverLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
FailOverLoadBalancer(List<Class<?>>) - Constructor for class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
FailOverLoadBalancer.State - Class in org.apache.camel.processor.loadbalancer
 
FAILURE_COUNT - Static variable in class org.apache.camel.impl.health.AbstractHealthCheck
 
fallbackConverters - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
FastAnnotationTypeConverterLoader - Class in org.apache.camel.impl.converter
 
FastAnnotationTypeConverterLoader(PackageScanClassResolver) - Constructor for class org.apache.camel.impl.converter.FastAnnotationTypeConverterLoader
 
FatalFallbackErrorHandler - Class in org.apache.camel.processor
An ErrorHandler used as a safe fallback when processing by other error handlers such as the org.apache.camel.model.OnExceptionDefinition.
FatalFallbackErrorHandler(Processor) - Constructor for class org.apache.camel.processor.FatalFallbackErrorHandler
 
FatalFallbackErrorHandler(Processor, boolean) - Constructor for class org.apache.camel.processor.FatalFallbackErrorHandler
 
fileAbsoluteExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
fileAbsolutePathExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
fileExtensionExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
fileExtensionSingleExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
FileLanguage - Class in org.apache.camel.language.simple
 
FileLanguage() - Constructor for class org.apache.camel.language.simple.FileLanguage
 
fileLastModifiedExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
fileNameExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
fileNameNoExtensionExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
fileNameNoExtensionSingleExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
fileOnlyNameExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
fileOnlyNameNoExtensionExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
fileOnlyNameNoExtensionSingleExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
fileParentExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
filePathExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
FilePropertiesSource - Class in org.apache.camel.component.properties
 
FilePropertiesSource(PropertiesComponent, PropertiesLocation) - Constructor for class org.apache.camel.component.properties.FilePropertiesSource
 
fileSizeExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
FileStateRepository - Class in org.apache.camel.impl.engine
This FileStateRepository class is a file-based implementation of a StateRepository.
FileStateRepository() - Constructor for class org.apache.camel.impl.engine.FileStateRepository
 
FileStateRepository(File, Map<String, String>) - Constructor for class org.apache.camel.impl.engine.FileStateRepository
 
fileStateRepository(File) - Static method in class org.apache.camel.impl.engine.FileStateRepository
Creates a new file based repository using as 1st level cache
fileStateRepository(File, long) - Static method in class org.apache.camel.impl.engine.FileStateRepository
Creates a new file based repository using a HashMap as 1st level cache.
fileStateRepository(File, Map<String, String>) - Static method in class org.apache.camel.impl.engine.FileStateRepository
Creates a new file based repository using the given Map as 1st level cache.
filter(String) - Method in class org.apache.camel.impl.engine.EventDrivenConsumerRoute
 
filter(ExceptionPolicyKey, Class<?>, Throwable) - Method in class org.apache.camel.processor.errorhandler.DefaultExceptionPolicyStrategy
Strategy to filter the given type exception class with the thrown exception
filterPackageNamesOnly(PackageScanClassResolver, String[], Set<Class<?>>) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
Filters the given list of packages and returns an array of only package names.
FilterProcessor - Class in org.apache.camel.processor
The processor which implements the Message Filter EIP pattern.
FilterProcessor(Predicate, Processor) - Constructor for class org.apache.camel.processor.FilterProcessor
 
FilterResult(boolean, String) - Constructor for class org.apache.camel.impl.engine.SupervisingRouteController.FilterResult
 
FilterResult(boolean, String, Object...) - Constructor for class org.apache.camel.impl.engine.SupervisingRouteController.FilterResult
 
filterUnwantedPackage(String, String[]) - Static method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
Filters the given list of packages
FinallyProcessor - Class in org.apache.camel.processor
Processor to handle do finally supporting asynchronous routing engine
FinallyProcessor(Processor) - Constructor for class org.apache.camel.processor.FinallyProcessor
 
finallyProcessor - Variable in class org.apache.camel.processor.TryProcessor
 
find(PackageScanFilter, String, Set<Class<?>>) - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
 
find(PackageScanFilter, String, ClassLoader, Set<Class<?>>) - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
 
findAnnotated(Class<? extends Annotation>, String...) - Method in class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
findAnnotated(Set<Class<? extends Annotation>>, String...) - Method in class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
findAnnotated(Class<? extends Annotation>, String...) - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
 
findAnnotated(Set<Class<? extends Annotation>>, String...) - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
 
findByFilter(PackageScanFilter, String...) - Method in class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
findByFilter(PackageScanFilter, String...) - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
 
findClass(String) - Method in class org.apache.camel.impl.engine.DefaultFactoryFinder
 
findClass(String, String) - Method in class org.apache.camel.impl.engine.DefaultFactoryFinder
 
findClass(String, String, Class<?>) - Method in class org.apache.camel.impl.engine.DefaultFactoryFinder
 
findFallbackTypeConverterClasses() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
Finds the fallback type converter classes from the classpath looking for text files on the classpath at the BaseTypeConverterRegistry.META_INF_SERVICES_FALLBACK_TYPE_CONVERTER location.
findImplementations(Class<?>, String...) - Method in class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
findImplementations(Class<?>, String...) - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
 
findInClasspath(String, Set<InputStream>, String) - Method in class org.apache.camel.impl.engine.DefaultPackageScanResourceResolver
 
findInFileSystem(File, Set<InputStream>, String) - Method in class org.apache.camel.impl.engine.DefaultPackageScanResourceResolver
 
findLanguage(String, CamelContext) - Method in class org.apache.camel.impl.engine.DefaultLanguageResolver
 
findLanguageResolver(String, CamelContext) - Method in class org.apache.camel.impl.engine.DefaultLanguageResolver
 
findOptionalClass(String, String) - Method in class org.apache.camel.impl.engine.DefaultFactoryFinder
 
findPackageNames() - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
Finds the names of the packages to search for on the classpath looking for text files on the classpath at the AnnotationTypeConverterLoader.META_INF_SERVICES location.
findPackageNames() - Method in class org.apache.camel.impl.converter.TypeConvertersLoader
 
findPackages(Set<String>, ClassLoader) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
findResources(String) - Method in class org.apache.camel.impl.engine.DefaultPackageScanResourceResolver
 
findSetterMethods(Class<?>, String, boolean, boolean, boolean) - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
findTypeConverterLoaderClasses() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
Finds the type converter loader classes from the classpath looking for text files on the classpath at the BaseTypeConverterRegistry.META_INF_SERVICES_TYPE_CONVERTER_LOADER location.
forceCompletionOfAllGroups() - Method in interface org.apache.camel.processor.aggregate.AggregateController
To force complete of all groups
forceCompletionOfAllGroups() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
forceCompletionOfAllGroups() - Method in class org.apache.camel.processor.aggregate.DefaultAggregateController
 
forceCompletionOfGroup(String) - Method in interface org.apache.camel.processor.aggregate.AggregateController
To force completing a specific group by its key.
forceCompletionOfGroup(String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
forceCompletionOfGroup(String) - Method in class org.apache.camel.processor.aggregate.DefaultAggregateController
 
forceDiscardingOfAllGroups() - Method in interface org.apache.camel.processor.aggregate.AggregateController
To force discardingof all groups
forceDiscardingOfAllGroups() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
forceDiscardingOfAllGroups() - Method in class org.apache.camel.processor.aggregate.DefaultAggregateController
 
forceDiscardingOfGroup(String) - Method in interface org.apache.camel.processor.aggregate.AggregateController
To force discarding a specific group by its key.
forceDiscardingOfGroup(String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
forceDiscardingOfGroup(String) - Method in class org.apache.camel.processor.aggregate.DefaultAggregateController
 
forceLazyInitialization() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
Force some lazy initialization to occur upfront before we start any components and create routes
forceShutdown(Service) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
forceStopLazyInitialization() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
Force clear lazy initialization so they can be re-created on restart
fromCharArray(char[]) - Static method in class org.apache.camel.converter.ObjectConverter
 
functionText() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
 
functionText() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
FutureTypeConverter - Class in org.apache.camel.impl.converter
Future type converter.
FutureTypeConverter(TypeConverter) - Constructor for class org.apache.camel.impl.converter.FutureTypeConverter
 

G

gatherEndpoints() - Method in class org.apache.camel.impl.engine.BaseRouteService
Gather all the endpoints this route service uses

This implementation finds the endpoints by searching all the child services for EndpointAware processors which uses an endpoint.

generateSanitizedId() - Method in class org.apache.camel.impl.engine.DefaultUuidGenerator
Generate a unique ID - that is friendly for a URL or file system
generateSanitizedId(String) - Static method in class org.apache.camel.impl.engine.DefaultUuidGenerator
Ensures that the id is friendly for a URL or file system
generateUuid() - Method in class org.apache.camel.impl.engine.DefaultUuidGenerator
 
generateUuid() - Method in class org.apache.camel.impl.engine.JavaUuidGenerator
 
get(Object) - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
get(String) - Method in class org.apache.camel.impl.engine.DefaultClaimCheckRepository
 
get() - Method in interface org.apache.camel.impl.engine.DefaultFactoryFinder.ClassSupplier
 
get(CamelContext, String) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
getAccumulatedProcessingTime() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getAction() - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
 
getAction() - Method in class org.apache.camel.impl.engine.DurationRoutePolicyFactory
 
getAdvice(Class<T>) - Method in class org.apache.camel.processor.CamelInternalProcessor
Gets the advice with the given type.
getAfter() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
getAggregateController() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getAggregationRepository() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getAggregationStrategy() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getAggregationStrategy() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getAggregationStrategy() - Method in class org.apache.camel.processor.Enricher
 
getAggregationStrategy(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
 
getAggregationStrategy() - Method in class org.apache.camel.processor.MulticastProcessor
getAggregationStrategy() - Method in class org.apache.camel.processor.PollEnricher
 
getAggregationStrategy() - Method in class org.apache.camel.processor.RecipientList
 
getAllEndpoints(boolean) - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
getAndRemove(String) - Method in class org.apache.camel.impl.engine.DefaultClaimCheckRepository
 
getAndRemoveBooleanHeader(Exchange, String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getAndRemoveBooleanProperty(Exchange, String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getAnnotationBasedProcessorFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getApplicationContextClassLoader() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getApplicationContextClassLoader() - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
getAsyncProcessorAwaitManager() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getAttempt() - Method in class org.apache.camel.impl.event.ExchangeRedeliveryEvent
 
getBacklogDebugger(CamelContext) - Static method in class org.apache.camel.processor.interceptor.BacklogDebugger
A helper method to return the BacklogDebugger instance if one is enabled
getBacklogSize() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
getBackOff(String) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
getBackOffConfigurations() - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
getBackOffContext(String) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
getBackOffMultiplier() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getBatchSize() - Method in class org.apache.camel.processor.Resequencer
 
getBatchTimeout() - Method in class org.apache.camel.processor.Resequencer
 
getBeanIntrospection() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getBeanPostProcessor() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getBeanProcessorFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getBeanProxyFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getBefore() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
getBody() - Method in class org.apache.camel.support.dump.MessageDump
 
getBodyMaxChars() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getBodyMaxChars() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
getBooleanProperty(Exchange, String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getBreakpoints() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getBreakpoints() - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
getBufferSize() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
getCache() - Method in class org.apache.camel.impl.engine.FileStateRepository
 
getCachedClassesCounter() - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
getCacheSize() - Method in class org.apache.camel.processor.Enricher
 
getCacheSize() - Method in class org.apache.camel.processor.PollEnricher
 
getCacheSize() - Method in class org.apache.camel.processor.RecipientList
 
getCacheSize() - Method in class org.apache.camel.processor.RoutingSlip
 
getCacheSize() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getCacheSize() - Method in class org.apache.camel.processor.WireTapProcessor
 
getCamelContext() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
getCamelContext() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
getCamelContext() - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
getCamelContext() - Method in class org.apache.camel.impl.engine.BasePackageScanResolver
 
getCamelContext() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
getCamelContext() - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultMessageHistoryFactory
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DefaultTracer
 
getCamelContext() - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
 
getCamelContext() - Method in class org.apache.camel.impl.health.ContextHealthCheck
 
getCamelContext() - Method in class org.apache.camel.impl.health.DefaultHealthCheckRegistry
 
getCamelContext() - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
getCamelContext() - Method in class org.apache.camel.impl.health.RegistryRepository
 
getCamelContext() - Method in class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
getCamelContext() - Method in class org.apache.camel.impl.saga.InMemorySagaService
 
getCamelContext() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
getCamelContext() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
getCamelContext() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.Enricher
 
getCamelContext() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getCamelContext() - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
getCamelContext() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getCamelContext() - Method in class org.apache.camel.processor.MulticastProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.PollEnricher
 
getCamelContext() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getCamelContext() - Method in class org.apache.camel.processor.WireTapProcessor
 
getCamelContext() - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
getCamelContext() - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
getCapacity() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
Gets the maximum cache size (capacity).
getCapacity() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
getCapacity() - Method in class org.apache.camel.processor.StreamResequencer
Returns this resequencer's capacity.
getCause() - Method in class org.apache.camel.impl.event.CamelContextResumeFailureEvent
 
getCause() - Method in class org.apache.camel.impl.event.CamelContextStartupFailureEvent
 
getCause() - Method in class org.apache.camel.impl.event.CamelContextStopFailureEvent
 
getCause() - Method in class org.apache.camel.impl.event.ExchangeFailedEvent
 
getCause() - Method in class org.apache.camel.impl.event.ServiceStartupFailureEvent
 
getCause() - Method in class org.apache.camel.impl.event.ServiceStopFailureEvent
 
getCause() - Method in class org.apache.camel.impl.event.StepFailedEvent
 
getCharset() - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
getCheckInterval() - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
getCheckIntervalUnit() - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
getChildren() - Method in class org.apache.camel.language.simple.ast.CompositeNodes
 
getClassLoaders() - Method in class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
getClassLoaders() - Method in class org.apache.camel.impl.engine.BasePackageScanResolver
 
getClassResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getCloseCorrelationKeyOnCompletion() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getClosedCorrelationKeysCacheSize() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Current number of closed correlation keys in the memory cache
getCollisionAvoidanceFactor() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getCollisionAvoidancePercent() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getComparator() - Method in class org.apache.camel.processor.SortProcessor
 
getCompletedByBatchConsumer() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion batch consumer trigger
getCompletedByForce() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion force trigger
getCompletedByInterval() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion interval trigger
getCompletedByPredicate() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion predicate trigger
getCompletedBySize() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion size trigger
getCompletedByStrategy() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion strategy trigger
getCompletedByTimeout() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged completed by completion timeout trigger
getCompletionInterval() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionPredicate() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionPredicate() - Method in class org.apache.camel.processor.Resequencer
 
getCompletionSize() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionSizeExpression() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionTimeout() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionTimeoutCheckerInterval() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCompletionTimeoutExpression() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getComponent(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getComponent(String, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getComponent(String, boolean, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getComponent(String, Class<T>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getComponentJSonSchema(String) - Method in class org.apache.camel.runtimecatalog.impl.CamelContextJSonSchemaResolver
 
getComponentNames() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getComponentParameterJsonSchema(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getComponentResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getConfiguration() - Method in class org.apache.camel.impl.health.AbstractHealthCheck
 
getConsumer() - Method in class org.apache.camel.impl.engine.EventDrivenConsumerRoute
 
getConsumerProcessor(Endpoint) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
 
getContext() - Method in class org.apache.camel.impl.event.AbstractContextEvent
 
getContext() - Method in class org.apache.camel.impl.event.ServiceStartupFailureEvent
 
getContext() - Method in class org.apache.camel.impl.event.ServiceStopFailureEvent
 
getContinuedPolicy() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getControlledRoutes() - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
getControlledRoutes() - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
getCorrelationExpression() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getCorrelationExpression() - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
getCorrelationKey() - Method in exception org.apache.camel.processor.aggregate.ClosedCorrelationKeyException
 
getCounter() - Method in class org.apache.camel.processor.SendProcessor
 
getCreatedWorkers() - Method in class org.apache.camel.impl.engine.DefaultReactiveExecutor
 
getCurrentCacheSize() - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
getCurrentCacheSize() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
getCurrentCacheSize() - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
getCurrentMaximumRequestsPerPeriod() - Method in class org.apache.camel.processor.Throttler
Gets the current maximum request per period value.
getCurrentSagaCoordinator(Exchange) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
getCurrentShutdownTaskFuture() - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
getDataFormatJSonSchema(String) - Method in class org.apache.camel.runtimecatalog.impl.CamelContextJSonSchemaResolver
 
getDataFormatParameterJsonSchema(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getDataFormatResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getDeadLetter() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Returns the dead letter that message exchanges will be sent to if the redelivery attempts fail
getDeadLetterUri() - Method in class org.apache.camel.impl.event.ExchangeFailureHandledEvent
 
getDeadLetterUri() - Method in class org.apache.camel.impl.event.ExchangeFailureHandlingEvent
 
getDeadLetterUri() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
getDebugCounter() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getDebugger() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getDefaultBackOff() - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
getDefaultEndpoint() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
getDefaultEndpoint() - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
getDefaultFactoryFinder() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getDefaultHandledPredicate() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
getDefaultThreadPoolProfile() - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
getDeferServiceFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getDelay(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
getDelay() - Method in class org.apache.camel.processor.Delayer
 
getDelayedCount() - Method in class org.apache.camel.processor.DelayProcessorSupport
Gets the current number of Exchanges being delayed (hold back due throttle limit hit)
getDelayer() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getDelayer() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getDelayPattern() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getDelayValue() - Method in class org.apache.camel.processor.Delayer
 
getDelegate() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
getDelimiter() - Method in class org.apache.camel.processor.RecipientList
 
getDeltaProcessingTime() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getDeltaProcessingTime() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getDeltaProcessingTime() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getDeltaProcessingTime() - Method in class org.apache.camel.support.dump.StepStatDump
 
getDescription() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
getDestination() - Method in class org.apache.camel.processor.SendProcessor
 
getDiscarded() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanged discarded
getDistributionWeight() - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
 
getDuplicateMessageCount() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getDynamicAware() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getEipParameterJsonSchema(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getEncoding() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
getEndpoint(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getEndpoint(String, Map<String, Object>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getEndpoint(String, Class<T>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getEndpoint() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
getEndpoint() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getEndpoint() - Method in class org.apache.camel.impl.engine.DeferProducer
 
getEndpoint() - Method in class org.apache.camel.impl.engine.InterceptSendToEndpointProcessor
 
getEndpoint() - Method in class org.apache.camel.impl.engine.SubscribeMethodProcessor
 
getEndpoint() - Method in class org.apache.camel.impl.event.ExchangeSendingEvent
 
getEndpoint() - Method in class org.apache.camel.impl.event.ExchangeSentEvent
 
getEndpoint() - Method in class org.apache.camel.processor.EventNotifierProducer
 
getEndpoint() - Method in class org.apache.camel.processor.SendProcessor
 
getEndpoint() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
getEndpointInjection(Object, String, String, String, boolean) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
 
getEndpointKey(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
Gets the endpoint key to use for lookup or whe adding endpoints to the DefaultEndpointRegistry
getEndpointKey(String, Endpoint) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
Gets the endpoint key to use for lookup or whe adding endpoints to the DefaultEndpointRegistry
getEndpointKey() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
getEndpointKeyPreNormalized(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
Gets the endpoint key to use for lookup or whe adding endpoints to the DefaultEndpointRegistry
getEndpointMap() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getEndpointRegistry() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getEndpoints() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getEndpointsPerRoute(String, boolean) - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
getEndpointStatistics() - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
getEndpointUri() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.processor.Enricher
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.processor.PollEnricher
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.processor.RecipientList
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.processor.RoutingSlip
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getEndpointUtilizationStatistics() - Method in class org.apache.camel.processor.WireTapProcessor
 
getEndToken() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getEnvironmentVariableMode() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
getErrorHandler() - Method in class org.apache.camel.processor.channel.DefaultChannel
 
getErrorHandler() - Method in class org.apache.camel.processor.RoutingSlip
 
getErrorHandlerExecutorService() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getErrorHandlerFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getErrorHandlerFactory() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getErrorHandlers(ErrorHandlerFactory) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getEventFactory() - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
getEventNotifiers() - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
getEvicted() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
Gets the cache evicted statistic

Will return -1 if it cannot determine this if a custom cache was used.

getEvicted() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
getEvicted() - Method in class org.apache.camel.impl.engine.ServicePool
 
getException() - Method in class org.apache.camel.impl.engine.DefaultRouteError
 
getException() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getExceptionClass() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
 
getExceptionFailureStatistics() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getExceptionHandler() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getExceptionHandler() - Method in class org.apache.camel.processor.Resequencer
 
getExceptionHandler() - Method in class org.apache.camel.processor.StreamResequencer
Returns this resequencer's exception handler.
getExceptionPolicy(Set<ExceptionPolicyKey>, Exchange, Throwable) - Method in class org.apache.camel.processor.errorhandler.DefaultExceptionPolicyStrategy
 
getExceptionPolicy(Exchange, Throwable) - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
CamelContextHelper Attempts to find the best suited ExceptionPolicy to be used for handling the given thrown exception.
getExceptionPolicy(Set<ExceptionPolicyKey>, Exchange, Throwable) - Method in interface org.apache.camel.processor.errorhandler.ExceptionPolicyStrategy
Resolves the ExceptionPolicyKey that should handle the thrown exception.
getExceptions() - Method in class org.apache.camel.processor.CatchProcessor
 
getExceptions() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getExceptions() - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
getExceptions() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getExchange() - Method in class org.apache.camel.impl.event.AbstractExchangeEvent
 
getExchange() - Method in exception org.apache.camel.processor.idempotent.NoMessageIdException
The exchange which caused this failure
getExchange() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
getExchangeFormatter() - Method in class org.apache.camel.impl.engine.DefaultTracer
 
getExchangeFormatterRef() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getExchangeId() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
getExchangeId() - Method in class org.apache.camel.support.dump.MessageDump
 
getExchangeIndex(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
 
getExchangeIndex(Exchange) - Method in class org.apache.camel.processor.Splitter
 
getExchangePattern() - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
getExchangesCompleted() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getExchangesCompleted() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getExchangesCompleted() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getExchangesCompleted() - Method in class org.apache.camel.support.dump.StepStatDump
 
getExchangesFailed() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getExchangesFailed() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getExchangesFailed() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getExchangesFailed() - Method in class org.apache.camel.support.dump.StepStatDump
 
getExchangesInflight() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getExchangesInflight() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getExcludePattern() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
getExcludePattern() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
getExecutorService() - Method in class org.apache.camel.impl.saga.InMemorySagaService
 
getExecutorService() - Method in class org.apache.camel.processor.RecipientList
 
getExecutorService() - Method in class org.apache.camel.processor.ThreadsProcessor
 
getExecutorServiceManager() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getExpression() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyParameterInfo
 
getExpression() - Method in class org.apache.camel.processor.Enricher
 
getExpression() - Method in exception org.apache.camel.processor.idempotent.NoMessageIdException
The expression which was used
getExpression() - Method in class org.apache.camel.processor.LogProcessor
 
getExpression() - Method in class org.apache.camel.processor.LoopProcessor
 
getExpression() - Method in class org.apache.camel.processor.MethodCallProcessor
 
getExpression() - Method in class org.apache.camel.processor.PollEnricher
 
getExpression() - Method in class org.apache.camel.processor.RecipientList
 
getExpression() - Method in class org.apache.camel.processor.Resequencer
 
getExpression() - Method in class org.apache.camel.processor.RoutingSlip
 
getExpression() - Method in class org.apache.camel.processor.ScriptProcessor
 
getExpression() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getExpression() - Method in class org.apache.camel.processor.SetBodyProcessor
 
getExpression() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
getExpression() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
getExpression() - Method in class org.apache.camel.processor.SortProcessor
 
getExpression() - Method in class org.apache.camel.processor.Splitter
 
getExpression() - Method in class org.apache.camel.processor.StreamResequencer
 
getExpression() - Method in class org.apache.camel.processor.TransformProcessor
 
getExtension(Class<T>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getFactoryFinder(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getFactoryFinderResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getFailureCounter(Class<?>) - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
getFailureHandler() - Method in class org.apache.camel.impl.event.ExchangeFailureHandledEvent
 
getFailureHandler() - Method in class org.apache.camel.impl.event.ExchangeFailureHandlingEvent
 
getFailures() - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
getFailuresHandled() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getFailuresHandled() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getFailuresHandled() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getFailuresHandled() - Method in class org.apache.camel.support.dump.StepStatDump
 
getFailureThreshold() - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
getFailureWindow() - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
getFallbackTimeout() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getFallbackTypeConverter() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry.FallbackTypeConverter
 
getFallbackUrls() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
getFilePath() - Method in class org.apache.camel.impl.engine.FileStateRepository
 
getFileStore() - Method in class org.apache.camel.impl.engine.FileStateRepository
 
getFilter() - Method in class org.apache.camel.processor.ClaimCheckAggregationStrategy
 
getFilter() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getFilteredCount() - Method in class org.apache.camel.processor.FilterProcessor
Gets the number of Exchanges that matched the filter predicate and therefore as filtered.
getFilters() - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
getFilters() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getFirstExchangeCompletedExchangeId() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getFirstExchangeCompletedExchangeId() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getFirstExchangeCompletedExchangeId() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getFirstExchangeCompletedExchangeId() - Method in class org.apache.camel.support.dump.StepStatDump
 
getFirstExchangeCompletedTimestamp() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getFirstExchangeCompletedTimestamp() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getFirstExchangeCompletedTimestamp() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getFirstExchangeCompletedTimestamp() - Method in class org.apache.camel.support.dump.StepStatDump
 
getFirstExchangeFailureExchangeId() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getFirstExchangeFailureExchangeId() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getFirstExchangeFailureExchangeId() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getFirstExchangeFailureExchangeId() - Method in class org.apache.camel.support.dump.StepStatDump
 
getFirstExchangeFailureTimestamp() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getFirstExchangeFailureTimestamp() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getFirstExchangeFailureTimestamp() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getFirstExchangeFailureTimestamp() - Method in class org.apache.camel.support.dump.StepStatDump
 
getFrom() - Method in class org.apache.camel.impl.transformer.TransformerKey
 
getFromRouteId() - Method in class org.apache.camel.impl.engine.DurationRoutePolicyFactory
 
getFunctions() - Method in class org.apache.camel.component.properties.PropertiesComponent
Gets the functions registered in this properties component.
getGlobalEndpointConfiguration() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getGlobalOption(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getGlobalOptions() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getGroup() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
getGroup() - Method in class org.apache.camel.impl.health.AbstractHealthCheck
 
getGroup() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getGroupDelimiter() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getHalfOpenAfter() - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
getHalfOpenHandler() - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
getHandledPolicy() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getHeaderName() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getHeaderName() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
getHeaderName() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
getHeaders() - Method in class org.apache.camel.support.dump.MessageDump
 
getHeadersMapFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getHealthCheckRegistry() - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
getHits() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
Gets the cache hits statistic

Will return -1 if it cannot determine this if a custom cache was used.

getHits() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
getHits() - Method in class org.apache.camel.impl.engine.ServicePool
 
getHostName() - Static method in class org.apache.camel.impl.engine.DefaultUuidGenerator
As we have to find the hostname as a side-affect of generating a unique stub, we allow it's easy retrieval here
getId() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
getId() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
getId() - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
getId() - Method in class org.apache.camel.impl.health.AbstractHealthCheck
 
getId() - Method in class org.apache.camel.impl.saga.InMemorySagaCoordinator
 
getId() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getId() - Method in class org.apache.camel.processor.CatchProcessor
 
getId() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getId() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getId() - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
getId() - Method in class org.apache.camel.processor.Delayer
 
getId() - Method in class org.apache.camel.processor.Enricher
 
getId() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getId() - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
getId() - Method in class org.apache.camel.processor.FilterProcessor
 
getId() - Method in class org.apache.camel.processor.FinallyProcessor
 
getId() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getId() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
getId() - Method in class org.apache.camel.processor.LogProcessor
 
getId() - Method in class org.apache.camel.processor.LoopProcessor
 
getId() - Method in class org.apache.camel.processor.MethodCallProcessor
 
getId() - Method in class org.apache.camel.processor.MulticastProcessor
 
getId() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
getId() - Method in class org.apache.camel.processor.Pipeline
 
getId() - Method in class org.apache.camel.processor.PollEnricher
 
getId() - Method in class org.apache.camel.processor.RecipientList
 
getId() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
getId() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
getId() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
getId() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
getId() - Method in class org.apache.camel.processor.Resequencer
 
getId() - Method in class org.apache.camel.processor.RollbackProcessor
 
getId() - Method in class org.apache.camel.processor.RoutingSlip
 
getId() - Method in class org.apache.camel.processor.SamplingThrottler
 
getId() - Method in class org.apache.camel.processor.ScriptProcessor
 
getId() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getId() - Method in class org.apache.camel.processor.SendProcessor
 
getId() - Method in class org.apache.camel.processor.SetBodyProcessor
 
getId() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
getId() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
getId() - Method in class org.apache.camel.processor.SortProcessor
 
getId() - Method in class org.apache.camel.processor.StopProcessor
 
getId() - Method in class org.apache.camel.processor.StreamResequencer
 
getId() - Method in class org.apache.camel.processor.ThreadsProcessor
 
getId() - Method in class org.apache.camel.processor.Throttler
 
getId() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getId() - Method in class org.apache.camel.processor.TransformProcessor
 
getId() - Method in class org.apache.camel.processor.TryProcessor
 
getId() - Method in class org.apache.camel.processor.WireTapProcessor
 
getId() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getId() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getId() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getId() - Method in class org.apache.camel.support.dump.StepStatDump
 
getIdempotentRepository() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getIndex() - Method in exception org.apache.camel.language.simple.types.SimpleIllegalSyntaxException
Index where the parsing error occurred
getIndex() - Method in exception org.apache.camel.language.simple.types.SimpleParserException
Index where the parsing error occurred
getIndex() - Method in class org.apache.camel.language.simple.types.SimpleToken
 
getIndex() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyParameterInfo
 
getIndex() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
getIndex() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getIndex() - Method in class org.apache.camel.support.dump.StepStatDump
 
getInflightRepository() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getInheritNamespaceTagName() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getInitialDelay() - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
getInitialization() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getInitialProperties() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
getInjectionBeanValue(Class<?>, String) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
 
getInjectionPropertyValue(Class<?>, String, String, String, Object, String) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
 
getInjectionValue(Class<?>, String, String, String, Object, String) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
Creates the object to be injected for an EndpointInject or Produce injection point
getInjectionValue(Class<?>, String, String, String, Object, String, boolean) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
Creates the object to be injected for an EndpointInject or Produce injection point
getInjector() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
getInjector() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getInProgressCompleteExchanges() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getInputs() - Method in class org.apache.camel.impl.engine.BaseRouteService
Gets the inputs to the routes.
getInputs() - Method in class org.apache.camel.impl.engine.DefaultRouteStartupOrder
 
getInterceptStrategies() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getInterceptStrategies() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getInvokedCounter() - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
getJSonSchemaResolver() - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
getKeepOpen() - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
getKey() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getKey() - Method in class org.apache.camel.support.dump.MessageDump.Header
 
getKeyedEntity(Exchange, String) - Method in interface org.apache.camel.language.simple.SimpleExpressionBuilder.KeyedOgnlExpressionAdapter.KeyedEntityRetrievalStrategy
 
getKeys() - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
getLanguageJSonSchema(String) - Method in class org.apache.camel.runtimecatalog.impl.CamelContextJSonSchemaResolver
 
getLanguageNames() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getLanguageParameterJsonSchema(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getLanguageResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getLastChosenProcessorIndex() - Method in class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
 
getLastChosenProcessorIndex() - Method in class org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer
 
getLastChosenProcessorIndex() - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
getLastChosenProcessorIndex() - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
getLastError() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getLastExchangeCompletedExchangeId() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getLastExchangeCompletedExchangeId() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getLastExchangeCompletedExchangeId() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getLastExchangeCompletedExchangeId() - Method in class org.apache.camel.support.dump.StepStatDump
 
getLastExchangeCompletedTimestamp() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getLastExchangeCompletedTimestamp() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getLastExchangeCompletedTimestamp() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getLastExchangeCompletedTimestamp() - Method in class org.apache.camel.support.dump.StepStatDump
 
getLastExchangeFailureExchangeId() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getLastExchangeFailureExchangeId() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getLastExchangeFailureExchangeId() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getLastExchangeFailureExchangeId() - Method in class org.apache.camel.support.dump.StepStatDump
 
getLastExchangeFailureTimestamp() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getLastExchangeFailureTimestamp() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getLastExchangeFailureTimestamp() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getLastExchangeFailureTimestamp() - Method in class org.apache.camel.support.dump.StepStatDump
 
getLastFailure() - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
getLastGoodIndex() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getLastProcessingTime() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getLastProcessingTime() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getLastProcessingTime() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getLastProcessingTime() - Method in class org.apache.camel.support.dump.StepStatDump
 
getLeft() - Method in class org.apache.camel.runtimecatalog.impl.Pair
 
getLength() - Method in class org.apache.camel.language.simple.types.SimpleToken
 
getLifecycleStrategies() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getLimit() - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
getLimit() - Method in class org.apache.camel.impl.engine.LimitedPollingConsumerPollStrategy
 
getLoaderUrls() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
getLocation() - Method in class org.apache.camel.component.properties.AbstractLocationPropertiesSource
 
getLocation() - Method in interface org.apache.camel.component.properties.LocationPropertiesSource
Gets the location of the properties
getLocation() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
getLocation() - Method in class org.apache.camel.component.properties.RefPropertiesSource
 
getLocations() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
getLog() - Method in class org.apache.camel.impl.engine.DefaultComponentResolver
 
getLog() - Method in class org.apache.camel.impl.engine.DefaultLanguageResolver
 
getLogExhaustedMessageBody() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Whether the option logExhaustedMessageBody has been configured or not
getLogExhaustedMessageHistory() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Whether the option logExhaustedMessageHistory has been configured or not
getLogFormatter() - Method in class org.apache.camel.processor.LogProcessor
 
getLogger() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
getLogger() - Method in class org.apache.camel.processor.LogProcessor
 
getLogger() - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
getLoggingLevel() - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
getLoggingLevel() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getLoggingLevel() - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
getLogListeners() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getManagementAgent() - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
getManagementInterceptStrategy() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getManagementMBeanAssembler() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getManagementName() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getManagementNameStrategy() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getManagementObjectNameStrategy() - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
getManagementObjectStrategy() - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
getManagementStrategy() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getMandatoryDefaultEndpoint() - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
getMaxCacheSize() - Method in class org.apache.camel.impl.engine.ServicePool
 
getMaxFileStoreSize() - Method in class org.apache.camel.impl.engine.FileStateRepository
 
getMaximumCacheSize() - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
getMaximumCacheSize() - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
getMaximumCacheSize() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
getMaximumCacheSize() - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
getMaximumFailoverAttempts() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getMaximumRedeliveries() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getMaximumRedeliveryDelay() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getMaximumRequestsPerPeriodExpression() - Method in class org.apache.camel.processor.Throttler
 
getMaximumRetries() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
getMaximumRetryDelay() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
getMaxInflightExchanges() - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
getMaxMessages() - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
 
getMaxProcessingTime() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getMaxProcessingTime() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getMaxProcessingTime() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getMaxProcessingTime() - Method in class org.apache.camel.support.dump.StepStatDump
 
getMaxRetryAttempts() - Method in class org.apache.camel.impl.saga.InMemorySagaService
 
getMaxSeconds() - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
 
getMaxSeconds() - Method in class org.apache.camel.impl.engine.DurationRoutePolicyFactory
 
getMDCLoggingKeysPattern() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getMeanProcessingTime() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getMeanProcessingTime() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getMeanProcessingTime() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getMeanProcessingTime() - Method in class org.apache.camel.support.dump.StepStatDump
 
getMessage() - Method in exception org.apache.camel.language.simple.types.SimpleIllegalSyntaxException
 
getMessage() - Method in class org.apache.camel.processor.RollbackProcessor
 
getMessage() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getMessageAsXml() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
getMessageFrequency() - Method in class org.apache.camel.processor.SamplingThrottler
 
getMessageHistoryFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getMessageIdExpression() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getMetaData() - Method in class org.apache.camel.impl.health.AbstractHealthCheck
 
getMethodName() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
getMinProcessingTime() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getMinProcessingTime() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getMinProcessingTime() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getMinProcessingTime() - Method in class org.apache.camel.support.dump.StepStatDump
 
getMisses() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
Gets the cache misses statistic

Will return -1 if it cannot determine this if a custom cache was used.

getMisses() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
getMisses() - Method in class org.apache.camel.impl.engine.ServicePool
 
getModelJAXBContextFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getModelJSonSchema(String) - Method in class org.apache.camel.runtimecatalog.impl.CamelContextJSonSchemaResolver
 
getName() - Method in class org.apache.camel.component.properties.ClasspathPropertiesSource
 
getName() - Method in class org.apache.camel.component.properties.EnvPropertiesFunction
 
getName() - Method in class org.apache.camel.component.properties.FilePropertiesSource
 
getName() - Method in interface org.apache.camel.component.properties.PropertiesFunction
Name of the function which is used as name: to let the properties component know its a function.
getName() - Method in class org.apache.camel.component.properties.RefPropertiesSource
 
getName() - Method in class org.apache.camel.component.properties.ServiceHostPropertiesFunction
 
getName() - Method in class org.apache.camel.component.properties.ServicePortPropertiesFunction
 
getName() - Method in class org.apache.camel.component.properties.ServicePropertiesFunction
 
getName() - Method in class org.apache.camel.component.properties.SysPropertiesFunction
 
getName() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getName() - Method in class org.apache.camel.impl.engine.DefaultCamelContextNameStrategy
 
getName() - Method in class org.apache.camel.impl.engine.DefaultManagementNameStrategy
 
getName() - Method in class org.apache.camel.impl.engine.ExplicitCamelContextNameStrategy
 
getNamePattern() - Method in class org.apache.camel.impl.engine.DefaultManagementNameStrategy
 
getNameStrategy() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getNewExchangeExpression() - Method in class org.apache.camel.processor.WireTapProcessor
 
getNewExchangeProcessors() - Method in class org.apache.camel.processor.WireTapProcessor
 
getNextCounter() - Static method in class org.apache.camel.impl.engine.DefaultCamelContextNameStrategy
 
getNextName() - Method in class org.apache.camel.impl.engine.DefaultCamelContextNameStrategy
 
getNextName() - Method in class org.apache.camel.impl.engine.DefaultManagementNameStrategy
 
getNextName() - Method in class org.apache.camel.impl.engine.ExplicitCamelContextNameStrategy
 
getNextProcessor() - Method in class org.apache.camel.processor.channel.DefaultChannel
 
getNodeCounter(String) - Static method in class org.apache.camel.impl.engine.DefaultNodeIdFactory
Returns the counter for the given node key, lazily creating one if necessary
getNodeIdFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getNodePattern() - Method in class org.apache.camel.impl.engine.DefaultMessageHistoryFactory
 
getNotFilteredCount() - Method in class org.apache.camel.processor.ChoiceProcessor
Gets the number of Exchanges that did not match any predicate and are routed using otherwise
getNumberOfHashGroups() - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
getOnCompletion(String) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getOnException(String) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getOnExceptionOccurred() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getOnPrepare() - Method in class org.apache.camel.processor.RecipientList
 
getOnPrepare() - Method in class org.apache.camel.processor.WireTapProcessor
 
getOnRedelivery() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getOpenedAt() - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
getOperation() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
getOperator() - Method in class org.apache.camel.language.simple.ast.BinaryExpression
 
getOperator() - Method in class org.apache.camel.language.simple.ast.LogicalExpression
 
getOperator() - Method in class org.apache.camel.language.simple.ast.UnaryExpression
 
getOperatorText(BinaryOperatorType) - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType
 
getOperatorText(LogicalOperatorType) - Method in enum org.apache.camel.language.simple.types.LogicalOperatorType
 
getOperatorText(UnaryOperatorType) - Method in enum org.apache.camel.language.simple.types.UnaryOperatorType
 
getOptimisticLockingExecutorService() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getOptimisticLockRetryPolicy() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getOrder() - Method in class org.apache.camel.impl.engine.DeferServiceStartupListener
 
getOrder() - Method in class org.apache.camel.processor.CamelInternalProcessor.BacklogDebuggerAdvice
 
getOrder() - Method in class org.apache.camel.processor.CamelInternalProcessor.BacklogTracerAdvice
 
getOrder() - Method in class org.apache.camel.processor.CamelInternalProcessor.DebuggerAdvice
 
getOrder() - Method in class org.apache.camel.processor.CamelInternalProcessor.StreamCachingAdvice
 
getOrElseProperty(Object, String, Object, boolean) - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
getOrFindTypeConverter(Class<?>, Class<?>) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
getOriginal() - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
getOriginalEndpoint() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
getOriginalInMessage() - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
getOrLookupCamelContext() - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
Strategy to get the CamelContext to use.
getOtherJSonSchema(String) - Method in class org.apache.camel.runtimecatalog.impl.CamelContextJSonSchemaResolver
 
getOtherwise() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getOutBatchSize() - Method in class org.apache.camel.processor.Resequencer
 
getOutput() - Method in class org.apache.camel.processor.channel.DefaultChannel
 
getOutput() - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
Gets the output
getOutput() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Returns the output processor
getOverrideProperties() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
getPackageScanClassResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getPackageScanResourceResolver() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getPath() - Method in class org.apache.camel.component.properties.PropertiesLocation
 
getPattern() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
getPattern() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
getPattern() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getPattern() - Method in class org.apache.camel.processor.SendProcessor
 
getPendingExchangesSize() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getPendingExchangesSize() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
getPendingExchangesSize() - Method in class org.apache.camel.processor.WireTapProcessor
 
getPendingInflightExchanges(RouteStartupOrder) - Static method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
Calculates the total number of inflight exchanges for the given route
getPendingRedeliveryCount() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Gets the number of exchanges that are pending for redelivery
getPendingTasks() - Method in class org.apache.camel.impl.engine.DefaultReactiveExecutor
 
getPhase() - Method in class org.apache.camel.impl.engine.DefaultRouteError
 
getPollingConsumerServicePool() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getPool(Endpoint) - Method in class org.apache.camel.impl.engine.ServicePool
 
getPostProcessorHelper() - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
Strategy to get the CamelPostProcessorHelper
getPredicate() - Method in class org.apache.camel.processor.FilterProcessor
 
getPredicate() - Method in class org.apache.camel.processor.LoopProcessor
 
getProcessor(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getProcessor(String, Class<T>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getProcessor() - Method in class org.apache.camel.impl.engine.EventDrivenConsumerRoute
 
getProcessor() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
getProcessor() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
getProcessor() - Method in class org.apache.camel.processor.Resequencer
 
getProcessor() - Method in class org.apache.camel.processor.StreamResequencer
Returns the next processor.
getProcessorDefinition() - Method in class org.apache.camel.processor.channel.DefaultChannel
 
getProcessorFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getProcessors() - Method in interface org.apache.camel.processor.loadbalancer.LoadBalancer
Returns the current processors available to this load balancer
getProcessors() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
getProcessors() - Method in class org.apache.camel.processor.MulticastProcessor
Returns the producers to multicast to
getProcessors() - Method in class org.apache.camel.processor.Pipeline
 
getProcessorStats() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getProducer() - Method in interface org.apache.camel.processor.ProcessorExchangePair
 
getProducerServicePool() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getProperties(Object, Map<String, Object>, String) - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
getProperties(Object, Map<String, Object>, String, boolean) - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
getProperties() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
getPropertiesComponent() - Method in class org.apache.camel.component.properties.DefaultPropertiesParser
 
getPropertiesComponent() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getPropertiesParser() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
getProperty(String) - Method in class org.apache.camel.component.properties.AbstractLocationPropertiesSource
 
getProperty(String) - Method in class org.apache.camel.component.properties.RefPropertiesSource
 
getPropertyGetter(Class<?>, String, boolean) - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
getPropertyName() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
getPropertyName() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
getRandomNumberGenerator() - Static method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getRatios() - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
getReactiveExecutor() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRedeliveries() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getRedeliveries() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getRedeliveries() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getRedeliveries() - Method in class org.apache.camel.support.dump.StepStatDump
 
getRedeliveryDelay() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getRedeliveryPolicy() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
getRegistry() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRegistry(Class<T>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRejectedPolicy() - Method in class org.apache.camel.processor.ThreadsProcessor
 
getRejectOld() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
 
getRepositories() - Method in class org.apache.camel.impl.health.DefaultHealthCheckRegistry
 
getResetTimestamp() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getResetTimestamp() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getResetTimestamp() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getResetTimestamp() - Method in class org.apache.camel.support.dump.StepStatDump
 
getResolver() - Method in class org.apache.camel.component.properties.PropertiesLocation
 
getResolver() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
getResourcePath() - Method in class org.apache.camel.impl.engine.DefaultFactoryFinder
 
getResources(ClassLoader, String) - Method in class org.apache.camel.impl.engine.BasePackageScanResolver
Strategy to get the resources by the given classloader.
getResources(ClassLoader, String) - Method in class org.apache.camel.impl.engine.WebSpherePackageScanClassResolver
Overloaded to handle specific problem with getting resources on the IBM WebSphere platform.
getRestConfiguration() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRestConfiguration(String, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRestConfigurations() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRestRegistry() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRestRegistryFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getResults() - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
getResumePercentOfMax() - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
getRetriesExhaustedLogLevel() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getRetryAttemptedLogInterval() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getRetryAttemptedLogLevel() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
getRetryDelay() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
getRetryDelayInMilliseconds() - Method in class org.apache.camel.impl.saga.InMemorySagaService
 
getRetryWhilePolicy() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getRight() - Method in class org.apache.camel.runtimecatalog.impl.Pair
 
getRoute(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRoute() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
getRoute() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getRoute() - Method in class org.apache.camel.impl.engine.DefaultRouteStartupOrder
 
getRoute() - Method in class org.apache.camel.impl.event.AbstractRouteEvent
 
getRouteContext() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
getRouteContext() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
getRouteContext() - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
getRouteContext() - Method in class org.apache.camel.processor.channel.DefaultChannel
 
getRouteController() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRouteController() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getRouteDescription() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
getRouteId() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getRouteId() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
getRouteId() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
 
getRouteId() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
getRoutePolicyFactories() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRoutePolicyList() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getRoutes() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRouteService() - Method in class org.apache.camel.impl.engine.DefaultRouteStartupOrder
 
getRouteServices() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRouteStartupOrder() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRouteStats() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getRouteStatus(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRouteStatus(String) - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
getRunningWorkers() - Method in class org.apache.camel.impl.engine.DefaultReactiveExecutor
 
getRuntimeEndpointRegistry() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getRuntimeRoute() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getRuntimeWeight() - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
 
getSaga(String) - Method in class org.apache.camel.impl.saga.InMemorySagaService
 
getSagaService() - Method in class org.apache.camel.processor.saga.SagaProcessor
 
getSamplePeriod() - Method in class org.apache.camel.processor.SamplingThrottler
 
getScheme() - Method in class org.apache.camel.impl.transformer.TransformerKey
 
getScope() - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
getSelfProcessingTime() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getSelfProcessingTime() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getSequenceSender() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Returns the sequence sender.
getService() - Method in class org.apache.camel.impl.event.ServiceStartupFailureEvent
 
getService() - Method in class org.apache.camel.impl.event.ServiceStopFailureEvent
 
getServices() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
getServices() - Method in class org.apache.camel.impl.engine.DefaultRouteStartupOrder
 
getShortMessage() - Method in exception org.apache.camel.language.simple.types.SimpleIllegalSyntaxException
Gets a short error message.
getShutdownAwaitTermination() - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
getShutdownRoute() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getShutdownRoute() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getShutdownRunningTask() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getShutdownRunningTask() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getShutdownStrategy() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getSource() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
Gets the source which uses this cache
getSource() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
getSources() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
getSpoolCipher() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
getSpoolDirectory() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
getSpoolThreshold() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
getSpoolUsedHeapMemoryLimit() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
getSpoolUsedHeapMemoryThreshold() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
getSSLContextParameters() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getStartTimestamp() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getStartTimestamp() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getStartupOrder() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
getStartupOrder() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getStartupOrder() - Method in class org.apache.camel.impl.engine.DefaultRouteStartupOrder
 
getState(String) - Method in class org.apache.camel.impl.engine.FileStateRepository
 
getState(String) - Method in class org.apache.camel.impl.engine.MemoryStateRepository
 
getState() - Method in class org.apache.camel.processor.interceptor.BreakpointSupport
 
getState() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getState() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getState() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getState() - Method in class org.apache.camel.support.dump.StepStatDump
 
getStatistics() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
getStatistics() - Method in class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
 
getStatistics() - Method in class org.apache.camel.impl.engine.DefaultEndpointUtilizationStatistics
 
getStatistics() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
getStatistics() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getStepId() - Method in class org.apache.camel.impl.event.AbstractStepEvent
 
getStepStats() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getStickyKey(Object) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
A strategy to create the key for the sticky load balancing map.
getStreamCachingStrategy() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getSuggestionStrategy() - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
getSuspendedBreakpointNodeIds() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
getSuspendedExchange(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
Gets the exchanged suspended at the given breakpoint id or null if there is none at that id.
getSystemPropertiesMode() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
getText() - Method in class org.apache.camel.language.simple.ast.LiteralExpression
 
getText() - Method in interface org.apache.camel.language.simple.ast.LiteralNode
Gets the text
getText() - Method in class org.apache.camel.language.simple.types.SimpleToken
 
getThreadNamePattern() - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
getThreadPoolFactory() - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
getThreadPoolProfile(String) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
getTimeout() - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
getTimeout() - Method in class org.apache.camel.processor.MulticastProcessor
An optional timeout in millis when using parallel processing
getTimeout() - Method in class org.apache.camel.processor.PollEnricher
 
getTimeout() - Method in class org.apache.camel.processor.RecipientList
 
getTimeout() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Returns this resequencer's timeout value.
getTimeout() - Method in class org.apache.camel.processor.StreamResequencer
Returns this resequencer's timeout.
getTimeoutCheckerExecutorService() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getTimeoutHandlers() - Method in class org.apache.camel.processor.resequencer.Timeout
Returns the timeout handler that has been registered for notification.
getTimePeriodMillis() - Method in class org.apache.camel.processor.Throttler
 
getTimestamp() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
getTimeTaken() - Method in class org.apache.camel.impl.event.ExchangeSentEvent
 
getTimeUnit() - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
getTo() - Method in class org.apache.camel.impl.transformer.TransformerKey
 
getToken() - Method in class org.apache.camel.language.simple.ast.BaseSimpleNode
 
getToken() - Method in interface org.apache.camel.language.simple.ast.SimpleNode
Gets the token by which this model was based upon
getToken() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
getToNode() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
getTotalCompleted() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanges completed and outgoing from the aggregator
getTotalIn() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Total number of exchanges arrived into the aggregator
getTotalProcessingTime() - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
getTotalProcessingTime() - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
getTotalProcessingTime() - Method in class org.apache.camel.support.dump.RouteStatDump
 
getTotalProcessingTime() - Method in class org.apache.camel.support.dump.StepStatDump
 
getTraceCounter() - Method in class org.apache.camel.impl.engine.DefaultTracer
 
getTraceCounter() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
getTraceFilter() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
getTraceLabel() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.CatchProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.ChoiceProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.Delayer
 
getTraceLabel() - Method in class org.apache.camel.processor.EvaluateExpressionProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.FilterProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.FinallyProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
getTraceLabel() - Method in class org.apache.camel.processor.LogProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.LoopProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.MethodCallProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.MulticastProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.Pipeline
 
getTraceLabel() - Method in class org.apache.camel.processor.RecipientListProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.Resequencer
 
getTraceLabel() - Method in class org.apache.camel.processor.RollbackProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.RoutingSlip
 
getTraceLabel() - Method in class org.apache.camel.processor.SamplingThrottler
 
getTraceLabel() - Method in class org.apache.camel.processor.ScriptProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.SendProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.SetBodyProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.SortProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.Splitter
 
getTraceLabel() - Method in class org.apache.camel.processor.StepProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.StreamResequencer
 
getTraceLabel() - Method in class org.apache.camel.processor.Throttler
 
getTraceLabel() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.TransformProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.TryProcessor
 
getTraceLabel() - Method in class org.apache.camel.processor.WireTapProcessor
 
getTracePattern() - Method in class org.apache.camel.impl.engine.DefaultTracer
 
getTracePattern() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
getTracer() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getTracingPattern() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getTracingPattern() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
getTransformerRegistry() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getType() - Method in class org.apache.camel.impl.validator.ValidatorKey
 
getType() - Method in class org.apache.camel.language.simple.types.SimpleToken
 
getType() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Gets the type of this token
getType() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyParameterInfo
 
getType() - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
getType() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
getType() - Method in class org.apache.camel.support.dump.MessageDump.Body
 
getType() - Method in class org.apache.camel.support.dump.MessageDump.Header
 
getTypeConverter(Class<?>, Class<?>) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
getTypeConverter() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getTypeConverterExists() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
getTypeConverterExistsLoggingLevel() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
getTypeConverterLoaders() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
getTypeConverterRegistry() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getUid() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
getUnitOfWorkFactory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getUnits() - Method in class org.apache.camel.processor.SamplingThrottler
 
getUptime() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getUptime() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
getUptimeMillis() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getUptimeMillis() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
getUri() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
getUri() - Method in class org.apache.camel.processor.WireTapProcessor
 
getUriDelimiter() - Method in class org.apache.camel.processor.RoutingSlip
 
getUuidGenerator() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getValidatorRegistry() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getValue() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Gets the input value in this token
getValue(Exchange) - Method in class org.apache.camel.processor.aggregate.AbstractListAggregationStrategy
This method is implemented by the sub-class and is called to retrieve an instance of the value that will be aggregated and forwarded to the receiving end point.
getValue(Exchange) - Method in class org.apache.camel.processor.aggregate.GroupedBodyAggregationStrategy
 
getValue(Exchange) - Method in class org.apache.camel.processor.aggregate.GroupedExchangeAggregationStrategy
 
getValue(Exchange) - Method in class org.apache.camel.processor.aggregate.GroupedMessageAggregationStrategy
 
getValue() - Method in class org.apache.camel.support.dump.MessageDump.Body
 
getValue() - Method in class org.apache.camel.support.dump.MessageDump.Header
 
getVersion() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
getWhen() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
 
GroupedBodyAggregationStrategy - Class in org.apache.camel.processor.aggregate
Aggregate body of input Message into a single combined Exchange holding all the aggregated bodies in a List of type Object as the message body.
GroupedBodyAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.GroupedBodyAggregationStrategy
 
GroupedExchangeAggregationStrategy - Class in org.apache.camel.processor.aggregate
Aggregate all exchanges into a single combined Exchange holding all the aggregated exchanges in a List of Exchange as the message body.
GroupedExchangeAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.GroupedExchangeAggregationStrategy
 
GroupedMessageAggregationStrategy - Class in org.apache.camel.processor.aggregate
Aggregate all Message into a single combined Exchange holding all the aggregated messages in a List of Message as the message body.
GroupedMessageAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.GroupedMessageAggregationStrategy
 

H

halfOpenCircuit(Route) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
handleException() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
 
handleSagaCompletion(Exchange, CamelSagaCoordinator, CamelSagaCoordinator, AsyncCallback) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
handleSleepInterruptedException(InterruptedException, Exchange) - Method in class org.apache.camel.processor.DelayProcessorSupport
Called when a sleep is interrupted; allows derived classes to handle this case differently
handoverSynchronization(Exchange) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
handoverSynchronization(Exchange, Predicate<Synchronization>) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
hasBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
hasComponent(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
hasEndpoint(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
hasFunction(String) - Method in class org.apache.camel.component.properties.PropertiesComponent
Is there a PropertiesFunction with the given name?
hasFunctionStartToken(String) - Static method in class org.apache.camel.language.simple.SimpleTokenizer
Does the expression include a simple function.
hashCode() - Method in class org.apache.camel.component.properties.PropertiesLocation
 
hashCode() - Method in class org.apache.camel.impl.health.AbstractHealthCheck
 
hashCode() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
 
hashCode() - Method in class org.apache.camel.runtimecatalog.impl.Pair
 
HashMapHeadersMapFactory - Class in org.apache.camel.impl.engine
HashMap HeadersMapFactory which uses a plain HashMap.
HashMapHeadersMapFactory() - Constructor for class org.apache.camel.impl.engine.HashMapHeadersMapFactory
 
hasNext() - Method in class org.apache.camel.impl.engine.SubscribeMethodProcessor
 
hasNext() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
hasNext() - Method in class org.apache.camel.processor.channel.DefaultChannel
 
hasNext() - Method in class org.apache.camel.processor.ChoiceProcessor
 
hasNext() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
hasNext() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
hasNext() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
hasNext() - Method in class org.apache.camel.processor.MulticastProcessor
 
hasNext() - Method in class org.apache.camel.processor.Pipeline
 
hasNext() - Method in class org.apache.camel.processor.Resequencer
 
hasNext(Exchange) - Method in interface org.apache.camel.processor.RoutingSlip.RoutingSlipIterator
Are the more routing slip(s)?
hasNext() - Method in class org.apache.camel.processor.StreamResequencer
 
hasNext() - Method in class org.apache.camel.processor.TryProcessor
 
hasService(Object) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
hasService(Class<T>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
hasServices(Class<T>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
hasSimpleFunction(String) - Static method in class org.apache.camel.language.simple.SimpleLanguage
Does the expression include a simple function.
hasTimeoutOccurred() - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
header(String) - Static method in class org.apache.camel.language.header.HeaderLanguage
 
header - Variable in class org.apache.camel.processor.RoutingSlip
 
Header() - Constructor for class org.apache.camel.support.dump.MessageDump.Header
 
HeaderLanguage - Class in org.apache.camel.language.header
A language for header expressions.
HeaderLanguage() - Constructor for class org.apache.camel.language.header.HeaderLanguage
 
HeadersMapFactoryResolver - Class in org.apache.camel.impl.engine
Factory to create the HeadersMapFactory implementation to be used.
HeadersMapFactoryResolver() - Constructor for class org.apache.camel.impl.engine.HeadersMapFactoryResolver
 
headersOgnlExpression(String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns the expression for the exchanges inbound message header invoking methods defined in a simple OGNL notation
higher(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the next higher element in the sequence to the given element.
hitCounter - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 

I

id - Variable in class org.apache.camel.processor.RoutingSlip
 
id - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
id - Variable in class org.apache.camel.processor.SendProcessor
 
id - Variable in class org.apache.camel.processor.TryProcessor
 
IdempotentConsumer - Class in org.apache.camel.processor.idempotent
An implementation of the Idempotent Consumer pattern.
IdempotentConsumer(Expression, IdempotentRepository, boolean, boolean, boolean, boolean, Processor) - Constructor for class org.apache.camel.processor.idempotent.IdempotentConsumer
 
IdempotentOnCompletion - Class in org.apache.camel.processor.idempotent
On completion strategy for IdempotentConsumer.
IdempotentOnCompletion(IdempotentRepository, String, boolean, boolean) - Constructor for class org.apache.camel.processor.idempotent.IdempotentOnCompletion
 
ifNotException(Throwable, Exchange, AsyncCallback, Runnable) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
ifNotException(Throwable, Exchange, boolean, CamelSagaCoordinator, CamelSagaCoordinator, AsyncCallback, Runnable) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
ignoreInvalidEndpoint - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
ignoreInvalidEndpoints - Variable in class org.apache.camel.processor.RoutingSlip
 
incrementTraceCounter() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
index - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
init() - Method in class org.apache.camel.language.simple.SimpleLanguage
 
init(List<Class<?>>) - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
initChannel(RouteContext, NamedNode, NamedNode, List<InterceptStrategy>, Processor, NamedRoute, boolean, boolean) - Method in class org.apache.camel.processor.channel.DefaultChannel
Initializes the channel.
initTypeConverterLoaders() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
initTypeConverterLoaders() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
injectBindToRegistryFields(Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
injectBindToRegistryMethods(Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
injectClass(Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
injectField(Field, String, String, Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
injectField(Field, String, String, Object, String, boolean) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
injectFieldBean(Field, String, Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
injectFieldProperty(Field, String, String, Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
injectFields(Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
A strategy method to allow implementations to perform some custom JBI based injection of the POJO
injectMethods(Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
injectNestedClasses(Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
injector - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
InMemorySagaCoordinator - Class in org.apache.camel.impl.saga
A in-memory implementation of a saga coordinator.
InMemorySagaCoordinator(CamelContext, InMemorySagaService, String) - Constructor for class org.apache.camel.impl.saga.InMemorySagaCoordinator
 
InMemorySagaService - Class in org.apache.camel.impl.saga
A in-memory implementation of a saga service.
InMemorySagaService() - Constructor for class org.apache.camel.impl.saga.InMemorySagaService
 
insert(E) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Inserts the given element into this resequencer.
InstanceMethodFallbackTypeConverter - Class in org.apache.camel.impl.converter
A TypeConverter implementation which instantiates an object so that an instance method can be used as a fallback type converter
InstanceMethodFallbackTypeConverter(CachingInjector<?>, Method, TypeConverterRegistry, boolean) - Constructor for class org.apache.camel.impl.converter.InstanceMethodFallbackTypeConverter
 
InstanceMethodTypeConverter - Class in org.apache.camel.impl.converter
A TypeConverter implementation which instantiates an object so that an instance method can be used as a type converter
InstanceMethodTypeConverter(CachingInjector<?>, Method, TypeConverterRegistry, boolean) - Constructor for class org.apache.camel.impl.converter.InstanceMethodTypeConverter
 
InterceptEndpointProcessor - Class in org.apache.camel.processor
Endpoint intercept processor so we know the processor is supposed to intercept an endpoint.
InterceptEndpointProcessor(String, Processor) - Constructor for class org.apache.camel.processor.InterceptEndpointProcessor
 
InterceptorToAsyncProcessorBridge - Class in org.apache.camel.processor
A bridge to have regular interceptors implemented as Processor work with the asynchronous routing engine without causing side effects.
InterceptorToAsyncProcessorBridge(Processor) - Constructor for class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
Constructs the bridge
InterceptSendToEndpointProcessor - Class in org.apache.camel.impl.engine
Processor used to interceptor and detour the routing when using the DefaultInterceptSendToEndpoint functionality.
InterceptSendToEndpointProcessor(DefaultInterceptSendToEndpoint, Endpoint, AsyncProducer, boolean) - Constructor for class org.apache.camel.impl.engine.InterceptSendToEndpointProcessor
 
InterceptSendToMockEndpointStrategy - Class in org.apache.camel.impl.engine
A EndpointStrategy which is capable of mocking endpoints.
InterceptSendToMockEndpointStrategy() - Constructor for class org.apache.camel.impl.engine.InterceptSendToMockEndpointStrategy
Mock all endpoints.
InterceptSendToMockEndpointStrategy(String) - Constructor for class org.apache.camel.impl.engine.InterceptSendToMockEndpointStrategy
Mock endpoints based on the given pattern.
InterceptSendToMockEndpointStrategy(String, boolean) - Constructor for class org.apache.camel.impl.engine.InterceptSendToMockEndpointStrategy
Mock endpoints based on the given pattern.
interrupt(String) - Method in class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
 
interrupt(Exchange) - Method in class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
 
InvertingPackageScanFilter - Class in org.apache.camel.impl.scan
Package scan filter for inverting the match result of a subfilter.
InvertingPackageScanFilter(PackageScanFilter) - Constructor for class org.apache.camel.impl.scan.InvertingPackageScanFilter
 
INVOCATION_ATTEMPT_TIME - Static variable in class org.apache.camel.impl.health.AbstractHealthCheck
 
INVOCATION_COUNT - Static variable in class org.apache.camel.impl.health.AbstractHealthCheck
 
INVOCATION_TIME - Static variable in class org.apache.camel.impl.health.AbstractHealthCheck
 
invoke(Object, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyMethodInfo
 
IOConverter - Class in org.apache.camel.converter
Some core java.io based Type Converters
IOConverterLoader - Class in org.apache.camel.converter
Source code generated by org.apache.camel:apt
IOConverterLoader() - Constructor for class org.apache.camel.converter.IOConverterLoader
 
isAcceptableScheme(String) - Method in class org.apache.camel.impl.engine.BasePackageScanResolver
 
isAggregateOnException() - Method in class org.apache.camel.processor.Enricher
 
isAggregateOnException() - Method in class org.apache.camel.processor.PollEnricher
 
isAllowDuplicates() - Method in class org.apache.camel.processor.Resequencer
 
isAllowNullNewExchange() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
isAllowNullOldExchange() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
isAllowOptimisedComponents() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
isAllowRedeliveryWhileStopping() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isAllowUseOriginalMessage() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isAllowUseOriginalMessage() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
isAnySpoolRules() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
isAsyncDelayed() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
isAsyncDelayed() - Method in class org.apache.camel.processor.Throttler
 
isAsyncDelayedRedelivery() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isAutoCreateComponents() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isAutoDiscoverPropertiesSources() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
isAutoStartup() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isAutoStartup() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
isAutoStartup() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
isBacklogTracing() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isBacklogTracing() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
isBasicPropertyBinding() - Method in class org.apache.camel.impl.engine.DefaultGlobalEndpointConfiguration
 
isBatchConsumer() - Method in class org.apache.camel.processor.Resequencer
 
isBinary() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is binary operator
isBodyIncludeFiles() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
isBodyIncludeFiles() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
isBodyIncludeStreams() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
isBodyIncludeStreams() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
isBooleanValue() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
isBooleanValueSupported() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isBridgeErrorHandler() - Method in class org.apache.camel.impl.engine.DefaultGlobalEndpointConfiguration
 
isCallerRunsWhenRejected() - Method in class org.apache.camel.processor.DelayProcessorSupport
 
isCallerRunsWhenRejected() - Method in class org.apache.camel.processor.Throttler
 
isCancelledOrInterrupted(Exchange) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Strategy to determine if the exchange was cancelled or interrupted
isCanPromote() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry.FallbackTypeConverter
 
isCaseInsensitive() - Method in class org.apache.camel.impl.engine.DefaultHeadersMapFactory
 
isCaseInsensitive() - Method in class org.apache.camel.impl.engine.HashMapHeadersMapFactory
 
isCompleteAllOnStop() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isCompleted(String, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Tests whether the given exchange is complete or not
isCompletionEager() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
isCompletionFromBatchConsumer() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isCompletionOnNewCorrelationGroup() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isContextScopedErrorHandler() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
isContinued() - Method in class org.apache.camel.impl.event.ExchangeFailureHandledEvent
 
isCopy() - Method in class org.apache.camel.processor.LoopProcessor
 
isCopy() - Method in class org.apache.camel.processor.WireTapProcessor
 
isCopyMessage() - Method in class org.apache.camel.impl.engine.DefaultMessageHistoryFactory
 
isCreateCopy() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
isDeadLetterChannel() - Method in class org.apache.camel.impl.event.ExchangeFailureHandledEvent
 
isDeadLetterChannel() - Method in class org.apache.camel.impl.event.ExchangeFailureHandlingEvent
 
isDeadLetterChannel() - Method in class org.apache.camel.processor.errorhandler.DeadLetterChannel
 
isDeadLetterChannel() - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
Whether this error handler handles exhausted errors by moving the exchange to a dead letter channel.
isDeadLetterHandleNewException() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
isDebugging() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isDebugging() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
isDefaultFallbackEnabled() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
isDisabled() - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
isDiscardOnAggregationFailure() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isDiscardOnCompletionTimeout() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isDone(Exchange) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Strategy to determine if the exchange is done so we can continue
isDoubleQuote() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is double quote
isDynamic(K) - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
isDynamic(String) - Method in class org.apache.camel.impl.engine.DefaultEndpointRegistry
 
isDynamic(String) - Method in class org.apache.camel.impl.engine.DefaultTransformerRegistry
 
isDynamic(DataType, DataType) - Method in class org.apache.camel.impl.engine.DefaultTransformerRegistry
 
isDynamic(DataType) - Method in class org.apache.camel.impl.engine.DefaultValidatorRegistry
 
isDynamicUri() - Method in class org.apache.camel.processor.WireTapProcessor
 
isEager() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
isEagerCheckCompletion() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isEmpty() - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
isEmpty(Object) - Static method in class org.apache.camel.runtimecatalog.impl.CatalogHelper
Tests whether the value is null or an empty string.
isEmpty(Object) - Static method in class org.apache.camel.runtimecatalog.impl.URISupport
Tests whether the value is null or an empty string.
isEnabled() - Method in class org.apache.camel.impl.engine.DefaultMessageHistoryFactory
 
isEnabled() - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
isEnabled(CamelEvent) - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
isEnabled() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
isEnabled() - Method in class org.apache.camel.impl.engine.DefaultTracer
 
isEnabled() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
isEnabled() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
isEol() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is eol
isEscape() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is escape
isEventNotifierEnabled() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
isEventNotifierEnabled() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
isEventNotifierEnabled() - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
isExponentialBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
isExtendedStatistics() - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
isExtendedStatistics() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
 
isExtendedStatistics() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
isFixedName() - Method in class org.apache.camel.impl.engine.DefaultCamelContextNameStrategy
 
isFixedName() - Method in class org.apache.camel.impl.engine.DefaultManagementNameStrategy
 
isFixedName() - Method in class org.apache.camel.impl.engine.ExplicitCamelContextNameStrategy
 
isFunctionEnd() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is a function end
isFunctionStart() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is a function start
isFunctionSupport() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isGroupExchanges() - Method in class org.apache.camel.processor.Resequencer
 
isHandled() - Method in class org.apache.camel.impl.event.ExchangeFailureHandledEvent
 
isIgnoreInvalidCorrelationKeys() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isIgnoreInvalidEndpoint() - Method in class org.apache.camel.processor.Enricher
 
isIgnoreInvalidEndpoint() - Method in class org.apache.camel.processor.PollEnricher
 
isIgnoreInvalidEndpoint() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
isIgnoreInvalidEndpoint() - Method in class org.apache.camel.processor.WireTapProcessor
 
isIgnoreInvalidEndpoints() - Method in class org.apache.camel.processor.RecipientList
 
isIgnoreInvalidEndpoints() - Method in class org.apache.camel.processor.RecipientListProcessor
 
isIgnoreInvalidEndpoints() - Method in class org.apache.camel.processor.RoutingSlip
 
isIgnoreInvalidExchanges() - Method in class org.apache.camel.processor.Resequencer
 
isIgnoreInvalidExchanges() - Method in class org.apache.camel.processor.StreamResequencer
 
isIgnoreMissingLocation() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
isIncludeTokens() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
isInstanceOf(Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultHeadersMapFactory
 
isInstanceOf(Map<String, Object>) - Method in class org.apache.camel.impl.engine.HashMapHeadersMapFactory
 
isInterruptThreadsWhileStopping() - Method in class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
 
isJMXDisabled() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isLazyStartProducer() - Method in class org.apache.camel.impl.engine.DefaultGlobalEndpointConfiguration
 
isLenientProperties() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
isLiteralSupported() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isLiteralWithFunctionSupport() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isLoadTypeConverters() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isLogContinued() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogExhausted() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogExhaustedMessageBody() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isLogExhaustedMessageBody() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
isLogExhaustedMessageBody() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogExhaustedMessageHistory() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogHandled() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogical() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is logical operator
isLogInflightExchangesOnTimeout() - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
isLogMask() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isLogMask() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
isLogNewException() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogRetryAttempted() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogRetryStackTrace() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isLogStackTrace() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isManaged(Object) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
isManagedName(Object) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
isMarkRollbackOnly() - Method in class org.apache.camel.processor.RollbackProcessor
 
isMarkRollbackOnlyLast() - Method in class org.apache.camel.processor.RollbackProcessor
 
isMessageHistory() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isMessageHistory() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
isMinusValue() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is a minus operator
isMinusValueSupported() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isNotEmpty(Object) - Static method in class org.apache.camel.runtimecatalog.impl.CatalogHelper
Tests whether the value is not null or an empty string.
isNotEmpty(Object) - Static method in class org.apache.camel.runtimecatalog.impl.URISupport
Tests whether the value is not null or an empty string.
isNullValue() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is a null value
isNullValueSupported() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isNumericValueSupported() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
 
isOptimisticLocking() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isOptional() - Method in class org.apache.camel.component.properties.PropertiesLocation
 
isParallelAggregate() - Method in class org.apache.camel.processor.MulticastProcessor
 
isParallelAggregate() - Method in class org.apache.camel.processor.RecipientList
 
isParallelProcessing() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isParallelProcessing() - Method in class org.apache.camel.processor.MulticastProcessor
 
isParallelProcessing() - Method in class org.apache.camel.processor.RecipientList
 
isPreCompleted(String, Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Tests whether the given exchanges is pre-complete or not
isRandomBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
isRaw(int, List<Pair<Integer>>) - Static method in class org.apache.camel.runtimecatalog.impl.URISupport
 
isReadyToBeClosed() - Method in interface org.apache.camel.throttling.ThrottlingExceptionHalfOpenHandler
Check the state of the Camel route
isRedeliveryAllowed() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
 
isRegex() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
isRejectExecution() - Method in class org.apache.camel.processor.Throttler
 
isRejectOld() - Method in class org.apache.camel.processor.StreamResequencer
 
isRemoveOnDump() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
isRemoveOnFailure() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
isRemoveSpoolDirectoryWhenStopping() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
isRemovingRoutes() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
isReverse() - Method in class org.apache.camel.processor.Resequencer
 
isRoundRobin() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
isRouteAdded() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
isRouteScoped() - Method in class org.apache.camel.processor.channel.DefaultChannel
 
isRunAllowed() - Method in class org.apache.camel.impl.converter.DefaultTypeConverter
 
isRunAllowed() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
 
isRunAllowed() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
isRunAllowedOnPreparingShutdown() - Method in class org.apache.camel.processor.errorhandler.DeadLetterChannel
 
isRunAllowedOnPreparingShutdown() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
isSetupRoutes() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isShareUnitOfWork() - Method in class org.apache.camel.processor.Enricher
 
isShareUnitOfWork() - Method in class org.apache.camel.processor.MulticastProcessor
 
isShareUnitOfWork() - Method in class org.apache.camel.processor.RecipientList
 
isShutdownExecutorService() - Method in class org.apache.camel.processor.RecipientList
 
isShutdownNowOnTimeout() - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
isShutdownOptimisticLockingExecutorService() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isShutdownRoutesInReverseOrder() - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
isShutdownTimeoutCheckerExecutorService() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
isSingleQuote() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is single quote
isSingleStepMode() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
isSingleton(Object, String) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
Implementations can override this method to determine if the bean is singleton.
isSingleton() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
isSingleton() - Method in class org.apache.camel.impl.engine.DeferProducer
 
isSingleton() - Method in class org.apache.camel.impl.engine.InterceptSendToEndpointProcessor
 
isSingleton() - Method in class org.apache.camel.language.constant.ConstantLanguage
 
isSingleton() - Method in class org.apache.camel.language.header.HeaderLanguage
 
isSingleton() - Method in class org.apache.camel.language.property.ExchangePropertyLanguage
 
isSingleton() - Method in class org.apache.camel.language.ref.RefLanguage
 
isSingleton() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
isSingleton() - Method in class org.apache.camel.processor.EventNotifierProducer
 
isSingleton() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
isSkip() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
isSkipDuplicate() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
isSkipFirst() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
isStartingRoutes() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isStartingRoutes() - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
isStatic(K) - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
isStatic(String) - Method in class org.apache.camel.impl.engine.DefaultEndpointRegistry
 
isStatic(String) - Method in class org.apache.camel.impl.engine.DefaultTransformerRegistry
 
isStatic(DataType, DataType) - Method in class org.apache.camel.impl.engine.DefaultTransformerRegistry
 
isStatic(DataType) - Method in class org.apache.camel.impl.engine.DefaultValidatorRegistry
 
isStatisticsEnabled() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Whether statistics is enabled.
isSticky() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
isStopOnAggregateException() - Method in class org.apache.camel.processor.MulticastProcessor
 
isStopOnAggregateException() - Method in class org.apache.camel.processor.RecipientList
 
isStopOnException() - Method in class org.apache.camel.processor.MulticastProcessor
Should the multicast processor stop processing further exchanges in case of an exception occurred?
isStopOnException() - Method in class org.apache.camel.processor.RecipientList
 
isStoreAsBodyOnCompletion() - Method in class org.apache.camel.processor.aggregate.AbstractListAggregationStrategy
Whether to store the completed aggregated List as message body, or to keep as property on the exchange.
isStreamCaching() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isStreamCaching() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
isStreamCachingInUse() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isStreaming() - Method in class org.apache.camel.processor.MulticastProcessor
Is the multicast processor working in streaming mode?

In streaming mode: we use Iterable to ensure we can send messages as soon as the data becomes available for parallel processing, we start aggregating responses as they get send back to the processor; this means the AggregationStrategy has to take care of handling out-of-order arrival of exchanges

isStreaming() - Method in class org.apache.camel.processor.RecipientList
 
isSuppressLoggingOnTimeout() - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
isThreadedAsyncMode() - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
isThresholdExceeded() - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
isTraceBeforeAndAfterRoute() - Method in class org.apache.camel.impl.engine.DefaultTracer
 
isTracing() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isTracing() - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
isTransacted() - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
isTransactedBy(Object) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
isTypeConverterStatisticsEnabled() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isUnary() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is unary operator
isUseBreadcrumb() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isUseCollisionAvoidance() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isUseDataType() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isUseExponentialBackOff() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
isUseMDCLogging() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isUseOriginalBodyPolicy() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
isUseOriginalInBody() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
isUseOriginalInMessage() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicy
 
isUseOriginalMessagePolicy() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
isValid(Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
isValid(E) - Method in interface org.apache.camel.processor.resequencer.SequenceElementComparator
Returns true if the o1 can be used in this comparator.
isValidConverterMethod(Method) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
isValidFallbackConverterMethod(Method) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
isValidMethod(Method) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
Validates whether the given method is valid.
isVetoStarted() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
isWebSphereClassLoader(ClassLoader) - Static method in class org.apache.camel.impl.engine.WebSpherePackageScanClassResolver
Is the classloader from IBM and thus the WebSphere platform?
isWhitespace() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
Whether the type is whitespace
isXml() - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
iterable(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Creates an iterable over the value
iterator(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Creates an iterator over the value

J

JavaUuidGenerator - Class in org.apache.camel.impl.engine
This implementation uses the UUID from Java.
JavaUuidGenerator() - Constructor for class org.apache.camel.impl.engine.JavaUuidGenerator
 

L

LANGUAGE_RESOLVER_RESOURCE_PATH - Static variable in class org.apache.camel.impl.engine.DefaultLanguageResolver
 
LANGUAGE_RESOURCE_PATH - Static variable in class org.apache.camel.impl.engine.DefaultLanguageResolver
 
languageFactory - Variable in class org.apache.camel.impl.engine.DefaultLanguageResolver
 
languageJSonSchema(String) - Method in class org.apache.camel.runtimecatalog.impl.DefaultRuntimeCamelCatalog
 
languageResolver - Variable in class org.apache.camel.impl.engine.DefaultLanguageResolver
 
lastProcessingTime(long, int) - Static method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators
 
LastProcessingTime(long, int) - Constructor for class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.LastProcessingTime
 
lazyEval(SimpleNode) - Method in class org.apache.camel.language.simple.ast.SimpleFunctionStart
 
LimitedPollingConsumerPollStrategy - Class in org.apache.camel.impl.engine
A PollingConsumerPollStrategy which supports suspending consumers if they failed for X number of times in a row.
LimitedPollingConsumerPollStrategy() - Constructor for class org.apache.camel.impl.engine.LimitedPollingConsumerPollStrategy
 
listAllTypeConvertersFromTo() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
LiteralExpression - Class in org.apache.camel.language.simple.ast
Represents literals in the AST.
LiteralExpression(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.LiteralExpression
 
LiteralNode - Interface in org.apache.camel.language.simple.ast
Represents a node in the AST which contains literals
load(TypeConverterRegistry) - Method in class org.apache.camel.converter.CamelConverterLoader
 
load(TypeConverterRegistry) - Method in class org.apache.camel.converter.CollectionConverterLoader
 
load(TypeConverterRegistry) - Method in class org.apache.camel.converter.DateTimeConverterLoader
 
load(TypeConverterRegistry) - Method in class org.apache.camel.converter.DurationConverterLoader
 
load(TypeConverterRegistry) - Method in class org.apache.camel.converter.IOConverterLoader
 
load(TypeConverterRegistry) - Method in class org.apache.camel.converter.NIOConverterLoader
 
load(TypeConverterRegistry) - Method in class org.apache.camel.converter.ObjectConverterLoader
 
load(TypeConverterRegistry) - Method in class org.apache.camel.converter.SQLConverterLoader
 
load(TypeConverterRegistry) - Method in class org.apache.camel.converter.TimePatternConverterLoader
 
load(TypeConverterRegistry) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
load(TypeConverterRegistry) - Method in class org.apache.camel.impl.converter.UriTypeConverterLoader
 
loadAllResourcesAsURL(String) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
LoadBalancer - Interface in org.apache.camel.processor.loadbalancer
A strategy for load balancing across a number of Processor instances
LoadBalancerConsumer - Class in org.apache.camel.processor.loadbalancer
Represents a consumer which on starting registers itself with a LoadBalancer and on closing unregisters itself with a load balancer
LoadBalancerConsumer(Endpoint, Processor, LoadBalancer) - Constructor for class org.apache.camel.processor.loadbalancer.LoadBalancerConsumer
 
LoadBalancerSupport - Class in org.apache.camel.processor.loadbalancer
A default base class for a LoadBalancer implementation.
LoadBalancerSupport() - Constructor for class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
loadClass(String, ClassLoader) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
loadConverterMethods(TypeConverterRegistry, Class<?>) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
Loads all of the converter methods for the given type
loadCoreAndFastTypeConverters() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
Loads the core type converters which is mandatory to use Camel, and also loads the fast type converters (generated via @Converter(loader = true).
loadFallbackTypeConverters() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
loadLines(InputStream, List<String>) - Static method in class org.apache.camel.runtimecatalog.impl.CatalogHelper
Loads the entire stream into memory as a String and returns it.
loadProperties() - Method in class org.apache.camel.component.properties.AbstractLocationPropertiesSource
 
loadProperties(Predicate<String>) - Method in class org.apache.camel.component.properties.AbstractLocationPropertiesSource
 
loadProperties() - Method in class org.apache.camel.component.properties.PropertiesComponent
 
loadProperties(Predicate<String>) - Method in class org.apache.camel.component.properties.PropertiesComponent
 
loadPropertiesFromLocation(PropertiesComponent, PropertiesLocation) - Method in class org.apache.camel.component.properties.ClasspathPropertiesSource
 
loadPropertiesFromLocation(PropertiesComponent, PropertiesLocation) - Method in class org.apache.camel.component.properties.FilePropertiesSource
 
loadResourceAsStream(String) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
loadResourceAsURL(String) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
loadResourcesAsURL(String) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
loadStore() - Method in class org.apache.camel.impl.engine.FileStateRepository
Loads the given file store into the 1st level cache
loadText(InputStream) - Static method in class org.apache.camel.runtimecatalog.impl.CatalogHelper
Loads the entire stream into memory as a String and returns it.
loadTypeConverters() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
Checks if the registry is loaded and if not lazily load it
LocationPropertiesSource - Interface in org.apache.camel.component.properties
A PropertiesSource which was created from a PropertiesLocation.
log - Variable in class org.apache.camel.component.properties.DefaultPropertiesParser
 
log - Variable in class org.apache.camel.impl.engine.BasePackageScanResolver
 
LOG - Static variable in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
logContinued - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logExhausted - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logExhausted(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log exhausted errors
logExhaustedMessageBody - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logExhaustedMessageBody(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log exhausted errors including message body (requires message history to be enabled)
logExhaustedMessageHistory - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logExhaustedMessageHistory(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log exhausted errors including message history
logger - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
logHandled - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logHandled(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log errors even if its handled
LogicalExpression - Class in org.apache.camel.language.simple.ast
Represents a logical expression in the AST
LogicalExpression(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.LogicalExpression
 
logicalOperator() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
LogicalOperatorType - Enum in org.apache.camel.language.simple.types
Types of logical operators supported
logInflightExchanges(CamelContext, List<RouteStartupOrder>, boolean) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
Logs information about the inflight exchanges
logNewException - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logNewException(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether errors should be logged when a new exception occurred during handling a previous exception
LogProcessor - Class in org.apache.camel.processor
A processor which evaluates an Expression and logs it.
LogProcessor(Expression, CamelLogger, MaskingFormatter, Set<LogListener>) - Constructor for class org.apache.camel.processor.LogProcessor
 
logRetryAttempted - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logRetryAttempted(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log retry attempts
logRetryStackTrace - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logRetryStackTrace(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log stacktrace for failed redelivery attempts
logRouteState(Route, String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
logStackTrace - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
logStackTrace(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether to log stacktrace for failed messages.
lookup(String) - Method in class org.apache.camel.component.properties.DefaultPropertiesLookup
 
lookup(String) - Method in interface org.apache.camel.component.properties.PropertiesLookup
Lookup the property with the given name
lookup(Class<?>, Class<?>) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
lookup(CamelContext, String, Class<T>) - Static method in class org.apache.camel.impl.engine.AbstractCamelContext
 
lookup(String, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
lookupByType(Class<T>) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
lookupPropertiesInRegistry(PropertiesComponent, PropertiesLocation) - Method in class org.apache.camel.component.properties.RefPropertiesSource
 
LoopProcessor - Class in org.apache.camel.processor
The processor which sends messages in a loop.
LoopProcessor(Processor, Expression, Predicate, boolean) - Constructor for class org.apache.camel.processor.LoopProcessor
 
lower(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the next lower element in the sequence to the given element.

M

manageObject(Object) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
manageProcessor(NamedNode) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
mandatoryBodyExpression(String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns the expression for the exchanges inbound message body converted to the given type
mandatoryBodyOgnlExpression(String, String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns the expression for the exchanges inbound message body converted to the given type and invoking methods on the converted body defined in a simple OGNL notation
mandatoryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
mandatoryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
mandatoryLookup(String, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
MandatorySagaProcessor - Class in org.apache.camel.processor.saga
Saga processor implementing the MANDATORY propagation mode.
MandatorySagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.MandatorySagaProcessor
 
matches(Class<?>) - Method in class org.apache.camel.impl.scan.AnnotatedWithAnyPackageScanFilter
 
matches(Class<?>) - Method in class org.apache.camel.impl.scan.AnnotatedWithPackageScanFilter
 
matches(Class<?>) - Method in class org.apache.camel.impl.scan.AssignableToPackageScanFilter
 
matches(Class<?>) - Method in class org.apache.camel.impl.scan.CompositePackageScanFilter
 
matches(Class<?>) - Method in class org.apache.camel.impl.scan.InvertingPackageScanFilter
 
matches(Exchange) - Method in class org.apache.camel.processor.FilterProcessor
 
matchesWhen(Exchange) - Method in class org.apache.camel.processor.CatchProcessor
Strategy method for matching the exception type with the current exchange.
matchesWhen(ExceptionPolicyKey, Exchange) - Method in class org.apache.camel.processor.errorhandler.DefaultExceptionPolicyStrategy
Strategy method for matching the exception type with the current exchange.
matchPattern(String, Endpoint, String) - Method in class org.apache.camel.impl.engine.InterceptSendToMockEndpointStrategy
Does the pattern match the endpoint?
matchWildcard(String, String) - Static method in class org.apache.camel.runtimecatalog.impl.CatalogHelper
Matches the name with the pattern.
MAX_BACKLOG_SIZE - Static variable in class org.apache.camel.processor.interceptor.BacklogTracer
 
maxCacheSize - Variable in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
maxCapacity() - Method in class org.apache.camel.impl.engine.DefaultEndpointUtilizationStatistics
 
maximumRedeliveries - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
maximumRedeliveries(int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the maximum number of times a message exchange will be redelivered
maximumRedeliveryDelay - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
maximumRedeliveryDelay(long) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the maximum redelivery delay if using exponential back off.
maximumRetries(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
maximumRetryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
maxProcessingTime(long, int) - Static method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators
 
MaxProcessingTime(long, int) - Constructor for class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.MaxProcessingTime
 
MDCUnitOfWork - Class in org.apache.camel.impl.engine
This unit of work supports MDC.
MDCUnitOfWork(Exchange, String) - Constructor for class org.apache.camel.impl.engine.MDCUnitOfWork
 
meanProcessingTime(long, int) - Static method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators
 
MeanProcessingTime(long, int) - Constructor for class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.MeanProcessingTime
 
MemoryAggregationRepository - Class in org.apache.camel.processor.aggregate
A memory based AggregationRepository which stores Exchanges in memory only.
MemoryAggregationRepository() - Constructor for class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
MemoryAggregationRepository(boolean) - Constructor for class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
MemoryStateRepository - Class in org.apache.camel.impl.engine
This MemoryStateRepository class is a memory-based implementation of a StateRepository.
MemoryStateRepository() - Constructor for class org.apache.camel.impl.engine.MemoryStateRepository
 
MessageDump - Class in org.apache.camel.support.dump
A model of a message dump from MessageHelper#dumpAsXml(org.apache.camel.Message).
MessageDump() - Constructor for class org.apache.camel.support.dump.MessageDump
 
MessageDump.Body - Class in org.apache.camel.support.dump
A model of a message dump body.
MessageDump.Header - Class in org.apache.camel.support.dump
A model of a message dump header.
MessageHistoryAdvice(MessageHistoryFactory, NamedNode) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.MessageHistoryAdvice
 
messageHistoryExpression(boolean) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns the message history (including exchange details or not)
MessageRejectedException - Exception in org.apache.camel.processor.resequencer
An exception thrown if message is rejected by the resequencer
MessageRejectedException(String) - Constructor for exception org.apache.camel.processor.resequencer.MessageRejectedException
 
META_INF_SERVICES - Static variable in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
META_INF_SERVICES_FALLBACK_TYPE_CONVERTER - Static variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
META_INF_SERVICES_TYPE_CONVERTER_LOADER - Static variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
MethodCallProcessor - Class in org.apache.camel.processor
A processor which are used when calling a method and setting the response as the message body
MethodCallProcessor(Expression) - Constructor for class org.apache.camel.processor.MethodCallProcessor
 
minProcessingTime(long, int) - Static method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators
 
MinProcessingTime(long, int) - Constructor for class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.MinProcessingTime
 
minusValue() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
MISS_CONVERTER - Static variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
missCounter - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
modelJSonSchema(String) - Method in class org.apache.camel.runtimecatalog.impl.DefaultRuntimeCamelCatalog
 
MulticastProcessor - Class in org.apache.camel.processor
Implements the Multicast pattern to send a message exchange to a number of endpoints, each endpoint receiving a copy of the message exchange.
MulticastProcessor(CamelContext, Collection<Processor>) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor(CamelContext, Collection<Processor>, AggregationStrategy) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor(CamelContext, Collection<Processor>, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor(CamelContext, Collection<Processor>, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean, boolean) - Constructor for class org.apache.camel.processor.MulticastProcessor
 
MulticastProcessor.MulticastState - Class in org.apache.camel.processor
 

N

navigate() - Method in class org.apache.camel.impl.engine.EventDrivenConsumerRoute
 
NeverSagaProcessor - Class in org.apache.camel.processor.saga
Saga processor implementing the NEVER propagation mode.
NeverSagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.NeverSagaProcessor
 
newCachedThreadPool(Object, String) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
newDefaultScheduledThreadPool(Object, String) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
newDefaultThreadPool(Object, String) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
newFixedThreadPool(Object, String, int) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
newInstance() - Method in class org.apache.camel.impl.converter.CachingInjector
 
newInstance(String) - Method in class org.apache.camel.impl.engine.DefaultFactoryFinder
 
newInstance(String, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultFactoryFinder
 
newInstance(Class<T>) - Method in class org.apache.camel.impl.engine.DefaultInjector
 
newInstance(Class<T>, String) - Method in class org.apache.camel.impl.engine.DefaultInjector
 
newInstance(Class<T>, boolean) - Method in class org.apache.camel.impl.engine.DefaultInjector
 
newInstance(CamelContext, String) - Static method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
newInstance(Exchange) - Method in class org.apache.camel.impl.engine.MDCUnitOfWork
 
newInstance(Exchange) - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
Creates a new instance as a clone of this strategy with the new given original.
newInstance(CamelContext, List<Processor>) - Static method in class org.apache.camel.processor.Pipeline
 
newInstance(CamelContext, Processor...) - Static method in class org.apache.camel.processor.Pipeline
 
newInstance(CamelContext, List<Processor>, String) - Static method in class org.apache.camel.processor.StepProcessor
 
newMap() - Method in class org.apache.camel.impl.engine.DefaultHeadersMapFactory
 
newMap(Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultHeadersMapFactory
 
newMap() - Method in class org.apache.camel.impl.engine.HashMapHeadersMapFactory
 
newMap(Map<String, Object>) - Method in class org.apache.camel.impl.engine.HashMapHeadersMapFactory
 
newMessageHistory(String, NamedNode, long, Exchange) - Method in class org.apache.camel.impl.engine.DefaultMessageHistoryFactory
 
newRoutingSlipProcessorForErrorHandler() - Method in class org.apache.camel.processor.RoutingSlip
Creates the embedded processor to use when wrapping this routing slip in an error handler.
newSaga() - Method in class org.apache.camel.impl.saga.InMemorySagaService
 
newScheduledThreadPool(Object, String, ThreadPoolProfile) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
newScheduledThreadPool(Object, String, String) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
newScheduledThreadPool(Object, String, int) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
newSingleThreadExecutor(Object, String) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
newSingleThreadScheduledExecutor(Object, String) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
newThread(String, Runnable) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
newThreadPool(Object, String, String) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
newThreadPool(Object, String, ThreadPoolProfile) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
newThreadPool(Object, String, int, int) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
next() - Method in class org.apache.camel.impl.engine.SubscribeMethodProcessor
 
next() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
next() - Method in class org.apache.camel.processor.channel.DefaultChannel
 
next() - Method in class org.apache.camel.processor.ChoiceProcessor
 
next() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
next() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
next() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
next() - Method in class org.apache.camel.processor.MulticastProcessor
 
next() - Method in class org.apache.camel.processor.Pipeline
 
next() - Method in class org.apache.camel.processor.Resequencer
 
next(Exchange) - Method in interface org.apache.camel.processor.RoutingSlip.RoutingSlipIterator
Returns the next routing slip(s).
next() - Method in class org.apache.camel.processor.StreamResequencer
 
next() - Method in class org.apache.camel.processor.TryProcessor
 
next() - Method in class org.apache.camel.processor.WrapProcessor
 
nextToken() - Method in class org.apache.camel.language.simple.BaseSimpleParser
Advances the parser position to the next known SimpleToken in the input.
nextToken(TokenType...) - Method in class org.apache.camel.language.simple.BaseSimpleParser
Advances the parser position to the next known SimpleToken in the input.
nextToken(String, int, boolean, TokenType...) - Static method in class org.apache.camel.language.simple.SimpleTokenizer
Create the next token
nextToken(String, int, boolean) - Static method in class org.apache.camel.language.simple.SimpleTokenizer
Create the next token
NIOConverter - Class in org.apache.camel.converter
Some core java.nio based Type Converters
NIOConverterLoader - Class in org.apache.camel.converter
Source code generated by org.apache.camel:apt
NIOConverterLoader() - Constructor for class org.apache.camel.converter.NIOConverterLoader
 
nodeCounters - Static variable in class org.apache.camel.impl.engine.DefaultNodeIdFactory
 
nodes - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
NoMessageIdException - Exception in org.apache.camel.processor.idempotent
An exception thrown if no message ID could be found on a message which is to be used with the Idempotent Consumer pattern.
NoMessageIdException(Exchange, Expression) - Constructor for exception org.apache.camel.processor.idempotent.NoMessageIdException
 
noopCounter - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
normalizeEndpointUri(String) - Static method in class org.apache.camel.impl.engine.AbstractCamelContext
Normalize uri so we can do endpoint hits with minor mistakes and parameters is not in the same order.
normalizeUri(String) - Static method in class org.apache.camel.runtimecatalog.impl.URISupport
Normalizes the URI so unsafe characters is encoded
noSpecificLanguageFound(String, CamelContext) - Method in class org.apache.camel.impl.engine.DefaultLanguageResolver
 
notify(CamelEvent) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
notify(CamelEvent) - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
notify(HealthCheck, HealthCheck.Result) - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
NotSupportedSagaProcessor - Class in org.apache.camel.processor.saga
Saga processor implementing the NOT_SUPPORTED propagation mode.
NotSupportedSagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.NotSupportedSagaProcessor
 
NullExpression - Class in org.apache.camel.language.simple.ast
Represents a null expression.
NullExpression(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.NullExpression
 
nullExpression() - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns the expression for the null value
nullValue() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
numericValue() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 

O

ObjectConverter - Class in org.apache.camel.converter
Some core java.lang based Type Converters
ObjectConverterLoader - Class in org.apache.camel.converter
Source code generated by org.apache.camel:apt
ObjectConverterLoader() - Constructor for class org.apache.camel.converter.ObjectConverterLoader
 
oldest(String) - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
on(CamelContext) - Static method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
Create the FluentProducerTemplate by setting the camel context
onAfterProcess(Exchange, Processor, NamedNode, long, Breakpoint) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
onAggregation(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
onBeforeProcess(Exchange, Processor, NamedNode, Breakpoint) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
onCamelContextStarted(CamelContext, boolean) - Method in class org.apache.camel.impl.engine.DeferServiceStartupListener
 
onComplete(Exchange) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
 
onCompletedMessage(Exchange, String) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
A strategy method to allow derived classes to overload the behavior of processing a completed message
onCompletion(Exchange) - Method in class org.apache.camel.processor.aggregate.AbstractListAggregationStrategy
 
onCompletion(String, Exchange, Exchange, boolean, boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
onCompletion(Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
onCompletion(Exchange) - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategy
 
OnCompletionProcessor - Class in org.apache.camel.processor
Processor implementing onCompletion.
OnCompletionProcessor(CamelContext, Processor, ExecutorService, boolean, boolean, boolean, Predicate, boolean, boolean) - Constructor for class org.apache.camel.processor.OnCompletionProcessor
 
onDuplicateMessage(Exchange, String) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
A strategy method to allow derived classes to overload the behaviour of processing a duplicate message
onEvent(Exchange, CamelEvent.ExchangeEvent, NamedNode) - Method in class org.apache.camel.processor.interceptor.BreakpointSupport
 
onEvent(Exchange, CamelEvent.ExchangeEvent) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
onEvent(Exchange, CamelEvent.ExchangeEvent, Breakpoint) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
onEvict(S) - Method in class org.apache.camel.impl.engine.ServicePool
 
onExceptionOccurred() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
Gives an optional configured OnExceptionOccurred processor a chance to process just after an exception was thrown while processing the Exchange.
onExceptionProcessor - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
onExchangeDone(Route, Exchange) - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
 
onExchangeDone(Route, Exchange) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
onExchangeDone(Route, Exchange) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
onFailedMessage(Exchange, String) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
A strategy method to allow derived classes to overload the behavior of processing a failed message
onFailure(Exchange) - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
 
onHandledFailure(Exception) - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
onHit(String) - Method in class org.apache.camel.impl.engine.DefaultEndpointUtilizationStatistics
 
onInit(Route) - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
 
onInit(Route) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
onInit(Route) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
onInterceptEndpoint(String, Endpoint, Endpoint, Producer) - Method in class org.apache.camel.impl.engine.InterceptSendToMockEndpointStrategy
Callback when an endpoint was intercepted with the given mock endpoint
onNewExecutorService(ExecutorService) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
Strategy callback when a new ExecutorService have been created.
onOptimisticLockFailure(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
onOptimisticLockingFailure(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
onPrepare - Variable in class org.apache.camel.processor.MulticastProcessor
 
onPrepareProcessor - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
onRollback(Consumer, Endpoint) - Method in class org.apache.camel.impl.engine.LimitedPollingConsumerPollStrategy
Rollback occurred.
onStart(AggregateProcessor) - Method in interface org.apache.camel.processor.aggregate.AggregateController
Callback when the aggregate processor is started.
onStart(AggregateProcessor) - Method in class org.apache.camel.processor.aggregate.DefaultAggregateController
 
onStart(Route) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
onStartingServices(List<Service>) - Method in class org.apache.camel.impl.engine.DefaultRoute
 
onStop(AggregateProcessor) - Method in interface org.apache.camel.processor.aggregate.AggregateController
Callback when the aggregate processor is stopped.
onStop(AggregateProcessor) - Method in class org.apache.camel.processor.aggregate.DefaultAggregateController
 
onSuspend(Consumer, Endpoint) - Method in class org.apache.camel.impl.engine.LimitedPollingConsumerPollStrategy
The consumer is to be suspended because it exceeded the limit
openCircuit(Route) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
OptimisticLockRetryPolicy - Class in org.apache.camel.processor.aggregate
Class to control how failed optimistic locks are tried.
OptimisticLockRetryPolicy() - Constructor for class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
org.apache.camel.component.properties - package org.apache.camel.component.properties
The Properties Component for lookup of property placeholders for endpoint URI.
org.apache.camel.converter - package org.apache.camel.converter
A set of helper classes for converting from different types of Java object to be used by the Type Conversion Support
org.apache.camel.impl.converter - package org.apache.camel.impl.converter
Default implementation classes the Type Conversion Strategies
org.apache.camel.impl.engine - package org.apache.camel.impl.engine
 
org.apache.camel.impl.event - package org.apache.camel.impl.event
Camel management events
org.apache.camel.impl.health - package org.apache.camel.impl.health
Camel Health Check implementations.
org.apache.camel.impl.saga - package org.apache.camel.impl.saga
In-memory Saga coordinator.
org.apache.camel.impl.scan - package org.apache.camel.impl.scan
Package scan classes.
org.apache.camel.impl.transformer - package org.apache.camel.impl.transformer
Transformer implementation classes.
org.apache.camel.impl.validator - package org.apache.camel.impl.validator
Validator implementation classes.
org.apache.camel.language.constant - package org.apache.camel.language.constant
Camel Constant language.
org.apache.camel.language.header - package org.apache.camel.language.header
Camel Header language.
org.apache.camel.language.property - package org.apache.camel.language.property
Camel Exchange Property language.
org.apache.camel.language.ref - package org.apache.camel.language.ref
Camel Ref language.
org.apache.camel.language.simple - package org.apache.camel.language.simple
Camel Simple language.
org.apache.camel.language.simple.ast - package org.apache.camel.language.simple.ast
AST for the Camel Simple language.
org.apache.camel.language.simple.types - package org.apache.camel.language.simple.types
Types for the Camel Simple language.
org.apache.camel.language.tokenizer - package org.apache.camel.language.tokenizer
Camel Tokenizer language.
org.apache.camel.processor - package org.apache.camel.processor
A collection of Processor implementations which are used to implement the Enterprise Integration Patterns
org.apache.camel.processor.aggregate - package org.apache.camel.processor.aggregate
Helper classes for the Aggregator pattern.
org.apache.camel.processor.channel - package org.apache.camel.processor.channel
 
org.apache.camel.processor.errorhandler - package org.apache.camel.processor.errorhandler
Exception policy startegies for Dead Letter Channel pattern.
org.apache.camel.processor.idempotent - package org.apache.camel.processor.idempotent
An implementation of the Idempotent Consumer pattern.
org.apache.camel.processor.interceptor - package org.apache.camel.processor.interceptor
Helper classes for interceptors.
org.apache.camel.processor.loadbalancer - package org.apache.camel.processor.loadbalancer
Various load balancer processors
org.apache.camel.processor.resequencer - package org.apache.camel.processor.resequencer
Helper classes for the Resequencer pattern.
org.apache.camel.processor.saga - package org.apache.camel.processor.saga
Saga EIP implementation.
org.apache.camel.runtimecatalog.impl - package org.apache.camel.runtimecatalog.impl
 
org.apache.camel.support.dump - package org.apache.camel.support.dump
 
org.apache.camel.throttling - package org.apache.camel.throttling
 
output - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
outputAsync - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
OVERRIDE_PROPERTIES - Static variable in class org.apache.camel.component.properties.PropertiesComponent
Key for stores special override properties that containers such as OSGi can store in the OSGi service registry

P

Pair<T> - Class in org.apache.camel.runtimecatalog.impl
Copied from org.apache.camel.util.Pair
Pair(T, T) - Constructor for class org.apache.camel.runtimecatalog.impl.Pair
 
parseAndCreateAstModel() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
 
parseExpression() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
 
parseParameters(URI) - Static method in class org.apache.camel.runtimecatalog.impl.URISupport
Parses the query parameters of the uri (eg the query part).
parsePredicate() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
parseProperty(String, String, PropertiesLookup) - Method in class org.apache.camel.component.properties.DefaultPropertiesParser
 
parseProperty(String, String, PropertiesLookup) - Method in interface org.apache.camel.component.properties.PropertiesParser
While parsing the uri using parseUri method each parsed property found invokes this callback.
parseQuery(String) - Static method in class org.apache.camel.runtimecatalog.impl.URISupport
Parses the query part of the uri (eg the parameters).
parseQuery(String, boolean) - Static method in class org.apache.camel.runtimecatalog.impl.URISupport
Parses the query part of the uri (eg the parameters).
parseTokensAndCreateNodes() - Method in class org.apache.camel.language.simple.SimplePredicateParser
Parses the tokens and crates the AST nodes.
parseUri(String, PropertiesLookup, boolean) - Method in class org.apache.camel.component.properties.DefaultPropertiesParser
 
parseUri(String) - Method in class org.apache.camel.component.properties.PropertiesComponent
 
parseUri(String, PropertiesLookup) - Method in class org.apache.camel.component.properties.PropertiesComponent
 
parseUri(String, PropertiesLookup, boolean) - Method in interface org.apache.camel.component.properties.PropertiesParser
Parses the string and replaces the property placeholders with values from the given properties.
pattern - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
pattern - Variable in class org.apache.camel.processor.SendProcessor
 
PerformanceCounterEvaluator<T extends org.apache.camel.api.management.mbean.ManagedPerformanceCounterMBean> - Interface in org.apache.camel.impl.health
 
performMaxDurationAction() - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
 
performMaxMessagesAction() - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
 
pick(Expression) - Method in class org.apache.camel.processor.aggregate.StringAggregationStrategy
Set an expression to extract the element to be aggregated from the incoming Exchange.
Pipeline - Class in org.apache.camel.processor
Creates a Pipeline pattern where the output of the previous step is sent as input to the next step, reusing the same message exchanges
Pipeline(CamelContext, Collection<Processor>) - Constructor for class org.apache.camel.processor.Pipeline
 
PipelineHelper - Class in org.apache.camel.processor
Helper for processing Exchange in a pipeline.
PollEnricher - Class in org.apache.camel.processor
A content enricher that enriches input data by first obtaining additional data from a resource represented by an endpoint producer and second by aggregating input data and additional data.
PollEnricher(Expression, long) - Constructor for class org.apache.camel.processor.PollEnricher
Creates a new PollEnricher.
pop() - Method in class org.apache.camel.impl.engine.DefaultClaimCheckRepository
 
popRouteContext() - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
popRouteContext() - Method in class org.apache.camel.impl.engine.MDCUnitOfWork
 
postInitChannel() - Method in class org.apache.camel.processor.channel.DefaultChannel
Post initializes the channel.
postProcess(Exchange) - Method in class org.apache.camel.processor.Resequencer
 
postProcessAfterInitialization(Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
preCheckPoll(Exchange) - Method in class org.apache.camel.processor.PollEnricher
Strategy to pre check polling.
preComplete(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
predecessor(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
predecessor(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the immediate predecessor of the given element in this sequence or null if no predecessor exists.
predecessor(E, E) - Method in interface org.apache.camel.processor.resequencer.SequenceElementComparator
Returns true if o1 is an immediate predecessor of o2.
predicate(String) - Static method in class org.apache.camel.language.simple.SimpleLanguage
Creates a new Predicate.
prepareBlocks() - Method in class org.apache.camel.language.simple.BaseSimpleParser
Prepares blocks, such as functions, single or double quoted texts.
prepareExchange(Exchange, int) - Method in class org.apache.camel.processor.LoopProcessor
Prepares the exchange for the next iteration
prepareExchange(Exchange) - Method in class org.apache.camel.processor.OnCompletionProcessor
Prepares the Exchange to send as onCompletion.
prepareExchangeAfterFailure(Exchange, boolean, boolean, boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
 
prepareExchangeForContinue(Exchange, boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
 
prepareExchangeForFailover(Exchange) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
Prepares the exchange for failover
prepareExchangeForRedelivery() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
 
prepareExchangeForRoutingSlip(Exchange, Endpoint) - Method in class org.apache.camel.processor.RoutingSlip
 
prepareLoadedProperties(Properties) - Static method in class org.apache.camel.component.properties.AbstractLocationPropertiesSource
Strategy to prepare loaded properties before being used by Camel.
prepareSharedUnitOfWork(Exchange, Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Prepares the exchange for participating in a shared unit of work

This ensures a child exchange can access its parent UnitOfWork when it participate in a shared unit of work.

prepareShutdown(boolean, boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
prepareShutdown(boolean, boolean) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
prepareShutdown(boolean, boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
prepareShutdown(boolean, boolean) - Method in class org.apache.camel.processor.WireTapProcessor
 
prepareUnaryExpressions() - Method in class org.apache.camel.language.simple.BaseSimpleParser
Prepares unary expressions.
preparingShutdown - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
previousIndex - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
process(AsyncProcessor, Exchange) - Method in class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
Calls the async version of the processor's process method and waits for it to complete before returning.
process(Exchange) - Method in class org.apache.camel.impl.engine.DeferProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.impl.engine.DeferProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.impl.engine.InterceptSendToEndpointProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.impl.engine.SubscribeMethodProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.CamelInternalProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.CatchProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ChoiceProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
process(Exchange) - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Enricher
Enriches the input data (exchange) by first obtaining additional data from an endpoint represented by an endpoint producer and second by aggregating input data and additional data.
process(Exchange) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Process the exchange using redelivery error handling.
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.EvaluateExpressionProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.EventNotifierProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.FatalFallbackErrorHandler
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.FilterProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.FinallyProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
process(Exchange) - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
Process invoked by the interceptor
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.loadbalancer.QueueLoadBalancer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.LogProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.LoopProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.MethodCallProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.MulticastProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.OnCompletionProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Pipeline
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.PollEnricher
Enriches the input data (exchange) by first obtaining additional data from an endpoint represented by an endpoint producer and second by aggregating input data and additional data.
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RecipientList
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Resequencer
Enqueues an exchange for later batch processing.
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RollbackProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.RoutingSlip
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.saga.MandatorySagaProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.saga.NeverSagaProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.saga.NotSupportedSagaProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.saga.RequiredSagaProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.saga.RequiresNewSagaProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.saga.SupportsSagaProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SamplingThrottler
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ScriptProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SendProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SetBodyProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SetHeaderProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SetPropertyProcessor
 
process(Exchange, AsyncProcessor, Processor) - Method in class org.apache.camel.processor.SharedCamelInternalProcessor
Synchronous API
process(Exchange, AsyncCallback, AsyncProcessor, Processor) - Method in class org.apache.camel.processor.SharedCamelInternalProcessor
Asynchronous API
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.SortProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Splitter
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.StepProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.StopProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.StreamResequencer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ThreadsProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.Throttler
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.TransformProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.TryProcessor
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.processor.WireTapProcessor
 
processAsync(Exchange) - Method in class org.apache.camel.impl.engine.DeferProducer
 
processAsync(Exchange) - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
processAsync(Exchange) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
processAsync(Exchange) - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
 
processAsynchronously(Exchange, AsyncCallback, Throttler.ThrottlingState) - Method in class org.apache.camel.processor.Throttler
Delegate blocking on the DelayQueue to an asyncExecutor.
processDelay(Exchange, AsyncCallback, long) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
processExchange(Exchange) - Method in class org.apache.camel.processor.Resequencer
Strategy Method to process an exchange in the batch.
processExchange(Endpoint, Exchange, Exchange, AsyncCallback, RoutingSlip.RoutingSlipIterator) - Method in class org.apache.camel.processor.RoutingSlip
 
ProcessorExchangePair - Interface in org.apache.camel.processor
Exchange pair to be executed by MulticastProcessor.
ProcessorStatDump - Class in org.apache.camel.support.dump
A model of a route stat dump from ManagedRouteMBean.dumpRouteStatsAsXml(boolean, boolean).
ProcessorStatDump() - Constructor for class org.apache.camel.support.dump.ProcessorStatDump
 
ProcessorTransformer - Class in org.apache.camel.impl.transformer
A Transformer implementation which leverages Processor to perform transformation.
ProcessorTransformer(CamelContext) - Constructor for class org.apache.camel.impl.transformer.ProcessorTransformer
 
ProcessorValidator - Class in org.apache.camel.impl.validator
A Validator implementation which leverages Processor to perform validation.
ProcessorValidator(CamelContext) - Constructor for class org.apache.camel.impl.validator.ProcessorValidator
 
producer - Variable in class org.apache.camel.processor.SendProcessor
 
producerCache - Variable in class org.apache.camel.processor.RoutingSlip
 
producerCache - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
producerCache - Variable in class org.apache.camel.processor.SendProcessor
 
propagateException(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
propagateFailure(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
propagateFailure(Exchange, Exchange) - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
propagation(SagaPropagation) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
PropertiesComponent - Class in org.apache.camel.component.properties
The properties component allows you to use property placeholders in Camel.
PropertiesComponent() - Constructor for class org.apache.camel.component.properties.PropertiesComponent
 
PropertiesComponent(String) - Constructor for class org.apache.camel.component.properties.PropertiesComponent
A list of locations to load properties.
PropertiesComponent(String...) - Constructor for class org.apache.camel.component.properties.PropertiesComponent
A list of locations to load properties.
PropertiesComponentFactoryResolver - Class in org.apache.camel.impl.engine
Factory resolver to find the PropertiesComponent from the classpath.
PropertiesComponentFactoryResolver() - Constructor for class org.apache.camel.impl.engine.PropertiesComponentFactoryResolver
 
PropertiesFunction - Interface in org.apache.camel.component.properties
A function that is applied instead of looking up a property placeholder.
PropertiesLocation - Class in org.apache.camel.component.properties
 
PropertiesLocation(String) - Constructor for class org.apache.camel.component.properties.PropertiesLocation
 
PropertiesLocation(String, String) - Constructor for class org.apache.camel.component.properties.PropertiesLocation
 
PropertiesLocation(String, String, Boolean) - Constructor for class org.apache.camel.component.properties.PropertiesLocation
 
PropertiesLookup - Interface in org.apache.camel.component.properties
Used by PropertiesParser to lookup properties by their name
PropertiesParser - Interface in org.apache.camel.component.properties
A parser to parse properties for a given input
propertyOgnlExpression(String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns an expression for the property value of exchange with the given name invoking methods defined in a simple OGNL notation
purge() - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
Purges the cache
purge() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
Purges this cache
purge() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
push(Exchange) - Method in class org.apache.camel.impl.engine.DefaultClaimCheckRepository
 
pushRouteContext(RouteContext) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
pushRouteContext(RouteContext) - Method in class org.apache.camel.impl.engine.MDCUnitOfWork
 
put(K, V) - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 

Q

QueueLoadBalancer - Class in org.apache.camel.processor.loadbalancer
A base class for LoadBalancer implementations which choose a single destination for each exchange (rather like JMS Queues)
QueueLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.QueueLoadBalancer
 
quoteEmbeddedNodes() - Method in class org.apache.camel.language.simple.ast.LiteralExpression
 
quoteEmbeddedNodes() - Method in interface org.apache.camel.language.simple.ast.LiteralNode
Whether to quote embedded nodes.

R

randomBackOff() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
randomExpression(String, String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns a random number between min and max (exclusive)
randomExpression(int) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns a random number between 0 and max (exclusive)
randomExpression(int, int) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns a random number between min and max (exclusive)
RandomLoadBalancer - Class in org.apache.camel.processor.loadbalancer
Implements the random load balancing policy
RandomLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.RandomLoadBalancer
 
randomNumberGenerator - Static variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
ratios - Variable in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
RAW_TOKEN_END - Static variable in class org.apache.camel.runtimecatalog.impl.URISupport
 
RAW_TOKEN_PREFIX - Static variable in class org.apache.camel.runtimecatalog.impl.URISupport
 
RAW_TOKEN_START - Static variable in class org.apache.camel.runtimecatalog.impl.URISupport
 
ReactiveExecutorResolver - Class in org.apache.camel.impl.engine
Factory resolver to create the ReactiveExecutor to be used.
ReactiveExecutorResolver() - Constructor for class org.apache.camel.impl.engine.ReactiveExecutorResolver
 
reason() - Method in class org.apache.camel.impl.engine.SupervisingRouteController.FilterResult
 
receive(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
 
receive(Endpoint, long) - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
 
receive(String) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receive(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receive(String, long) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receive(Endpoint, long) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveBody(String) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveBody(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveBody(String, long) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveBody(Endpoint, long) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveBody(String, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveBody(Endpoint, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveBody(String, long, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveBody(Endpoint, long, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveBodyNoWait(String) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveBodyNoWait(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveBodyNoWait(String, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveBodyNoWait(Endpoint, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveNoWait(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
 
receiveNoWait(String) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
receiveNoWait(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
RecipientList - Class in org.apache.camel.processor
Implements a dynamic Recipient List pattern where the list of actual endpoints to send a message exchange to are dependent on some dynamic expression.
RecipientList(CamelContext) - Constructor for class org.apache.camel.processor.RecipientList
 
RecipientList(CamelContext, String) - Constructor for class org.apache.camel.processor.RecipientList
 
RecipientList(CamelContext, Expression) - Constructor for class org.apache.camel.processor.RecipientList
 
RecipientList(CamelContext, Expression, String) - Constructor for class org.apache.camel.processor.RecipientList
 
RecipientListProcessor - Class in org.apache.camel.processor
Implements a dynamic Recipient List pattern where the list of actual endpoints to send a message exchange to are dependent on some dynamic expression.
RecipientListProcessor(CamelContext, ProducerCache, Iterator<?>) - Constructor for class org.apache.camel.processor.RecipientListProcessor
 
RecipientListProcessor(CamelContext, ProducerCache, Iterator<?>, AggregationStrategy) - Constructor for class org.apache.camel.processor.RecipientListProcessor
 
RecipientListProcessor(CamelContext, ProducerCache, Iterator<?>, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean) - Constructor for class org.apache.camel.processor.RecipientListProcessor
 
RecipientListProcessor(CamelContext, ProducerCache, Iterator<?>, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean, boolean) - Constructor for class org.apache.camel.processor.RecipientListProcessor
 
redeliver() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
 
redeliveries(long) - Static method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators
 
Redeliveries(long) - Constructor for class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.Redeliveries
 
redeliveryDelay - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
redeliveryDelay(long) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the initial redelivery delay in milliseconds
redeliveryEnabled - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
RedeliveryErrorHandler - Class in org.apache.camel.processor.errorhandler
Base redeliverable error handler that also supports a final dead letter queue in case all redelivery attempts fail.
RedeliveryErrorHandler(CamelContext, Processor, CamelLogger, Processor, RedeliveryPolicy, Processor, String, boolean, boolean, boolean, Predicate, ScheduledExecutorService, Processor, Processor) - Constructor for class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
RedeliveryErrorHandler.RedeliveryState - Class in org.apache.camel.processor.errorhandler
Contains the current redelivery state
redeliveryPolicy - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
RedeliveryPolicy - Class in org.apache.camel.processor.errorhandler
The policy used to decide how many times to redeliver and the time between the redeliveries before being sent to a Dead Letter Channel
RedeliveryPolicy() - Constructor for class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
redeliveryProcessor - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
redeliverySleepCounter - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
RedeliveryState(Exchange, AsyncCallback) - Constructor for class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
 
ref(Object) - Static method in class org.apache.camel.language.ref.RefLanguage
 
RefLanguage - Class in org.apache.camel.language.ref
A language for referred expressions or predicates.
RefLanguage() - Constructor for class org.apache.camel.language.ref.RefLanguage
 
RefPropertiesSource - Class in org.apache.camel.component.properties
 
RefPropertiesSource(PropertiesComponent, PropertiesLocation) - Constructor for class org.apache.camel.component.properties.RefPropertiesSource
 
register(HealthCheck) - Method in class org.apache.camel.impl.health.DefaultHealthCheckRegistry
 
registerEndpoint(String, Endpoint) - Method in class org.apache.camel.impl.engine.InterceptSendToMockEndpointStrategy
 
registerEndpointCallback(EndpointStrategy) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
registerFallbackTypeConverter(TypeConverterRegistry, TypeConverter, Method) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
registerMissType(Class) - Static method in class org.apache.camel.impl.converter.ToStringTypeConverter
 
registerStep(CamelSagaStep) - Method in class org.apache.camel.impl.saga.InMemorySagaService
 
registerThreadPoolProfile(ThreadPoolProfile) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
registerTypeConverter(TypeConverterRegistry, Method, Class<?>, Class<?>, TypeConverter) - Method in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
RegistryRepository - Class in org.apache.camel.impl.health
 
RegistryRepository() - Constructor for class org.apache.camel.impl.health.RegistryRepository
 
release(Endpoint, S) - Method in class org.apache.camel.impl.engine.ServicePool
Releases the service back to the pool
releasePollingConsumer(Endpoint, PollingConsumer) - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
Releases an acquired producer back after usage.
releaseProducer(Endpoint, AsyncProducer) - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
remove(Object) - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
remove(String) - Method in class org.apache.camel.impl.engine.DefaultEndpointUtilizationStatistics
 
remove(Exchange) - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
remove(Exchange, String) - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
remove(CamelContext, String, Exchange) - Method in class org.apache.camel.processor.aggregate.MemoryAggregationRepository
 
removeAggregationStrategyFromExchange(Exchange) - Method in class org.apache.camel.processor.MulticastProcessor
Removes the associated AggregationStrategy from the Exchange which must be done after use.
removeAllBreakpoints() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
removeBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
removeBreakpoint(Breakpoint) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
removeComponent(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
removeEndpoint(Endpoint) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
removeEndpoints(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
removeEventNotifier(EventNotifier) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
removeFilter(PackageScanFilter) - Method in class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
removeFilter(PackageScanFilter) - Method in class org.apache.camel.impl.engine.DefaultPackageScanClassResolver
 
RemoveHeaderProcessor - Class in org.apache.camel.processor
A processor which removes the header from the IN or OUT message
RemoveHeaderProcessor(String) - Constructor for class org.apache.camel.processor.RemoveHeaderProcessor
 
RemoveHeadersProcessor - Class in org.apache.camel.processor
A processor which removes one ore more headers from the IN or OUT message
RemoveHeadersProcessor(String, String[]) - Constructor for class org.apache.camel.processor.RemoveHeadersProcessor
 
removeLeadingAndEndingQuotes(String) - Static method in class org.apache.camel.runtimecatalog.impl.CatalogHelper
Removes all leading and ending quotes (single and double) from the string
removeMessageBodyOnBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
removeMessageHeaderOnBreakpoint(String, String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
removeProcessor(AsyncProcessor) - Method in interface org.apache.camel.processor.loadbalancer.LoadBalancer
Removes the given processor from the load balancer
removeProcessor(AsyncProcessor) - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
removeProcessor(AsyncProcessor) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
RemovePropertiesProcessor - Class in org.apache.camel.processor
A processor which removes one ore more properties from the exchange
RemovePropertiesProcessor(String, String[]) - Constructor for class org.apache.camel.processor.RemovePropertiesProcessor
 
RemovePropertyProcessor - Class in org.apache.camel.processor
A processor which removes the property from the exchange
RemovePropertyProcessor(String) - Constructor for class org.apache.camel.processor.RemovePropertyProcessor
 
removeRepository(HealthCheckRepository) - Method in class org.apache.camel.impl.health.DefaultHealthCheckRegistry
 
removeRoute(Route) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
removeRoute(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
removeRoute(String) - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
removeService(Object) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
removeStateChangeListener(BiConsumer<HealthCheck.State, HealthCheck>) - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
removeSynchronization(Synchronization) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
removeTypeConverter(Class<?>, Class<?>) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
request() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
request(Class<T>) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
request(Endpoint, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
request(String, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBody(Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBody(Endpoint, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBody(String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBody(Object, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBody(Endpoint, Object, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBody(String, Object, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBodyAndHeader(Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBodyAndHeader(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBodyAndHeader(Endpoint, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBodyAndHeader(String, Object, String, Object, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBodyAndHeaders(Object, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBodyAndHeaders(String, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
requestBodyAndHeaders(Endpoint, Object, Map<String, Object>, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
RequiredSagaProcessor - Class in org.apache.camel.processor.saga
Saga processor implementing the REQUIRED propagation mode.
RequiredSagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.RequiredSagaProcessor
 
RequiresNewSagaProcessor - Class in org.apache.camel.processor.saga
Saga processor implementing the REQUIRES_NEW propagation mode.
RequiresNewSagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.RequiresNewSagaProcessor
 
Resequencer - Class in org.apache.camel.processor
An implementation of the Resequencer which can reorder messages within a batch.
Resequencer(CamelContext, Processor, Expression) - Constructor for class org.apache.camel.processor.Resequencer
 
Resequencer(CamelContext, Processor, Expression, boolean, boolean) - Constructor for class org.apache.camel.processor.Resequencer
 
Resequencer(CamelContext, Processor, Set<Exchange>, Expression) - Constructor for class org.apache.camel.processor.Resequencer
 
ResequencerEngine<E> - Class in org.apache.camel.processor.resequencer
Resequences elements based on a given SequenceElementComparator.
ResequencerEngine(SequenceElementComparator<E>) - Constructor for class org.apache.camel.processor.resequencer.ResequencerEngine
Creates a new resequencer instance with a default timeout of 2000 milliseconds.
reset(CamelContext, String) - Static method in class org.apache.camel.impl.engine.DefaultRouteError
 
reset() - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
reset() - Method in class org.apache.camel.impl.engine.FileStateRepository
Resets and clears the store to force it to reload from file
reset() - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Reset the counters
reset() - Method in class org.apache.camel.processor.ChoiceProcessor
Reset counters.
reset() - Method in class org.apache.camel.processor.FilterProcessor
Reset counters.
reset() - Method in class org.apache.camel.processor.loadbalancer.DistributionRatio
 
reset() - Method in class org.apache.camel.processor.loadbalancer.ExceptionFailureStatistics
 
reset() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
reset() - Method in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
reset() - Method in class org.apache.camel.processor.loadbalancer.WeightedRoundRobinLoadBalancer
 
reset() - Method in class org.apache.camel.processor.SendProcessor
 
resetAllCounters() - Static method in class org.apache.camel.impl.engine.DefaultNodeIdFactory
Helper method for test purposes that allows tests to start clean (made protected to ensure that it is not called accidentally)
resetCacheStatistics() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
Resets the cache statistics
resetCacheStatistics() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
resetCounters() - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
resetDebugCounter() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
resetDuplicateMessageCount() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
Resets the duplicate message counter to 0L.
resetStatistics() - Method in class org.apache.camel.impl.engine.ServicePool
 
resetTraceCounter() - Method in class org.apache.camel.impl.engine.DefaultTracer
 
resetTraceCounter() - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
resolve(CamelContext) - Method in class org.apache.camel.impl.engine.BeanProcessorFactoryResolver
 
resolve(CamelContext) - Method in class org.apache.camel.impl.engine.BeanProxyFactoryResolver
 
resolve(CamelContext) - Method in class org.apache.camel.impl.engine.HeadersMapFactoryResolver
 
resolve(CamelContext) - Method in class org.apache.camel.impl.engine.PropertiesComponentFactoryResolver
 
resolve(CamelContext) - Method in class org.apache.camel.impl.engine.ReactiveExecutorResolver
 
resolve(CamelContext) - Method in class org.apache.camel.impl.engine.RestRegistryFactoryResolver
 
resolve(CamelContext, String) - Method in class org.apache.camel.processor.SendDynamicAwareResolver
 
resolveClass(String) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
resolveClass(String, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
resolveClass(String, ClassLoader) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
resolveClass(String, Class<T>, ClassLoader) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
resolveComponent(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
resolveComponent(String, CamelContext) - Method in class org.apache.camel.impl.engine.DefaultComponentResolver
 
resolveDataFormat(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
resolveDataFormat(String, CamelContext) - Method in class org.apache.camel.impl.engine.DefaultDataFormatResolver
 
resolveDefaultFactoryFinder(ClassResolver) - Method in class org.apache.camel.impl.engine.DefaultFactoryFinderResolver
 
resolveEndpoint(String) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
resolveEndpoint(String, String) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
resolveEndpoint(Exchange, Object) - Method in class org.apache.camel.processor.Enricher
 
resolveEndpoint(Exchange, Object) - Method in class org.apache.camel.processor.PollEnricher
 
resolveEndpoint(Exchange, Object) - Method in class org.apache.camel.processor.RecipientList
 
resolveEndpoint(Exchange, Object) - Static method in class org.apache.camel.processor.RecipientListProcessor
 
resolveEndpoint(RoutingSlip.RoutingSlipIterator, Exchange) - Method in class org.apache.camel.processor.RoutingSlip
 
resolveEndpoint(Exchange, Object) - Static method in class org.apache.camel.processor.SendDynamicProcessor
 
resolveExchangePattern(Object) - Method in class org.apache.camel.processor.RecipientListProcessor
 
resolveFactoryFinder(ClassResolver, String) - Method in class org.apache.camel.impl.engine.DefaultFactoryFinderResolver
 
resolveLanguage(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
resolveLanguage(String, CamelContext) - Method in class org.apache.camel.impl.engine.DefaultLanguageResolver
 
resolveManagementName(String, String, boolean) - Method in class org.apache.camel.impl.engine.DefaultManagementNameStrategy
Creates a new management name with the given pattern
resolveMandatoryClass(String) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
resolveMandatoryClass(String, Class<T>) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
resolveMandatoryClass(String, ClassLoader) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
resolveMandatoryClass(String, Class<T>, ClassLoader) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
resolveMandatoryEndpoint(String) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
resolveMandatoryEndpoint(String) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
resolveProperty(String) - Method in class org.apache.camel.component.properties.PropertiesComponent
 
resolvePropertyPlaceholders(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
resolver - Variable in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
resolver - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
resolveScheme(Exchange, String) - Static method in class org.apache.camel.processor.SendDynamicProcessor
 
resolveSpoolDirectory(String) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
resolveThreadName(String) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
resolveTransformer(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
resolveTransformer(DataType, DataType) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
resolveTransformer(TransformerKey) - Method in class org.apache.camel.impl.engine.DefaultTransformerRegistry
 
resolveUri(Exchange, Object) - Static method in class org.apache.camel.processor.SendDynamicProcessor
 
resolveValidator(DataType) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
resolveValidator(ValidatorKey) - Method in class org.apache.camel.impl.engine.DefaultValidatorRegistry
 
RESOURCE_PATH - Static variable in class org.apache.camel.impl.engine.BeanProcessorFactoryResolver
 
RESOURCE_PATH - Static variable in class org.apache.camel.impl.engine.BeanProxyFactoryResolver
 
RESOURCE_PATH - Static variable in class org.apache.camel.impl.engine.DefaultComponentResolver
 
RESOURCE_PATH - Static variable in class org.apache.camel.impl.engine.DefaultProcessorFactory
 
RESOURCE_PATH - Static variable in class org.apache.camel.impl.engine.HeadersMapFactoryResolver
 
RESOURCE_PATH - Static variable in class org.apache.camel.impl.engine.PropertiesComponentFactoryResolver
 
RESOURCE_PATH - Static variable in class org.apache.camel.impl.engine.ReactiveExecutorResolver
 
RESOURCE_PATH - Static variable in class org.apache.camel.impl.engine.RestRegistryFactoryResolver
 
RESOURCE_PATH - Static variable in class org.apache.camel.processor.SendDynamicAwareResolver
 
RestBindingAdvice - Class in org.apache.camel.processor
A CamelInternalProcessorAdvice that binds the REST DSL incoming and outgoing messages from sources of json or xml to Java Objects.
RestBindingAdvice(CamelContext, DataFormat, DataFormat, DataFormat, DataFormat, String, String, String, boolean, boolean, boolean, Map<String, String>, Map<String, String>, boolean, Set<String>, Set<String>) - Constructor for class org.apache.camel.processor.RestBindingAdvice
 
restoreTimeoutMapFromAggregationRepository() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
Restores the timeout map with timeout values from the aggregation repository.
RestRegistryFactoryResolver - Class in org.apache.camel.impl.engine
Factory to create the RestRegistryFactory implementation to be used.
RestRegistryFactoryResolver() - Constructor for class org.apache.camel.impl.engine.RestRegistryFactoryResolver
 
resume() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
resumeAll() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
resumeBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
resumeRoute(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
resumeRoute(String) - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
resumeRoute(String) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
resumeRouteService(BaseRouteService) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
Resumes the given route service
retriesExhaustedLogLevel - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
retriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the logging level to use for log messages when retries have been exhausted.
retryAttemptedLogInterval - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
retryAttemptedLogInterval(int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the interval to log retry attempts
retryAttemptedLogLevel - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
retryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the logging level to use for log messages when retries are attempted.
retryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
retryWhilePolicy - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
rollback(Consumer, Endpoint, int, Exception) - Method in class org.apache.camel.impl.engine.LimitedPollingConsumerPollStrategy
 
RollbackProcessor - Class in org.apache.camel.processor
Processor for marking an Exchange to rollback.
RollbackProcessor() - Constructor for class org.apache.camel.processor.RollbackProcessor
 
RollbackProcessor(String) - Constructor for class org.apache.camel.processor.RollbackProcessor
 
RoundRobinLoadBalancer - Class in org.apache.camel.processor.loadbalancer
Implements the round robin load balancing policy
RoundRobinLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.RoundRobinLoadBalancer
 
RouteAddedEvent - Class in org.apache.camel.impl.event
 
RouteAddedEvent(Route) - Constructor for class org.apache.camel.impl.event.RouteAddedEvent
 
RouteHealthCheck - Class in org.apache.camel.impl.health
 
RouteHealthCheck(Route) - Constructor for class org.apache.camel.impl.health.RouteHealthCheck
 
RouteHealthCheck(Route, Collection<PerformanceCounterEvaluator<ManagedRouteMBean>>) - Constructor for class org.apache.camel.impl.health.RouteHealthCheck
 
RouteInflightRepositoryAdvice(InflightRepository, String) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.RouteInflightRepositoryAdvice
 
RouteLifecycleAdvice() - Constructor for class org.apache.camel.processor.CamelInternalProcessor.RouteLifecycleAdvice
 
RoutePerformanceCounterEvaluators - Class in org.apache.camel.impl.health
 
RoutePerformanceCounterEvaluators.ExchangesFailed - Class in org.apache.camel.impl.health
 
RoutePerformanceCounterEvaluators.ExchangesInflight - Class in org.apache.camel.impl.health
 
RoutePerformanceCounterEvaluators.ExternalRedeliveries - Class in org.apache.camel.impl.health
 
RoutePerformanceCounterEvaluators.LastProcessingTime - Class in org.apache.camel.impl.health
 
RoutePerformanceCounterEvaluators.MaxProcessingTime - Class in org.apache.camel.impl.health
 
RoutePerformanceCounterEvaluators.MeanProcessingTime - Class in org.apache.camel.impl.health
 
RoutePerformanceCounterEvaluators.MinProcessingTime - Class in org.apache.camel.impl.health
 
RoutePerformanceCounterEvaluators.Redeliveries - Class in org.apache.camel.impl.health
 
RoutePolicyAdvice(List<RoutePolicy>) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.RoutePolicyAdvice
 
RouteRemovedEvent - Class in org.apache.camel.impl.event
 
RouteRemovedEvent(Route) - Constructor for class org.apache.camel.impl.event.RouteRemovedEvent
 
RoutesHealthCheckRepository - Class in org.apache.camel.impl.health
 
RoutesHealthCheckRepository() - Constructor for class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
RouteStartedEvent - Class in org.apache.camel.impl.event
 
RouteStartedEvent(Route) - Constructor for class org.apache.camel.impl.event.RouteStartedEvent
 
RouteStatDump - Class in org.apache.camel.support.dump
A model of a route stat dump from ManagedRouteMBean.dumpRouteStatsAsXml(boolean, boolean).
RouteStatDump() - Constructor for class org.apache.camel.support.dump.RouteStatDump
 
RouteStoppedEvent - Class in org.apache.camel.impl.event
 
RouteStoppedEvent(Route) - Constructor for class org.apache.camel.impl.event.RouteStoppedEvent
 
routeSupportsSuspension(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
RoutingSlip - Class in org.apache.camel.processor
Implements a Routing Slip pattern where the list of actual endpoints to send a message exchange to are dependent on the value of a message header.
RoutingSlip(CamelContext) - Constructor for class org.apache.camel.processor.RoutingSlip
 
RoutingSlip(CamelContext, Expression, String) - Constructor for class org.apache.camel.processor.RoutingSlip
 
RoutingSlip.RoutingSlipIterator - Interface in org.apache.camel.processor
The iterator to be used for retrieving the next routing slip(s) to be used.
run() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
Redelivery logic.
run() - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer.State
 
run() - Method in class org.apache.camel.processor.loadbalancer.TopicLoadBalancer.State
 
run() - Method in class org.apache.camel.processor.MulticastProcessor.MulticastState
 
run() - Method in class org.apache.camel.processor.resequencer.Timeout
Notifies the timeout handler about the scheduled timeout.
runtimeRatioSum - Variable in class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 

S

safelyStartRouteServices(boolean, boolean, boolean, boolean, Collection<BaseRouteService>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
Starts the routes services in a proper manner which ensures the routes will be started in correct order, check for clash and that the routes will also be shutdown in correct order as well.
safelyStartRouteServices(boolean, boolean, boolean, boolean, boolean, BaseRouteService...) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
SagaCompletionMode - Enum in org.apache.camel.processor.saga
Enumerates all saga completion modes.
SagaProcessor - Class in org.apache.camel.processor.saga
Processor for handling sagas.
SagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.SagaProcessor
 
SagaProcessorBuilder - Class in org.apache.camel.processor.saga
Builder of Saga processors.
SagaProcessorBuilder() - Constructor for class org.apache.camel.processor.saga.SagaProcessorBuilder
 
SagaPropagation - Enum in org.apache.camel.processor.saga
Enumerates all saga propagation modes.
sagaService - Variable in class org.apache.camel.processor.saga.SagaProcessor
 
sagaService(CamelSagaService) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
SamplingThrottler - Class in org.apache.camel.processor
A SamplingThrottler is a special kind of throttler.
SamplingThrottler(long) - Constructor for class org.apache.camel.processor.SamplingThrottler
 
SamplingThrottler(long, TimeUnit) - Constructor for class org.apache.camel.processor.SamplingThrottler
 
sanitizeHostName(String) - Static method in class org.apache.camel.impl.engine.DefaultUuidGenerator
 
scanRaw(String) - Static method in class org.apache.camel.runtimecatalog.impl.URISupport
 
schedule(Runnable, String) - Method in class org.apache.camel.impl.engine.DefaultReactiveExecutor
 
schedule(Runnable) - Method in class org.apache.camel.processor.MulticastProcessor
 
schedule(Executor, Runnable, long, TimeUnit) - Method in class org.apache.camel.processor.MulticastProcessor
 
schedule() - Method in class org.apache.camel.processor.resequencer.Timeout
Schedules this timeout task.
scheduleMain(Runnable, String) - Method in class org.apache.camel.impl.engine.DefaultReactiveExecutor
 
scheduleSync(Runnable, String) - Method in class org.apache.camel.impl.engine.DefaultReactiveExecutor
 
ScriptProcessor - Class in org.apache.camel.processor
A processor which executes the script as an expression and does not change the message body.
ScriptProcessor(Expression) - Constructor for class org.apache.camel.processor.ScriptProcessor
 
send() - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
send(Endpoint, Exchange, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
send(String, Exchange) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
send(String, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
send(String, ExchangePattern, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
send(Endpoint, Exchange) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
send(Endpoint, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
send(Endpoint, ExchangePattern, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
send(Endpoint, ExchangePattern, Processor, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
send(Endpoint, Exchange, Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
send(Exchange) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
send(Processor) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBody(Endpoint, ExchangePattern, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBody(Endpoint, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBody(String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBody(String, ExchangePattern, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBody(Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndHeader(String, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndHeader(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndHeader(Endpoint, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndHeader(String, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndHeader(Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndHeaders(String, Object, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndHeaders(Endpoint, Object, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndHeaders(String, ExchangePattern, Object, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndHeaders(Endpoint, ExchangePattern, Object, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndHeaders(Object, Map<String, Object>) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndProperty(String, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndProperty(Endpoint, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndProperty(Endpoint, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndProperty(String, ExchangePattern, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
sendBodyAndProperty(Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
SendDynamicAwareResolver - Class in org.apache.camel.processor
 
SendDynamicAwareResolver() - Constructor for class org.apache.camel.processor.SendDynamicAwareResolver
 
SendDynamicProcessor - Class in org.apache.camel.processor
Processor for forwarding exchanges to a dynamic endpoint destination.
SendDynamicProcessor(String, Expression) - Constructor for class org.apache.camel.processor.SendDynamicProcessor
 
sendElement(E) - Method in interface org.apache.camel.processor.resequencer.SequenceSender
Sends the given element.
sendElement(Exchange) - Method in class org.apache.camel.processor.StreamResequencer
Sends the exchange to the next processor.
SendProcessor - Class in org.apache.camel.processor
Processor for forwarding exchanges to a static endpoint destination.
SendProcessor(Endpoint) - Constructor for class org.apache.camel.processor.SendProcessor
 
SendProcessor(Endpoint, ExchangePattern) - Constructor for class org.apache.camel.processor.SendProcessor
 
sendToRecipientList(Exchange, Object, AsyncCallback) - Method in class org.apache.camel.processor.RecipientList
Sends the given exchange to the recipient list
Sequence<E> - Class in org.apache.camel.processor.resequencer
A sorted set of elements with additional methods for obtaining immediate successors and immediate predecessors of a given element in the sequence.
Sequence(SequenceElementComparator<E>) - Constructor for class org.apache.camel.processor.resequencer.Sequence
Creates a new Sequence instance.
SequenceElementComparator<E> - Interface in org.apache.camel.processor.resequencer
A strategy for comparing elements of a sequence.
SequenceSender<E> - Interface in org.apache.camel.processor.resequencer
An interface used by the ResequencerEngine.deliver() and ResequencerEngine.deliverNext() methods to send out re-ordered elements.
ServiceHostPropertiesFunction - Class in org.apache.camel.component.properties
A PropertiesFunction that lookup the property value from OS environment variables using the service idiom.
ServiceHostPropertiesFunction() - Constructor for class org.apache.camel.component.properties.ServiceHostPropertiesFunction
 
ServicePool<S extends org.apache.camel.Service> - Class in org.apache.camel.impl.engine
A service pool is like a connection pool but can pool any kind of objects.
ServicePool(ThrowingFunction<Endpoint, S, Exception>, Function<S, Endpoint>, int) - Constructor for class org.apache.camel.impl.engine.ServicePool
 
ServicePortPropertiesFunction - Class in org.apache.camel.component.properties
A PropertiesFunction that lookup the property value from OS environment variables using the service idiom.
ServicePortPropertiesFunction() - Constructor for class org.apache.camel.component.properties.ServicePortPropertiesFunction
 
ServicePropertiesFunction - Class in org.apache.camel.component.properties
A PropertiesFunction that lookup the property value from OS environment variables using the service idiom.
ServicePropertiesFunction() - Constructor for class org.apache.camel.component.properties.ServicePropertiesFunction
 
ServiceStartupFailureEvent - Class in org.apache.camel.impl.event
 
ServiceStartupFailureEvent(CamelContext, Object, Throwable) - Constructor for class org.apache.camel.impl.event.ServiceStartupFailureEvent
 
ServiceStopFailureEvent - Class in org.apache.camel.impl.event
 
ServiceStopFailureEvent(CamelContext, Object, Throwable) - Constructor for class org.apache.camel.impl.event.ServiceStopFailureEvent
 
set(CamelContext, String, RouteError.Phase, Throwable) - Static method in class org.apache.camel.impl.engine.DefaultRouteError
 
setAcceptableSchemes(String) - Method in class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
setAcceptableSchemes(String) - Method in class org.apache.camel.impl.engine.BasePackageScanResolver
To specify a set of accepted schemas to use for loading resources as URL connections (besides http and https schemas)
setAccumulatedProcessingTime(Long) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setAction(DurationRoutePolicy.Action) - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
What action to perform when maximum is triggered.
setAction(DurationRoutePolicy.Action) - Method in class org.apache.camel.impl.engine.DurationRoutePolicyFactory
What action to perform when maximum is triggered.
setAfter(Processor) - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
setAggregateController(AggregateController) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setAggregateOnException(boolean) - Method in class org.apache.camel.processor.Enricher
 
setAggregateOnException(boolean) - Method in class org.apache.camel.processor.PollEnricher
 
setAggregationRepository(AggregationRepository) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.Enricher
 
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.PollEnricher
Sets the aggregation strategy for this poll enricher.
setAggregationStrategy(AggregationStrategy) - Method in class org.apache.camel.processor.RecipientList
 
setAggregationStrategyOnExchange(Exchange, AggregationStrategy) - Method in class org.apache.camel.processor.MulticastProcessor
Sets the given AggregationStrategy on the Exchange.
setAllowDuplicates(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setAllowNullNewExchange(boolean) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
setAllowNullOldExchange(boolean) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
setAllowOptimisedComponents(boolean) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setAllowRedeliveryWhileStopping(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Controls whether to allow redelivery while stopping/shutting down a route that uses error handling.
setAllowUseOriginalMessage(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setAllowUseOriginalMessage(Boolean) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setAnySpoolRules(boolean) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
setApplicationContextClassLoader(ClassLoader) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setAsyncDelayed(boolean) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
setAsyncDelayed(boolean) - Method in class org.apache.camel.processor.Throttler
 
setAsyncDelayedRedelivery(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether asynchronous delayed redelivery is allowed.
setAsyncProcessorAwaitManager(AsyncProcessorAwaitManager) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setAutoCreateComponents(boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setAutoDiscoverPropertiesSources(boolean) - Method in class org.apache.camel.component.properties.PropertiesComponent
Whether to automatically discovery instances of PropertiesSource from registry and service factory.
setAutoStartup(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setAutoStartup(Boolean) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setBacklogSize(int) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setBacklogTracing(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setBacklogTracing(Boolean) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setBackOff(String, BackOff) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
Sets the back-off to be applied to the given id.
setBackOffConfigurations(Map<String, BackOff>) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
Set the back-off for the given IDs.
setBackOffMultiplier(double) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the multiplier used to increase the delay between redeliveries if RedeliveryPolicy.setUseExponentialBackOff(boolean) is enabled
setBasicPropertyBinding(boolean) - Method in class org.apache.camel.impl.engine.DefaultGlobalEndpointConfiguration
 
setBatchConsumer(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setBatchSize(int) - Method in class org.apache.camel.processor.Resequencer
Sets the in batch size.
setBatchTimeout(long) - Method in class org.apache.camel.processor.Resequencer
 
setBeanIntrospection(BeanIntrospection) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setBeanPostProcessor(CamelBeanPostProcessor) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setBefore(Processor) - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
setBlacklistedRoutes(Collection<String>) - Method in class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
setBody(MessageDump.Body) - Method in class org.apache.camel.support.dump.MessageDump
 
setBodyIncludeFiles(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setBodyIncludeFiles(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setBodyIncludeStreams(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setBodyIncludeStreams(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setBodyMaxChars(int) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setBodyMaxChars(int) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
SetBodyProcessor - Class in org.apache.camel.processor
A processor which sets the body on the IN or OUT message with an Expression
SetBodyProcessor(Expression) - Constructor for class org.apache.camel.processor.SetBodyProcessor
 
setBridgeErrorHandler(boolean) - Method in class org.apache.camel.impl.engine.DefaultGlobalEndpointConfiguration
 
setBufferSize(int) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
setCache(Map<String, String>) - Method in class org.apache.camel.impl.engine.FileStateRepository
 
setCacheSize(int) - Method in class org.apache.camel.processor.Enricher
 
setCacheSize(int) - Method in class org.apache.camel.processor.PollEnricher
 
setCacheSize(int) - Method in class org.apache.camel.processor.RecipientList
 
setCacheSize(int) - Method in class org.apache.camel.processor.RoutingSlip
 
setCacheSize(int) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setCallerRunsWhenRejected(boolean) - Method in class org.apache.camel.processor.DelayProcessorSupport
 
setCallerRunsWhenRejected(boolean) - Method in class org.apache.camel.processor.Throttler
 
setCamelContext(CamelContext) - Method in class org.apache.camel.component.properties.PropertiesComponent
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.engine.BasePackageScanResolver
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.engine.DefaultClassResolver
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.engine.DefaultMessageHistoryFactory
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.engine.DefaultTracer
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.health.ContextHealthCheck
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.health.DefaultHealthCheckRegistry
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.health.RegistryRepository
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
setCamelContext(CamelContext) - Method in class org.apache.camel.impl.saga.InMemorySagaService
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.Enricher
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.PollEnricher
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.WireTapProcessor
 
setCamelContext(CamelContext) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
setCamelContext(CamelContext) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
setCapacity(int) - Method in class org.apache.camel.processor.StreamResequencer
 
setCheckInterval(long) - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
setCheckInterval(long, TimeUnit) - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
setCheckIntervalUnit(TimeUnit) - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
setClassResolver(ClassResolver) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setCloseCorrelationKeyOnCompletion(Integer) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCollisionAvoidanceFactor(double) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the factor used for collision avoidance if enabled via RedeliveryPolicy.setUseCollisionAvoidance(boolean)
setCollisionAvoidancePercent(double) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the percentage used for collision avoidance if enabled via RedeliveryPolicy.setUseCollisionAvoidance(boolean)
setCompleteAllOnStop(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionFromBatchConsumer(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionInterval(long) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionOnNewCorrelationGroup(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionPredicate(Predicate) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionPredicate(Predicate) - Method in class org.apache.camel.processor.Resequencer
 
setCompletionSize(int) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionSizeExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionTimeout(long) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionTimeoutCheckerInterval(long) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCompletionTimeoutExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setComponentResolver(ComponentResolver) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setConfiguration(HealthCheckConfiguration) - Method in class org.apache.camel.impl.health.AbstractHealthCheck
 
setContextCounter(int) - Static method in class org.apache.camel.impl.engine.AbstractCamelContext
Reset context counter to a preset value.
setCopy(boolean) - Method in class org.apache.camel.processor.WireTapProcessor
 
setCopyMessage(boolean) - Method in class org.apache.camel.impl.engine.DefaultMessageHistoryFactory
 
setCorrelationExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setCounter(int) - Static method in class org.apache.camel.impl.engine.DefaultCamelContextNameStrategy
To reset the counter, should only be used for testing purposes.
setCounter(int) - Static method in class org.apache.camel.impl.engine.DefaultManagementNameStrategy
To reset the counter, should only be used for testing purposes.
setCurrentSagaCoordinator(Exchange, CamelSagaCoordinator) - Method in class org.apache.camel.processor.saga.SagaProcessor
 
setDataFormat(DataFormat) - Method in class org.apache.camel.impl.transformer.DataFormatTransformer
Set DataFormat.
setDataFormatResolver(DataFormatResolver) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setDebugger(Debugger) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setDebugging(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setDebugging(Boolean) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setDefaultAggregationStrategy() - Method in class org.apache.camel.processor.PollEnricher
Sets the default aggregation strategy for this poll enricher.
setDefaultBackOff(BackOff) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
Sets the default back-off.
setDefaultEndpoint(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
setDefaultEndpoint(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
setDefaultEndpointUri(String) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
setDefaultEndpointUri(String) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
Sets the default endpoint to use if none is specified
setDefaultExtension(Class<T>, Supplier<T>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setDefaultFallbackEnabled(boolean) - Method in class org.apache.camel.component.properties.PropertiesComponent
If false, the component does not attempt to find a default for the key by looking after the colon separator.
setDefaultThreadPoolProfile(ThreadPoolProfile) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
setDefinition(NamedNode) - Method in class org.apache.camel.processor.channel.DefaultChannel
 
setDelay(Expression) - Method in class org.apache.camel.processor.Delayer
 
setDelayer(Long) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setDelayer(Long) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setDelayPattern(String) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets an optional delay pattern to use instead of fixed delay.
setDelimiter(String) - Method in class org.apache.camel.processor.RoutingSlip
 
setDeliveryAttemptInterval(long) - Method in class org.apache.camel.processor.StreamResequencer
 
setDeltaProcessingTime(Long) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setDeltaProcessingTime(Long) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setDeltaProcessingTime(Long) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setDeltaProcessingTime(Long) - Method in class org.apache.camel.support.dump.StepStatDump
 
setDiscardOnAggregationFailure(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setDiscardOnCompletionTimeout(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setEagerCheckCompletion(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setEnabled(boolean) - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
setEnabled(boolean) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
setEnabled(boolean) - Method in class org.apache.camel.impl.engine.DefaultTracer
 
setEnabled(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setEncoding(String) - Method in class org.apache.camel.component.properties.PropertiesComponent
Encoding to use when loading properties file from the file system or classpath.
setEndpoint(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setEndToken(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setEnvironmentVariableMode(int) - Method in class org.apache.camel.component.properties.PropertiesComponent
Sets the OS environment variables mode (0 = never, 1 = fallback, 2 = override).
setErrorHandler(Processor) - Method in class org.apache.camel.processor.channel.DefaultChannel
Sets the ErrorHandler this Channel uses.
setErrorHandler(AsyncProcessor) - Method in class org.apache.camel.processor.RoutingSlip
 
setErrorHandlerExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setErrorHandlerFactory(ErrorHandlerFactory) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setErrorHandlerFactory(ErrorHandlerFactory) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setEvaluators(Collection<PerformanceCounterEvaluator<ManagedRouteMBean>>) - Method in class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
setEventFactory(EventFactory) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
setEventNotifierEnabled(boolean) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
setEventNotifierEnabled(boolean) - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
setEventNotifierEnabled(boolean) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setExceptionHandler(ExceptionHandler) - Method in class org.apache.camel.processor.Resequencer
 
setExceptionPolicy(ExceptionPolicyStrategy) - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
Sets the strategy to use for resolving the ExceptionPolicy to use for handling thrown exceptions.
setExchangeFormatter(ExchangeFormatter) - Method in class org.apache.camel.impl.engine.DefaultTracer
 
setExchangeFormatterRef(String) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the reference of the instance of ExchangeFormatter to generate the log message from exchange.
setExchangeId(String) - Method in class org.apache.camel.support.dump.MessageDump
 
setExchangePattern(ExchangePattern) - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
setExchangesCompleted(Long) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setExchangesCompleted(Long) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setExchangesCompleted(Long) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setExchangesCompleted(Long) - Method in class org.apache.camel.support.dump.StepStatDump
 
setExchangesFailed(Long) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setExchangesFailed(Long) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setExchangesFailed(Long) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setExchangesFailed(Long) - Method in class org.apache.camel.support.dump.StepStatDump
 
setExchangesInflight(Long) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setExchangesInflight(Long) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
setExecutorService(ExecutorService) - Method in class org.apache.camel.processor.RecipientList
 
setExecutorServiceManager(ExecutorServiceManager) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setExponentialBackOff(boolean) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setExpression(Expression) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyParameterInfo
 
setExpression(Expression) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
setExpression(Expression) - Method in interface org.apache.camel.processor.resequencer.ExpressionResultComparator
Set the expression used for comparing Exchanges.
setExtendedStatistics(boolean) - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
setExtendedStatistics(boolean) - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
Whether extended JMX statistics is enabled for EndpointUtilizationStatistics
setExtendedStatistics(boolean) - Method in class org.apache.camel.impl.engine.DefaultProducerCache
Whether extended JMX statistics is enabled for EndpointUtilizationStatistics
setExtension(Class<T>, T) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setFactoryFinderResolver(FactoryFinderResolver) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setFailuresHandled(Long) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setFailuresHandled(Long) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setFailuresHandled(Long) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setFailuresHandled(Long) - Method in class org.apache.camel.support.dump.StepStatDump
 
setFailureThreshold(int) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
setFailureWindow(long) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
setFallbackTimeout(long) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setFileStore(File) - Method in class org.apache.camel.impl.engine.FileStateRepository
 
setFilter(String) - Method in class org.apache.camel.processor.ClaimCheckAggregationStrategy
 
setFilter(String) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setFilters(Collection<SupervisingRouteController.Filter>) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
Sets the filters user to determine the routes to supervise.
setFirstExchangeCompletedExchangeId(String) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setFirstExchangeCompletedExchangeId(String) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setFirstExchangeCompletedExchangeId(String) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setFirstExchangeCompletedExchangeId(String) - Method in class org.apache.camel.support.dump.StepStatDump
 
setFirstExchangeCompletedTimestamp(String) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setFirstExchangeCompletedTimestamp(String) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setFirstExchangeCompletedTimestamp(String) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setFirstExchangeCompletedTimestamp(String) - Method in class org.apache.camel.support.dump.StepStatDump
 
setFirstExchangeFailureExchangeId(String) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setFirstExchangeFailureExchangeId(String) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setFirstExchangeFailureExchangeId(String) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setFirstExchangeFailureExchangeId(String) - Method in class org.apache.camel.support.dump.StepStatDump
 
setFirstExchangeFailureTimestamp(String) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setFirstExchangeFailureTimestamp(String) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setFirstExchangeFailureTimestamp(String) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setFirstExchangeFailureTimestamp(String) - Method in class org.apache.camel.support.dump.StepStatDump
 
setForceCompletionOnStop(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setFromRouteId(String) - Method in class org.apache.camel.impl.engine.DurationRoutePolicyFactory
Limit the route policy to the route which matches this pattern
setGlobalOptions(Map<String, String>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setGroup(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setGroupDelimiter(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setGroupExchanges(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setHalfOpenAfter(long) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
setHalfOpenHandler(ThrottlingExceptionHalfOpenHandler) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
setHeaderName(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
SetHeaderProcessor - Class in org.apache.camel.processor
A processor which sets the header on the IN or OUT message with an Expression
SetHeaderProcessor(Expression, Expression) - Constructor for class org.apache.camel.processor.SetHeaderProcessor
 
setHeaders(List<MessageDump.Header>) - Method in class org.apache.camel.support.dump.MessageDump
 
setHeadersMapFactory(HeadersMapFactory) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setHealthCheckOptions(String, Map<String, Object>) - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
setHealthCheckRegistry(HealthCheckRegistry) - Method in class org.apache.camel.impl.health.DefaultHealthCheckService
 
setId(String) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setId(String) - Method in class org.apache.camel.processor.CatchProcessor
 
setId(String) - Method in class org.apache.camel.processor.ChoiceProcessor
 
setId(String) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setId(String) - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
setId(String) - Method in class org.apache.camel.processor.Delayer
 
setId(String) - Method in class org.apache.camel.processor.Enricher
 
setId(String) - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
setId(String) - Method in class org.apache.camel.processor.FilterProcessor
 
setId(String) - Method in class org.apache.camel.processor.FinallyProcessor
 
setId(String) - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
setId(String) - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
setId(String) - Method in class org.apache.camel.processor.LogProcessor
 
setId(String) - Method in class org.apache.camel.processor.LoopProcessor
 
setId(String) - Method in class org.apache.camel.processor.MethodCallProcessor
 
setId(String) - Method in class org.apache.camel.processor.MulticastProcessor
 
setId(String) - Method in class org.apache.camel.processor.OnCompletionProcessor
 
setId(String) - Method in class org.apache.camel.processor.Pipeline
 
setId(String) - Method in class org.apache.camel.processor.PollEnricher
 
setId(String) - Method in class org.apache.camel.processor.RecipientList
 
setId(String) - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
setId(String) - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
setId(String) - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
setId(String) - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
setId(String) - Method in class org.apache.camel.processor.Resequencer
 
setId(String) - Method in class org.apache.camel.processor.RollbackProcessor
 
setId(String) - Method in class org.apache.camel.processor.RoutingSlip
 
setId(String) - Method in class org.apache.camel.processor.SamplingThrottler
 
setId(String) - Method in class org.apache.camel.processor.ScriptProcessor
 
setId(String) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setId(String) - Method in class org.apache.camel.processor.SendProcessor
 
setId(String) - Method in class org.apache.camel.processor.SetBodyProcessor
 
setId(String) - Method in class org.apache.camel.processor.SetHeaderProcessor
 
setId(String) - Method in class org.apache.camel.processor.SetPropertyProcessor
 
setId(String) - Method in class org.apache.camel.processor.SortProcessor
 
setId(String) - Method in class org.apache.camel.processor.StopProcessor
 
setId(String) - Method in class org.apache.camel.processor.StreamResequencer
 
setId(String) - Method in class org.apache.camel.processor.ThreadsProcessor
 
setId(String) - Method in class org.apache.camel.processor.Throttler
 
setId(String) - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
setId(String) - Method in class org.apache.camel.processor.TransformProcessor
 
setId(String) - Method in class org.apache.camel.processor.TryProcessor
 
setId(String) - Method in class org.apache.camel.processor.WireTapProcessor
 
setId(String) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setId(String) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setId(String) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setId(String) - Method in class org.apache.camel.support.dump.StepStatDump
 
setIgnoreInvalidCorrelationKeys(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setIgnoreInvalidEndpoint(boolean) - Method in class org.apache.camel.processor.Enricher
 
setIgnoreInvalidEndpoint(boolean) - Method in class org.apache.camel.processor.PollEnricher
 
setIgnoreInvalidEndpoint(boolean) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setIgnoreInvalidEndpoints(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setIgnoreInvalidEndpoints(boolean) - Method in class org.apache.camel.processor.RecipientListProcessor
 
setIgnoreInvalidEndpoints(boolean) - Method in class org.apache.camel.processor.RoutingSlip
 
setIgnoreInvalidExchanges(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setIgnoreInvalidExchanges(boolean) - Method in class org.apache.camel.processor.StreamResequencer
Sets whether to ignore invalid exchanges which cannot be used by this stream resequencer.
setIgnoreMissingLocation(boolean) - Method in class org.apache.camel.component.properties.PropertiesComponent
Whether to silently ignore if a location cannot be located, such as a properties file not found.
setIncludeTokens(boolean) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setIndex(Integer) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setIndex(Integer) - Method in class org.apache.camel.support.dump.StepStatDump
 
setInflightRepository(InflightRepository) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setInheritNamespaceTagName(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setInitialDelay(Duration) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
Set the amount of time the route controller should wait before to start the routes after the camel context is started or after the route is initialized if the route is created after the camel context is started.
setInitialDelay(long, TimeUnit) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
#see this#setInitialDelay(Duration)
setInitialDelay(long) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
#see this#setInitialDelay(Duration)
setInitialization(AbstractCamelContext.Initialization) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setInitialProperties(Properties) - Method in class org.apache.camel.component.properties.PropertiesComponent
Sets initial properties which will be used before any locations are resolved.
setInjector(Injector) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
setInjector(Injector) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setInterceptStrategies(List<InterceptStrategy>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setInterceptStrategies(List<InterceptStrategy>) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setInterruptThreadsWhileStopping(boolean) - Method in class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
 
setIsRouteAdded(boolean) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setJSonSchemaResolver(JSonSchemaResolver) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
setKeepOpen(boolean) - Method in class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
setKey(String) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setKey(String) - Method in class org.apache.camel.support.dump.MessageDump.Header
 
setLanguageResolver(LanguageResolver) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setLastError(RouteError) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setLastExchangeCompletedExchangeId(String) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setLastExchangeCompletedExchangeId(String) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setLastExchangeCompletedExchangeId(String) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setLastExchangeCompletedExchangeId(String) - Method in class org.apache.camel.support.dump.StepStatDump
 
setLastExchangeCompletedTimestamp(String) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setLastExchangeCompletedTimestamp(String) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setLastExchangeCompletedTimestamp(String) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setLastExchangeCompletedTimestamp(String) - Method in class org.apache.camel.support.dump.StepStatDump
 
setLastExchangeFailureExchangeId(String) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setLastExchangeFailureExchangeId(String) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setLastExchangeFailureExchangeId(String) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setLastExchangeFailureExchangeId(String) - Method in class org.apache.camel.support.dump.StepStatDump
 
setLastExchangeFailureTimestamp(String) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setLastExchangeFailureTimestamp(String) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setLastExchangeFailureTimestamp(String) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setLastExchangeFailureTimestamp(String) - Method in class org.apache.camel.support.dump.StepStatDump
 
setLastProcessingTime(Long) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setLastProcessingTime(Long) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setLastProcessingTime(Long) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setLastProcessingTime(Long) - Method in class org.apache.camel.support.dump.StepStatDump
 
setLazyStartProducer(boolean) - Method in class org.apache.camel.impl.engine.DefaultGlobalEndpointConfiguration
 
setLimit(int) - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
setLimit(int) - Method in class org.apache.camel.impl.engine.LimitedPollingConsumerPollStrategy
Sets the limit for how many straight rollbacks causes this strategy to suspend the fault consumer.
setLoadTypeConverters(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setLocation(String) - Method in class org.apache.camel.component.properties.PropertiesComponent
A list of locations to load properties.
setLocations(List<PropertiesLocation>) - Method in class org.apache.camel.component.properties.PropertiesComponent
A list of locations to load properties.
setLocations(String[]) - Method in class org.apache.camel.component.properties.PropertiesComponent
A list of locations to load properties.
setLocations(Collection<String>) - Method in class org.apache.camel.component.properties.PropertiesComponent
A list of locations to load properties.
setLogContinued(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether errors should be logged even if its continued
setLogExhausted(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether exhausted exceptions should be logged or not
setLogExhaustedMessageBody(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setLogExhaustedMessageBody(Boolean) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setLogExhaustedMessageBody(Boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether exhausted message body/headers should be logged with message history included (requires logExhaustedMessageHistory to be enabled).
setLogExhaustedMessageHistory(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether exhausted exceptions should be logged with message history included.
setLogger(CamelLogger) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
Sets the logger to use for logging throttling activity.
setLoggingLevel(LoggingLevel) - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
setLoggingLevel(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setLoggingLevel(LoggingLevel) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
Sets the logging level to report the throttling activity.
setLogHandled(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether errors should be logged even if its handled
setLogInflightExchangesOnTimeout(boolean) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
setLogMask(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setLogMask(Boolean) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setLogNewException(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether errors should be logged when a new exception occurred during handling a previous exception
setLogRetryAttempted(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether retry attempts should be logged or not
setLogRetryStackTrace(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether stack traces should be logged or not
setLogStackTrace(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets whether stack traces should be logged or not
setManagementAgent(ManagementAgent) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
setManagementInterceptStrategy(ManagementInterceptStrategy) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setManagementMBeanAssembler(ManagementMBeanAssembler) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setManagementName(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setManagementNameStrategy(ManagementNameStrategy) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setManagementObjectNameStrategy(ManagementObjectNameStrategy) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
setManagementObjectStrategy(ManagementObjectStrategy) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
setManagementStrategy(ManagementStrategy) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setMarkRollbackOnly(boolean) - Method in class org.apache.camel.processor.RollbackProcessor
 
setMarkRollbackOnlyLast(boolean) - Method in class org.apache.camel.processor.RollbackProcessor
 
setMaxFileStoreSize(long) - Method in class org.apache.camel.impl.engine.FileStateRepository
Sets the maximum file size for the file store in bytes.
setMaximumCacheSize(int) - Method in class org.apache.camel.impl.engine.DefaultConsumerTemplate
 
setMaximumCacheSize(int) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
setMaximumCacheSize(int) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
setMaximumFailoverAttempts(int) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
setMaximumRedeliveries(int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the maximum number of times a message exchange will be redelivered.
setMaximumRedeliveryDelay(long) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the maximum redelivery delay.
setMaximumRequestsPerPeriodExpression(Expression) - Method in class org.apache.camel.processor.Throttler
Sets the maximum number of requests per time period expression
setMaximumRetries(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setMaximumRetryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setMaxInflightExchanges(int) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
Sets the upper limit of number of concurrent inflight exchanges at which point reached the throttler should suspend the route.
setMaxMessages(int) - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
Maximum number of messages to process before the action is triggered
setMaxMessages(int) - Method in class org.apache.camel.impl.engine.DurationRoutePolicyFactory
Maximum number of messages to process before the action is triggered
setMaxProcessingTime(Long) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setMaxProcessingTime(Long) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setMaxProcessingTime(Long) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setMaxProcessingTime(Long) - Method in class org.apache.camel.support.dump.StepStatDump
 
setMaxRetryAttempts(int) - Method in class org.apache.camel.impl.saga.InMemorySagaService
 
setMaxSeconds(int) - Method in class org.apache.camel.impl.engine.DurationRoutePolicy
Maximum seconds Camel is running before the action is triggered
setMaxSeconds(int) - Method in class org.apache.camel.impl.engine.DurationRoutePolicyFactory
Maximum seconds Camel is running before the action is triggered
setMDCLoggingKeysPattern(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setMeanProcessingTime(Long) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setMeanProcessingTime(Long) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setMeanProcessingTime(Long) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setMeanProcessingTime(Long) - Method in class org.apache.camel.support.dump.StepStatDump
 
setMessageBodyOnBreakpoint(String, Object) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setMessageBodyOnBreakpoint(String, Object, Class<?>) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setMessageHeaderOnBreakpoint(String, String, Object) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setMessageHeaderOnBreakpoint(String, String, Object, Class<?>) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
setMessageHistory(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setMessageHistory(Boolean) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setMessageHistoryFactory(MessageHistoryFactory) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setMethodName(String) - Method in class org.apache.camel.processor.aggregate.AggregationStrategyBeanAdapter
 
setMinProcessingTime(Long) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setMinProcessingTime(Long) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setMinProcessingTime(Long) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setMinProcessingTime(Long) - Method in class org.apache.camel.support.dump.StepStatDump
 
setModelJAXBContextFactory(ModelJAXBContextFactory) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setName(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setNamePattern(String) - Method in class org.apache.camel.impl.engine.DefaultManagementNameStrategy
 
setNameStrategy(CamelContextNameStrategy) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setNewExchangeExpression(Expression) - Method in class org.apache.camel.processor.WireTapProcessor
 
setNewExchangeProcessors(List<Processor>) - Method in class org.apache.camel.processor.WireTapProcessor
 
setNodeIdFactory(NodeIdFactory) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setNodePattern(String) - Method in class org.apache.camel.impl.engine.DefaultMessageHistoryFactory
 
setNumberOfHashGroups(int) - Method in class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
setOnCompletion(String, Processor) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setOnException(String, Processor) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setOnPrepare(Processor) - Method in class org.apache.camel.processor.RecipientList
 
setOnPrepare(Processor) - Method in class org.apache.camel.processor.WireTapProcessor
 
setOperation(String) - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
setOptimisticLocking(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setOptimisticLockingExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setOptimisticLockRetryPolicy(OptimisticLockRetryPolicy) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setOutBatchSize(int) - Method in class org.apache.camel.processor.Resequencer
Sets the out batch size.
setOutput(Processor) - Method in class org.apache.camel.processor.channel.DefaultChannel
 
setOverrideProperties(Properties) - Method in class org.apache.camel.component.properties.PropertiesComponent
Sets a special list of override properties that take precedence and will use first, if a property exist.
setPackageScanClassResolver(PackageScanClassResolver) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setPackageScanResourceResolver(PackageScanResourceResolver) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setParallelAggregate(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setParallelProcessing(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setParallelProcessing(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setParentUnitOfWork(UnitOfWork) - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
setPattern(ExchangePattern) - Method in class org.apache.camel.processor.SendDynamicProcessor
 
setPollingConsumerServicePool(ServicePool<PollingConsumer>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setProcessor(Processor) - Method in class org.apache.camel.impl.transformer.ProcessorTransformer
Set processor to use
setProcessor(Processor) - Method in class org.apache.camel.impl.validator.ProcessorValidator
Set processor to use
setProcessorFactory(ProcessorFactory) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setProcessorStats(List<ProcessorStatDump>) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setProducerServicePool(ServicePool<Producer>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setPropertiesComponent(PropertiesComponent) - Method in class org.apache.camel.component.properties.DefaultPropertiesParser
 
setPropertiesComponent(PropertiesComponent) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setPropertiesParser(PropertiesParser) - Method in class org.apache.camel.component.properties.PropertiesComponent
To use a custom PropertiesParser
setProperty(CamelContext, TypeConverter, Object, String, Object, String, boolean, boolean, boolean) - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
setProperty(CamelContext, Object, String, Object) - Method in class org.apache.camel.impl.engine.DefaultBeanIntrospection
 
SetPropertyProcessor - Class in org.apache.camel.processor
A processor which sets the property on the exchange with an Expression
SetPropertyProcessor(Expression, Expression) - Constructor for class org.apache.camel.processor.SetPropertyProcessor
 
setRandomBackOff(boolean) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setReactiveExecutor(ReactiveExecutor) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setRedeliveries(Long) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setRedeliveries(Long) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setRedeliveries(Long) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setRedeliveries(Long) - Method in class org.apache.camel.support.dump.StepStatDump
 
setRedeliveryDelay(long) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the initial redelivery delay in milliseconds
setRegex(boolean) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setRegistry(Registry) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setRejectExecution(boolean) - Method in class org.apache.camel.processor.Throttler
 
setRejectOld(Boolean) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
 
setRejectOld(Boolean) - Method in class org.apache.camel.processor.StreamResequencer
 
setRemoveOnDump(boolean) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setRemoveSpoolDirectoryWhenStopping(boolean) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
setRemovingRoutes(boolean) - Method in class org.apache.camel.impl.engine.BaseRouteService
 
setRepositories(Collection<HealthCheckRepository>) - Method in class org.apache.camel.impl.health.DefaultHealthCheckRegistry
 
setResetTimestamp(String) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setResetTimestamp(String) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setResetTimestamp(String) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setResetTimestamp(String) - Method in class org.apache.camel.support.dump.StepStatDump
 
setRestConfiguration(RestConfiguration) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setRestRegistry(RestRegistry) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setRestRegistryFactory(RestRegistryFactory) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setResumePercentOfMax(int) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
Sets at which percentage of the max the throttler should start resuming the route.
setRetriesExhaustedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the logging level to use for log messages when retries have been exhausted.
setRetryAttemptedLogInterval(int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the interval to log retry attempts
setRetryAttemptedLogLevel(LoggingLevel) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sets the logging level to use for log messages when retries are attempted.
setRetryDelay(long) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
setRetryDelayInMilliseconds(long) - Method in class org.apache.camel.impl.saga.InMemorySagaService
 
setReverse(boolean) - Method in class org.apache.camel.processor.Resequencer
 
setRoundRobin(boolean) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
setRoute(Route) - Method in class org.apache.camel.processor.CamelInternalProcessor.RouteLifecycleAdvice
 
setRoute(Route) - Method in class org.apache.camel.processor.CamelInternalProcessor.RoutePolicyAdvice
 
setRouteController(RouteController) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setRouteController(RouteController) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setRouteEvaluators(String, Collection<PerformanceCounterEvaluator<ManagedRouteMBean>>) - Method in class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
setRoutePolicyFactories(List<RoutePolicyFactory>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setRoutePolicyList(List<RoutePolicy>) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setRoutesEvaluators(Map<String, Collection<PerformanceCounterEvaluator<ManagedRouteMBean>>>) - Method in class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
setRouteStats(List<RouteStatDump>) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setRuntimeEndpointRegistry(RuntimeEndpointRegistry) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setScope(ThrottlingInflightRoutePolicy.ThrottlingScope) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
Sets which scope the throttling should be based upon, either route or total scoped.
setSelfProcessingTime(Long) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setSelfProcessingTime(Long) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setSequenceSender(SequenceSender<E>) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Sets the sequence sender.
setShareUnitOfWork(boolean) - Method in class org.apache.camel.processor.Enricher
 
setShareUnitOfWork(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setShutdownAwaitTermination(long) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
setShutdownExecutorService(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setShutdownNowOnTimeout(boolean) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
setShutdownOptimisticLockingExecutorService(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setShutdownRoute(ShutdownRoute) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setShutdownRoute(ShutdownRoute) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setShutdownRoutesInReverseOrder(boolean) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
setShutdownRunningTask(ShutdownRunningTask) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setShutdownRunningTask(ShutdownRunningTask) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setShutdownStrategy(ShutdownStrategy) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setShutdownTimeoutCheckerExecutorService(boolean) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setSkip(boolean) - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
setSkipFirst(boolean) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setSpoolCipher(String) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
setSpoolDirectory(String) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
setSpoolDirectory(File) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
setSpoolThreshold(long) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
setSpoolUsedHeapMemoryLimit(StreamCachingStrategy.SpoolUsedHeapMemoryLimit) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
setSpoolUsedHeapMemoryThreshold(int) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
setSSLContextParameters(SSLContextParameters) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setStartingRoutes(boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setStartTimestamp(String) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setStartTimestamp(String) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setStartupOrder(Integer) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setState(String, String) - Method in class org.apache.camel.impl.engine.FileStateRepository
 
setState(String, String) - Method in class org.apache.camel.impl.engine.MemoryStateRepository
 
setState(String) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setState(String) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setState(String) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setState(String) - Method in class org.apache.camel.support.dump.StepStatDump
 
setStatisticsEnabled(boolean) - Method in interface org.apache.camel.processor.aggregate.AggregateProcessorStatistics
Sets whether statistics is enabled.
setStepStats(List<StepStatDump>) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setSticky(boolean) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
 
setStopOnAggregateException(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setStopOnException(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setStreamCaching(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setStreamCaching(Boolean) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setStreamCachingStrategy(StreamCachingStrategy) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setStreaming(boolean) - Method in class org.apache.camel.processor.RecipientList
 
setSuggestionStrategy(SuggestionStrategy) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
setSuppressLoggingOnTimeout(boolean) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
setSystemPropertiesMode(int) - Method in class org.apache.camel.component.properties.PropertiesComponent
Sets the JVM system property mode (0 = never, 1 = fallback, 2 = override).
setTarget(Processor) - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
 
setterBeanInjection(Method, String, Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
setterInjection(Method, Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
setterInjection(Method, Object, String, String, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
setterPropertyInjection(Method, String, String, Object, String) - Method in class org.apache.camel.impl.engine.DefaultCamelBeanPostProcessor
 
setThreadedAsyncMode(boolean) - Method in class org.apache.camel.impl.engine.DefaultProducerTemplate
 
setThreadNamePattern(String) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
setThreadPoolFactory(ThreadPoolFactory) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
setTimeout(long) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
setTimeout(long) - Method in class org.apache.camel.processor.PollEnricher
Sets the timeout to use when polling.
setTimeout(long) - Method in class org.apache.camel.processor.RecipientList
 
setTimeout(long) - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Sets this sequencer's timeout value.
setTimeout(long) - Method in class org.apache.camel.processor.StreamResequencer
 
setTimeoutCheckerExecutorService(ScheduledExecutorService) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
setTimeoutHandler(TimeoutHandler) - Method in class org.apache.camel.processor.resequencer.Timeout
Sets a timeout handler for receiving timeout notifications.
setTimePeriodMillis(long) - Method in class org.apache.camel.processor.Throttler
Sets the time period during which the maximum number of requests apply
setTimeUnit(TimeUnit) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
setToEndpoint(Exchange, Processor) - Static method in class org.apache.camel.processor.MulticastProcessor
 
setToken(String) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
setTotalProcessingTime(Long) - Method in class org.apache.camel.support.dump.CamelContextStatDump
 
setTotalProcessingTime(Long) - Method in class org.apache.camel.support.dump.ProcessorStatDump
 
setTotalProcessingTime(Long) - Method in class org.apache.camel.support.dump.RouteStatDump
 
setTotalProcessingTime(Long) - Method in class org.apache.camel.support.dump.StepStatDump
 
setTraceBeforeAndAfterRoute(boolean) - Method in class org.apache.camel.impl.engine.DefaultTracer
 
setTraceFilter(String) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setTracePattern(String) - Method in class org.apache.camel.impl.engine.DefaultTracer
 
setTracePattern(String) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
setTracer(Tracer) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setTracing(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setTracing(Boolean) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setTracingPattern(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setTracingPattern(String) - Method in class org.apache.camel.impl.engine.DefaultRouteContext
 
setType(String) - Method in class org.apache.camel.support.dump.MessageDump.Body
 
setType(String) - Method in class org.apache.camel.support.dump.MessageDump.Header
 
setTypeConverter(TypeConverter) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setTypeConverterExists(TypeConverterExists) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
setTypeConverterExistsLoggingLevel(LoggingLevel) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
setTypeConverterRegistry(TypeConverterRegistry) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setTypeConverterStatisticsEnabled(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setUnitOfWorkFactory(UnitOfWorkFactory) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setupManagement(Map<String, Object>) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setupManagement(CamelContext, ManagementStrategy, LifecycleStrategy) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategyFactory
 
setupRoutes(boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setUseBreadcrumb(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setUseCollisionAvoidance(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Enables/disables collision avoidance which adds some randomization to the backoff timings to reduce contention probability
setUseDataType(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setUseExponentialBackOff(boolean) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Enables/disables exponential backoff using the RedeliveryPolicy.getBackOffMultiplier() to increase the time between retries
setUseMDCLogging(Boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setUuidGenerator(UuidGenerator) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
setValue(String) - Method in class org.apache.camel.support.dump.MessageDump.Body
 
setValue(String) - Method in class org.apache.camel.support.dump.MessageDump.Header
 
setXml(boolean) - Method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
SharedCamelInternalProcessor - Class in org.apache.camel.processor
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 ...
SharedCamelInternalProcessor(CamelInternalProcessorAdvice...) - Constructor for class org.apache.camel.processor.SharedCamelInternalProcessor
 
ShareUnitOfWorkAggregationStrategy - Class in org.apache.camel.processor.aggregate
An AggregationStrategy which are used when the option shareUnitOfWork is enabled on EIPs such as multicast, splitter or recipientList.
ShareUnitOfWorkAggregationStrategy(AggregationStrategy) - Constructor for class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
shouldFailOver(Exchange) - Method in class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer
Should the given failed Exchange failover?
shouldHandleException(Exchange) - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
Strategy whether the exchange has an exception that we should try to handle.
shouldRedeliver(Exchange, int, Predicate) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Returns true if the policy decides that the message exchange should be redelivered.
shouldRetry(int) - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
shouldSpoolCache(long) - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
shouldStartRoutes() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
Should we start newly added routes?
shouldTrace(NamedNode) - Method in class org.apache.camel.impl.engine.DefaultTracer
 
shouldTrace(NamedNode, Exchange) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
Whether or not to trace the given processor definition.
shouldTracePattern(NamedNode) - Method in class org.apache.camel.impl.engine.DefaultTracer
 
shutdown() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
shutdown(ExecutorService) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
shutdown() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
shutdown(CamelContext, List<RouteStartupOrder>) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
shutdown(CamelContext, List<RouteStartupOrder>, long, TimeUnit) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
shutdown(CamelContext, RouteStartupOrder, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
shutdownForced(CamelContext, List<RouteStartupOrder>) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
shutdownGraceful(ExecutorService) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
shutdownGraceful(ExecutorService, long) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
shutdownNow(ExecutorService) - Method in class org.apache.camel.impl.engine.BaseExecutorServiceManager
 
shutdownNow(List<Consumer>) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
Shutdown all the consumers immediately.
shutdownNow(Consumer) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
Shutdown the consumer immediately.
shutdownRouteService(BaseRouteService) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
shutdownRoutesNow(List<RouteStartupOrder>) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
Shutdown all the consumers immediately.
Simple - Annotation Type in org.apache.camel.language.simple
Used to inject a simple expression into a field, property, method or parameter when using Bean Integration.
simple(String) - Static method in class org.apache.camel.language.simple.SimpleLanguage
Creates a new Expression.
simple(String, Class<?>) - Static method in class org.apache.camel.language.simple.SimpleLanguage
Creates a new Expression (or Predicate if the resultType is a Boolean, or boolean type).
SimpleExpressionBuilder - Class in org.apache.camel.language.simple
Expression builder used by the simple language.
SimpleExpressionBuilder.KeyedOgnlExpressionAdapter - Class in org.apache.camel.language.simple
Expression adapter for OGNL expression from Message Header or Exchange property
SimpleExpressionBuilder.KeyedOgnlExpressionAdapter.KeyedEntityRetrievalStrategy - Interface in org.apache.camel.language.simple
Strategy to retrieve the value based on the key
SimpleExpressionParser - Class in org.apache.camel.language.simple
A parser to parse simple language as a Camel Expression
SimpleExpressionParser(String, boolean, Map<String, Expression>) - Constructor for class org.apache.camel.language.simple.SimpleExpressionParser
 
SimpleFunctionEnd - Class in org.apache.camel.language.simple.ast
Ends a function
SimpleFunctionEnd(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.SimpleFunctionEnd
 
SimpleFunctionExpression - Class in org.apache.camel.language.simple.ast
Represents one of built-in functions of the simple language
SimpleFunctionExpression(SimpleToken, Map<String, Expression>) - Constructor for class org.apache.camel.language.simple.ast.SimpleFunctionExpression
 
SimpleFunctionStart - Class in org.apache.camel.language.simple.ast
Starts a function
SimpleFunctionStart(SimpleToken, Map<String, Expression>) - Constructor for class org.apache.camel.language.simple.ast.SimpleFunctionStart
 
SimpleIllegalSyntaxException - Exception in org.apache.camel.language.simple.types
Syntax error in the simple language expression.
SimpleIllegalSyntaxException(String, int, String) - Constructor for exception org.apache.camel.language.simple.types.SimpleIllegalSyntaxException
 
SimpleIllegalSyntaxException(String, int, String, Throwable) - Constructor for exception org.apache.camel.language.simple.types.SimpleIllegalSyntaxException
 
SimpleLanguage - Class in org.apache.camel.language.simple
A simple language which maps simple property style notations to access headers and bodies.
SimpleLanguage() - Constructor for class org.apache.camel.language.simple.SimpleLanguage
Default constructor.
SimpleNode - Interface in org.apache.camel.language.simple.ast
Represents a node in the Simple AST
SimpleParserException - Exception in org.apache.camel.language.simple.types
Holds information about error parsing the simple expression at a given location in the input.
SimpleParserException(String, int) - Constructor for exception org.apache.camel.language.simple.types.SimpleParserException
 
SimplePredicateParser - Class in org.apache.camel.language.simple
A parser to parse simple language as a Camel Predicate
SimplePredicateParser(String, boolean, Map<String, Expression>) - Constructor for class org.apache.camel.language.simple.SimplePredicateParser
 
SimpleToken - Class in org.apache.camel.language.simple.types
Holder for a token, with associated type and position in the input.
SimpleToken(SimpleTokenType, int) - Constructor for class org.apache.camel.language.simple.types.SimpleToken
 
SimpleToken(SimpleTokenType, int, int) - Constructor for class org.apache.camel.language.simple.types.SimpleToken
 
SimpleTokenizer - Class in org.apache.camel.language.simple
Tokenizer to create SimpleToken from the input.
SimpleTokenType - Class in org.apache.camel.language.simple.types
The different token types used by the simple parser.
SimpleTokenType(TokenType, String) - Constructor for class org.apache.camel.language.simple.types.SimpleTokenType
 
singleQuotedLiteralText() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
singleQuotedLiteralWithFunctionsText() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
SingleQuoteEnd - Class in org.apache.camel.language.simple.ast
Ends a block enclosed by single quotes
SingleQuoteEnd(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.SingleQuoteEnd
 
SingleQuoteStart - Class in org.apache.camel.language.simple.ast
Starts a block enclosed by single quotes
SingleQuoteStart(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.SingleQuoteStart
 
size() - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
size() - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
size() - Method in class org.apache.camel.impl.engine.DefaultAsyncProcessorAwaitManager
 
size() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
Returns the current size of the cache
size() - Method in class org.apache.camel.impl.engine.DefaultEndpointUtilizationStatistics
 
size() - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
size(String) - Method in class org.apache.camel.impl.engine.DefaultInflightRepository
 
size() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
size() - Method in class org.apache.camel.impl.engine.DefaultRuntimeEndpointRegistry
 
size() - Method in class org.apache.camel.impl.engine.ServicePool
Returns the current size of the pool
size() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Returns the number of elements currently maintained by this resequencer.
skipExpression(String, int) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns an iterator to skip (iterate) the given expression
skipIteratorExpression(Expression, int) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
 
sleep() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
Method for sleeping during redelivery attempts.
sleep(long, int) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Calculates the new redelivery delay based on the last one and then sleeps for the necessary amount of time.
sleep(long) - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Sleeps for the given delay
SortProcessor<T> - Class in org.apache.camel.processor
A processor that sorts the expression using a comparator
SortProcessor(Expression, Comparator<? super T>) - Constructor for class org.apache.camel.processor.SortProcessor
 
Splitter - Class in org.apache.camel.processor
Implements a dynamic Splitter pattern where an expression is evaluated to iterate through each of the parts of a message and then each part is then send to some endpoint.
Splitter(CamelContext, Expression, Processor, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean) - Constructor for class org.apache.camel.processor.Splitter
 
Splitter(CamelContext, Expression, Processor, AggregationStrategy, boolean, ExecutorService, boolean, boolean, boolean, long, Processor, boolean, boolean, boolean) - Constructor for class org.apache.camel.processor.Splitter
 
SQLConverter - Class in org.apache.camel.converter
SQL Date and time related converters.
SQLConverterLoader - Class in org.apache.camel.converter
Source code generated by org.apache.camel:apt
SQLConverterLoader() - Constructor for class org.apache.camel.converter.SQLConverterLoader
 
start() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
start() - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
start() - Method in class org.apache.camel.impl.engine.DefaultClaimCheckRepository
 
start() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
start() - Method in class org.apache.camel.impl.engine.DefaultRoute
Do not invoke this method directly, use RouteController.startRoute(String) to start a route.
start() - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
start() - Method in class org.apache.camel.impl.engine.InterceptSendToEndpointProcessor
 
start() - Method in class org.apache.camel.impl.engine.LimitedPollingConsumerPollStrategy
 
start() - Method in class org.apache.camel.language.simple.SimpleLanguage
 
start() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
 
start() - Method in class org.apache.camel.runtimecatalog.impl.DefaultRuntimeCamelCatalog
 
startAllRoutes() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
startAllRoutes() - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
startChildService(Route, List<Service>) - Method in class org.apache.camel.impl.engine.BaseRouteService
 
startRoute(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
startRoute(String) - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
startRoute(String) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
startRouteDefinitions() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
startRouteService(BaseRouteService, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
Starts the given route service
startService(Service, CamelContext, Object, String) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
Stats the given service
startSingleStepExchange(String, Breakpoint) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
State(Exchange, AsyncCallback, AsyncProcessor[]) - Constructor for class org.apache.camel.processor.loadbalancer.FailOverLoadBalancer.State
 
State(Exchange, AsyncCallback, AsyncProcessor[]) - Constructor for class org.apache.camel.processor.loadbalancer.TopicLoadBalancer.State
 
staticMap - Variable in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
StaticMethodFallbackTypeConverter - Class in org.apache.camel.impl.converter
A TypeConverter implementation which invokes a static method as a fallback type converter from a type to another type
StaticMethodFallbackTypeConverter(Method, TypeConverterRegistry, boolean) - Constructor for class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
 
StaticMethodTypeConverter - Class in org.apache.camel.impl.converter
A TypeConverter implementation which invokes a static method to convert from a type to another type
StaticMethodTypeConverter(Method, boolean) - Constructor for class org.apache.camel.impl.converter.StaticMethodTypeConverter
 
staticSize() - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
statistics - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
step() - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
step - Variable in class org.apache.camel.processor.saga.SagaProcessor
 
step(CamelSagaStep) - Method in class org.apache.camel.processor.saga.SagaProcessorBuilder
 
stepBreakpoint(String) - Method in class org.apache.camel.processor.interceptor.BacklogDebugger
 
StepCompletedEvent - Class in org.apache.camel.impl.event
Event after a step has been completed successfully.
StepCompletedEvent(Exchange, String) - Constructor for class org.apache.camel.impl.event.StepCompletedEvent
 
StepFailedEvent - Class in org.apache.camel.impl.event
Event after a step has failed.
StepFailedEvent(Exchange, String) - Constructor for class org.apache.camel.impl.event.StepFailedEvent
 
StepProcessor - Class in org.apache.camel.processor
 
StepProcessor(CamelContext, Collection<Processor>, String) - Constructor for class org.apache.camel.processor.StepProcessor
 
StepStartedEvent - Class in org.apache.camel.impl.event
Event after a step has been created.
StepStartedEvent(Exchange, String) - Constructor for class org.apache.camel.impl.event.StepStartedEvent
 
StepStatDump - Class in org.apache.camel.support.dump
A model of a step stat dump from ManagedRouteMBean.dumpStepStatsAsXml(boolean).
StepStatDump() - Constructor for class org.apache.camel.support.dump.StepStatDump
 
StickyLoadBalancer - Class in org.apache.camel.processor.loadbalancer
Implements a sticky load balancer using an Expression to calculate a correlation key to perform the sticky load balancing; rather like jsessionid in the web or JMSXGroupID in JMS.
StickyLoadBalancer(Expression) - Constructor for class org.apache.camel.processor.loadbalancer.StickyLoadBalancer
 
stop() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
stop() - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
stop() - Method in class org.apache.camel.impl.engine.DefaultClaimCheckRepository
 
stop() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
stop() - Method in class org.apache.camel.impl.engine.DefaultRoute
Do not invoke this method directly, use RouteController.stopRoute(String) to stop a route.
stop() - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
stop() - Method in class org.apache.camel.impl.engine.InterceptSendToEndpointProcessor
 
stop() - Method in class org.apache.camel.impl.engine.LimitedPollingConsumerPollStrategy
 
stop() - Method in class org.apache.camel.impl.engine.MDCUnitOfWork
 
stop() - Method in class org.apache.camel.language.simple.SimpleLanguage
 
stop() - Method in class org.apache.camel.processor.resequencer.ResequencerEngine
Stops this resequencer (i.e.
stop() - Method in class org.apache.camel.runtimecatalog.impl.DefaultRuntimeCamelCatalog
 
stopChildService(Route, Set<Service>, boolean) - Method in class org.apache.camel.impl.engine.BaseRouteService
 
StopProcessor - Class in org.apache.camel.processor
Stops continue processing the route and marks it as complete.
StopProcessor() - Constructor for class org.apache.camel.processor.StopProcessor
 
stopRoute(String, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
stopRoute(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
stopRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
stopRoute(String) - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
stopRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
stopRoute(String, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
stopRoute(String) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
stopRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
stopRoute(String, long, TimeUnit, boolean) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
stopRouteService(BaseRouteService, boolean) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
stopRouteService(BaseRouteService) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
stopSingleStepExchange(String) - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
stream() - Method in class org.apache.camel.impl.health.DefaultHealthCheckRegistry
 
stream() - Method in class org.apache.camel.impl.health.RegistryRepository
 
stream() - Method in class org.apache.camel.impl.health.RoutesHealthCheckRepository
 
StreamCachingAdvice(StreamCachingStrategy) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.StreamCachingAdvice
 
StreamResequencer - Class in org.apache.camel.processor
A resequencer that re-orders a (continuous) stream of Exchanges.
StreamResequencer(CamelContext, Processor, SequenceElementComparator<Exchange>, Expression) - Constructor for class org.apache.camel.processor.StreamResequencer
Creates a new StreamResequencer instance.
StringAggregationStrategy - Class in org.apache.camel.processor.aggregate
Aggregate result of pick expression into a single combined Exchange holding all the aggregated bodies in a String as the message body.
StringAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.StringAggregationStrategy
 
stripPrefix(String, String) - Static method in class org.apache.camel.runtimecatalog.impl.URISupport
Strips the prefix from the value.
stripQuery(String) - Static method in class org.apache.camel.runtimecatalog.impl.URISupport
Strips the query parameters from the uri
subscribeMethod(Method, Object, String, String, String, String) - Method in class org.apache.camel.impl.engine.CamelPostProcessorHelper
 
SubscribeMethodProcessor - Class in org.apache.camel.impl.engine
A Processor which is used for POJO @Consume where you can have multiple @Consume on the same endpoint/consumer and via predicate's can filter and call different methods.
SubscribeMethodProcessor(Endpoint) - Constructor for class org.apache.camel.impl.engine.SubscribeMethodProcessor
 
successor(Exchange, Exchange) - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
successor(E) - Method in class org.apache.camel.processor.resequencer.Sequence
Returns the immediate successor of the given element in this sequence or null if no successor exists.
successor(E, E) - Method in interface org.apache.camel.processor.resequencer.SequenceElementComparator
Returns true if o1 is an immediate successor of o2.
suggestEndpointOptions(Set<String>, String) - Method in interface org.apache.camel.runtimecatalog.impl.SuggestionStrategy
Provides a list of valid option names for a did you mean function.
SuggestionStrategy - Interface in org.apache.camel.runtimecatalog.impl
Strategy to provide suggestions for unknown endpoint options
SUPERVISED - Static variable in class org.apache.camel.impl.engine.SupervisingRouteController.FilterResult
 
supervised() - Method in class org.apache.camel.impl.engine.SupervisingRouteController.FilterResult
 
SupervisingRouteController - Class in org.apache.camel.impl.engine
A simple implementation of the RouteController that delays the startup of the routes after the camel context startup and retries to start failing routes.
SupervisingRouteController() - Constructor for class org.apache.camel.impl.engine.SupervisingRouteController
 
SupervisingRouteController.Filter - Interface in org.apache.camel.impl.engine
 
SupervisingRouteController.FilterResult - Class in org.apache.camel.impl.engine
 
SupervisingRouteControllerFilters - Class in org.apache.camel.impl.engine
 
SupervisingRouteControllerFilters.BlackList - Class in org.apache.camel.impl.engine
 
supportedParameterTypes(BinaryOperatorType) - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType
Returns the types of right hand side parameters this operator supports.
supportsAutoWiring() - Method in class org.apache.camel.impl.engine.DefaultInjector
 
SupportsSagaProcessor - Class in org.apache.camel.processor.saga
Saga processor implementing the SUPPORTS propagation mode.
SupportsSagaProcessor(CamelContext, Processor, CamelSagaService, SagaCompletionMode, CamelSagaStep) - Constructor for class org.apache.camel.processor.saga.SupportsSagaProcessor
 
supportsSuspension() - Method in class org.apache.camel.impl.engine.EventDrivenConsumerRoute
 
supportTransacted() - Method in class org.apache.camel.processor.errorhandler.ErrorHandlerSupport
Whether this error handler supports transacted exchanges or not.
supportTransacted() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
suspend() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
suspend(CamelContext, List<RouteStartupOrder>) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
suspend(CamelContext, List<RouteStartupOrder>, long, TimeUnit) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
 
suspend() - Method in class org.apache.camel.processor.interceptor.BreakpointSupport
 
suspendAllBreakpoints() - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
suspendNow(Consumer) - Method in class org.apache.camel.impl.engine.DefaultShutdownStrategy
Suspends/stops the consumer immediately.
suspendRoute(String) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
suspendRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
suspendRoute(String) - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
suspendRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.engine.DefaultRouteController
 
suspendRoute(String) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
suspendRoute(String, long, TimeUnit) - Method in class org.apache.camel.impl.engine.SupervisingRouteController
 
suspendRouteService(BaseRouteService) - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
SysPropertiesFunction - Class in org.apache.camel.component.properties
A PropertiesFunction that lookup the property value from JVM system property.
SysPropertiesFunction() - Constructor for class org.apache.camel.component.properties.SysPropertiesFunction
 
SYSTEM_PROPERTIES_MODE_FALLBACK - Static variable in class org.apache.camel.component.properties.PropertiesComponent
Check system properties if not resolvable in the specified properties.
SYSTEM_PROPERTIES_MODE_NEVER - Static variable in class org.apache.camel.component.properties.PropertiesComponent
Never check system properties.
SYSTEM_PROPERTIES_MODE_OVERRIDE - Static variable in class org.apache.camel.component.properties.PropertiesComponent
Check system properties variables) first, before trying the specified properties.

T

templateText() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
 
test(T, HealthCheckResultBuilder, Map<String, Object>) - Method in interface org.apache.camel.impl.health.PerformanceCounterEvaluator
Check the given performance counter.
test(ManagedRouteMBean, HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.ExchangesFailed
 
test(ManagedRouteMBean, HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.ExchangesInflight
 
test(ManagedRouteMBean, HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.ExternalRedeliveries
 
test(ManagedRouteMBean, HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.LastProcessingTime
 
test(ManagedRouteMBean, HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.MaxProcessingTime
 
test(ManagedRouteMBean, HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.MeanProcessingTime
 
test(ManagedRouteMBean, HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.MinProcessingTime
 
test(ManagedRouteMBean, HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.impl.health.RoutePerformanceCounterEvaluators.Redeliveries
 
text - Variable in class org.apache.camel.language.simple.ast.LiteralExpression
 
ThreadsProcessor - Class in org.apache.camel.processor
Threads processor that leverage a thread pool for continue processing the Exchanges using the asynchronous routing engine.
ThreadsProcessor(CamelContext, ExecutorService, boolean, ThreadPoolRejectedPolicy) - Constructor for class org.apache.camel.processor.ThreadsProcessor
 
throttle(Route, Exchange) - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
Throttles the route when Exchanges is done.
Throttler - Class in org.apache.camel.processor
A Throttler will set a limit on the maximum number of message exchanges which can be sent to a processor within a specific time period.
Throttler(CamelContext, Expression, long, ScheduledExecutorService, boolean, boolean, Expression) - Constructor for class org.apache.camel.processor.Throttler
 
ThrottlerRejectedExecutionException - Exception in org.apache.camel.processor
 
ThrottlerRejectedExecutionException(String) - Constructor for exception org.apache.camel.processor.ThrottlerRejectedExecutionException
 
ThrottlingExceptionHalfOpenHandler - Interface in org.apache.camel.throttling
Used by the ThrottlingExceptionRoutePolicy to allow custom code to handle the half open circuit state and how to determine if a route should be closed
ThrottlingExceptionRoutePolicy - Class in org.apache.camel.throttling
Modeled after the circuit breaker ThrottlingInflightRoutePolicy this RoutePolicy will stop consuming from an endpoint based on the type of exceptions that are thrown and the threshold setting.
ThrottlingExceptionRoutePolicy(int, long, long, List<Class<?>>) - Constructor for class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
ThrottlingExceptionRoutePolicy(int, long, long, List<Class<?>>, boolean) - Constructor for class org.apache.camel.throttling.ThrottlingExceptionRoutePolicy
 
ThrottlingInflightRoutePolicy - Class in org.apache.camel.throttling
A throttle based RoutePolicy which is capable of dynamic throttling a route based on number of current inflight exchanges.
ThrottlingInflightRoutePolicy() - Constructor for class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
ThrottlingInflightRoutePolicy.ThrottlingScope - Enum in org.apache.camel.throttling
 
ThrowExceptionProcessor - Class in org.apache.camel.processor
The processor which sets an Exception on the Exchange
ThrowExceptionProcessor(Exception) - Constructor for class org.apache.camel.processor.ThrowExceptionProcessor
 
ThrowExceptionProcessor(Exception, Class<? extends Exception>, String) - Constructor for class org.apache.camel.processor.ThrowExceptionProcessor
 
timeout(Exchange, int, int, long) - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
timeout() - Method in class org.apache.camel.processor.MulticastProcessor.MulticastState
 
Timeout - Class in org.apache.camel.processor.resequencer
A timer task that notifies handlers about scheduled timeouts.
Timeout(Timer, long) - Constructor for class org.apache.camel.processor.resequencer.Timeout
Creates a new timeout task using the given Timer instance and timeout value.
timeout(Timeout) - Method in interface org.apache.camel.processor.resequencer.TimeoutHandler
Handles a timeout notification.
TimeoutHandler - Interface in org.apache.camel.processor.resequencer
Implemented by classes that handle timeout notifications.
TimePatternConverter - Class in org.apache.camel.converter
Converter from String syntax to milli seconds.
TimePatternConverter - Class in org.apache.camel.runtimecatalog.impl
This class is a copy from camel-core so we can use it independent to validate uris with time patterns
TimePatternConverterLoader - Class in org.apache.camel.converter
Source code generated by org.apache.camel:apt
TimePatternConverterLoader() - Constructor for class org.apache.camel.converter.TimePatternConverterLoader
 
to(String) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
to(Endpoint) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
toArray(Collection<?>) - Static method in class org.apache.camel.converter.CollectionConverter
Converts a collection to an array
toArrayList(Iterator<T>) - Static method in class org.apache.camel.converter.CollectionConverter
Converts an Iterator to a ArrayList
toBigInteger(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toBool(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Converts the given value to a boolean, handling strings or Boolean objects; otherwise returning false if the value could not be converted to a boolean
toBoolean(Object) - Static method in class org.apache.camel.converter.ObjectConverter
Converts the given value to a Boolean, handling strings or Boolean objects; otherwise returning null if the value cannot be converted to a boolean
toBoolean(String) - Static method in class org.apache.camel.converter.ObjectConverter
 
toByte(Number) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toByte(String) - Static method in class org.apache.camel.converter.ObjectConverter
 
toByteArray(File) - Static method in class org.apache.camel.converter.IOConverter
 
toByteArray(Reader, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toByteArray(BufferedReader, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toByteArray(String, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toByteArray(ByteArrayOutputStream) - Static method in class org.apache.camel.converter.IOConverter
 
toByteArray(ByteBuffer) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(byte[]) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(File) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(String, Exchange) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(Short) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(Integer) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(Long) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(Float) - Static method in class org.apache.camel.converter.NIOConverter
 
toByteBuffer(Double) - Static method in class org.apache.camel.converter.NIOConverter
 
toBytes(InputStream) - Static method in class org.apache.camel.converter.IOConverter
 
toChar(String) - Static method in class org.apache.camel.converter.ObjectConverter
 
toCharacter(String) - Static method in class org.apache.camel.converter.ObjectConverter
 
toCharArray(String) - Static method in class org.apache.camel.converter.ObjectConverter
 
toCharSequence(URI) - Static method in class org.apache.camel.impl.converter.UriTypeConverter
 
toClass(String, Exchange) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toDate(Long) - Static method in class org.apache.camel.converter.DateTimeConverter
 
toDouble(Number) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toDouble(String) - Static method in class org.apache.camel.converter.ObjectConverter
 
toDuration(String) - Static method in class org.apache.camel.converter.DurationConverter
 
toFile(String) - Static method in class org.apache.camel.converter.IOConverter
 
toFloat(Number) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toFloat(String) - Static method in class org.apache.camel.converter.ObjectConverter
 
toHashMap(Map<? extends K, ? extends V>) - Static method in class org.apache.camel.converter.CollectionConverter
 
toHashtable(Map<? extends K, ? extends V>) - Static method in class org.apache.camel.converter.CollectionConverter
 
toInputStream(Stream, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(URL) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(File) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(String, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(StringBuffer, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(StringBuilder, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(BufferedReader, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(byte[]) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(ByteArrayOutputStream) - Static method in class org.apache.camel.converter.IOConverter
 
toInputStream(ByteBuffer) - Static method in class org.apache.camel.converter.NIOConverter
 
toInteger(Number) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toInteger(String) - Static method in class org.apache.camel.converter.ObjectConverter
 
token - Variable in class org.apache.camel.language.simple.ast.BaseSimpleNode
 
token - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
tokenize(String) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenize(String, boolean) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenize(String, String) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenize(String, String, boolean) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
TokenizeLanguage - Class in org.apache.camel.language.tokenizer
A language for tokenizer expressions.
TokenizeLanguage() - Constructor for class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenizePair(String, String, boolean) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokenizeXML(String, String) - Static method in class org.apache.camel.language.tokenizer.TokenizeLanguage
 
tokens - Variable in class org.apache.camel.language.simple.BaseSimpleParser
 
TokenType - Enum in org.apache.camel.language.simple.types
Classifications of known token types.
toList(Object[]) - Static method in class org.apache.camel.converter.CollectionConverter
Converts an array to a collection
toList(Collection<T>) - Static method in class org.apache.camel.converter.CollectionConverter
Converts a collection to a List if it is not already
toList(Iterable<T>) - Static method in class org.apache.camel.converter.CollectionConverter
Converts an Iterable into a List
toLong(Date) - Static method in class org.apache.camel.converter.DateTimeConverter
 
toLong(Number) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toLong(String) - Static method in class org.apache.camel.converter.ObjectConverter
 
toLong(Timestamp) - Static method in class org.apache.camel.converter.SQLConverter
 
toMilliSeconds(Duration) - Static method in class org.apache.camel.converter.DurationConverter
 
toMilliSeconds(String) - Static method in class org.apache.camel.converter.TimePatternConverter
 
toMilliSeconds(String) - Static method in class org.apache.camel.runtimecatalog.impl.TimePatternConverter
 
toObjectInput(InputStream, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toObjectOutput(OutputStream) - Static method in class org.apache.camel.converter.IOConverter
 
toOutputStream(File) - Static method in class org.apache.camel.converter.IOConverter
 
TopicLoadBalancer - Class in org.apache.camel.processor.loadbalancer
A LoadBalancer implementations which sends to all destinations (rather like JMS Topics).
TopicLoadBalancer() - Constructor for class org.apache.camel.processor.loadbalancer.TopicLoadBalancer
 
TopicLoadBalancer.State - Class in org.apache.camel.processor.loadbalancer
 
toProcessor(Predicate) - Static method in class org.apache.camel.converter.CamelConverter
 
toProcessor(Expression) - Static method in class org.apache.camel.converter.CamelConverter
 
toProperties(Map<Object, Object>) - Static method in class org.apache.camel.converter.CollectionConverter
 
toProperties(File) - Static method in class org.apache.camel.converter.IOConverter
 
toProperties(InputStream) - Static method in class org.apache.camel.converter.IOConverter
 
toProperties(Reader) - Static method in class org.apache.camel.converter.IOConverter
 
toReader(File, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toReader(InputStream, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toReader(byte[], Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toReader(String) - Static method in class org.apache.camel.converter.IOConverter
 
toSet(Object[]) - Static method in class org.apache.camel.converter.CollectionConverter
 
toSet(Collection<T>) - Static method in class org.apache.camel.converter.CollectionConverter
 
toSet(Map<K, V>) - Static method in class org.apache.camel.converter.CollectionConverter
 
toShort(Number) - Static method in class org.apache.camel.converter.ObjectConverter
Returns the converted value, or null if the value is null
toShort(String) - Static method in class org.apache.camel.converter.ObjectConverter
 
toString() - Method in class org.apache.camel.component.properties.PropertiesLocation
 
toString(Duration) - Static method in class org.apache.camel.converter.DurationConverter
 
toString(byte[], Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toString(File, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toString(URL, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toString(Reader) - Static method in class org.apache.camel.converter.IOConverter
 
toString(BufferedReader) - Static method in class org.apache.camel.converter.IOConverter
 
toString(InputStream, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toString(ByteArrayOutputStream, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toString(ByteBuffer, Exchange) - Static method in class org.apache.camel.converter.NIOConverter
 
toString(Integer) - Static method in class org.apache.camel.converter.ObjectConverter
 
toString(Long) - Static method in class org.apache.camel.converter.ObjectConverter
 
toString(Boolean) - Static method in class org.apache.camel.converter.ObjectConverter
 
toString(StringBuffer) - Static method in class org.apache.camel.converter.ObjectConverter
 
toString(StringBuilder) - Static method in class org.apache.camel.converter.ObjectConverter
 
toString() - Method in class org.apache.camel.impl.converter.InstanceMethodFallbackTypeConverter
 
toString() - Method in class org.apache.camel.impl.converter.InstanceMethodTypeConverter
 
toString() - Method in class org.apache.camel.impl.converter.StaticMethodFallbackTypeConverter
 
toString() - Method in class org.apache.camel.impl.converter.StaticMethodTypeConverter
 
toString() - Method in class org.apache.camel.impl.engine.AbstractCamelContext
 
toString() - Method in class org.apache.camel.impl.engine.AbstractDynamicRegistry
 
toString() - Method in class org.apache.camel.impl.engine.DefaultConsumerCache
 
toString() - Method in class org.apache.camel.impl.engine.DefaultEndpointRegistry
 
toString() - Method in class org.apache.camel.impl.engine.DefaultInterceptSendToEndpoint
 
toString() - Method in class org.apache.camel.impl.engine.DefaultProducerCache
 
toString() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
toString() - Method in class org.apache.camel.impl.engine.DefaultRouteError
 
toString() - Method in class org.apache.camel.impl.engine.DefaultRouteStartupOrder
 
toString() - Method in class org.apache.camel.impl.engine.DefaultStreamCachingStrategy
 
toString() - Method in class org.apache.camel.impl.engine.DefaultTransformerRegistry
 
toString() - Method in class org.apache.camel.impl.engine.DefaultUnitOfWork
 
toString() - Method in class org.apache.camel.impl.engine.DefaultValidatorRegistry
 
toString() - Method in class org.apache.camel.impl.engine.DeferProducer
 
toString() - Method in class org.apache.camel.impl.engine.EndpointKey
 
toString() - Method in class org.apache.camel.impl.engine.EventDrivenConsumerRoute
 
toString() - Method in class org.apache.camel.impl.engine.InterceptSendToMockEndpointStrategy
 
toString() - Method in class org.apache.camel.impl.engine.MDCUnitOfWork
 
toString() - Method in class org.apache.camel.impl.engine.SubscribeMethodProcessor
 
toString() - Method in class org.apache.camel.impl.event.CamelContextResumedEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextResumeFailureEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextResumingEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextRoutesStartedEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextRoutesStartingEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextRoutesStoppedEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextRoutesStoppingEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextStartedEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextStartingEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextStartupFailureEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextStopFailureEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextStoppedEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextStoppingEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextSuspendedEvent
 
toString() - Method in class org.apache.camel.impl.event.CamelContextSuspendingEvent
 
toString() - Method in class org.apache.camel.impl.event.ExchangeCompletedEvent
 
toString() - Method in class org.apache.camel.impl.event.ExchangeCreatedEvent
 
toString() - Method in class org.apache.camel.impl.event.ExchangeFailedEvent
 
toString() - Method in class org.apache.camel.impl.event.ExchangeFailureHandledEvent
 
toString() - Method in class org.apache.camel.impl.event.ExchangeFailureHandlingEvent
 
toString() - Method in class org.apache.camel.impl.event.ExchangeRedeliveryEvent
 
toString() - Method in class org.apache.camel.impl.event.ExchangeSendingEvent
 
toString() - Method in class org.apache.camel.impl.event.ExchangeSentEvent
 
toString() - Method in class org.apache.camel.impl.event.RouteAddedEvent
 
toString() - Method in class org.apache.camel.impl.event.RouteRemovedEvent
 
toString() - Method in class org.apache.camel.impl.event.RouteStartedEvent
 
toString() - Method in class org.apache.camel.impl.event.RouteStoppedEvent
 
toString() - Method in class org.apache.camel.impl.event.ServiceStartupFailureEvent
 
toString() - Method in class org.apache.camel.impl.event.ServiceStopFailureEvent
 
toString() - Method in class org.apache.camel.impl.event.StepCompletedEvent
 
toString() - Method in class org.apache.camel.impl.event.StepFailedEvent
 
toString() - Method in class org.apache.camel.impl.event.StepStartedEvent
 
toString() - Method in class org.apache.camel.impl.scan.AnnotatedWithAnyPackageScanFilter
 
toString() - Method in class org.apache.camel.impl.scan.AnnotatedWithPackageScanFilter
 
toString() - Method in class org.apache.camel.impl.scan.AssignableToPackageScanFilter
 
toString() - Method in class org.apache.camel.impl.scan.InvertingPackageScanFilter
 
toString() - Method in class org.apache.camel.impl.transformer.DataFormatTransformer
 
toString() - Method in class org.apache.camel.impl.transformer.ProcessorTransformer
 
toString() - Method in class org.apache.camel.impl.transformer.TransformerKey
 
toString() - Method in class org.apache.camel.impl.validator.ProcessorValidator
 
toString() - Method in class org.apache.camel.impl.validator.ValidatorKey
 
toString() - Method in class org.apache.camel.language.simple.ast.BaseSimpleNode
 
toString() - Method in class org.apache.camel.language.simple.ast.BinaryExpression
 
toString() - Method in class org.apache.camel.language.simple.ast.CompositeNodes
 
toString() - Method in class org.apache.camel.language.simple.ast.DoubleQuoteStart
 
toString() - Method in class org.apache.camel.language.simple.ast.LiteralExpression
 
toString() - Method in class org.apache.camel.language.simple.ast.LogicalExpression
 
toString() - Method in class org.apache.camel.language.simple.ast.SimpleFunctionStart
 
toString() - Method in class org.apache.camel.language.simple.ast.SingleQuoteStart
 
toString() - Method in class org.apache.camel.language.simple.ast.UnaryExpression
 
toString() - Method in class org.apache.camel.language.simple.SimpleExpressionBuilder.KeyedOgnlExpressionAdapter
 
toString() - Method in enum org.apache.camel.language.simple.types.BinaryOperatorType
 
toString() - Method in enum org.apache.camel.language.simple.types.LogicalOperatorType
 
toString() - Method in class org.apache.camel.language.simple.types.SimpleToken
 
toString() - Method in class org.apache.camel.language.simple.types.SimpleTokenType
 
toString() - Method in enum org.apache.camel.language.simple.types.UnaryOperatorType
 
toString() - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
toString() - Method in class org.apache.camel.processor.aggregate.AggregationStrategyParameterInfo
 
toString() - Method in class org.apache.camel.processor.aggregate.OptimisticLockRetryPolicy
 
toString() - Method in class org.apache.camel.processor.aggregate.ShareUnitOfWorkAggregationStrategy
 
toString() - Method in class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
toString() - Method in class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
toString() - Method in class org.apache.camel.processor.CamelInternalProcessor
 
toString() - Method in class org.apache.camel.processor.CatchProcessor
 
toString() - Method in class org.apache.camel.processor.channel.DefaultChannel
 
toString() - Method in class org.apache.camel.processor.ChoiceProcessor
 
toString() - Method in class org.apache.camel.processor.ClaimCheckProcessor
 
toString() - Method in class org.apache.camel.processor.ConvertBodyProcessor
 
toString() - Method in class org.apache.camel.processor.Delayer
 
toString() - Method in class org.apache.camel.processor.Enricher
 
toString() - Method in class org.apache.camel.processor.errorhandler.DeadLetterChannel
 
toString() - Method in class org.apache.camel.processor.errorhandler.DefaultErrorHandler
 
toString() - Method in class org.apache.camel.processor.errorhandler.ExceptionPolicyKey
 
toString() - Method in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler.RedeliveryState
 
toString() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
toString() - Method in class org.apache.camel.processor.EvaluateExpressionProcessor
 
toString() - Method in class org.apache.camel.processor.ExchangePatternProcessor
 
toString() - Method in class org.apache.camel.processor.FatalFallbackErrorHandler
 
toString() - Method in class org.apache.camel.processor.FilterProcessor
 
toString() - Method in class org.apache.camel.processor.FinallyProcessor
 
toString() - Method in class org.apache.camel.processor.idempotent.IdempotentConsumer
 
toString() - Method in class org.apache.camel.processor.idempotent.IdempotentOnCompletion
 
toString() - Method in class org.apache.camel.processor.InterceptEndpointProcessor
 
toString() - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
 
toString() - Method in class org.apache.camel.processor.interceptor.DefaultDebugger
 
toString() - Method in class org.apache.camel.processor.InterceptorToAsyncProcessorBridge
 
toString() - Method in class org.apache.camel.processor.loadbalancer.LoadBalancerSupport
 
toString() - Method in class org.apache.camel.processor.LogProcessor
 
toString() - Method in class org.apache.camel.processor.LoopProcessor
 
toString() - Method in class org.apache.camel.processor.MethodCallProcessor
 
toString() - Method in class org.apache.camel.processor.MulticastProcessor.MulticastState
 
toString() - Method in class org.apache.camel.processor.MulticastProcessor
 
toString() - Method in class org.apache.camel.processor.OnCompletionProcessor
 
toString() - Method in class org.apache.camel.processor.Pipeline
 
toString() - Method in class org.apache.camel.processor.PollEnricher
 
toString() - Method in class org.apache.camel.processor.RecipientList
 
toString() - Method in class org.apache.camel.processor.RecipientListProcessor
 
toString() - Method in class org.apache.camel.processor.RemoveHeaderProcessor
 
toString() - Method in class org.apache.camel.processor.RemoveHeadersProcessor
 
toString() - Method in class org.apache.camel.processor.RemovePropertiesProcessor
 
toString() - Method in class org.apache.camel.processor.RemovePropertyProcessor
 
toString() - Method in class org.apache.camel.processor.resequencer.DefaultExchangeComparator
 
toString() - Method in class org.apache.camel.processor.Resequencer
 
toString() - Method in class org.apache.camel.processor.RollbackProcessor
 
toString() - Method in class org.apache.camel.processor.RoutingSlip
 
toString() - Method in class org.apache.camel.processor.saga.SagaProcessor
 
toString() - Method in class org.apache.camel.processor.SamplingThrottler
 
toString() - Method in class org.apache.camel.processor.ScriptProcessor
 
toString() - Method in class org.apache.camel.processor.SendDynamicProcessor
 
toString() - Method in class org.apache.camel.processor.SendProcessor
 
toString() - Method in class org.apache.camel.processor.SetBodyProcessor
 
toString() - Method in class org.apache.camel.processor.SetHeaderProcessor
 
toString() - Method in class org.apache.camel.processor.SetPropertyProcessor
 
toString() - Method in class org.apache.camel.processor.SortProcessor
 
toString() - Method in class org.apache.camel.processor.Splitter
 
toString() - Method in class org.apache.camel.processor.StepProcessor
 
toString() - Method in class org.apache.camel.processor.StopProcessor
 
toString() - Method in class org.apache.camel.processor.StreamResequencer
 
toString() - Method in class org.apache.camel.processor.ThreadsProcessor
 
toString() - Method in class org.apache.camel.processor.Throttler
 
toString() - Method in class org.apache.camel.processor.ThrowExceptionProcessor
 
toString() - Method in class org.apache.camel.processor.TransformProcessor
 
toString() - Method in class org.apache.camel.processor.TryProcessor
 
toString() - Method in class org.apache.camel.processor.UnitOfWorkProducer
 
toString() - Method in class org.apache.camel.processor.WireTapProcessor
 
toString() - Method in class org.apache.camel.processor.WrapProcessor
 
toString() - Method in class org.apache.camel.runtimecatalog.impl.Pair
 
toString() - Method in class org.apache.camel.throttling.ThrottlingInflightRoutePolicy
 
ToStringTypeConverter - Class in org.apache.camel.impl.converter
A simple converter that can convert any object to a String type by using the toString() method of the object.
ToStringTypeConverter() - Constructor for class org.apache.camel.impl.converter.ToStringTypeConverter
 
toTimestamp(Long) - Static method in class org.apache.camel.converter.SQLConverter
 
toTimeZone(String) - Static method in class org.apache.camel.converter.DateTimeConverter
 
toUri(CharSequence) - Static method in class org.apache.camel.impl.converter.UriTypeConverter
 
toWriter(File, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toWriter(OutputStream, Exchange) - Static method in class org.apache.camel.converter.IOConverter
 
toXml(int) - Method in class org.apache.camel.processor.interceptor.DefaultBacklogTracerEventMessage
Dumps the event message as XML using the BacklogTracerEventMessage.ROOT_TAG as root tag.
traceAfterNode(NamedNode, Exchange) - Method in class org.apache.camel.impl.engine.DefaultTracer
 
traceAfterRoute(Route, Exchange) - Method in class org.apache.camel.impl.engine.DefaultTracer
 
traceBeforeNode(NamedNode, Exchange) - Method in class org.apache.camel.impl.engine.DefaultTracer
 
traceBeforeRoute(NamedRoute, Exchange) - Method in class org.apache.camel.impl.engine.DefaultTracer
 
traceEvent(DefaultBacklogTracerEventMessage) - Method in class org.apache.camel.processor.interceptor.BacklogTracer
 
traceLabelToString - Variable in class org.apache.camel.processor.SendProcessor
 
TracingAdvice(Tracer, NamedNode, NamedRoute, boolean) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.TracingAdvice
 
trackTimeout(String, Exchange) - Method in class org.apache.camel.processor.aggregate.AggregateProcessor
 
transform(Message, DataType, DataType) - Method in class org.apache.camel.impl.transformer.DataFormatTransformer
Perform data transformation with specified from/to type using DataFormat.
transform(Message, DataType, DataType) - Method in class org.apache.camel.impl.transformer.ProcessorTransformer
Perform data transformation with specified from/to type using Processor.
TransformerKey - Class in org.apache.camel.impl.transformer
Key used in TransformerRegistry in AbstractCamelContext, to ensure a consistent lookup.
TransformerKey(String) - Constructor for class org.apache.camel.impl.transformer.TransformerKey
 
TransformerKey(DataType, DataType) - Constructor for class org.apache.camel.impl.transformer.TransformerKey
 
TransformProcessor - Class in org.apache.camel.processor
A processor which sets the body on the OUT message with an Expression.
TransformProcessor(Expression) - Constructor for class org.apache.camel.processor.TransformProcessor
 
trunkStore() - Method in class org.apache.camel.impl.engine.FileStateRepository
Trunks the file store when the max store size is hit by rewriting the 1st level cache to the file store.
tryConvertTo(Class<T>, Object) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
tryConvertTo(Class<T>, Exchange, Object) - Method in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
TryProcessor - Class in org.apache.camel.processor
Implements try/catch/finally type processing
TryProcessor(Processor, List<Processor>, Processor) - Constructor for class org.apache.camel.processor.TryProcessor
 
tryProcessor - Variable in class org.apache.camel.processor.TryProcessor
 
typeConverterExists - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
typeConverterExistsLoggingLevel - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
typeConverterLoaders - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 
TypeConvertersLoader - Class in org.apache.camel.impl.converter
A type converter loader, that only supports scanning a TypeConverters class for methods that has been annotated with Converter.
TypeConvertersLoader(TypeConverters) - Constructor for class org.apache.camel.impl.converter.TypeConvertersLoader
Creates the loader
TypeConvertersPackageScanClassResolver - Class in org.apache.camel.impl.converter
A ClassResolver which loads type converters from an instance that implements TypeConverters.
TypeConvertersPackageScanClassResolver(Class<?>) - Constructor for class org.apache.camel.impl.converter.TypeConvertersPackageScanClassResolver
 
TypedProcessorFactory<T extends org.apache.camel.NamedNode> - Class in org.apache.camel.impl.engine
 
TypedProcessorFactory(Class<T>) - Constructor for class org.apache.camel.impl.engine.TypedProcessorFactory
 
typeExpression(String) - Static method in class org.apache.camel.language.simple.SimpleExpressionBuilder
Returns an expression for a type value
typeMappings - Variable in class org.apache.camel.impl.converter.BaseTypeConverterRegistry
 

U

UnaryExpression - Class in org.apache.camel.language.simple.ast
Represents an unary expression in the AST
UnaryExpression(SimpleToken) - Constructor for class org.apache.camel.language.simple.ast.UnaryExpression
 
unaryOperator() - Method in class org.apache.camel.language.simple.SimpleExpressionParser
 
unaryOperator() - Method in class org.apache.camel.language.simple.SimplePredicateParser
 
UnaryOperatorType - Enum in org.apache.camel.language.simple.types
Types of unary operators supported.
UnitOfWorkProcessorAdvice(RouteContext) - Constructor for class org.apache.camel.processor.CamelInternalProcessor.UnitOfWorkProcessorAdvice
 
UnitOfWorkProducer - Class in org.apache.camel.processor
Ensures a Producer is executed within an UnitOfWork.
UnitOfWorkProducer(Producer) - Constructor for class org.apache.camel.processor.UnitOfWorkProducer
The producer which should be executed within an UnitOfWork.
unmanageObject(Object) - Method in class org.apache.camel.impl.engine.DefaultManagementStrategy
 
unregister(HealthCheck) - Method in class org.apache.camel.impl.health.DefaultHealthCheckRegistry
 
UnsafeUriCharactersEncoder - Class in org.apache.camel.runtimecatalog.impl
Encoder for unsafe URI characters.
unwrap(CamelInternalProcessorAdvice<?>) - Static method in class org.apache.camel.processor.CamelInternalProcessor
 
updateNewExchange(Exchange, int, Iterable<ProcessorExchangePair>, boolean) - Method in class org.apache.camel.processor.MulticastProcessor
 
updateNewExchange(Exchange, int, Iterable<ProcessorExchangePair>, boolean) - Method in class org.apache.camel.processor.Splitter
 
uri - Variable in class org.apache.camel.processor.SendDynamicProcessor
 
uriDelimiter - Variable in class org.apache.camel.processor.RoutingSlip
 
URISupport - Class in org.apache.camel.runtimecatalog.impl
Copied from org.apache.camel.util.URISupport
UriTypeConverter - Class in org.apache.camel.impl.converter
A TypeConverter that converts to and from URIs.
UriTypeConverterLoader - Class in org.apache.camel.impl.converter
Source code generated by org.apache.camel:apt
UriTypeConverterLoader() - Constructor for class org.apache.camel.impl.converter.UriTypeConverterLoader
 
useCollisionAvoidance - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
useCollisionAvoidance() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Enables collision avoidance which adds some randomization to the backoff timings to reduce contention probability
useExponentialBackOff - Variable in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
 
useExponentialBackOff() - Method in class org.apache.camel.processor.errorhandler.RedeliveryPolicy
Enables exponential backoff using the RedeliveryPolicy.getBackOffMultiplier() to increase the time between retries
UseLatestAggregationStrategy - Class in org.apache.camel.processor.aggregate
An AggregationStrategy which just uses the latest exchange which is useful for status messages where old status messages have no real value.
UseLatestAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.UseLatestAggregationStrategy
 
UseOriginalAggregationStrategy - Class in org.apache.camel.processor.aggregate
An AggregationStrategy which just uses the original exchange which can be needed when you want to preserve the original Exchange.
UseOriginalAggregationStrategy() - Constructor for class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
UseOriginalAggregationStrategy(boolean) - Constructor for class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
UseOriginalAggregationStrategy(Exchange, boolean) - Constructor for class org.apache.camel.processor.aggregate.UseOriginalAggregationStrategy
 
useOriginalBodyPolicy - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 
useOriginalMessagePolicy - Variable in class org.apache.camel.processor.errorhandler.RedeliveryErrorHandler
 

V

validate(Message, DataType) - Method in class org.apache.camel.impl.validator.ProcessorValidator
Perform content validation with specified type using Processor.
validateEndpointProperties(String) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
validateEndpointProperties(String, boolean) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
validateEndpointProperties(String, boolean, boolean, boolean) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
validateLanguageExpression(ClassLoader, String, String) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
validateLanguagePredicate(ClassLoader, String, String) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
validateProperties(String, Map<String, String>) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
validateTimePattern(String) - Method in class org.apache.camel.runtimecatalog.impl.AbstractCamelCatalog
 
ValidatorKey - Class in org.apache.camel.impl.validator
Key used in ValidatorRegistry in CamelContext, to ensure a consistent lookup.
ValidatorKey(DataType) - Constructor for class org.apache.camel.impl.validator.ValidatorKey
 
valueOf(String) - Static method in enum org.apache.camel.impl.engine.AbstractCamelContext.Initialization
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.language.simple.types.LogicalOperatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.language.simple.types.TokenType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.language.simple.types.UnaryOperatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.processor.saga.SagaCompletionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.processor.saga.SagaPropagation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.throttling.ThrottlingInflightRoutePolicy.ThrottlingScope
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.camel.impl.engine.AbstractCamelContext.Initialization
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType.ParameterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.language.simple.types.BinaryOperatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.language.simple.types.LogicalOperatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.language.simple.types.TokenType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.language.simple.types.UnaryOperatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.processor.errorhandler.ExceptionPolicy.RedeliveryOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.processor.saga.SagaCompletionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.processor.saga.SagaPropagation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.throttling.ThrottlingInflightRoutePolicy.ThrottlingScope
Returns an array containing the constants of this enum type, in the order they are declared.
visitedClasses - Variable in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 
visitedURIs - Variable in class org.apache.camel.impl.converter.AnnotationTypeConverterLoader
 

W

warmUp() - Method in class org.apache.camel.impl.engine.BaseRouteService
 
warmUp() - Method in class org.apache.camel.impl.engine.DefaultRoute
 
WebSpherePackageScanClassResolver - Class in org.apache.camel.impl.engine
WebSphere specific resolver to handle loading annotated resources in JAR files.
WebSpherePackageScanClassResolver(String) - Constructor for class org.apache.camel.impl.engine.WebSpherePackageScanClassResolver
Constructor.
WeightedLoadBalancer - Class in org.apache.camel.processor.loadbalancer
 
WeightedLoadBalancer(List<Integer>) - Constructor for class org.apache.camel.processor.loadbalancer.WeightedLoadBalancer
 
WeightedRandomLoadBalancer - Class in org.apache.camel.processor.loadbalancer
 
WeightedRandomLoadBalancer(List<Integer>) - Constructor for class org.apache.camel.processor.loadbalancer.WeightedRandomLoadBalancer
 
WeightedRoundRobinLoadBalancer - Class in org.apache.camel.processor.loadbalancer
 
WeightedRoundRobinLoadBalancer(List<Integer>) - Constructor for class org.apache.camel.processor.loadbalancer.WeightedRoundRobinLoadBalancer
 
WireTapProcessor - Class in org.apache.camel.processor
Processor for wire tapping exchanges to an endpoint destination.
WireTapProcessor(SendDynamicProcessor, Processor, ExchangePattern, ExecutorService, boolean, boolean) - Constructor for class org.apache.camel.processor.WireTapProcessor
 
withBody(Object) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
withBodyAs(Object, Class<?>) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
withExchange(Exchange) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
withExchange(Supplier<Exchange>) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
withHeader(String, Object) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
withProcessor(Processor) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
withProcessor(Supplier<Processor>) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
withTemplateCustomizer(Consumer<ProducerTemplate>) - Method in class org.apache.camel.impl.engine.DefaultFluentProducerTemplate
 
wrap(ManagementInterceptStrategy.InstrumentationProcessor<T>) - Static method in class org.apache.camel.processor.CamelInternalProcessor
Wrap an InstrumentationProcessor into a CamelInternalProcessorAdvice
WrapProcessor - Class in org.apache.camel.processor
A processor which ensures wrapping processors is having lifecycle handled.
WrapProcessor(Processor, Processor) - Constructor for class org.apache.camel.processor.WrapProcessor
 
A B C D E F G H I J L M N O P Q R S T U V W 
Skip navigation links

Apache Camel