Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



#Org.apache.camel Classes and Interfaces - 1284 results found.
NameDescriptionTypePackageFramework
AbstractApiComponentAbstract base class for API Component Camel Component classes.Classorg.apache.camel.util.componentApache Camel
AbstractApiConsumerAbstract base class for API Component Consumers.Classorg.apache.camel.util.componentApache Camel
AbstractApiEndpointAbstract base class for API Component Endpoints.Classorg.apache.camel.util.componentApache Camel
AbstractApiProducerClassorg.apache.camel.util.componentApache Camel
AbstractCamelInvocationHandlerClassorg.apache.camel.component.beanApache Camel
AbstractExchangeEventBase class for Exchange events.Classorg.apache.camel.management.eventApache Camel
AbstractListAggregationStrategyAggregate all exchanges into a List of values defined by the getValue(Exchange) call.Classorg.apache.camel.processor.aggregateApache Camel
ActivatorClassorg.apache.camel.impl.osgiApache Camel
Activator .BaseResolverClassorg.apache.camel.impl.osgi.ActivatorApache Camel
Activator .BaseServiceClassorg.apache.camel.impl.osgi.ActivatorApache Camel
Activator .BundleComponentResolverClassorg.apache.camel.impl.osgi.ActivatorApache Camel
Activator .BundleDataFormatResolverClassorg.apache.camel.impl.osgi.ActivatorApache Camel
Activator .BundleLanguageResolverClassorg.apache.camel.impl.osgi.ActivatorApache Camel
Activator .BundleMetaLanguageResolverClassorg.apache.camel.impl.osgi.ActivatorApache Camel
Activator .BundleTypeConverterLoaderClassorg.apache.camel.impl.osgi.ActivatorApache Camel
ActiveMQUuidGeneratorUuidGenerator which is a fast implementation based on how Apache ActiveMQ generates its UUID.Classorg.apache.camel.implApache Camel
AdviceWithBuilderA builder when using the advice with feature.Classorg.apache.camel.builderApache Camel
AdviceWithRouteBuilderA RouteBuilder which has extended capabilities when using the advice with feature.Classorg.apache.camel.builderApache Camel
AdviceWithTaskTask or command being executed when using the advice with feature.Interfaceorg.apache.camel.builderApache Camel
AdviceWithTasksAdviceWithTask tasks which are used by the AdviceWithRouteBuilder.Classorg.apache.camel.builderApache Camel
AggregateDefinitionClassorg.apache.camel.modelApache Camel
AggregateProcessorAn implementation of the Aggregator pattern where a batch of messages are processed (up to a maximum amount orClassorg.apache.camel.processor.aggregateApache Camel
AggregateRouteNodeClassorg.apache.camel.implApache Camel
AggregationRepositoryAccess to a repository to store aggregated exchanges to support pluggable implementations.Interfaceorg.apache.camel.spiApache Camel
AggregationStrategiesToolbox class to create commonly used Aggregation Strategies in a fluent manner.Classorg.apache.camel.util.toolboxApache Camel
AggregationStrategyA strategy for aggregating two exchanges together into a single exchange.Interfaceorg.apache.camel.processor.aggregateApache Camel
AggregationStrategyBeanAdapterAn AggregationStrategy that adapts to a POJO.Classorg.apache.camel.processor.aggregateApache Camel
AggregationStrategyBeanInfoClass information about the POJO method to call when using the AggregationStrategyBeanAdapter.Classorg.apache.camel.processor.aggregateApache Camel
AggregationStrategyMethodInfoMethod information about the POJO method to call when using the AggregationStrategyBeanAdapter.Classorg.apache.camel.processor.aggregateApache Camel
AliasedX509ExtendedKeyManagerKeyManager to select a key with desired alias while delegating processing to specified KeyManager Can be used both with server and client socketsClassorg.apache.camel.util.jsseApache Camel
AlreadyStoppedExceptionException thrown in situations when a Service has already been stopped.Classorg.apache.camelApache Camel
AmbiguousMethodCallExceptionAn exception thrown if an attempted method invocation resulted in an ambiguous method such that multiple methods match the inbound message exchangeClassorg.apache.camel.component.beanApache Camel
AnnotatedParameterConfigurationAn implementation of ParameterConfiguration which comes from a field or setter method which has access to its underlying annotations to be able to expose additional validationClassorg.apache.camel.implApache Camel
AnnotatedWithAnyPackageScanFilterPackage scan filter for testing if a given class is annotated with any of the annotations.Classorg.apache.camel.impl.scanApache Camel
AnnotatedWithPackageScanFilterPackage scan filter for testing if a given class is annotated with a certain annotation.Classorg.apache.camel.impl.scanApache Camel
AnnotationExpressionFactoryA factory which creates an Expression object from an annotation on a field, property or method parameter of a specified type.Interfaceorg.apache.camel.component.beanApache Camel
AnnotationTypeConverterLoaderA class which will auto-discover Converter objects and methods to pre-load the TypeConverterRegistry of converters on startup.Classorg.apache.camel.impl.converterApache Camel
AntPathMatcherPathMatcher implementation for Ant-style path patterns.Classorg.apache.camel.utilApache Camel
AntPathMatcherFileFilterFile filter using AntPathMatcher.Classorg.apache.camel.component.fileApache Camel
AntPathMatcherGenericFileFilterFile filter using AntPathMatcher.Classorg.apache.camel.component.fileApache Camel
AOPDefinitionClassorg.apache.camel.modelApache Camel
AOPProcessorClassorg.apache.camel.processorApache Camel
ApiCollectionBase class for a collection of ApiMethods.Classorg.apache.camel.util.componentApache Camel
ApiConsumerHelperUtility class for API Consumers.Classorg.apache.camel.util.componentApache Camel
ApiMethodInterface for proxy methods.Interfaceorg.apache.camel.util.componentApache Camel
ApiMethodHelperHelper class for working with ApiMethod.Classorg.apache.camel.util.componentApache Camel
ApiMethodHelper .MatchTypeClassorg.apache.camel.util.component.ApiMethodHelperApache Camel
ApiMethodImplDelegate class for ApiMethod.Classorg.apache.camel.util.componentApache Camel
ApiMethodParserParser base class for generating ApiMethod enumerations.Classorg.apache.camel.util.componentApache Camel
ApiMethodParser .ApiMethodModelClassorg.apache.camel.util.component.ApiMethodParserApache Camel
ApiMethodParser .ArgumentClassorg.apache.camel.util.component.ApiMethodParserApache Camel
ApiMethodPropertiesHelperHelper class to work with ApiMethod arguments to be extended by components.Classorg.apache.camel.util.componentApache Camel
ApiNameMarker interface for ApiName enumerations.Interfaceorg.apache.camel.util.componentApache Camel
ArgumentSubstitutionParserAdds support for parameter name substitutions.Classorg.apache.camel.util.componentApache Camel
ArgumentSubstitutionParser .SubstitutionClassorg.apache.camel.util.component.ArgumentSubstitutionParserApache Camel
ArrayBlockingQueueFactoryClassorg.apache.camel.component.sedaApache Camel
ArrayTypeConverterA type converter which is used to convert to and from array types particularly for derived types of array component types and dealing withClassorg.apache.camel.impl.converterApache Camel
AssertionClauseClassorg.apache.camel.component.mockApache Camel
AssignableToPackageScanFilterPackage scan filter for testing if a given class is assignable to another class.Classorg.apache.camel.impl.scanApache Camel
AsyncCallbackThe callback interface for an AsyncProcessor so that it can notify you when an Exchange is done.Interfaceorg.apache.camelApache Camel
AsyncProcessorAn asynchronous processor which can process an Exchange in an asynchronous fashion and signal completion by invoking the AsyncCallback.Interfaceorg.apache.camelApache Camel
AsyncProcessorAwaitManagerA manager to handle async routing engine, when Exchanges are being handed over from one thread to another, while the callee thread is blocked waiting for the other threads to complete, before it can continue.Interfaceorg.apache.camel.spiApache Camel
AsyncProcessorAwaitManager .AwaitThreadInformation about the thread and exchange that are inflight.Interfaceorg.apache.camel.spi.AsyncProcessorAwaitManagerApache Camel
AsyncProcessorAwaitManager .StatisticsUtilization statistics of the this manager.Interfaceorg.apache.camel.spi.AsyncProcessorAwaitManagerApache Camel
AsyncProcessorConverterHelperA simple converter that can convert any Processor to an AsyncProcessor.Classorg.apache.camel.utilApache Camel
AsyncProcessorHelperHelper methods for AsyncProcessor objects.Classorg.apache.camel.utilApache Camel
AsyncProcessorTypeConverterA simple converter that can convert any Processor to an AsyncProcessor.Classorg.apache.camel.impl.converterApache Camel
AsyncProducerCallbackCallback for sending a exchange message to a endpoint using an AsyncProcessor capable producer.Interfaceorg.apache.camelApache Camel
AtomicExceptionConvenience class for holding an Exception in a thread-safe waySee Also:Serialized FormClassorg.apache.camel.util.concurrentApache Camel
AtomicExchangeConvenience class for holding an Exchange in a thread-safe waySee Also:Serialized FormClassorg.apache.camel.util.concurrentApache Camel
AugmentedPropertyNameAwarePropertiesParserInterface for property parses that can attempt parsing property names using a fixed property name prefix and suffix.Interfaceorg.apache.camel.component.propertiesApache Camel
AvroDataFormatClassorg.apache.camel.model.dataformatApache Camel
BacklogDebuggerA Debugger that has easy debugging functionality which can be used from JMX with ManagedBacklogDebuggerMBean.Classorg.apache.camel.processor.interceptorApache Camel
BacklogTracerA tracer used for message tracing, storing a copy of the message details in a backlog.Classorg.apache.camel.processor.interceptorApache Camel
BacklogTracerEventMessageRepresents a traced message by the BacklogTracer.Interfaceorg.apache.camel.api.management.mbeanApache Camel
BarcodeDataFormatClassorg.apache.camel.model.dataformatApache Camel
Base64DataFormatClassorg.apache.camel.model.dataformatApache Camel
BaseSimpleNodeBase class for SimpleNode nodes.Classorg.apache.camel.language.simple.astApache Camel
BaseSimpleParserBase class for Simple language parser.Classorg.apache.camel.language.simpleApache Camel
BaseSSLContextParametersRepresents configuration options that can be applied in the client-side or server-side context depending on what they are applied to.Classorg.apache.camel.util.jsseApache Camel
BaseSSLContextParameters .SSLContextDecoratorMakes a decorated SSLContext appear as a normal SSLContext.Classorg.apache.camel.util.jsse.BaseSSLContextParametersApache Camel
BaseSSLContextParameters .SSLContextSpiDecorator Since SSLContext is an abstract class and requires an instance of SSLContextSpi, this class effectively wraps anClassorg.apache.camel.util.jsse.BaseSSLContextParametersApache Camel
BaseSSLContextParameters .SSLServerSocketFactoryDecoratorA decorator that enables the application of configuration options to be applied to created sockets even after this factory has been created andClassorg.apache.camel.util.jsse.BaseSSLContextParametersApache Camel
BaseSSLContextParameters .SSLSocketFactoryDecoratorA decorator that enables the application of configuration options to be applied to created sockets even after this factory has been created andClassorg.apache.camel.util.jsse.BaseSSLContextParametersApache Camel
BaseTypeConverterRegistryBase implementation of a type converter registry used for type converters in Camel.Classorg.apache.camel.impl.converterApache Camel
BaseTypeConverterRegistry .FallbackTypeConverterClassorg.apache.camel.impl.converter.BaseTypeConverterRegistryApache Camel
BaseTypeConverterRegistry .TypeMappingClassorg.apache.camel.impl.converter.BaseTypeConverterRegistryApache Camel
BatchConsumerInterfaceorg.apache.camelApache Camel
BatchProcessorA base class for any kind of Processor which implements some kind of batch processing.Classorg.apache.camel.processorApache Camel
BatchResequencerConfigConfigures batch-processing resequence eip.Classorg.apache.camel.model.configApache Camel
BeanUsed to inject a bean expression into a field, property, method or parameter when usingRequired Element SummaryClassorg.apache.camel.languageApache Camel
BeanAnnotationExpressionFactoryClassorg.apache.camel.component.beanApache Camel
BeanComponentThe Bean Component is for invoking Java beans from Camel.Classorg.apache.camel.component.beanApache Camel
BeanConstantsClassorg.apache.camel.component.beanApache Camel
BeanConverterClassorg.apache.camel.component.beanApache Camel
BeanDefinitionClassorg.apache.camel.modelApache Camel
BeanEndpointEndpoint for the bean component.Classorg.apache.camel.component.beanApache Camel
BeanExpressionClassorg.apache.camel.language.beanApache Camel
BeanHelperHelper for the bean component.Classorg.apache.camel.component.beanApache Camel
BeanHolderObject holder for a bean.Interfaceorg.apache.camel.component.beanApache Camel
BeanInfoRepresents the metadata about a bean type created via a combination of introspection and annotations together with some useful sensible defaultsClassorg.apache.camel.component.beanApache Camel
BeanInfoCacheKeyClassorg.apache.camel.component.beanApache Camel
BeanInjectUsed to indicate an injection point of a bean obtained from the Registry, into a POJO.Classorg.apache.camelApache Camel
BeanInvocationInvocation of beans that can handle being serialized.Classorg.apache.camel.component.beanApache Camel
BeanioDataFormatClassorg.apache.camel.model.dataformatApache Camel
BeanLanguage which uses a simple text notation to invoke methods on beans to evaluate predicates or expressions The notation is essentially beanName.Classorg.apache.camel.language.beanApache Camel
BeanProcessorA Processor which converts the inbound exchange to a method invocation on a POJOClassorg.apache.camel.component.beanApache Camel
BeanProducerClassorg.apache.camel.component.beanApache Camel
BeanTypeHolderObject holder for a bean type.Interfaceorg.apache.camel.component.beanApache Camel
BinaryExpressionRepresents a binary expression in the AST.Classorg.apache.camel.language.simple.astApache Camel
BinaryOperatorTypeenum BinaryOperatorTypeTypes of binary operators supportedClassorg.apache.camel.language.simple.typesApache Camel
BinaryOperatorType .ParameterTypeParameter types a binary operator supports on the right hand side.Classorg.apache.camel.language.simple.types.BinaryOperatorTypeApache Camel
BinaryPredicateA predicate which evaluates a binary expression.Interfaceorg.apache.camelApache Camel
BinaryPredicateSupportClassorg.apache.camel.builderApache Camel
BindingRepresents a Binding or contract which can be applied to an Endpoint; such as ensuring that a particularInterfaceorg.apache.camel.spiApache Camel
BindingComponentA composite Component which creates a BindingEndpoint from a configured Binding instance and using the optional setUriPrefix(String)Classorg.apache.camel.component.bindingApache Camel
BindingConsumerProcessorClassorg.apache.camel.component.bindingApache Camel
BindingEndpointApplies a Binding to an underlying Endpoint so that the binding processes messages before its sent to the endpoint and processes messages received by the endpoint consumer before its passedClassorg.apache.camel.component.bindingApache Camel
BindingExceptionAn exception if a binding is not possible, such as binding to json or xml cannot be done.Classorg.apache.camel.processor.bindingApache Camel
BindingNameComponentClassorg.apache.camel.component.bindingApache Camel
BindingProducerClassorg.apache.camel.component.bindingApache Camel
BindyDataFormatClassorg.apache.camel.model.dataformatApache Camel
BindyTypeRepresents the different types of bindy data formats.Classorg.apache.camel.model.dataformatApache Camel
BlockA model which is a block, containing other nodes.Interfaceorg.apache.camel.language.simple.astApache Camel
BlockInterface to add block featuring to the XML element type.Interfaceorg.apache.camel.modelApache Camel
BlockingQueueFactoryInterfaceorg.apache.camel.component.sedaApache Camel
BreakpointBreakpoint are used by the Debugger API.Interfaceorg.apache.camel.spiApache Camel
Breakpoint .StateState of the breakpoint as either active or suspended.Classorg.apache.camel.spi.BreakpointApache Camel
BreakpointSupportA support class for Breakpoint implementations to use as base class.Classorg.apache.camel.implApache Camel
BridgeExceptionHandlerToErrorHandlerAn ExceptionHandler that uses the DefaultConsumer to process the caused exception to send the message into the Camel routing engineClassorg.apache.camel.implApache Camel
BrowsableEndpointAn optional interface an Endpoint may choose to implement which allows it to expose a way of browsing the exchanges available.Interfaceorg.apache.camel.spiApache Camel
BrowseComponentThe Browse Component provides a simple BrowsableEndpoint for testing visualization or debugging.Classorg.apache.camel.component.browseApache Camel
BrowseEndpointAn endpoint which maintains a List of Exchange instances which can be useful for tooling, debugging and visualising routes.Classorg.apache.camel.component.browseApache Camel
BuilderClassorg.apache.camel.builderApache Camel
BuilderSupportClassorg.apache.camel.builderApache Camel
BundleTrackerThe BundleTracker class simplifies tracking bundles much like the ServiceTracker simplifies tracking services.Classorg.apache.camel.impl.osgi.trackerApache Camel
BundleTrackerCustomizerThe BundleTrackerCustomizer interface allows a BundleTracker to customize the Bundles that areInterfaceorg.apache.camel.impl.osgi.trackerApache Camel
ByteArrayInputStreamCacheClassorg.apache.camel.converter.streamApache Camel
BytesSourceA helper class which provides a JAXP Source from a byte[] which can be read as many times as required.Classorg.apache.camelApache Camel
CachedByteArrayOutputStreamA ByteArrayOutputStream that is capable of returning a InputStreamCache view of the buffer.Classorg.apache.camel.converter.streamApache Camel
CachedOutputStreamThis output stream will store the content into a File if the stream context size is exceed the THRESHOLD value.Classorg.apache.camel.converter.streamApache Camel
CachingInjectorClassorg.apache.camel.impl.converterApache Camel
CamelAuthorizationExceptionAn exception thrown for either authentication or authorization errors occurring in a Camel exchange.Classorg.apache.camelApache Camel
CamelContextInterface used to represent the context used to configure routes and the policies to use during message exchanges between endpoints.Interfaceorg.apache.camelApache Camel
CamelContextAwareAn interface to represent an object which wishes to be injected with a CamelContext such as when working with Spring or GuiceInterfaceorg.apache.camelApache Camel
CamelContextHelperClassorg.apache.camel.utilApache Camel
CamelContextNameStrategyStrategy for assigning name to a CamelContext.Interfaceorg.apache.camel.spiApache Camel
CamelContextResumedEventClassorg.apache.camel.management.eventApache Camel
CamelContextResumeFailureEventClassorg.apache.camel.management.eventApache Camel
CamelContextResumingEventClassorg.apache.camel.management.eventApache Camel
CamelContextStartedEventClassorg.apache.camel.management.eventApache Camel
CamelContextStartingEventClassorg.apache.camel.management.eventApache Camel
CamelContextStartupFailureEventClassorg.apache.camel.management.eventApache Camel
CamelContextStatDumpA model of a CamelContext stat dump from ManagedCamelContextMBean.Classorg.apache.camel.utilApache Camel
CamelContextStopFailureEventClassorg.apache.camel.management.eventApache Camel
CamelContextStoppedEventClassorg.apache.camel.management.eventApache Camel
CamelContextStoppingEventClassorg.apache.camel.management.eventApache Camel
CamelContextSuspendedEventClassorg.apache.camel.management.eventApache Camel
CamelContextSuspendingEventClassorg.apache.camel.management.eventApache Camel
CamelContextTrackerA camel context creation tracker.Classorg.apache.camel.spiApache Camel
CamelContextTrackerRegistryA registry for CamelContextTracker.Classorg.apache.camel.implApache Camel
CamelConverterClassorg.apache.camel.converterApache Camel
CamelExceptionBase class for all Camel checked exceptions typically thrown by a ProcessorVersion:See Also:Serialized FormClassorg.apache.camelApache Camel
CamelExchangeExceptionAn exception caused by a specific message ExchangeVersion:See Also:Serialized FormClassorg.apache.camelApache Camel
CamelExecutionExceptionException occurred during execution/processing of an Exchange.Classorg.apache.camelApache Camel
CamelInitialContextFactoryA factory of the Camel InitialContext which allows a Map to be used to create a This implementation is prototype based, by creating a new context on each call toClassorg.apache.camel.util.jndiApache Camel
CamelInternalProcessorInternal Processor that Camel routing engine used during routing for cross cutting functionality such as: Execute UnitOfWorkKeeping track which route currently is being routedExecute RoutePolicyGather JMX performance staticsTracingDebuggingMessage HistoryStream CachingClassorg.apache.camel.processorApache Camel
CamelInternalProcessor .BacklogDebuggerAdviceAdvice to execute the BacklogDebugger if enabled.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .BacklogTracerAdviceAdvice to execute the BacklogTracer if enabled.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .ChildUnitOfWorkProcessorAdviceAdvice when an EIP uses the shareUnitOfWork functionality.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .DelayerAdviceClassorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .InstrumentationAdviceAdvice for JMX instrumentation of the process being invoked.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .MessageHistoryAdviceAdvice when Message History has been enabled.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .RouteContextAdviceClassorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .RouteInflightRepositoryAdviceAdvice to keep the InflightRepository up to date.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .RouteLifecycleAdviceAdvice to invoke callbacks for before and after routing.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .RoutePolicyAdviceAdvice to execute any RoutePolicy a route may have been configured with.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .StreamCachingAdviceClassorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .SubUnitOfWorkProcessorAdviceAdvice when an EIP uses the shareUnitOfWork functionality.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessor .UnitOfWorkProcessorAdviceAdvice to inject new UnitOfWork to the Exchange if needed, and as well to ensure the UnitOfWork is done and stopped.Classorg.apache.camel.processor.CamelInternalProcessorApache Camel
CamelInternalProcessorAdviceAn advice (before and after) to execute cross cutting functionality in the Camel routing engine.Interfaceorg.apache.camel.processorApache Camel
CamelInvocationHandlerAn InvocationHandler which invokes a message exchange on a camel EndpointClassorg.apache.camel.component.beanApache Camel
CamelLoggerA Processor which just logs to a CamelLogger object which can be used as an exception handler instead of using a dead letter queue.Classorg.apache.camel.processorApache Camel
CamelLoggerA logger which logs to a slf4j Logger.Classorg.apache.camel.utilApache Camel
CamelLogProcessorA Processor which just logs to a CamelLogger object which can be used as an exception handler instead of using a dead letter queue.Classorg.apache.camel.processorApache Camel
CamelOpenMBeanTypesVarious JMX openmbean types used by Camel.Classorg.apache.camel.api.management.mbeanApache Camel
CamelPostProcessorHelperClassorg.apache.camel.implApache Camel
CamelSingletonInitialContextFactoryA factory of the Camel InitialContext which allows a Map to be used to create a This implementation is singleton based, by creating a new context once, and reusing it on each call toClassorg.apache.camel.util.jndiApache Camel
CamelThreadFactoryThread factory which creates threads supporting a naming pattern.Classorg.apache.camel.util.concurrentApache Camel
CamelUnitOfWorkExceptionA UnitOfWork failed with a number of caused exceptions.Classorg.apache.camelApache Camel
CaseInsensitiveMapA map that uses case insensitive keys, but preserves the original key cases.Classorg.apache.camel.utilApache Camel
CastorDataFormatClassorg.apache.camel.model.dataformatApache Camel
CastUtilsUtility methods for type casting.Classorg.apache.camel.utilApache Camel
CatchDefinitionClassorg.apache.camel.modelApache Camel
CatchProcessorA processor which catches exceptions.Classorg.apache.camel.processorApache Camel
ChannelChannel acts as a channel between Processors in the route graph.Interfaceorg.apache.camelApache Camel
ChildServiceSupportBase class to control lifecycle for a set of child Services.Classorg.apache.camel.supportApache Camel
ChoiceDefinitionClassorg.apache.camel.modelApache Camel
ChoiceProcessorClassorg.apache.camel.processorApache Camel
CipherPairA class to hold a pair of encryption and decryption ciphers.Classorg.apache.camel.converter.streamApache Camel
CipherSuitesParametersRepresents a list of TLS/SSL cipher suite names.Classorg.apache.camel.util.jsseApache Camel
CircuitBreakerLoadBalancerClassorg.apache.camel.processor.loadbalancerApache Camel
CircuitBreakerLoadBalancerDefinitionCircuit break load balancer The Circuit Breaker load balancer is a stateful pattern that monitors all calls for certain exceptions.Classorg.apache.camel.model.loadbalancerApache Camel
ClassComponentThe Class Component is for binding JavaBeans to Camel message exchanges based on class name.Classorg.apache.camel.component.beanclassApache Camel
ClassEndpointEndpoint for the class component.Classorg.apache.camel.component.beanclassApache Camel
ClassResolverA class resolver for loading classes in a loosly coupled manner to cater for different platforms such as standalone, web container, j2ee container and OSGi platforms.Interfaceorg.apache.camel.spiApache Camel
ClientAuthenticationenum ClientAuthenticationRepresents the options for the client authentication settings of a server socket.Classorg.apache.camel.util.jsseApache Camel
ClosedCorrelationKeyExceptionThe correlation key has been closed and the Exchange cannot be aggregated.Classorg.apache.camel.processor.aggregateApache Camel
CollectionConverterSome core java.Classorg.apache.camel.converterApache Camel
CollectionHelperClassorg.apache.camel.utilApache Camel
CollectionProducerA simple Producer which just appends to a Collection the Exchange object.Classorg.apache.camel.component.sedaApache Camel
CollectionStringBufferA little helper class for converting a collection of values to a (usually comma separated) string.Classorg.apache.camel.utilApache Camel
CompletionAwareAggregationStrategyA specialized AggregationStrategy which has callback when the aggregated Exchange is completed.Interfaceorg.apache.camel.processor.aggregateApache Camel
Component a factory of Endpoint objects.Interfaceorg.apache.camelApache Camel
ComponentConfigurationRepresents a set of configuration values for an endpoint URI which can be created from a URI string or a base URI string and a set of parameter names and values.Interfaceorg.apache.camelApache Camel
ComponentConfigurationSupportClassorg.apache.camel.implApache Camel
ComponentResolverRepresents a resolver of components from a URI to be able to auto-load them using some discovery mechanism like DefaultComponentResolverInterfaceorg.apache.camel.spiApache Camel
CompositeNodesA node which contains other nodes.Classorg.apache.camel.language.simple.astApache Camel
CompositePackageScanFilterCompositePackageScanFilter allows multiple PackageScanFilters to be composed into a single filter.Classorg.apache.camel.impl.scanApache Camel
CompositePerformanceCounterA composite PerformanceCounter is used for tracking performance statistics on both a per context and route level, by issuing callbacks on both when an event happens.Classorg.apache.camel.managementApache Camel
CompositeRegistryThis registry will look up the object with the sequence of the registry list until it finds the Object.Classorg.apache.camel.implApache Camel
ConditionA condition to define when a given Exchange matches when is being routed.Interfaceorg.apache.camel.spiApache Camel
ConditionSupportA support class for Condition implementations to use as base class.Classorg.apache.camel.implApache Camel
ConfigurationHelperClassorg.apache.camel.implApache Camel
ConfigurationHelper .FieldParameterSetterClassorg.apache.camel.impl.ConfigurationHelperApache Camel
ConfigurationHelper .ParameterSetterInterfaceorg.apache.camel.impl.ConfigurationHelperApache Camel
ConstantBeanHolderClassorg.apache.camel.component.beanApache Camel
ConstantExpressionClassorg.apache.camel.model.languageApache Camel
ConstantLanguageA language for constant expressions.Classorg.apache.camel.language.constantApache Camel
ConstantsClassorg.apache.camel.modelApache Camel
ConstantStaticTypeBeanHolderA constant BeanHolder for a class or static class where the intention is to only invoke static methods, without the need for creating an instance of the type.Classorg.apache.camel.component.beanApache Camel
ConstantTypeBeanHolderClassorg.apache.camel.component.beanApache Camel
ConsumeSubscribes a method to an Endpoint either via its URI or via the name of the endpoint referenceClassorg.apache.camelApache Camel
ConsumerCacheCache containing created Consumer.Classorg.apache.camel.implApache Camel
ConsumerTemplateTemplate for working with Camel and consuming Message instances in an Exchange from an Endpoint.Interfaceorg.apache.camelApache Camel
ContainerThe Container interface defines an object that can be used to customize all Camel CONTEXTS created.Interfaceorg.apache.camel.spiApache Camel
Container .InstanceThe Instance class holds a Container singleton.Classorg.apache.camel.spi.ContainerApache Camel
ContextScanDefinitionScans for Java RouteBuilder instances in the context Registry.Classorg.apache.camel.modelApache Camel
ControlBusComponentThe Control Bus component allows sending messages to a control-bus endpoint to control the lifecycle of routes.Classorg.apache.camel.component.controlbusApache Camel
ControlBusEndpointThe control bus endpoint.Classorg.apache.camel.component.controlbusApache Camel
ControlBusProducerThe control bus producer.Classorg.apache.camel.component.controlbusApache Camel
ConvertBodyDefinitionClassorg.apache.camel.modelApache Camel
ConvertBodyProcessorA processor which converts the payload of the input message to be of the given type If the conversion fails an InvalidPayloadException is thrown.Classorg.apache.camel.processorApache Camel
ConverterAn annotation used to mark classes and methods to indicate code capable of converting from a type to another type which are then auto-discovered usingClassorg.apache.camelApache Camel
CorePackageScanClassResolverA ClassResolver which loads type converters from a hardcoded list of classes.Classorg.apache.camel.impl.converterApache Camel
CoreTypeConverterLoaderWill load all type converters from camel-core without classpath scanning, which makes The CorePackageScanClassResolver contains a hardcoded list of the type converter classes to load.Classorg.apache.camel.impl.converterApache Camel
CryptoDataFormatClassorg.apache.camel.model.dataformatApache Camel
CsvDataFormatClassorg.apache.camel.model.dataformatApache Camel
CustomDataFormatClassorg.apache.camel.model.dataformatApache Camel
CustomLoadBalancerDefinitionClassorg.apache.camel.model.loadbalancerApache Camel
DataFormat used to marshal objects to and from streams such as Java Serialization or using JAXB2 to encode/decode objects using XMLInterfaceorg.apache.camel.spiApache Camel
DataFormatBindingRepresents a Binding which Marshals the message in the ProduceProcessor and Unmarshals the message in the ConsumeProcessorClassorg.apache.camel.processor.bindingApache Camel
DataFormatClauseClassorg.apache.camel.builderApache Camel
DataFormatClause .OperationDataFormat operations.Classorg.apache.camel.builder.DataFormatClauseApache Camel
DataFormatComponentThe Data Format Component enables using Data Format as a component.Classorg.apache.camel.component.dataformatApache Camel
DataFormatDefinitionClassorg.apache.camel.modelApache Camel
DataFormatEndpointClassorg.apache.camel.component.dataformatApache Camel
DataFormatResolverRepresents a resolver of data formats.Interfaceorg.apache.camel.spiApache Camel
DataFormatsDefinitionClassorg.apache.camel.model.dataformatApache Camel
DataSetRepresents a strategy for testing endpoints with canned data.Interfaceorg.apache.camel.component.datasetApache Camel
DataSetComponentComponent for DataSet.Classorg.apache.camel.component.datasetApache Camel
DataSetConsumerClassorg.apache.camel.component.datasetApache Camel
DataSetEndpointEndpoint for DataSet.Classorg.apache.camel.component.datasetApache Camel
DataSetSupportClassorg.apache.camel.component.datasetApache Camel
DateTimeConverterDate and time related converters.Classorg.apache.camel.converterApache Camel
DeadLetterChannelClassorg.apache.camel.processorApache Camel
DeadLetterChannelBuilderClassorg.apache.camel.builderApache Camel
DebugA debug interceptor to notify Debugger with Exchanges being processed.Classorg.apache.camel.processor.interceptorApache Camel
DebuggerA debugger which allows tooling to attach breakpoints which is is being invoked when Exchanges is being routed.Interfaceorg.apache.camel.spiApache Camel
DefaultAnnotationExpressionFactoryDefault implementation of the AnnotationExpressionFactory.Classorg.apache.camel.component.beanApache Camel
DefaultAsyncProcessorAwaitManagerClassorg.apache.camel.implApache Camel
DefaultAsyncProducerA default implementation of Producer for implementation inheritance, which can process Exchanges asynchronously.Classorg.apache.camel.implApache Camel
DefaultBacklogTracerEventMessageAn event message holding the traced message by the BacklogTracer.Classorg.apache.camel.processor.interceptorApache Camel
DefaultCamelBeanPostProcessorA bean post processor which implements the Bean Integration features in Camel.Classorg.apache.camel.implApache Camel
DefaultCamelContextRepresents the context used to configure routes and the policies to use.Classorg.apache.camel.implApache Camel
DefaultCamelContextNameStrategyA default name strategy which auto assigns a name using a prefix-counter pattern.Classorg.apache.camel.implApache Camel
DefaultChannelDefaultChannel is the default Channel.Classorg.apache.camel.processor.interceptorApache Camel
DefaultClassResolverDefault class resolver that uses regular class loader to load classes.Classorg.apache.camel.implApache Camel
DefaultComponentDefault component to use for base for components implementations.Classorg.apache.camel.implApache Camel
DefaultComponentConfigurationDefault implementation for components which do not inherit from UriEndpointComponent and do not have Endpoint classes annotated with UriEndpointClassorg.apache.camel.implApache Camel
DefaultComponentResolverThe default implementation of ComponentResolver which tries to find components by using the URI scheme prefix and searching for a file of the URIClassorg.apache.camel.implApache Camel
DefaultConsumerA default consumer useful for implementation inheritance.Classorg.apache.camel.implApache Camel
DefaultConsumerTemplateTemplate (named like Spring's TransactionTemplate & JmsTemplate et al) for working with Camel and consuming Message instances in anClassorg.apache.camel.implApache Camel
DefaultDataFormatResolverClassorg.apache.camel.implApache Camel
DefaultDebuggerThe default implementation of the Debugger.Classorg.apache.camel.implApache Camel
DefaultEndpointA default endpoint useful for implementation inheritance.Classorg.apache.camel.implApache Camel
DefaultEndpointConfigurationDefault implementation of EndpointConfiguration.Classorg.apache.camel.implApache Camel
DefaultEndpointRegistryDefault implementation of EndpointRegistrySee Also:Serialized FormClassorg.apache.camel.implApache Camel
DefaultErrorHandlerClassorg.apache.camel.processorApache Camel
DefaultErrorHandlerBuilderThe default error handler builder.Classorg.apache.camel.builderApache Camel
DefaultEventFactoryDefault implementation of the EventFactory.Classorg.apache.camel.management.eventApache Camel
DefaultExceptionPolicyStrategyThe default strategy used in Camel to resolve the OnExceptionDefinition that should handle the thrown exception.Classorg.apache.camel.processor.exceptionpolicyApache Camel
DefaultExchangeClassorg.apache.camel.implApache Camel
DefaultExchangeComparatorCompares elements of an Exchange sequence by comparing long values returned by this comparator'sClassorg.apache.camel.processor.resequencerApache Camel
DefaultExchangeFormatterDefault ExchangeFormatter that have fine grained options to configure what to include in the output.Classorg.apache.camel.processorApache Camel
DefaultExchangeFormatter .OutputStyleClassorg.apache.camel.processor.DefaultExchangeFormatterApache Camel
DefaultExchangeHolderHolder object for sending an exchange over a remote wire as a serialized object.Classorg.apache.camel.implApache Camel
DefaultExecutorServiceManagerDefault ExecutorServiceManager.Classorg.apache.camel.implApache Camel
DefaultExecutorServiceStrategyClassorg.apache.camel.implApache Camel
DefaultFactoryFinderDefault factory finder.Classorg.apache.camel.implApache Camel
DefaultFactoryFinderResolverDefault factory finder.Classorg.apache.camel.implApache Camel
DefaultHeaderFilterStrategyThe default header filtering strategy.Classorg.apache.camel.implApache Camel
DefaultInflightRepositoryDefault InflightRepository.Classorg.apache.camel.implApache Camel
DefaultInjectorA default implementation of Injector which just uses reflection to instantiate new objects using their zero argument constructor,Classorg.apache.camel.implApache Camel
DefaultLanguageResolverDefault 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/.Classorg.apache.camel.implApache Camel
DefaultLSResourceResolverDefault LSResourceResolver which can included schema resources.Classorg.apache.camel.component.validatorApache Camel
DefaultManagementAgentClassorg.apache.camel.managementApache Camel
DefaultManagementLifecycleStrategyDefault JMX managed lifecycle strategy that registered objects using the configured ManagementStrategy.Classorg.apache.camel.managementApache Camel
DefaultManagementMBeanAssemblerAn assembler to assemble a ModelMBean which can be used to register the object in JMX.Classorg.apache.camel.managementApache Camel
DefaultManagementNameStrategyDefault implementation of ManagementNameStrategy This implementation will by default use a name pattern as #name# and in caseClassorg.apache.camel.implApache Camel
DefaultManagementNamingStrategyNaming strategy used when registering MBeans.Classorg.apache.camel.managementApache Camel
DefaultManagementObjectStrategyDefault ManagementObjectStrategy.Classorg.apache.camel.managementApache Camel
DefaultManagementStrategyA default management strategy that does not manage.Classorg.apache.camel.managementApache Camel
DefaultMessageThe default implementation of Message This implementation uses a CaseInsensitiveMap storing the headers.Classorg.apache.camel.implApache Camel
DefaultMessageHistoryDefault MessageHistory.Classorg.apache.camel.implApache Camel
DefaultModelJAXBContextFactoryDefault implementation of ModelJAXBContextFactory.Classorg.apache.camel.implApache Camel
DefaultNamespaceContextAn implementation of NamespaceContext which uses a simple Map where the keys are the prefixes and the values are the URIsClassorg.apache.camel.builder.xmlApache Camel
DefaultNodeIdFactoryClassorg.apache.camel.implApache Camel
DefaultPackageScanClassResolverClassorg.apache.camel.implApache Camel
DefaultParameterMappingStrategyClassorg.apache.camel.component.beanApache Camel
DefaultPollingConsumerPollStrategyA default implementation that will not retry on rollback.Classorg.apache.camel.implApache Camel
DefaultPollingConsumerServicePoolA service pool for PollingConsumer.Classorg.apache.camel.implApache Camel
DefaultPollingEndpointClassorg.apache.camel.implApache Camel
DefaultProducerA default implementation of Producer for implementation inheritance.Classorg.apache.camel.implApache Camel
DefaultProducerServicePoolA service pool for Producer.Classorg.apache.camel.implApache Camel
DefaultProducerTemplateTemplate (named like Spring's TransactionTemplate & JmsTemplate et al) for working with Camel and sending Message instances in anClassorg.apache.camel.implApache Camel
DefaultPropertiesParserA parser to parse a string which contains property placeholders.Classorg.apache.camel.component.propertiesApache Camel
DefaultPropertiesResolverDefault PropertiesResolver which can resolve properties from file and classpath.Classorg.apache.camel.component.propertiesApache Camel
DefaultRestRegistryClassorg.apache.camel.implApache Camel
DefaultRouteDefault implementation of Route.Classorg.apache.camel.implApache Camel
DefaultRouteContextClassorg.apache.camel.implApache Camel
DefaultRouteNodeClassorg.apache.camel.implApache Camel
DefaultRouteStartupOrderDefault implementation of RouteStartupOrder.Classorg.apache.camel.implApache Camel
DefaultRuntimeEndpointRegistryClassorg.apache.camel.implApache Camel
DefaultScheduledPollConsumerClassorg.apache.camel.implApache Camel
DefaultScheduledPollConsumerSchedulerDefault ScheduledBatchPollingConsumer.Classorg.apache.camel.implApache Camel
DefaultServicePoolDefault implementation to inherit for a basic service pool.Classorg.apache.camel.implApache Camel
DefaultShutdownStrategyDefault ShutdownStrategy which uses graceful shutdown.Classorg.apache.camel.implApache Camel
DefaultStreamCachingStrategyClassorg.apache.camel.implApache Camel
DefaultSubUnitOfWorkA default implementation of SubUnitOfWork combined with a SubUnitOfWorkCallback to gather callbacks into this SubUnitOfWork stateClassorg.apache.camel.implApache Camel
DefaultThreadPoolFactoryFactory for thread pools that uses the JDK Executors for creating the thread pools.Classorg.apache.camel.implApache Camel
DefaultTimeoutMapDefault implementation of the TimeoutMap.Classorg.apache.camel.supportApache Camel
DefaultTracedRouteNodesClassorg.apache.camel.implApache Camel
DefaultTraceEventHandlerClassorg.apache.camel.processor.interceptorApache Camel
DefaultTraceEventMessageDefault TraceEventMessage.Classorg.apache.camel.processor.interceptorApache Camel
DefaultTraceFormatterClassorg.apache.camel.processor.interceptorApache Camel
DefaultTraceInterceptorFactoryClassorg.apache.camel.processor.interceptorApache Camel
DefaultTransformErrorHandlerErrorHandler and ErrorListener which will ignore warnings, and throws error and fatal as exception, which ensures those can be caught by Camel and dealt-with.Classorg.apache.camel.builder.xmlApache Camel
DefaultTypeConverterDefault implementation of a type converter registry used for type converters in Camel.Classorg.apache.camel.impl.converterApache Camel
DefaultUnitOfWorkClassorg.apache.camel.implApache Camel
DefaultUnitOfWorkFactoryClassorg.apache.camel.implApache Camel
DefaultValidationErrorHandlerA default error handler which just stores all the errors so they can be reported or transformed.Classorg.apache.camel.processor.validationApache Camel
DelayDefinitionClassorg.apache.camel.modelApache Camel
Delayer delays processing the exchange until the correct amount of time has elapsed using an expression to determine the delivery time.Classorg.apache.camel.processorApache Camel
DelayerAn interceptor strategy for delaying routes.Classorg.apache.camel.processor.interceptorApache Camel
DelayInterceptorAn interceptor for delaying routes.Classorg.apache.camel.processor.interceptorApache Camel
DelayProcessorSupportA useful base class for any processor which provides some kind of throttling or delayed processing.Classorg.apache.camel.processorApache Camel
DelegateAsyncProcessorA Delegate pattern which delegates processing to a nested AsyncProcessor which can be useful for implementation inheritance when writing an PolicyClassorg.apache.camel.processorApache Camel
DelegateEndpointAn interface to represent an Endpoint which are delegated.Interfaceorg.apache.camelApache Camel
DelegatePerformanceCounterDelegates to another PerformanceCounter.Classorg.apache.camel.managementApache Camel
DelegateProcessorInterfaceorg.apache.camelApache Camel
DelegateProcessorA Delegate pattern which delegates processing to a nested Processor which can be useful for implementation inheritance when writing an PolicyClassorg.apache.camel.processorApache Camel
DelegateSyncProcessorA Delegate pattern which delegates synchronous processing to a nested Processor which can be useful for implementation inheritance when writing an PolicyClassorg.apache.camel.processorApache Camel
DeleteVerbDefinitionClassorg.apache.camel.model.restApache Camel
DescriptionDefinitionTo provide comments about the node.Classorg.apache.camel.modelApache Camel
DirectBlockingProducerThe direct producer.Classorg.apache.camel.component.directApache Camel
DirectComponentThe Direct Component manages DirectEndpoint and holds the list of named direct endpoints.Classorg.apache.camel.component.directApache Camel
DirectConsumerThe direct consumer.Classorg.apache.camel.component.directApache Camel
DirectConsumerNotAvailableExceptionException thrown when no consumers are available.Classorg.apache.camel.component.directApache Camel
DirectEndpointRepresents a direct endpoint that synchronously invokes the consumer of the endpoint when a producer sends a message to it.Classorg.apache.camel.component.directApache Camel
DirectProducerThe direct producer.Classorg.apache.camel.component.directApache Camel
DirectVmBlockingProducerThe direct producer.Classorg.apache.camel.component.directvmApache Camel
DirectVmComponentThe Direct VM Component manages DirectVmEndpoint and holds the list of named direct-vm endpoints.Classorg.apache.camel.component.directvmApache Camel
DirectVmConsumerClassorg.apache.camel.component.directvmApache Camel
DirectVmConsumerExpressionThe expression to select direct-vm consumers based on ant-like path pattern matching.Classorg.apache.camel.component.directvmApache Camel
DirectVmConsumerNotAvailableExceptionException thrown when no consumers are available.Classorg.apache.camel.component.directvmApache Camel
DirectVmEndpointThe direct-vm endpoint.Classorg.apache.camel.component.directvmApache Camel
DirectVmProcessorClassorg.apache.camel.component.directvmApache Camel
DirectVmProducerClassorg.apache.camel.component.directvmApache Camel
DistributionRatioClassorg.apache.camel.processor.loadbalancerApache Camel
DoCatchRouteNodeRouteNode representing do catch.Classorg.apache.camel.implApache Camel
DoFinallyRouteNodeRouteNode representing do finally.Classorg.apache.camel.implApache Camel
DomConverterClassorg.apache.camel.converter.jaxpApache Camel
DomResultHandlerClassorg.apache.camel.builder.xmlApache Camel
DomResultHandlerFactoryClassorg.apache.camel.builder.xmlApache Camel
DoubleQuoteEndClassorg.apache.camel.language.simple.astApache Camel
DoubleQuoteStartClassorg.apache.camel.language.simple.astApache Camel
DynamicRouterIndicates that this method is to be used as a Dynamic Router routing the incoming messageClassorg.apache.camelApache Camel
DynamicRouter where the destination(s) is computed at runtime.Classorg.apache.camel.processorApache Camel
DynamicRouterDefinitionClassorg.apache.camel.modelApache Camel
ELExpressionClassorg.apache.camel.model.languageApache Camel
EmptyProducerCacheA ProducerCache which is always empty and does not cache any Producers.Classorg.apache.camel.implApache Camel
Endpoint implements the Message Endpoint pattern and represents an endpoint that can send and receiveInterfaceorg.apache.camelApache Camel
EndpointAwareInterfaceorg.apache.camelApache Camel
EndpointCompleterA helper interface used by the ComponentConfiguration.Interfaceorg.apache.camel.spiApache Camel
EndpointConfigurationHolds an Endpoint configuration as a pojo that can be manipulated and validated.Interfaceorg.apache.camelApache Camel
EndpointConfiguration .UriFormatDataFormat operations.Classorg.apache.camel.EndpointConfigurationApache Camel
EndpointHelperClassorg.apache.camel.utilApache Camel
EndpointInjectUsed to indicate an injection point of an Endpoint, Producer or ProducerTemplate into a POJO.Classorg.apache.camelApache Camel
EndpointRegistryRegistry to cache endpoints in memory.Interfaceorg.apache.camel.spiApache Camel
EndpointRequiredDefinitionInterfaceorg.apache.camel.modelApache Camel
EndpointStrategyEndpoint strategy with callback invoked when an Endpoint is about to be registered to the endpoint registry in CamelContext.Interfaceorg.apache.camel.spiApache Camel
EnrichDefinitionClassorg.apache.camel.modelApache Camel
EnricherA content enricher that enriches input data by first obtaining additional data from a resource represented by an endpoint producerClassorg.apache.camel.processorApache Camel
EnumTypeConverterClassorg.apache.camel.impl.converterApache Camel
EnvPropertiesFunctionA PropertiesFunction that lookup the property value from OS environment variables.Classorg.apache.camel.component.propertiesApache Camel
ErrorHandlerBuilderInterfaceorg.apache.camel.builderApache Camel
ErrorHandlerBuilderRefClassorg.apache.camel.builderApache Camel
ErrorHandlerBuilderSupportBase class for builders of error handling.Classorg.apache.camel.builderApache Camel
ErrorHandlerFactoryFactory for creating ErrorHandlers.Interfaceorg.apache.camelApache Camel
ErrorHandlerSupportSupport class for ErrorHandler implementations.Classorg.apache.camel.processorApache Camel
EvaluateExpressionProcessorA Processor which evaluates an Expression and stores the result as a property on the Exchange with the keyClassorg.apache.camel.processorApache Camel
EventDrivenConsumerRouteA DefaultRoute which starts with an Event Driven ConsumerClassorg.apache.camel.implApache Camel
EventDrivenPollingConsumerA default implementation of the PollingConsumer which uses the normal asynchronous consumer mechanism along with a BlockingQueue to allowClassorg.apache.camel.implApache Camel
EventFactoryFactory to create events that are emitted when such an event occur.Interfaceorg.apache.camel.spiApache Camel
EventHelperClassorg.apache.camel.utilApache Camel
EventNotifierNotifier to send events.Interfaceorg.apache.camel.spiApache Camel
EventNotifierSupportClassorg.apache.camel.managementApache Camel
EventNotifierSupportBase class to extend for custom EventNotifier implementations.Classorg.apache.camel.supportApache Camel
ExceptionHandlerA Strategy pattern for handling exceptions; particularly in asynchronous processes such as consumers.Interfaceorg.apache.camel.spiApache Camel
ExceptionPolicyKeyException policy key is a compound key for storing: route id + exception class + when => exception type.Classorg.apache.camel.processor.exceptionpolicyApache Camel
ExceptionPolicyStrategyA strategy to determine which OnExceptionDefinition should handle the thrownSee Also:DefaultExceptionPolicyInterfaceorg.apache.camel.processor.exceptionpolicyApache Camel
ExchangeAn Exchange is the message container holding the information during the entire routing of a Message received by a Consumer.Interfaceorg.apache.camelApache Camel
ExchangeBuilderBuilder to create Exchange and add headers and set body on the Exchange Message.Classorg.apache.camel.builderApache Camel
ExchangeCompletedEventClassorg.apache.camel.management.eventApache Camel
ExchangeCreatedEventEvent after an Exchange has been created.Classorg.apache.camel.management.eventApache Camel
ExchangeFailedEventClassorg.apache.camel.management.eventApache Camel
ExchangeFailureHandledEventClassorg.apache.camel.management.eventApache Camel
ExchangeFormatterA plugin used to turn an Exchange into a String representation usually to be used for logging or tracing purposes.Interfaceorg.apache.camel.spiApache Camel
ExchangeHelperClassorg.apache.camel.utilApache Camel
ExchangeIdempotentRepositoryAccess to a repository of Message IDs to implement the Idempotent Consumer pattern.Interfaceorg.apache.camel.spiApache Camel
ExchangePatternenum ExchangePatternRepresents the kind of message exchange patternClassorg.apache.camelApache Camel
ExchangePatternProcessorProcessor to set ExchangePattern on the Exchange.Classorg.apache.camel.processorApache Camel
ExchangePropertyMarks a parameter as being an injection point of a property of an ExchangeVersion:See Also:Exchange.Classorg.apache.camelApache Camel
ExchangePropertyExpressionClassorg.apache.camel.model.languageApache Camel
ExchangePropertyLanguageA language for exchange property expressions.Classorg.apache.camel.language.propertyApache Camel
ExchangeRedeliveryEventClassorg.apache.camel.management.eventApache Camel
ExchangeSendingEventEvent for before sending an Exchange to an Endpoint.Classorg.apache.camel.management.eventApache Camel
ExchangeSentEventEvent for after an Exchange has been sent to an Endpoint.Classorg.apache.camel.management.eventApache Camel
ExchangeTimedOutExceptionAn exception thrown if an InOut exchange times out receiving the OUT messageVersion:See Also:Serialized FormClassorg.apache.camelApache Camel
ExecutorServiceAwareIs used for easy configuration of ExecutorService.Interfaceorg.apache.camelApache Camel
ExecutorServiceAwareDefinitionInterfaceorg.apache.camel.modelApache Camel
ExecutorServiceManagerStrategy to create thread pools.Interfaceorg.apache.camel.spiApache Camel
ExecutorServiceStrategyStrategy to create thread pools.Interfaceorg.apache.camel.spiApache Camel
ExpectedBodyTypeExceptionThrown if the body could not be converted to the required typeVersion:See Also:Serialized FormClassorg.apache.camelApache Camel
ExplicitCamelContextNameStrategyStrategy to used an explicit (fixed) name for CamelContext.Classorg.apache.camel.implApache Camel
Expression provides a plugin strategy for evaluating expressions on a message exchange to support things like scripting languages,Interfaceorg.apache.camelApache Camel
ExpressionAdapterClassorg.apache.camel.implApache Camel
ExpressionAdapterA helper class for developers wishing to implement an Expression using Java code with a minimum amount of code to write so that the developer only needsClassorg.apache.camel.supportApache Camel
ExpressionBuilderA helper class for working with expressions.Classorg.apache.camel.builderApache Camel
ExpressionClauseRepresents an expression clause within the DSL which when the expression is complete the clause continues to another part of the DSLClassorg.apache.camel.builderApache Camel
ExpressionClauseSupportA support class for building expression clauses.Classorg.apache.camel.builderApache Camel
ExpressionComparatorAn implementation of Comparator that takes an Expression which is evaluated on each exchange to be comparedClassorg.apache.camel.utilApache Camel
ExpressionDefinitionClassorg.apache.camel.model.languageApache Camel
ExpressionEvaluationExceptionAn exception thrown if evaluation of the expression failed.Classorg.apache.camelApache Camel
ExpressionIllegalSyntaxExceptionAn exception thrown if the expression contains illegal syntax.Classorg.apache.camelApache Camel
ExpressionListComparatorAn implementation of Comparator which takes a list of Expression objects which is evaluatedClassorg.apache.camel.utilApache Camel
ExpressionNodeClassorg.apache.camel.modelApache Camel
ExpressionNodeHelperClassorg.apache.camel.modelApache Camel
ExpressionResultComparatorA SequenceElementComparator that compares Exchanges based on the result of an expression evaluation.Interfaceorg.apache.camel.processor.resequencerApache Camel
ExpressionSubElementDefinitionClassorg.apache.camel.modelApache Camel
ExpressionSupportClassorg.apache.camel.implApache Camel
ExpressionSupportClassorg.apache.camel.supportApache Camel
ExpressionToPredicateAdapterClassorg.apache.camel.utilApache Camel
FactoryFinderFinder to find factories from the resource classpath, usually META-INF/services/org/apache/camel/.Interfaceorg.apache.camel.spiApache Camel
FactoryFinderResolverInterfaceorg.apache.camel.spiApache Camel
FailedToCreateConsumerExceptionThrown if Camel failed to create a consumer for a given endpoint.Classorg.apache.camelApache Camel
FailedToCreateProducerExceptionThrown if Camel failed to create a producer for a given endpoint.Classorg.apache.camelApache Camel
FailedToCreateRouteExceptionException when failing to create a Route.Classorg.apache.camelApache Camel
FailedToStartRouteExceptionException when failing to start a Route.Classorg.apache.camelApache Camel
FailOverLoadBalancerThis FailOverLoadBalancer will failover to use next processor when an exception occurred This implementation mirrors the logic from the Pipeline in the async variationClassorg.apache.camel.processor.loadbalancerApache Camel
FailoverLoadBalancerDefinitionFailover load balancer The failover load balancer is capable of trying the next processor in case an Exchange failed with an exception during processing.Classorg.apache.camel.model.loadbalancerApache Camel
FallbackConverterAn annotation used to mark methods to indicate code capable of being a fallback converter which are then auto-discovered usingClassorg.apache.camelApache Camel
FatalFallbackErrorHandlerAn ErrorHandler used as a safe fallback when processing by other error handlers such as the OnExceptionDefinition.Classorg.apache.camel.processorApache Camel
FileBindingFile binding with the File type.Classorg.apache.camel.component.fileApache Camel
FileChangedExclusiveReadLockStrategyAcquires exclusive read lock to the given file by checking whether the file is being changed by scanning the file at different intervals (to detect changes).Classorg.apache.camel.component.file.strategyApache Camel
FileComponent* The File Component provides access to file systems.Classorg.apache.camel.component.fileApache Camel
FileConsumerClassorg.apache.camel.component.fileApache Camel
FileEndpointClassorg.apache.camel.component.fileApache Camel
FileIdempotentRepositoryA file based implementation of IdempotentRepository.Classorg.apache.camel.processor.idempotentApache Camel
FileInputStreamCacheClassorg.apache.camel.converter.streamApache Camel
FileLanguageClassorg.apache.camel.language.simpleApache Camel
FileLockExclusiveReadLockStrategyAcquires exclusive read lock to the given file.Classorg.apache.camel.component.file.strategyApache Camel
FileOperationsFile operations for File.Classorg.apache.camel.component.fileApache Camel
FilePathResolverA resolver for file paths that supports resolving with system and environment properties.Classorg.apache.camel.utilApache Camel
FileProcessStrategyFactoryClassorg.apache.camel.component.file.strategyApache Camel
FileRenameExclusiveReadLockStrategyAcquires exclusive read lock to the given file.Classorg.apache.camel.component.file.strategyApache Camel
FileResultHandlerUse file to handle the result of XSLT transformation.Classorg.apache.camel.builder.xmlApache Camel
FileResultHandlerFactoryFactory for StreamResult which is streamed to file.Classorg.apache.camel.builder.xmlApache Camel
FileUtilClassorg.apache.camel.utilApache Camel
FilterDefinitionClassorg.apache.camel.modelApache Camel
FilterParametersRepresents a set of regular expression based filter patterns for including and excluding content of some type.Classorg.apache.camel.util.jsseApache Camel
FilterParameters .PatternsAn immutable collection of compiled includes and excludes filter Patterns.Classorg.apache.camel.util.jsse.FilterParametersApache Camel
FilterProcessorThe processor which implements the Message Filter EIP pattern.Classorg.apache.camel.processorApache Camel
FinallyDefinitionClassorg.apache.camel.modelApache Camel
FinallyProcessorClassorg.apache.camel.processorApache Camel
FlatpackDataFormatClassorg.apache.camel.model.dataformatApache Camel
FlexibleAggregationStrategyThe Flexible Aggregation Strategy is a highly customizable, fluently configurable aggregation strategy.Classorg.apache.camel.util.toolboxApache Camel
FlexibleAggregationStrategy .TimeoutAwareMixinInterfaceorg.apache.camel.util.toolbox.FlexibleAggregationStrategyApache Camel
FromDefinitionClassorg.apache.camel.modelApache Camel
FutureTypeConverterFuture type converter.Classorg.apache.camel.impl.converterApache Camel
GenericFileGeneric File.Classorg.apache.camel.component.fileApache Camel
GenericFileBindingBinding between the generic file and the body content.Interfaceorg.apache.camel.component.fileApache Camel
GenericFileComponentBase class file component.Classorg.apache.camel.component.fileApache Camel
GenericFileConfigurationClassorg.apache.camel.component.fileApache Camel
GenericFileConsumerBase class for file consumers.Classorg.apache.camel.component.fileApache Camel
GenericFileConverterClassorg.apache.camel.component.fileApache Camel
GenericFileDefaultBindingDefault binding for generic file.Classorg.apache.camel.component.fileApache Camel
GenericFileDefaultSorterDefault file sorter.Classorg.apache.camel.component.fileApache Camel
GenericFileDeleteProcessStrategyClassorg.apache.camel.component.file.strategyApache Camel
GenericFileEndpointClassorg.apache.camel.component.fileApache Camel
GenericFileExclusiveReadLockStrategyStrategy for acquiring exclusive read locks for files to be consumed.Interfaceorg.apache.camel.component.fileApache Camel
GenericFileExistenum GenericFileExistRepresent the kinds of options when writing a file and what to do in case of an existing file exists.Classorg.apache.camel.component.fileApache Camel
GenericFileExpressionRenamerClassorg.apache.camel.component.file.strategyApache Camel
GenericFileFilterA filter for GenericFile.Interfaceorg.apache.camel.component.fileApache Camel
GenericFileMessageClassorg.apache.camel.component.fileApache Camel
GenericFileNoOpProcessStrategyClassorg.apache.camel.component.file.strategyApache Camel
GenericFileOnCompletionOn completion strategy that performs the required work after the Exchange has been processed.Classorg.apache.camel.component.fileApache Camel
GenericFileOperationFailedExceptionException thrown in case of last file operation failed.Classorg.apache.camel.component.fileApache Camel
GenericFileOperationsInterfaceorg.apache.camel.component.fileApache Camel
GenericFileProcessStrategyRepresents a pluggable strategy when processing files.Interfaceorg.apache.camel.component.fileApache Camel
GenericFileProcessStrategyFactoryClassorg.apache.camel.component.file.strategyApache Camel
GenericFileProcessStrategySupportBase class for implementations of GenericFileProcessStrategy.Classorg.apache.camel.component.file.strategyApache Camel
GenericFileProducerClassorg.apache.camel.component.fileApache Camel
GenericFileRenameExclusiveReadLockStrategyAcquires exclusive read lock to the given file.Classorg.apache.camel.component.file.strategyApache Camel
GenericFileRenameProcessStrategyClassorg.apache.camel.component.file.strategyApache Camel
GenericFileRenamerUsed for renaming files.Interfaceorg.apache.camel.component.file.strategyApache Camel
GetVerbDefinitionClassorg.apache.camel.model.restApache Camel
GraphGeneratorSupportClassorg.apache.camel.viewApache Camel
GraphSupportClassorg.apache.camel.viewApache Camel
GroovyExpressionClassorg.apache.camel.model.languageApache Camel
GroupedExchangeAggregationStrategyAggregate all exchanges into a single combined Exchange holding all the aggregated exchanges in a List of Exchange as the message body.Classorg.apache.camel.processor.aggregateApache Camel
GroupIteratorGroup based Iterator which groups the given Iterator a number of times and then return a combined response as a String.Classorg.apache.camel.utilApache Camel
GzipDataFormatGZip DataFormat for reading/writing data using gzip.Classorg.apache.camel.implApache Camel
GzipDataFormatClassorg.apache.camel.model.dataformatApache Camel
GZIPHelperHelper class to help wrapping content into GZIP input and output streams.Classorg.apache.camel.utilApache Camel
HandleFaultClassorg.apache.camel.processor.interceptorApache Camel
HandleFaultInterceptorClassorg.apache.camel.processor.interceptorApache Camel
HasAnnotationUsed to indicate that the actual type of a parameter on a converter method must have the given annotation class to be applicable.Classorg.apache.camel.converterApache Camel
HasBindingAllows objects such as Endpoints to expose that they have a For example bean or cxf endpoints can expose the internal binding metadata at runtimeInterfaceorg.apache.camel.spiApache Camel
HasIdA simple marker interface for an object which has a unique ID which is useful for referring to objects in REST or JMX style APIsInterfaceorg.apache.camel.spiApache Camel
HeaderExpressionClassorg.apache.camel.model.languageApache Camel
HeaderFilterStrategyInterface to allow plug-able implementation to filter header to and from Camel message.Interfaceorg.apache.camel.spiApache Camel
HeaderFilterStrategy .DirectionThe direction is either IN or OUT.Classorg.apache.camel.spi.HeaderFilterStrategyApache Camel
HeaderFilterStrategyAwareAn interface to represent an object which can make use of injected HeaderFilterStrategy.Interfaceorg.apache.camel.spiApache Camel
HeaderFilterStrategyComponentBase class for components to support configuring a HeaderFilterStrategy.Classorg.apache.camel.implApache Camel
HeaderLanguageA language for header expressions.Classorg.apache.camel.language.headerApache Camel
HeadVerbDefinitionClassorg.apache.camel.model.restApache Camel
HL7DataFormatClassorg.apache.camel.model.dataformatApache Camel
HostUtilsClassorg.apache.camel.utilApache Camel
IcalDataFormatClassorg.apache.camel.model.dataformatApache Camel
IdempotentConsumerAn implementation of the Idempotent Consumer pattern.Classorg.apache.camel.processor.idempotentApache Camel
IdempotentConsumerDefinitionClassorg.apache.camel.modelApache Camel
IdempotentOnCompletionOn completion strategy for IdempotentConsumer.Classorg.apache.camel.processor.idempotentApache Camel
IdempotentRepositoryAccess to a repository of Message IDs to implement the Idempotent Consumer pattern.Interfaceorg.apache.camel.spiApache Camel
IdentifiedTypeThe unique identifier for a bean.Classorg.apache.camel.modelApache Camel
InetAddressUtilClassorg.apache.camel.utilApache Camel
InflightRepositoryA repository which tracks in flight Exchanges.Interfaceorg.apache.camel.spiApache Camel
InflightRepository .InflightExchangeInformation about the inflight exchange.Interfaceorg.apache.camel.spi.InflightRepositoryApache Camel
InjectorA pluggable strategy for creating and possibly dependency injecting objects which could be implemented using straight forward reflection or using SpringInterfaceorg.apache.camel.spiApache Camel
InOnlyMarks methods as being ExchangePattern.Classorg.apache.camelApache Camel
InOnlyDefinitionClassorg.apache.camel.modelApache Camel
InOutMarks a method as being ExchangePattern.Classorg.apache.camelApache Camel
InOutDefinitionClassorg.apache.camel.modelApache Camel
InputStreamCacheA StreamCache for caching using an in-memory byte array.Classorg.apache.camel.converter.streamApache Camel
InstanceMethodFallbackTypeConverterA TypeConverter implementation which instantiates an object so that an instance method can be used as a fallback type converterClassorg.apache.camel.impl.converterApache Camel
InstanceMethodTypeConverterA TypeConverter implementation which instantiates an object so that an instance method can be used as a type converterClassorg.apache.camel.impl.converterApache Camel
InstrumentationInterceptStrategyThis strategy class wraps targeted processors with a InstrumentationProcessor.Classorg.apache.camel.managementApache Camel
InstrumentationProcessorJMX enabled processor that uses the ManagedCounter for instrumenting processing of exchanges.Classorg.apache.camel.managementApache Camel
InterceptDefinitionClassorg.apache.camel.modelApache Camel
InterceptEndpointProcessorEndpoint intercept processor so we know the processor is supposed to intercept an endpoint.Classorg.apache.camel.processorApache Camel
InterceptFromDefinitionClassorg.apache.camel.modelApache Camel
InterceptorToAsyncProcessorBridgeA bridge to have regular interceptors implemented as Processor work with the asynchronous routing engine without causing side effects.Classorg.apache.camel.processorApache Camel
InterceptSendToEndpointClassorg.apache.camel.implApache Camel
InterceptSendToEndpointDefinitionClassorg.apache.camel.modelApache Camel
InterceptSendToMockEndpointStrategyA EndpointStrategy which is capable of mocking endpoints.Classorg.apache.camel.implApache Camel
InterceptStrategyThe purpose of this interface is to allow an implementation to wrap processors in a route with interceptors.Interfaceorg.apache.camel.spiApache Camel
IntrospectionSupportHelper for introspections of beans.Classorg.apache.camel.utilApache Camel
IntrospectionSupport .ClassInfoStructure of an introspected class.Classorg.apache.camel.util.IntrospectionSupportApache Camel
IntrospectionSupport .MethodInfoStructure of an introspected method.Classorg.apache.camel.util.IntrospectionSupportApache Camel
InvalidPayloadExceptionIs thrown if the payload from the exchange could not be retrieved because of being null, wrong class type etc.Classorg.apache.camelApache Camel
InvalidPayloadRuntimeExceptionRuntime version of the InvalidPayloadException.Classorg.apache.camelApache Camel
InvalidPropertyExceptionAn exception caused when an invalid property name is used on an objectSee Also:Serialized FormClassorg.apache.camelApache Camel
InvalidXPathExpressionAn exception thrown if am XPath expression could not be parsed or evaluatedVersion:See Also:Serialized FormClassorg.apache.camel.builder.xmlApache Camel
InvertingPackageScanFilterPackage scan filter for inverting the match result of a subfilter.Classorg.apache.camel.impl.scanApache Camel
IOConverterSome core java.Classorg.apache.camel.converterApache Camel
IOHelperClassorg.apache.camel.utilApache Camel
IsSingletonUsed for defining if a given class is singleton or not.Interfaceorg.apache.camelApache Camel
JavaScriptExpressionClassorg.apache.camel.model.languageApache Camel
JavaUuidGeneratorThis implementation uses the UUID from Java.Classorg.apache.camel.implApache Camel
JaxbDataFormatClassorg.apache.camel.model.dataformatApache Camel
JibxDataFormatClassorg.apache.camel.model.dataformatApache Camel
JmxNotificationBroadcasterAwareStrategy to use a custom NotificationBroadcasterSupport when broadcasting JMX notifications using for example the JmxNotificationEventNotifier.Interfaceorg.apache.camel.api.managementApache Camel
JmxNotificationEventNotifierA JMX based EventNotifier which broadcasts JMX Notifications.Classorg.apache.camel.managementApache Camel
JMXNotificationTraceEventHandlerClassorg.apache.camel.management.mbeanApache Camel
JmxSystemPropertyKeysThis module contains jmx related system property key constants.Classorg.apache.camel.managementApache Camel
JndiContextA default JNDI contextVersion:See Also:Serialized FormClassorg.apache.camel.util.jndiApache Camel
JndiRegistryClassorg.apache.camel.implApache Camel
JsonDataFormatClassorg.apache.camel.model.dataformatApache Camel
JsonLibraryRepresents the concrete Json libraries Camel supports.Classorg.apache.camel.model.dataformatApache Camel
JsonPathExpressionClassorg.apache.camel.model.languageApache Camel
JsonSchemaHelperA helper class for JSON schema.Classorg.apache.camel.utilApache Camel
JsseParametersBase class that provides optional integration with core Camel capabilities.Classorg.apache.camel.util.jsseApache Camel
JXPathExpressionClassorg.apache.camel.model.languageApache Camel
KeyManagersParametersA representation of configuration options for creating and loading KeyManager instance(s).Classorg.apache.camel.util.jsseApache Camel
KeyStoreParametersClassorg.apache.camel.util.jsseApache Camel
KeyValueHolderHolder for a key and value.Classorg.apache.camel.utilApache Camel
LanguageInterfaceorg.apache.camel.spiApache Camel
LanguageAnnotationBase annotation for languages.Classorg.apache.camel.languageApache Camel
LanguageComponentThe Language component enables sending Exchanges to a given language in order to have a script executed.Classorg.apache.camel.component.languageApache Camel
LanguageEndpointClassorg.apache.camel.component.languageApache Camel
LanguageExpressionBase annotation for language expressions.Classorg.apache.camel.languageApache Camel
LanguageExpressionRepresents a parameterised language expression which can support any language at runtime using the language attribute.Classorg.apache.camel.model.languageApache Camel
LanguageProducerClassorg.apache.camel.component.languageApache Camel
LanguageResolverInterfaceorg.apache.camel.spiApache Camel
LanguageSupportBase language for Language implementations.Classorg.apache.camel.supportApache Camel
LazyLoadingTypeConverterLazy implementation of a type converter registry used for type converters in Camel.Classorg.apache.camel.impl.converterApache Camel
LifecycleStrategyStrategy for lifecycle notifications.Interfaceorg.apache.camel.spiApache Camel
LifecycleStrategySupportA useful base class for LifecycleStrategy implementations.Classorg.apache.camel.supportApache Camel
LimitedPollingConsumerPollStrategyA PollingConsumerPollStrategy which supports suspending consumers if they failed for X number of times in a row.Classorg.apache.camel.implApache Camel
LinkedBlockingQueueFactoryClassorg.apache.camel.component.sedaApache Camel
LiteralExpressionRepresents literals in the AST.Classorg.apache.camel.language.simple.astApache Camel
LiteralNodeInterfaceorg.apache.camel.language.simple.astApache Camel
LoadBalanceDefinitionClassorg.apache.camel.modelApache Camel
LoadBalancerInterfaceorg.apache.camel.processor.loadbalancerApache Camel
LoadBalancerConsumerRepresents a consumer which on starting registers itself with a LoadBalancer and on closing unregisters itself with a load balancerClassorg.apache.camel.processor.loadbalancerApache Camel
LoadBalancerDefinitionClassorg.apache.camel.modelApache Camel
LoadBalancerSupportA default base class for a LoadBalancer implementation.Classorg.apache.camel.processor.loadbalancerApache Camel
LoadPropertiesExceptionRepresents a failure to open a Properties file at a given URLSee Also:Serialized FormClassorg.apache.camel.utilApache Camel
LoadTripletHolds the loads averaged over 1min, 5min, and 15min.Classorg.apache.camel.management.mbeanApache Camel
LogComponent is for logging message exchanges via the underlying logging mechanism.Classorg.apache.camel.component.logApache Camel
LogDefinitionClassorg.apache.camel.modelApache Camel
LogEndpointClassorg.apache.camel.component.logApache Camel
LoggingErrorHandlerClassorg.apache.camel.processorApache Camel
LoggingErrorHandlerBuilderUses the Logger as an error handler, will log at ERROR level by default.Classorg.apache.camel.builderApache Camel
LoggingEventNotifierLogging event notifier that only notifies if INFO log level has been configured for its logger.Classorg.apache.camel.managementApache Camel
LoggingExceptionHandlerClassorg.apache.camel.implApache Camel
LoggingExceptionHandlerA default implementation of ExceptionHandler which uses a CamelLogger to This implementation will by default log the exception with stack trace at WARN level.Classorg.apache.camel.supportApache Camel
LoggingLevelUsed to configure the logging levelsEnum Constant SummaryClassorg.apache.camelApache Camel
LogicalExpressionClassorg.apache.camel.language.simple.astApache Camel
LogicalOperatorTypeenum LogicalOperatorTypeTypes of logical operators supportedClassorg.apache.camel.language.simple.typesApache Camel
LogProcessorA processor which evaluates an Expression and logs it.Classorg.apache.camel.processorApache Camel
LogProducerClassorg.apache.camel.component.logApache Camel
LoopDefinitionClassorg.apache.camel.modelApache Camel
LoopProcessorThe processor which sends messages in a loop.Classorg.apache.camel.processorApache Camel
LRUCacheA Least Recently Used Cache.Classorg.apache.camel.utilApache Camel
LRUSoftCacheA Least Recently Used Cache which uses SoftReference.Classorg.apache.camel.utilApache Camel
LRUWeakCacheA Least Recently Used Cache which uses WeakReference.Classorg.apache.camel.utilApache Camel
MainClassorg.apache.camelApache Camel
MainClassorg.apache.camel.mainApache Camel
MainSupportClassorg.apache.camel.implApache Camel
MainSupportBase class for main implementations to allow starting up a JVM with Camel embedded.Classorg.apache.camel.mainApache Camel
ManagedAsyncProcessorAwaitManagerClassorg.apache.camel.management.mbeanApache Camel
ManagedAsyncProcessorAwaitManagerMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedAttributeA method level annotation to mark the method as being a JMX attribute.Classorg.apache.camel.api.managementApache Camel
ManagedBacklogDebuggerClassorg.apache.camel.management.mbeanApache Camel
ManagedBacklogDebuggerMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedBacklogTracerClassorg.apache.camel.management.mbeanApache Camel
ManagedBacklogTracerMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedBeanProcessorClassorg.apache.camel.management.mbeanApache Camel
ManagedBrowsableEndpointClassorg.apache.camel.management.mbeanApache Camel
ManagedBrowsableEndpointMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedCamelContextClassorg.apache.camel.management.mbeanApache Camel
ManagedCamelContextMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedComponentClassorg.apache.camel.management.mbeanApache Camel
ManagedComponentMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedConsumerClassorg.apache.camel.management.mbeanApache Camel
ManagedConsumerCacheClassorg.apache.camel.management.mbeanApache Camel
ManagedConsumerCacheMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedConsumerMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedCounterClassorg.apache.camel.management.mbeanApache Camel
ManagedCounterMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedDelayerClassorg.apache.camel.management.mbeanApache Camel
ManagedDelayerMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedEndpointClassorg.apache.camel.management.mbeanApache Camel
ManagedEndpointMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedEndpointRegistryClassorg.apache.camel.management.mbeanApache Camel
ManagedEndpointRegistryMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedErrorHandlerClassorg.apache.camel.management.mbeanApache Camel
ManagedErrorHandlerMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedEventNotifierClassorg.apache.camel.management.mbeanApache Camel
ManagedEventNotifierMBeanInterfaceorg.apache.camel.management.mbeanApache Camel
ManagedIdempotentConsumerClassorg.apache.camel.management.mbeanApache Camel
ManagedIdempotentConsumerMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedInflightRepositoryClassorg.apache.camel.management.mbeanApache Camel
ManagedInflightRepositoryMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedInstanceHolds the instance being managed.Interfaceorg.apache.camel.api.managementApache Camel
ManagedManagementStrategyA JMX capable ManagementStrategy that Camel by default uses if possible.Classorg.apache.camel.managementApache Camel
ManagedNotificationA class level annotation to define the mbean emits this JMX notificationRequired Element SummaryClassorg.apache.camel.api.managementApache Camel
ManagedOperationA method level annotation to mark the method as being a JMX operation.Classorg.apache.camel.api.managementApache Camel
ManagedPerformanceCounterClassorg.apache.camel.management.mbeanApache Camel
ManagedPerformanceCounterMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedProcessorClassorg.apache.camel.management.mbeanApache Camel
ManagedProcessorMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedProducerClassorg.apache.camel.management.mbeanApache Camel
ManagedProducerCacheClassorg.apache.camel.management.mbeanApache Camel
ManagedProducerCacheMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedProducerMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedResourceEndpointMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedRestRegistryClassorg.apache.camel.management.mbeanApache Camel
ManagedRestRegistryMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedRouteClassorg.apache.camel.management.mbeanApache Camel
ManagedRouteMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedRuntimeEndpointRegistryClassorg.apache.camel.management.mbeanApache Camel
ManagedRuntimeEndpointRegistryMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedScheduledPollConsumerClassorg.apache.camel.management.mbeanApache Camel
ManagedSchedulePollConsumerMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedSendProcessorClassorg.apache.camel.management.mbeanApache Camel
ManagedSendProcessorMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedServiceClassorg.apache.camel.management.mbeanApache Camel
ManagedServiceMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedStreamCachingStrategyClassorg.apache.camel.management.mbeanApache Camel
ManagedStreamCachingStrategyMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedSuspendableRouteClassorg.apache.camel.management.mbeanApache Camel
ManagedSuspendableRouteMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedThreadPoolClassorg.apache.camel.management.mbeanApache Camel
ManagedThreadPoolMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedThrottlerClassorg.apache.camel.management.mbeanApache Camel
ManagedThrottlerMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedThrottlingInflightRoutePolicyClassorg.apache.camel.management.mbeanApache Camel
ManagedThrottlingInflightRoutePolicyMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedThroughputLoggerClassorg.apache.camel.management.mbeanApache Camel
ManagedThroughputLoggerMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedTracerClassorg.apache.camel.management.mbeanApache Camel
ManagedTracerMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagedTypeConverterRegistryClassorg.apache.camel.management.mbeanApache Camel
ManagedTypeConverterRegistryMBeanInterfaceorg.apache.camel.api.management.mbeanApache Camel
ManagementAgentInterfaceorg.apache.camel.spiApache Camel
ManagementAwareAn interface to represent an object being managed.Interfaceorg.apache.camel.spiApache Camel
ManagementMBeanAssemblerAn assembler to assemble a RequiredModelMBean which can be used to register the object in JMX.Interfaceorg.apache.camel.spiApache Camel
ManagementNameStrategyStrategy for assigning the name part of the ObjectName for a managed CamelContext.Interfaceorg.apache.camel.spiApache Camel
ManagementNamingStrategyStrategy for computing ObjectName names for the various beans that Camel register for management.Interfaceorg.apache.camel.spiApache Camel
ManagementObjectStrategyStrategy for creating the managed object for the various beans Camel register for management.Interfaceorg.apache.camel.spiApache Camel
ManagementStatisticsLevelenum ManagementStatisticsLevelLevel of granularity for performance statistics enabledClassorg.apache.camelApache Camel
ManagementStrategyStrategy for management.Interfaceorg.apache.camel.spiApache Camel
ManagementStrategyFactoryClassorg.apache.camel.managementApache Camel
MappedEndpointConfigurationFallback implementation of EndpointConfiguration used by Components that did not yet define a configuration type.Classorg.apache.camel.implApache Camel
MarkerFileExclusiveReadLockStrategyAcquires read lock to the given file using a marker file so other Camel consumers wont acquire the same file.Classorg.apache.camel.component.file.strategyApache Camel
MarshalDefinitionClassorg.apache.camel.modelApache Camel
MarshalProcessorClassorg.apache.camel.processorApache Camel
MaskRequiredModelMBeanA RequiredModelMBean which allows us to intercept invoking operations on the MBean.Classorg.apache.camel.managementApache Camel
MBeanInfoAssemblerA Camel specific MBeanInfo assembler that reads the details from the ManagedResource, ManagedAttribute, ManagedOperation,Classorg.apache.camel.managementApache Camel
MDCUnitOfWorkThis unit of work supports MDC.Classorg.apache.camel.implApache Camel
MemoryAggregationRepositoryA memory based AggregationRepository which stores Exchanges in memory only.Classorg.apache.camel.processor.aggregateApache Camel
MemoryIdempotentRepositoryA memory based implementation of IdempotentRepository.Classorg.apache.camel.processor.idempotentApache Camel
Message represents an inbound or outbound message as part of an Exchange.Interfaceorg.apache.camelApache Camel
MessageDumpA model of a message dump from MessageHelper.Classorg.apache.camel.utilApache Camel
MessageDump .BodyA model of a message dump body.Classorg.apache.camel.util.MessageDumpApache Camel
MessageDump .HeaderA model of a message dump header.Classorg.apache.camel.util.MessageDumpApache Camel
MessageHelperSome helper methods when working with Message.Classorg.apache.camel.utilApache Camel
MessageHistoryRepresents the history of a Camel Message how it was routed by the Camel routing engine.Interfaceorg.apache.camelApache Camel
MessageRejectedExceptionAn exception thrown if message is rejected by the resequencerVersion:See Also:Serialized FormClassorg.apache.camel.processor.resequencerApache Camel
MessageSupportA base class for implementation inheritance providing the core Message body handling features but letting the derived class dealClassorg.apache.camel.implApache Camel
MessageVariableResolverA variable resolver for XPath expressions which support properties on the message, exchange as well as making system properties and environmentClassorg.apache.camel.builder.xmlApache Camel
MethodBeanRepresents a Serializable version of a MethodVersion:See Also:Serialized FormClassorg.apache.camel.component.beanApache Camel
MethodCallExpressionClassorg.apache.camel.model.languageApache Camel
MethodInfoInformation about a method to be used for invocation.Classorg.apache.camel.component.beanApache Camel
MethodInfoCacheRepresents a cache of MethodInfo objects to avoid the expense of introspection for each invocation of a method via a proxy.Classorg.apache.camel.component.beanApache Camel
MethodInvocationInformation used by Camel to perform method invocation.Interfaceorg.apache.camel.component.beanApache Camel
MethodNotFoundExceptionClassorg.apache.camel.component.beanApache Camel
MockComponentThe Mock Component provides mock endpoints for testing.Classorg.apache.camel.component.mockApache Camel
MockEndpointA Mock endpoint which provides a literate, fluent API for testing routes using a JMock style API.Classorg.apache.camel.component.mockApache Camel
ModelCamelContextInterfaceorg.apache.camel.modelApache Camel
ModelChannelInterfaceorg.apache.camel.modelApache Camel
ModelFileGeneratorClassorg.apache.camel.viewApache Camel
ModelHelperHelper for the Camel model classes.Classorg.apache.camel.modelApache Camel
ModelJAXBContextFactoryFactory to abstract the creation of the Model's JAXBContext.Interfaceorg.apache.camel.spiApache Camel
MulticastDefinitionRoutes the same message to multiple paths either sequentially or in parallel.Classorg.apache.camel.modelApache Camel
MulticastProcessor endpoints, each endpoint receiving a copy of the message exchange.Classorg.apache.camel.processorApache Camel
MultipleConsumersSupportEndpoint can optionally implement this interface to indicate whether or not it supports multiple consumers.Interfaceorg.apache.camelApache Camel
MvelExpressionClassorg.apache.camel.model.languageApache Camel
MyCurrencyClassorg.apache.camel.component.beanApache Camel
NamedNodeRepresents a node in the routes which is identified by an id.Interfaceorg.apache.camelApache Camel
NamespaceAwareRepresents an object which is aware of the namespaces in which its used such as XPath and XQuery type expressions so that the current namespace context can be injectedInterfaceorg.apache.camel.spiApache Camel
NamespaceAwareExpressionA useful base class for any expression which may be namespace or XML content aware such as XPathExpression or XQueryExpressionClassorg.apache.camel.model.languageApache Camel
NamespacesClassorg.apache.camel.builder.xmlApache Camel
Navigate returns a List of outputs of type T that can contain 0.Interfaceorg.apache.camelApache Camel
NIOConverterSome core java.Classorg.apache.camel.converterApache Camel
NodeDataClassorg.apache.camel.viewApache Camel
NodeIdFactoryFactory to generate unique ids for model nodes.Interfaceorg.apache.camel.spiApache Camel
NoErrorHandlerBuilderA builder to disable the use of an error handler so that any exceptions are thrown.Classorg.apache.camel.builderApache Camel
NoFactoryAvailableExceptionThrown if no factory resource is available for the given URIVersion:See Also:Serialized FormClassorg.apache.camelApache Camel
NoMessageIdExceptionAn exception thrown if no message ID could be found on a message which is to be used with the Idempotent Consumer pattern.Classorg.apache.camel.processor.idempotentApache Camel
NoOutputDefinitionBase class for definitions which does not support outputs.Classorg.apache.camel.modelApache Camel
NoOutputExpressionNodeAn ExpressionNode which does not support any outputs.Classorg.apache.camel.modelApache Camel
NoSuchBeanExceptionA runtime exception if a given bean could not be found in the RegistryVersion:See Also:Serialized FormClassorg.apache.camelApache Camel
NoSuchEndpointExceptionA runtime exception thrown if a routing processor such as a RecipientList is unable to resolve anClassorg.apache.camelApache Camel
NoSuchHeaderExceptionAn exception caused when a mandatory header is not available on a messageVersion:See Also:ExchangeHelper.Classorg.apache.camelApache Camel
NoSuchLanguageExceptionA runtime exception thrown if an attempt is made to resolve an unknown language definition.Classorg.apache.camelApache Camel
NoSuchPropertyExceptionAn exception caused when a mandatory property is not available on a messageVersion:See Also:ExchangeHelper.Classorg.apache.camelApache Camel
NotificationSenderInterfaceorg.apache.camel.api.managementApache Camel
NotificationSenderAdapterCan be used to broadcast JMX notifications.Classorg.apache.camel.managementApache Camel
NotificationSenderAwareInterfaceorg.apache.camel.api.managementApache Camel
NotifyBuilderA builder to build an expression based on EventNotifier notifications about Exchange being routed.Classorg.apache.camel.builderApache Camel
NoTypeConversionAvailableExceptionAn exception thrown if a value could not be converted to the required typeVersion:See Also:Serialized FormClassorg.apache.camelApache Camel
NoXmlBodyValidationExceptionAn exception found if no XML body is available on the inbound messageVersion:See Also:Serialized FormClassorg.apache.camel.processor.validationApache Camel
NoXmlHeaderValidationExceptionAn exception thrown if the XML header is not available on the inbound messageVersion:See Also:Serialized FormClassorg.apache.camel.processor.validationApache Camel
NullExpressionRepresents a null expression.Classorg.apache.camel.language.simple.astApache Camel
ObjectConverterSome core java.Classorg.apache.camel.converterApache Camel
ObjectHelperClassorg.apache.camel.utilApache Camel
OgnlExpressionClassorg.apache.camel.model.languageApache Camel
OgnlHelperHelper for Camel OGNL (Object-Graph Navigation Language) expressions.Classorg.apache.camel.utilApache Camel
OnCompletionDefinitionClassorg.apache.camel.modelApache Camel
OnCompletionModeenum OnCompletionModeEnum Constant SummaryClassorg.apache.camel.modelApache Camel
OnCompletionProcessorProcessor implementing onCompletion.Classorg.apache.camel.processorApache Camel
OnCompletionRouteNodeRouteNode representing onCompletion.Classorg.apache.camel.implApache Camel
OnExceptionDefinitionClassorg.apache.camel.modelApache Camel
OnExceptionRouteNodeRouteNode representing onException.Classorg.apache.camel.implApache Camel
OptimisticLockingAggregationRepositoryA specialized AggregationRepository which also supports optimistic locking.Interfaceorg.apache.camel.spiApache Camel
OptimisticLockingAggregationRepository .OptimisticLockingExceptionException used by an AggregationRepository to indicate that an optimistic update error has occurred and that the operation should be retried by the caller.Classorg.apache.camel.spi.OptimisticLockingAggregationRepositoryApache Camel
OptimisticLockingAwareAggregationStrategyA specialized AggregationStrategy which gets a callback when the aggregated Exchange fails to add in the OptimisticLockingAggregationRepository because ofInterfaceorg.apache.camel.processor.aggregateApache Camel
OptimisticLockRetryPolicyClass to control how failed optimistic locks are tried.Classorg.apache.camel.processor.aggregateApache Camel
OptimisticLockRetryPolicyDefinitionClassorg.apache.camel.modelApache Camel
OptionalIdentifiedDefinitionClassorg.apache.camel.modelApache Camel
OrderedInterface to be implemented by objects that should be orderable, such as with a Collection.Interfaceorg.apache.camelApache Camel
OrderedComparatorClassorg.apache.camel.utilApache Camel
OtherwiseDefinitionClassorg.apache.camel.modelApache Camel
OutputDefinitionClassorg.apache.camel.modelApache Camel
PackageHelperSome helper methods for working with Java packages and versioning.Classorg.apache.camel.utilApache Camel
PackageScanClassResolverA resolver that can find resources based on package scanning.Interfaceorg.apache.camel.spiApache Camel
PackageScanDefinitionClassorg.apache.camel.modelApache Camel
PackageScanFilterFilter that can be used with the PackageScanClassResolver resolver.Interfaceorg.apache.camel.spiApache Camel
ParameterBindingExceptionClassorg.apache.camel.component.beanApache Camel
ParameterConfigurationRepresents the configuration of a URI query parameter value to allow type conversion and better validation of the configuration of URIs and EndpointsClassorg.apache.camel.implApache Camel
ParameterInfoParameter information to be used for method invocation.Classorg.apache.camel.component.beanApache Camel
ParameterMappingStrategyInterfaceorg.apache.camel.component.beanApache Camel
PatternMarks a method as having a specific kind of ExchangePattern for use with Bean Integration orClassorg.apache.camelApache Camel
PerformanceCounterA counter that gathers performance metrics when an Exchange is routed in Camel.Interfaceorg.apache.camel.api.managementApache Camel
PGPDataFormatClassorg.apache.camel.model.dataformatApache Camel
PhpExpressionClassorg.apache.camel.model.languageApache Camel
PipelineCreates a Pipeline pattern where the output of the previous step is sent as input to the next step, reusing the same message exchangesClassorg.apache.camel.processorApache Camel
PipelineDefinitionRoutes the message to a sequence of processors.Classorg.apache.camel.modelApache Camel
PipelineHelperClassorg.apache.camel.processorApache Camel
PlatformHelperUtility dedicated for resolving runtime information related to the platform on which Camel is currently running.Classorg.apache.camel.utilApache Camel
PojoMessageInvocationHandlerSpecial InvocationHandler for methods that have only one parameter.Classorg.apache.camel.component.beanApache Camel
PojoProxyHelperCreate a dynamic proxy for a given interface and endpoint that sends the parameter object to the endpoint and optionally receives a reply.Classorg.apache.camel.component.beanApache Camel
PolicyA strategy capable of applying interceptors to a processor.Interfaceorg.apache.camel.spiApache Camel
PolicyDefinitionClassorg.apache.camel.modelApache Camel
PollEnrichDefinitionClassorg.apache.camel.modelApache Camel
PollEnricherA content enricher that enriches input data by first obtaining additional data from a resource represented by an endpoint producerClassorg.apache.camel.processorApache Camel
PollingConsumerRepresents a Polling Consumer where the caller polls for messages when it is ready.Interfaceorg.apache.camelApache Camel
PollingConsumerPollingStrategyStrategy that allows Consumers to influence the PollingConsumer.Interfaceorg.apache.camelApache Camel
PollingConsumerPollStrategyStrategy for a PollingConsumer when polling an Endpoint.Interfaceorg.apache.camel.spiApache Camel
PollingConsumerSupportClassorg.apache.camel.implApache Camel
PostVerbDefinitionClassorg.apache.camel.model.restApache Camel
PredicateEvaluates a binary predicate on the message exchange to support things like scriptingInterfaceorg.apache.camelApache Camel
PredicateAssertHelperA helper for doing Predicate assertions.Classorg.apache.camel.utilApache Camel
PredicateBuilderClassorg.apache.camel.builderApache Camel
PredicateToExpressionAdapterClassorg.apache.camel.utilApache Camel
PredicateValidatingProcessorA processor which validates the content of the inbound message body against a Predicate.Classorg.apache.camel.processor.validationApache Camel
PredicateValidationExceptionA predicate validation exception occurredVersion:See Also:Serialized FormClassorg.apache.camel.processor.validationApache Camel
PriorityBlockingQueueFactoryClassorg.apache.camel.component.sedaApache Camel
ProcessDefinitionCalls a Camel processor.Classorg.apache.camel.modelApache Camel
ProcessorA processor is used to implement the Event Driven ConsumerInterfaceorg.apache.camelApache Camel
ProcessorBuilderClassorg.apache.camel.builderApache Camel
ProcessorDefinitionBase class for processor types that most XML types extend.Classorg.apache.camel.modelApache Camel
ProcessorDefinitionHelperHelper class for ProcessorDefinition and the other model classes.Classorg.apache.camel.modelApache Camel
ProcessorEndpointAn endpoint which allows exchanges to be sent into it which just invokes a given Processor.Classorg.apache.camel.implApache Camel
ProcessorExchangePairExchange pair to be executed by MulticastProcessor.Interfaceorg.apache.camel.processorApache Camel
ProcessorFactoryA factory to create Processor based on the definition.Interfaceorg.apache.camel.spiApache Camel
ProcessorPollingConsumerA simple implementation of PollingConsumer which just uses a Processor.Classorg.apache.camel.implApache Camel
ProcessorStatDumpA model of a route stat dump from ManagedRouteMBean.Classorg.apache.camel.utilApache Camel
ProduceMarks a field or property as being a producer to an Endpoint either via its URI or via the name of the endpoint referenceClassorg.apache.camelApache Camel
ProducerInterfaceorg.apache.camelApache Camel
ProducerCacheCache containing created Producer.Classorg.apache.camel.implApache Camel
ProducerCallbackCallback for sending a exchange message to a endpoint using a producer.Interfaceorg.apache.camelApache Camel
ProducerTemplateTemplate for working with Camel and sending Message instances in an Exchange to an Endpoint.Interfaceorg.apache.camelApache Camel
PropertiesComponentClassorg.apache.camel.component.propertiesApache Camel
PropertiesDefinitionClassorg.apache.camel.modelApache Camel
PropertiesFunctionA function that is applied instead of looking up a property placeholder.Interfaceorg.apache.camel.component.propertiesApache Camel
PropertiesInterceptorIntercepts Property values used to invoke API Method.Interfaceorg.apache.camel.util.componentApache Camel
PropertiesParserInterfaceorg.apache.camel.component.propertiesApache Camel
PropertiesResolverA resolver to load properties from a given source such as a file from a classpath.Interfaceorg.apache.camel.component.propertiesApache Camel
PropertyMarks a parameter as being an injection point of a property of an ExchangeVersion:See Also:Exchange.Classorg.apache.camelApache Camel
PropertyDefinitionClassorg.apache.camel.modelApache Camel
PropertyEditorTypeConverterUses the PropertyEditor conversion system to convert Objects to and from String values.Classorg.apache.camel.impl.converterApache Camel
PropertyInjectUsed to indicate an injection point of a property placeholder into a POJO.Classorg.apache.camelApache Camel
PropertyNamesInterceptorIntercepts Property names used to find methods.Interfaceorg.apache.camel.util.componentApache Camel
PropertyPlaceholderDelegateRegistryA Registry which delegates to the real registry.Classorg.apache.camel.implApache Camel
ProtobufDataFormatClassorg.apache.camel.model.dataformatApache Camel
ProxyBuilderA build to create Camel proxies.Classorg.apache.camel.builderApache Camel
ProxyHelperClassorg.apache.camel.component.beanApache Camel
ProxyInstantiationExceptionException indicating a failure while trying to create a proxy of a given type and on a given endpointVersion:See Also:Serialized FormClassorg.apache.camelApache Camel
PublishEventNotifierA EventNotifier which publishes the EventObject to some This notifier is only enabled when CamelContext is started.Classorg.apache.camel.managementApache Camel
PutVerbDefinitionClassorg.apache.camel.model.restApache Camel
PythonExpressionClassorg.apache.camel.model.languageApache Camel
QueueLoadBalancerA base class for LoadBalancer implementations which choose a single destination for each exchange (rather like JMS Queues)Classorg.apache.camel.processor.loadbalancerApache Camel
QueueReferenceHolder for queue references.Classorg.apache.camel.component.sedaApache Camel
RandomLoadBalancerClassorg.apache.camel.processor.loadbalancerApache Camel
RandomLoadBalancerDefinitionRandom load balancer The random load balancer selects a random endpoint for each exchange.Classorg.apache.camel.model.loadbalancerApache Camel
ReaderCacheClassorg.apache.camel.converter.streamApache Camel
RecipientList pattern where the list of actual endpoints to send a message exchange to are dependent on some dynamic expression.Classorg.apache.camel.processorApache Camel
RecipientListIndicates that this method is to be used as a Dynamic Recipient List routing the incoming messageClassorg.apache.camelApache Camel
RecipientListDefinitionClassorg.apache.camel.modelApache Camel
RecipientListProcessor pattern where the list of actual endpoints to send a message exchange to are dependent on some dynamic expression.Classorg.apache.camel.processorApache Camel
RecoverableAggregationRepositoryA specialized AggregationRepository which also supports recovery.Interfaceorg.apache.camel.spiApache Camel
RedeliveryErrorHandlerBase redeliverable error handler that also supports a final dead letter queue in case all redelivery attempts fail.Classorg.apache.camel.processorApache Camel
RedeliveryPolicyThe policy used to decide how many times to redeliver and the time between the redeliveries before being sent to a Dead LetterClassorg.apache.camel.processorApache Camel
RedeliveryPolicyDefinitionClassorg.apache.camel.modelApache Camel
RefComponentThe Ref Component is for lookup of existing endpoints bound in the Registry.Classorg.apache.camel.component.refApache Camel
RefEndpointClassorg.apache.camel.component.refApache Camel
RefExpressionClassorg.apache.camel.model.languageApache Camel
RefLanguageA language for referred expressions.Classorg.apache.camel.language.refApache Camel
ReflectionHelperHelper for working with reflection on classes.Classorg.apache.camel.utilApache Camel
ReflectionHelper .FieldCallbackCallback interface invoked on each field in the hierarchy.Interfaceorg.apache.camel.util.ReflectionHelperApache Camel
ReflectionHelper .MethodCallbackAction to take on each method.Interfaceorg.apache.camel.util.ReflectionHelperApache Camel
ReflectionInjectorA simple implementation of Injector which just uses reflection to instantiate new objects using their zero argument constructor.Classorg.apache.camel.utilApache Camel
RegistryRepresents a service registry which may be implemented via a Spring ApplicationContext, via JNDI, a simple Map or the OSGi Service RegistryInterfaceorg.apache.camel.spiApache Camel
RegistryBeanClassorg.apache.camel.component.beanApache Camel
RejectableFutureTaskA Rejectable FutureTask used by RejectableThreadPoolExecutor.Classorg.apache.camel.util.concurrentApache Camel
RejectableScheduledThreadPoolExecutorScheduled thread pool executor that creates RejectableFutureTask instead of FutureTask when registering new tasks for execution.Classorg.apache.camel.util.concurrentApache Camel
RejectableThreadPoolExecutorThread pool executor that creates RejectableFutureTask instead of FutureTask when registering new tasks for execution.Classorg.apache.camel.util.concurrentApache Camel
RemoveHeaderDefinitionClassorg.apache.camel.modelApache Camel
RemoveHeaderProcessorClassorg.apache.camel.processorApache Camel
RemoveHeadersDefinitionClassorg.apache.camel.modelApache Camel
RemoveHeadersProcessorClassorg.apache.camel.processorApache Camel
RemovePropertiesDefinitionClassorg.apache.camel.modelApache Camel
RemovePropertiesProcessorClassorg.apache.camel.processorApache Camel
RemovePropertyDefinitionClassorg.apache.camel.modelApache Camel
RemovePropertyProcessorClassorg.apache.camel.processorApache Camel
ResequenceDefinitionClassorg.apache.camel.modelApache Camel
ResequencerAn implementation of the Resequencer which can reorder messages within a batch.Classorg.apache.camel.processorApache Camel
ResequencerConfigClassorg.apache.camel.model.configApache Camel
ResequencerEngineResequences elements based on a given SequenceElementComparator.Classorg.apache.camel.processor.resequencerApache Camel
ResolveEndpointFailedExceptionA runtime exception thrown if an Endpoint cannot be resolved via URIVersion:See Also:Serialized FormClassorg.apache.camelApache Camel
ResourceEndpointA useful base class for endpoints which depend on a resource such as things like Velocity or XQuery based components.Classorg.apache.camel.componentApache Camel
ResourceHelperHelper class for loading resources on the classpath or file system.Classorg.apache.camel.utilApache Camel
RestBindingDefinitionClassorg.apache.camel.model.restApache Camel
RestBindingModeenum RestBindingModeEnum Constant SummaryClassorg.apache.camel.model.restApache Camel
RestBindingProcessorA Processor that binds the REST DSL incoming and outgoing messages from sources of json or xml to Java Objects.Classorg.apache.camel.processor.bindingApache Camel
RestComponentClassorg.apache.camel.component.restApache Camel
RestConfigurationConfiguration use by RestConsumerFactory for Camel components to support the Camel rest DSL.Classorg.apache.camel.spiApache Camel
RestConfiguration .RestBindingModeClassorg.apache.camel.spi.RestConfigurationApache Camel
RestConfiguration .RestHostNameResolverClassorg.apache.camel.spi.RestConfigurationApache Camel
RestConfigurationDefinitionClassorg.apache.camel.model.restApache Camel
RestConsumerFactoryInterfaceorg.apache.camel.spiApache Camel
RestContainerContainer to hold Rest.Interfaceorg.apache.camel.model.restApache Camel
RestContextRefDefinitionClassorg.apache.camel.modelApache Camel
RestContextRefDefinitionHelperHelper for RestContextRefDefinition.Classorg.apache.camel.modelApache Camel
RestDefinitionClassorg.apache.camel.model.restApache Camel
RestEndpointClassorg.apache.camel.component.restApache Camel
RestHostNameResolverenum RestHostNameResolverTo configure the rest hostname resolverClassorg.apache.camel.model.restApache Camel
RestPropertyDefinitionClassorg.apache.camel.model.restApache Camel
RestRegistryA registry of all REST services running within the CamelContext which have been defined and created using the Rest DSL.Interfaceorg.apache.camel.spiApache Camel
RestRegistry .RestServiceInterfaceorg.apache.camel.spi.RestRegistryApache Camel
RestsDefinitionClassorg.apache.camel.model.restApache Camel
ResultHandlerFactoryInterfaceorg.apache.camel.builder.xmlApache Camel
ResultInterceptorIntercepts API method invocation result Exchange.Interfaceorg.apache.camel.util.componentApache Camel
RollbackDefinitionClassorg.apache.camel.modelApache Camel
RollbackExchangeExceptionException used for forcing an Exchange to be rolled back.Classorg.apache.camelApache Camel
RollbackProcessorProcessor for marking an Exchange to rollback.Classorg.apache.camel.processorApache Camel
RoundRobinLoadBalancerClassorg.apache.camel.processor.loadbalancerApache Camel
RoundRobinLoadBalancerDefinitionRound robin load balancer The round robin load balancer will use the next endpoint for each message.Classorg.apache.camel.model.loadbalancerApache Camel
Route defines the processing used on an inbound message exchange from a specific Endpoint within a CamelContext.Interfaceorg.apache.camelApache Camel
RouteAddedEventClassorg.apache.camel.management.eventApache Camel
RouteAwareAn interface to represent an object which wishes to be injected with a Route such as Consumer which is the consumer for a route.Interfaceorg.apache.camelApache Camel
RouteBuilder used to build DefaultRoute instances in a CamelContext for smart routing.Classorg.apache.camel.builderApache Camel
RouteBuilderDefinitionTo refer to a Java RouteBuilder instance to use.Classorg.apache.camel.modelApache Camel
RouteContainerContainer to hold Route.Interfaceorg.apache.camel.modelApache Camel
RouteContextInterfaceorg.apache.camel.spiApache Camel
RouteContextRefDefinitionClassorg.apache.camel.modelApache Camel
RouteContextRefDefinitionHelperHelper for RouteContextRefDefinition.Classorg.apache.camel.modelApache Camel
RouteDefinitionClassorg.apache.camel.modelApache Camel
RouteDefinitionHelperHelper for RouteDefinition Utility methods to help preparing RouteDefinition before they are added toClassorg.apache.camel.modelApache Camel
RouteDotGeneratorA DOT file creator plugin which creates a DOT file showing the current routesClassorg.apache.camel.viewApache Camel
RouteNodeRepresents a model of a node in the runtime route path.Interfaceorg.apache.camelApache Camel
RoutePolicyPolicy for a Route which allows controlling the route at runtime.Interfaceorg.apache.camel.spiApache Camel
RoutePolicyFactoryA factory to create RoutePolicy and assign to routes automatic.Interfaceorg.apache.camel.spiApache Camel
RoutePolicySupportClassorg.apache.camel.implApache Camel
RoutePolicySupportA base class for developing custom RoutePolicy implementations.Classorg.apache.camel.supportApache Camel
RouteRemovedEventClassorg.apache.camel.management.eventApache Camel
RoutesBuilderA routes builder is capable of building routes using the builder and model classes.Interfaceorg.apache.camelApache Camel
RoutesDefinitionClassorg.apache.camel.modelApache Camel
RouteServiceClassorg.apache.camel.implApache Camel
RouteStartedEventClassorg.apache.camel.management.eventApache Camel
RouteStartupOrderInformation about a route to be started where we want to control the order in which they are started by CamelContext.Interfaceorg.apache.camel.spiApache Camel
RouteStatDumpA model of a route stat dump from ManagedRouteMBean.Classorg.apache.camel.utilApache Camel
RouteStoppedEventClassorg.apache.camel.management.eventApache Camel
RoutingSlip pattern where the list of actual endpoints to send a message exchange to are dependent on the value of a message header.Classorg.apache.camel.processorApache Camel
RoutingSlipIndicates that this method is to be used as a Routing Slip routing the incoming messageClassorg.apache.camelApache Camel
RoutingSlip .RoutingSlipIteratorThe iterator to be used for retrieving the next routing slip(s) to be used.Interfaceorg.apache.camel.processor.RoutingSlipApache Camel
RoutingSlipDefinitionClassorg.apache.camel.modelApache Camel
RssDataFormatClassorg.apache.camel.model.dataformatApache Camel
RubyExpressionClassorg.apache.camel.model.languageApache Camel
RuntimeBeanExpressionExceptionException thrown if invocation of bean failed.Classorg.apache.camel.language.beanApache Camel
RuntimeCamelExceptionBase class for all Camel unchecked exceptions.Classorg.apache.camelApache Camel
RuntimeConfigurationVarious runtime configuration options used by CamelContext and RouteContext for cross cutting functions such as tracing, delayer, stream cache and the like.Interfaceorg.apache.camelApache Camel
RuntimeEndpointRegistryA registry which listen for runtime usage of Endpoint during routing in Camel.Interfaceorg.apache.camel.spiApache Camel
RuntimeExchangeExceptionA runtime exception caused by a specific message ExchangeVersion:See Also:Serialized FormClassorg.apache.camelApache Camel
RuntimeExpressionExceptionThrown if an expression evaluation failsVersion:See Also:Serialized FormClassorg.apache.camelApache Camel
RuntimeTransformExceptionThrown if a message transformation failsVersion:See Also:Serialized FormClassorg.apache.camelApache Camel
SamplingDefinitionClassorg.apache.camel.modelApache Camel
SamplingThrottlerA SamplingThrottler is a special kind of throttler.Classorg.apache.camel.processorApache Camel
ScheduledBatchPollingConsumerClassorg.apache.camel.implApache Camel
ScheduledPollConsumerClassorg.apache.camel.implApache Camel
ScheduledPollConsumerSchedulerA pluggable scheduler for ScheduledPollConsumer consumers.Interfaceorg.apache.camel.spiApache Camel
ScheduledPollEndpointClassorg.apache.camel.implApache Camel
SchedulerComponentClassorg.apache.camel.component.schedulerApache Camel
SchedulerConsumerClassorg.apache.camel.component.schedulerApache Camel
SchedulerEndpointClassorg.apache.camel.component.schedulerApache Camel
SchemaValidationExceptionA Schema validation exception occurredVersion:See Also:Serialized FormClassorg.apache.camel.processor.validationApache Camel
SecureRandomParametersClassorg.apache.camel.util.jsseApache Camel
SecureSocketProtocolsParametersRepresents a list of TLS/SSL cipher suite names.Classorg.apache.camel.util.jsseApache Camel
SedaComponentClassorg.apache.camel.component.sedaApache Camel
SedaConsumerA Consumer for the SEDA component.Classorg.apache.camel.component.sedaApache Camel
SedaConsumerNotAvailableExceptionClassorg.apache.camel.component.sedaApache Camel
SedaEndpointAn implementation of the Queue components for asynchronous SEDA exchanges on a BlockingQueue within a CamelContextClassorg.apache.camel.component.sedaApache Camel
SedaPollingConsumerClassorg.apache.camel.component.sedaApache Camel
SedaProducerClassorg.apache.camel.component.sedaApache Camel
SendDefinitionClassorg.apache.camel.modelApache Camel
SendProcessorProcessor for forwarding exchanges to an endpoint destination.Classorg.apache.camel.processorApache Camel
SequenceA sorted set of elements with additional methods for obtaining immediate successors and immediate predecessors of a given element in the sequence.Classorg.apache.camel.processor.resequencerApache Camel
SequenceElementComparatorA strategy for comparing elements of a sequence.Interfaceorg.apache.camel.processor.resequencerApache Camel
SequenceSenderAn interface used by the ResequencerEngine.Interfaceorg.apache.camel.processor.resequencerApache Camel
SerializationDataFormat using Java Serialiation.Classorg.apache.camel.implApache Camel
SerializationDataFormatClassorg.apache.camel.model.dataformatApache Camel
ServiceInterfaceorg.apache.camelApache Camel
ServiceHelperA collection of helper methods for working with Service objects.Classorg.apache.camel.utilApache Camel
ServicePoolA service pool is like a connection pool but can pool any kind of objects.Interfaceorg.apache.camel.spiApache Camel
ServicePropertiesFunctionA PropertiesFunction that lookup the property value from OS environment variables using the service idiom.Classorg.apache.camel.component.propertiesApache Camel
ServiceStartupFailureEventClassorg.apache.camel.management.eventApache Camel
ServiceStatusRepresents the status of a Service instanceEnum Constant SummaryClassorg.apache.camelApache Camel
ServiceStopFailureEventClassorg.apache.camel.management.eventApache Camel
ServiceSupportClassorg.apache.camel.implApache Camel
ServiceSupportA useful base class which ensures that a service is only initialized once and provides some helper methods for enquiring of its status.Classorg.apache.camel.supportApache Camel
SetBodyDefinitionClassorg.apache.camel.modelApache Camel
SetBodyProcessorClassorg.apache.camel.processorApache Camel
SetExchangePatternDefinitionClassorg.apache.camel.modelApache Camel
SetFaultBodyDefinitionClassorg.apache.camel.modelApache Camel
SetHeaderDefinitionClassorg.apache.camel.modelApache Camel
SetHeaderProcessorClassorg.apache.camel.processorApache Camel
SetOutHeaderDefinitionClassorg.apache.camel.modelApache Camel
SetPropertyDefinitionClassorg.apache.camel.modelApache Camel
SetPropertyProcessorClassorg.apache.camel.processorApache Camel
SharedPollingConsumerServicePoolA shared DefaultPollingConsumerServicePool which is used by CamelContext by default.Classorg.apache.camel.implApache Camel
SharedProducerServicePoolA shared DefaultProducerServicePool which is used by CamelContext by default.Classorg.apache.camel.implApache Camel
ShutdownableServiceA Service which is capable of being shut down.Interfaceorg.apache.camelApache Camel
ShutdownAwareAllows Consumer to fine grained control on shutdown which mostly have to cater for in-memory based components.Interfaceorg.apache.camel.spiApache Camel
ShutdownPreparedAllows a Service to prepare for shutdown.Interfaceorg.apache.camel.spiApache Camel
ShutdownRouteRepresents the options available when shutting down routes.Classorg.apache.camelApache Camel
ShutdownRunningTaskenum ShutdownRunningTaskRepresents the kind of options for what to do with the current task when shutting down.Classorg.apache.camelApache Camel
ShutdownStrategyPluggable shutdown strategy executed during shutdown of routes.Interfaceorg.apache.camel.spiApache Camel
SimpleBackwardsCompatibleParserA backwards compatible parser, which supports the old simple language syntax by which simple functions can be given without using start andClassorg.apache.camel.language.simpleApache Camel
SimpleBuilderCreates an Simple language builder.Classorg.apache.camel.builderApache Camel
SimpleDataSetA simple DataSet that allows a static payload to be used to create each message exchange along with using a pluggable transformer to randomize the message.Classorg.apache.camel.component.datasetApache Camel
SimpleExpressionClassorg.apache.camel.model.languageApache Camel
SimpleExpressionParserClassorg.apache.camel.language.simpleApache Camel
SimpleFunctionEndClassorg.apache.camel.language.simple.astApache Camel
SimpleFunctionExpressionClassorg.apache.camel.language.simple.astApache Camel
SimpleFunctionStartClassorg.apache.camel.language.simple.astApache Camel
SimpleIllegalSyntaxExceptionSyntax error in the simple language expression.Classorg.apache.camel.language.simple.typesApache Camel
SimpleLanguage which maps simple property style notations to access headers and bodies.Classorg.apache.camel.language.simpleApache Camel
SimpleLoadBalancerSupportA default base class for a LoadBalancer implementation.Classorg.apache.camel.processor.loadbalancerApache Camel
SimpleNodeInterfaceorg.apache.camel.language.simple.astApache Camel
SimpleParserExceptionHolds information about error parsing the simple expression at a given locationSee Also:Serialized FormClassorg.apache.camel.language.simple.typesApache Camel
SimplePredicateParserClassorg.apache.camel.language.simpleApache Camel
SimpleRegistryA Map-based registry.Classorg.apache.camel.implApache Camel
SimpleTokenHolder for a token, with associated type and position in the input.Classorg.apache.camel.language.simple.typesApache Camel
SimpleTokenizerTokenizer to create SimpleToken from the input.Classorg.apache.camel.language.simpleApache Camel
SimpleTokenTypeThe different token types used by the simple parser.Classorg.apache.camel.language.simple.typesApache Camel
SimpleUuidGeneratorClassorg.apache.camel.implApache Camel
SingleQuoteEndClassorg.apache.camel.language.simple.astApache Camel
SingleQuoteStartClassorg.apache.camel.language.simple.astApache Camel
SizedScheduledExecutorServiceA sized ScheduledExecutorService which will reject executing tasks if the task queue is full.Classorg.apache.camel.util.concurrentApache Camel
SoapJaxbDataFormatClassorg.apache.camel.model.dataformatApache Camel
SortDefinitionClassorg.apache.camel.modelApache Camel
SortProcessorClassorg.apache.camel.processorApache Camel
SourceCacheStreamCache implementation for StringSourcesSee Also:Serialized FormClassorg.apache.camel.converter.streamApache Camel
SpELAn annotation for injection of Spring Expression Language (SpEL) expressions into method parameters, fields or properties.Classorg.apache.camel.languageApache Camel
SpELExpressionClassorg.apache.camel.model.languageApache Camel
SplitDefinitionSplits a single message into many sub-messages.Classorg.apache.camel.modelApache Camel
Splitter 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.Classorg.apache.camel.processorApache Camel
SQLConverterSQL Date and time related converters.Classorg.apache.camel.converterApache Camel
SqlExpressionClassorg.apache.camel.model.languageApache Camel
SSLContextClientParametersConfiguration model for client side JSSE options.Classorg.apache.camel.util.jsseApache Camel
SSLContextParametersRepresents SSLContext configuration options used in instantiating an SSLContext instance.Classorg.apache.camel.util.jsseApache Camel
SSLContextServerParametersClassorg.apache.camel.util.jsseApache Camel
StartupListenerAllows objects to be notified when CamelContext has done all work when starting.Interfaceorg.apache.camelApache Camel
StatefulServiceA Service which has all the lifecycle events and offers details about its current state.Interfaceorg.apache.camelApache Camel
StaticMethodFallbackTypeConverterA TypeConverter implementation which invokes a static method as a fallback type converter from a type to another typeClassorg.apache.camel.impl.converterApache Camel
StaticMethodTypeConverterClassorg.apache.camel.impl.converterApache Camel
StatisticClassorg.apache.camel.management.mbeanApache Camel
Statistic .UpdateMode VALUE - A statistic with this update mode is a simple value that is a straight forward representation of the updated value.Classorg.apache.camel.management.mbean.StatisticApache Camel
StaxConverterClassorg.apache.camel.converter.jaxpApache Camel
StaxSourceClassorg.apache.camel.converter.jaxpApache Camel
StickyLoadBalancer a correlation key to perform the sticky load balancing; rather like jsessionid in the web or JMSXGroupID in JMS.Classorg.apache.camel.processor.loadbalancerApache Camel
StickyLoadBalancerDefinitionSticky load balancer Sticky load balancing using an Expression to calculate a correlation key to perform the sticky load balancing;Classorg.apache.camel.model.loadbalancerApache Camel
StopDefinitionClassorg.apache.camel.modelApache Camel
StopProcessorStops continue processing the route and marks it as complete.Classorg.apache.camel.processorApache Camel
StopWatchA very simple stop watch.Classorg.apache.camel.utilApache Camel
StreamCacheTagging interface to indicate that a type is capable of caching the underlying data stream.Interfaceorg.apache.camelApache Camel
StreamCacheConverterA set of Converter methods for wrapping stream-based messages in a StreamCache implementation to ensure message re-readability (eg multicasting, retrying)Classorg.apache.camel.converter.streamApache Camel
StreamCachingClassorg.apache.camel.processor.interceptorApache Camel
StreamCachingInterceptorAn interceptor that converts streams messages into a re-readable format by wrapping the stream into a StreamCache.Classorg.apache.camel.processor.interceptorApache Camel
StreamCachingStrategyStrategy for using stream caching.Interfaceorg.apache.camel.spiApache Camel
StreamCachingStrategy .SpoolRuleRule for determine if stream caching should be spooled to disk or kept in-memory.Interfaceorg.apache.camel.spi.StreamCachingStrategyApache Camel
StreamCachingStrategy .SpoolUsedHeapMemoryLimitUsed for selecting if the memory limit is committed or maximum heap memory setting.Classorg.apache.camel.spi.StreamCachingStrategyApache Camel
StreamCachingStrategy .StatisticsUtilization statistics of stream caching.Interfaceorg.apache.camel.spi.StreamCachingStrategyApache Camel
StreamResequencerA resequencer that re-orders a (continuous) stream of Exchanges.Classorg.apache.camel.processorApache Camel
StreamResequencerConfigConfigures stream-processing resequence eip.Classorg.apache.camel.model.configApache Camel
StreamResultHandlerClassorg.apache.camel.builder.xmlApache Camel
StreamResultHandlerFactoryClassorg.apache.camel.builder.xmlApache Camel
StreamSourceCacheClassorg.apache.camel.converter.streamApache Camel
StreamSourceConverterClassorg.apache.camel.converter.jaxpApache Camel
StringDataFormatClassorg.apache.camel.implApache Camel
StringDataFormatClassorg.apache.camel.model.dataformatApache Camel
StringHelperHelper methods for working with Strings.Classorg.apache.camel.utilApache Camel
StringQuoteHelperUtility class for parsing quoted string which is intended for parameters, separated by comma.Classorg.apache.camel.utilApache Camel
StringResultHandlerClassorg.apache.camel.builder.xmlApache Camel
StringResultHandlerFactoryClassorg.apache.camel.builder.xmlApache Camel
StringSourceA helper class which provides a JAXP Source from a String which can be read as many times as required.Classorg.apache.camelApache Camel
StubComponentThe Stub Component is for stubbing out endpoints while developing or testing.Classorg.apache.camel.component.stubApache Camel
StubConsumerClassorg.apache.camel.component.stubApache Camel
StubEndpointClassorg.apache.camel.component.stubApache Camel
SubmitOrderedCompletionServiceA CompletionService that orders the completed tasks in the same order as they where submitted.Classorg.apache.camel.util.concurrentApache Camel
SubUnitOfWorkA sub unit of work is a way of implement sub-transactions in Camel routing.Interfaceorg.apache.camel.spiApache Camel
SubUnitOfWorkCallbackTo allow unit of work for the UnitOfWork while processing a number of Exchanges.Interfaceorg.apache.camel.spiApache Camel
SuspendableServiceA Service which is also capable of suspending and resuming.Interfaceorg.apache.camelApache Camel
SynchronizationProvides a hook for custom Processor or Component instances to respond to completed or failed processing of an Exchange rather like Spring'sInterfaceorg.apache.camel.spiApache Camel
SynchronizationAdapterClassorg.apache.camel.implApache Camel
SynchronizationAdapterClassorg.apache.camel.supportApache Camel
SynchronizationRouteAwareAn extended Synchronization which is route aware.Interfaceorg.apache.camel.spiApache Camel
SynchronizationVetoableA vetoable Synchronization.Interfaceorg.apache.camel.spiApache Camel
SynchronousDelegateProducerTo process the delegated producer in synchronous mode.Classorg.apache.camel.implApache Camel
SynchronousExecutorServiceA synchronous ExecutorService which always invokes the task in the caller thread (just a thread pool facade).Classorg.apache.camel.util.concurrentApache Camel
SyslogDataFormatClassorg.apache.camel.model.dataformatApache Camel
SysPropertiesFunctionA PropertiesFunction that lookup the property value from JVM system property.Classorg.apache.camel.component.propertiesApache Camel
TerserExpressionClassorg.apache.camel.model.languageApache Camel
TestComponentThe Test Component is for simplifying unit and integration tests.Classorg.apache.camel.component.testApache Camel
TestEndpointA Test Endpoint is a Mock Endpoint for testing but it willClassorg.apache.camel.component.testApache Camel
ThreadHelperVarious helper method for thread naming.Classorg.apache.camel.util.concurrentApache Camel
ThreadPoolBuilderA builder to create thread pools.Classorg.apache.camel.builderApache Camel
ThreadPoolFactoryCreates ExecutorService and ScheduledExecutorService objects that work with a thread pool for a given ThreadPoolProfile and ThreadFactory.Interfaceorg.apache.camel.spiApache Camel
ThreadPoolProfileA profile which defines thread pool settings.Classorg.apache.camel.spiApache Camel
ThreadPoolProfileBuilderBuilder to build ThreadPoolProfile.Classorg.apache.camel.builderApache Camel
ThreadPoolProfileDefinitionClassorg.apache.camel.modelApache Camel
ThreadPoolProfileSupportUse ThreadPoolProfile insteadSee Also:Serialized FormClassorg.apache.camel.implApache Camel
ThreadPoolRejectedPolicyenum ThreadPoolRejectedPolicyRepresent the kinds of options for rejection handlers for thread pools.Classorg.apache.camelApache Camel
ThreadsDefinitionClassorg.apache.camel.modelApache Camel
ThreadsProcessorThreads processor that leverage a thread pool for continue processing the Exchanges using the asynchronous routing engine.Classorg.apache.camel.processorApache Camel
ThrottleDefinitionClassorg.apache.camel.modelApache Camel
Throttler will set a limit on the maximum number of message exchanges which can be sent to a processor within a specific time period.Classorg.apache.camel.processorApache Camel
ThrottlerRejectedExecutionExceptionClassorg.apache.camel.processorApache Camel
ThrottlingInflightRoutePolicyA throttle based RoutePolicy which is capable of dynamic throttling a route based on number of current inflight exchanges.Classorg.apache.camel.implApache Camel
ThrottlingInflightRoutePolicy .ThrottlingScopeClassorg.apache.camel.impl.ThrottlingInflightRoutePolicyApache Camel
ThroughputLoggerA logger for logging message throughput.Classorg.apache.camel.processorApache Camel
ThrowExceptionDefinitionClassorg.apache.camel.modelApache Camel
ThrowExceptionProcessorClassorg.apache.camel.processorApache Camel
TidyMarkupDataFormatClassorg.apache.camel.model.dataformatApache Camel
TimeClassorg.apache.camel.utilApache Camel
TimeClauseRepresents time based clauses for setting expectations on the mocks.Classorg.apache.camel.component.mockApache Camel
TimeoutA timer task that notifies handlers about scheduled timeouts.Classorg.apache.camel.processor.resequencerApache Camel
TimeoutAwareAggregationStrategyA specialized AggregationStrategy which can handle timeouts as well.Interfaceorg.apache.camel.processor.aggregateApache Camel
TimeoutHandlerInterfaceorg.apache.camel.processor.resequencerApache Camel
TimeoutMapRepresents a map of values which timeout after a period of inactivity.Interfaceorg.apache.camelApache Camel
TimeoutMapEntryClassorg.apache.camel.supportApache Camel
TimePatternConverterConverter from String syntax to milli seconds.Classorg.apache.camel.converterApache Camel
TimerComponentThe Timer Component is for generating message exchanges when a timer fires.Classorg.apache.camel.component.timerApache Camel
TimerConsumerClassorg.apache.camel.component.timerApache Camel
TimerEndpointRepresents a timer endpoint that can generate periodic inbound exchanges triggered by a timer.Classorg.apache.camel.component.timerApache Camel
TimerListenerListener for receiving timer events.Interfaceorg.apache.camelApache Camel
TimerListenerManagerA TimerListener manager which triggers the TimerListener listeners once every second.Classorg.apache.camel.supportApache Camel
TimeUnitAdapterTimeUnitAdapter is a simple adapter to convert between Strings and instances of the TimeUnit enumerationClassorg.apache.camel.builder.xmlApache Camel
TimeUtilsClassorg.apache.camel.utilApache Camel
ToDefinitionClassorg.apache.camel.modelApache Camel
TokenizeLanguageA language for tokenizer expressions.Classorg.apache.camel.language.tokenizerApache Camel
TokenizerExpressionFor expressions and predicates using a body or header tokenizer.Classorg.apache.camel.model.languageApache Camel
TokenPairExpressionIteratorExpression to walk a Message body using an Iterator, which grabs the content between a start and end token.Classorg.apache.camel.supportApache Camel
TokenTypeClassifications of known token types.Classorg.apache.camel.language.simple.typesApache Camel
TokenXMLExpressionIteratorExpression to walk a Message XML body using an Iterator, which grabs the content between a XML start and end token,Classorg.apache.camel.supportApache Camel
TokenXMLPairExpressionIteratorExpression to walk a Message XML body using an Iterator, which grabs the content between a XML start and end token.Classorg.apache.camel.supportApache Camel
TopicLoadBalancerA LoadBalancer implementations which sends to all destinations (rather like JMS Topics).Classorg.apache.camel.processor.loadbalancerApache Camel
TopicLoadBalancerDefinitionClassorg.apache.camel.model.loadbalancerApache Camel
ToStringTypeConverterA simple converter that can convert any object to a String type by using the toString() method of the object.Classorg.apache.camel.impl.converterApache Camel
TraceableTraceable processors allowing easier tracing using constructed labels to help identify the processor and where it's defined in the route model.Interfaceorg.apache.camelApache Camel
TracedRouteNodesTracing information used by TraceInterceptor so we can trace the exact route path a given Exchange has been processed.Interfaceorg.apache.camel.spiApache Camel
TraceEventHandlerA handler which reacts on trace events.Interfaceorg.apache.camel.processor.interceptorApache Camel
TraceEventMessageA trace event message that contains decomposed information about the traced Exchange at the point of interception.Interfaceorg.apache.camel.processor.interceptorApache Camel
TraceFormatterFormatter to format trace logs when tracing Exchange during routing.Interfaceorg.apache.camel.processor.interceptorApache Camel
TraceInterceptorClassorg.apache.camel.processor.interceptorApache Camel
TraceInterceptorFactoryFactory to create the trace interceptor.Interfaceorg.apache.camel.processor.interceptorApache Camel
TracerClassorg.apache.camel.processor.interceptorApache Camel
TransactedDefinitionClassorg.apache.camel.modelApache Camel
TransformDefinitionClassorg.apache.camel.modelApache Camel
TransformProcessorClassorg.apache.camel.processorApache Camel
TrustManagersParametersClassorg.apache.camel.util.jsseApache Camel
TryDefinitionClassorg.apache.camel.modelApache Camel
TryProcessorClassorg.apache.camel.processorApache Camel
TypeConversionExceptionException when failing during type conversion.Classorg.apache.camelApache Camel
TypeConverterA pluggable strategy to be able to convert objects to different types such as to and from String, InputStream/OutputStream,Interfaceorg.apache.camelApache Camel
TypeConverterAwareAn interface for an object which is interested in being injected with the root TypeConverter such as for implementing a fallback type converterInterfaceorg.apache.camel.spiApache Camel
TypeConverterLoaderA pluggable strategy to load type converters into a TypeConverterRegistry from some kind of mechanism.Interfaceorg.apache.camel.spiApache Camel
TypeConverterLoaderExceptionException when failing to load type converters.Classorg.apache.camelApache Camel
TypeConverterRegistryRegistry for type converters.Interfaceorg.apache.camel.spiApache Camel
TypeConverterRegistry .StatisticsUtilization statistics of the this registry.Interfaceorg.apache.camel.spi.TypeConverterRegistryApache Camel
TypeConverterSupportBase class for TypeConverter implementations.Classorg.apache.camel.supportApache Camel
UnaryExpressionClassorg.apache.camel.language.simple.astApache Camel
UnaryOperatorTypeenum UnaryOperatorTypeTypes of unary operators supported.Classorg.apache.camel.language.simple.typesApache Camel
UnitOfWorkAn object representing the unit of work processing an Exchange which allows the use of Synchronization hooks.Interfaceorg.apache.camel.spiApache Camel
UnitOfWorkFactoryFactory to create UnitOfWork.Interfaceorg.apache.camel.spiApache Camel
UnitOfWorkHelperClassorg.apache.camel.utilApache Camel
UnitOfWorkProducerEnsures a Producer is executed within an UnitOfWork.Classorg.apache.camel.processorApache Camel
UnitUtilsClassorg.apache.camel.utilApache Camel
UniVocityAbstractDataFormatRepresents the common parts of all uniVocity DataFormat parsers.Classorg.apache.camel.model.dataformatApache Camel
UniVocityCsvDataFormatClassorg.apache.camel.model.dataformatApache Camel
UniVocityFixedWidthDataFormatClassorg.apache.camel.model.dataformatApache Camel
UniVocityHeaderTo configure headers for UniVocity data formats.Classorg.apache.camel.model.dataformatApache Camel
UniVocityTsvDataFormatClassorg.apache.camel.model.dataformatApache Camel
UnmarshalDefinitionClassorg.apache.camel.modelApache Camel
UnmarshalProcessorClassorg.apache.camel.processorApache Camel
UnsafeUriCharactersEncoderEncoder for unsafe URI characters.Classorg.apache.camel.utilApache Camel
UriComponentConfiguration which are annotated with UriEndpoint to use the UriParam and UriParams annotationsClassorg.apache.camel.implApache Camel
UriEndpointComponentA component implementation for endpoints which are annotated with UriEndpoint to describe their configurable parameters via annotationsClassorg.apache.camel.implApache Camel
UriEndpointConfiguration which are annotated with UriEndpoint to use the UriParam and UriParams annotations to denote its parameters which can be specified via URI query parameters.Classorg.apache.camel.implApache Camel
URIFieldUsed to indicate the field of an EndpointConfiguration.Classorg.apache.camelApache Camel
URISupportClassorg.apache.camel.utilApache Camel
UseLatestAggregationStrategyAn AggregationStrategy which just uses the latest exchange which is useful for status messages where old status messages have no real value.Classorg.apache.camel.processor.aggregateApache Camel
UseOriginalAggregationStrategyAn AggregationStrategy which just uses the original exchange which can be needed when you want to preserve the original Exchange.Classorg.apache.camel.processor.aggregateApache Camel
UuidGeneratorGenerator to generate UUID strings.Interfaceorg.apache.camel.spiApache Camel
ValidateDefinitionClassorg.apache.camel.modelApache Camel
ValidatingProcessorA processor which validates the XML version of the inbound message body against some schema either in XSD or RelaxNGClassorg.apache.camel.processor.validationApache Camel
ValidationExceptionThe base class for any validation exception, such as SchemaValidationException soClassorg.apache.camelApache Camel
ValidatorComponentClassorg.apache.camel.component.validatorApache Camel
ValidatorEndpointClassorg.apache.camel.component.validatorApache Camel
ValidatorErrorHandlerValidator error handler.Interfaceorg.apache.camel.processor.validationApache Camel
ValidatorProducerClassorg.apache.camel.component.validatorApache Camel
ValueBuilderA builder of expressions or predicates based on values.Classorg.apache.camel.builderApache Camel
ValueHolderHolder object for a given value.Classorg.apache.camel.utilApache Camel
VerbDefinitionClassorg.apache.camel.model.restApache Camel
VetoCamelContextStartExceptionAn exception to veto starting CamelContext.Classorg.apache.camelApache Camel
VmComponentThe VM component is for asynchronous SEDA exchanges on a BlockingQueue within the classloader tree containing the camel-core.Classorg.apache.camel.component.vmApache Camel
VmConsumerClassorg.apache.camel.component.vmApache Camel
VmEndpointClassorg.apache.camel.component.vmApache Camel
VtdXmlExpressionClassorg.apache.camel.model.languageApache Camel
WaitForTaskToCompleteenum WaitForTaskToCompleteRepresent the kinds of options for wait for tasks to complete.Classorg.apache.camelApache Camel
WebSpherePackageScanClassResolverWebSphere specific resolver to handle loading annotated resources in JAR files.Classorg.apache.camel.implApache Camel
WeightedLoadBalancerClassorg.apache.camel.processor.loadbalancerApache Camel
WeightedLoadBalancerDefinitionWeighted load balancer The weighted load balancing policy allows you to specify a processing load distribution ratio for each serverClassorg.apache.camel.model.loadbalancerApache Camel
WeightedRandomLoadBalancerClassorg.apache.camel.processor.loadbalancerApache Camel
WeightedRoundRobinLoadBalancerClassorg.apache.camel.processor.loadbalancerApache Camel
WhenDefinitionClassorg.apache.camel.modelApache Camel
WhenSkipSendToEndpointDefinitionPredicate to determine if the message should be sent or not to the endpoint, when using interceptSentToEndpoint.Classorg.apache.camel.modelApache Camel
WireTapDefinitionRoutes a copy of a message (or creates a new message) to a secondary destination while continue routing the original message.Classorg.apache.camel.modelApache Camel
WireTapProcessorProcessor for wire tapping exchanges to an endpoint destination.Classorg.apache.camel.processorApache Camel
WrapProcessorA processor which ensures wrapping processors is having lifecycle handled.Classorg.apache.camel.processorApache Camel
XMLBeansDataFormatClassorg.apache.camel.model.dataformatApache Camel
XmlConverterClassorg.apache.camel.converter.jaxpApache Camel
XmlErrorListenerA ErrorListener that logs the errors.Classorg.apache.camel.converter.jaxpApache Camel
XmlGraphGeneratorClassorg.apache.camel.viewApache Camel
XmlJsonDataFormatClassorg.apache.camel.model.dataformatApache Camel
XmlRpcDataFormatClassorg.apache.camel.model.dataformatApache Camel
XMLSecurityDataFormatClassorg.apache.camel.model.dataformatApache Camel
XMLTokenExpressionIteratorClassorg.apache.camel.supportApache Camel
XMLTokenizeLanguageA language for tokenizer expressions.Classorg.apache.camel.language.tokenizerApache Camel
XMLTokenizerExpressionFor expressions and predicates using a body or header tokenizer.Classorg.apache.camel.model.languageApache Camel
XPathUsed to inject an XPath expression into a field, property, method or parameter when usingRequired Element SummaryClassorg.apache.camel.languageApache Camel
XPathAnnotationExpressionFactoryFactory for the XPath expression annotations.Classorg.apache.camel.component.beanApache Camel
XPathBuilderCreates an XPath expression builder which creates a nodeset result by default.Classorg.apache.camel.builder.xmlApache Camel
XPathExpressionClassorg.apache.camel.model.languageApache Camel
XPathLanguageClassorg.apache.camel.language.xpathApache Camel
XQueryExpressionClassorg.apache.camel.model.languageApache Camel
XsltBuilder which performs an XSLT transformation of the IN message body.Classorg.apache.camel.builder.xmlApache Camel
XsltComponentClassorg.apache.camel.component.xsltApache Camel
XsltConstantsXSLT component constants.Classorg.apache.camel.component.xsltApache Camel
XsltEndpointClassorg.apache.camel.component.xsltApache Camel
XsltErrorListenerErrorListener which logs the errors.Classorg.apache.camel.builder.xmlApache Camel
XsltOutputClassorg.apache.camel.component.xsltApache Camel
XsltUriResolverCamel specific URIResolver which is capable of loading files from the classpath and file system.Classorg.apache.camel.builder.xmlApache Camel
XStreamDataFormatClassorg.apache.camel.model.dataformatApache Camel
XStreamDataFormat .AliasAdapterClassorg.apache.camel.model.dataformat.XStreamDataFormatApache Camel
XStreamDataFormat .AliasEntryClassorg.apache.camel.model.dataformat.XStreamDataFormatApache Camel
XStreamDataFormat .AliasListClassorg.apache.camel.model.dataformat.XStreamDataFormatApache Camel
XStreamDataFormat .ConverterEntryClassorg.apache.camel.model.dataformat.XStreamDataFormatApache Camel
XStreamDataFormat .ConverterListClassorg.apache.camel.model.dataformat.XStreamDataFormatApache Camel
XStreamDataFormat .ConvertersAdapterClassorg.apache.camel.model.dataformat.XStreamDataFormatApache Camel
XStreamDataFormat .ImplicitCollectionEntryClassorg.apache.camel.model.dataformat.XStreamDataFormatApache Camel
XStreamDataFormat .ImplicitCollectionListClassorg.apache.camel.model.dataformat.XStreamDataFormatApache Camel
XStreamDataFormat .ImplicitCollectionsAdapterClassorg.apache.camel.model.dataformat.XStreamDataFormatApache Camel
XStreamDataFormat .OmitFieldEntryClassorg.apache.camel.model.dataformat.XStreamDataFormatApache Camel
XStreamDataFormat .OmitFieldListClassorg.apache.camel.model.dataformat.XStreamDataFormatApache Camel
XStreamDataFormat .OmitFieldsAdapterClassorg.apache.camel.model.dataformat.XStreamDataFormatApache Camel
ZipDataFormatDeflate compression data format.Classorg.apache.camel.implApache Camel
ZipDataFormatClassorg.apache.camel.model.dataformatApache Camel
ZipFileDataFormatClassorg.apache.camel.model.dataformatApache Camel