Package | Description |
---|---|
org.apache.camel |
The core Camel API.
|
org.apache.camel.builder | |
org.apache.camel.builder.xml | |
org.apache.camel.component |
Base classes for Components
|
org.apache.camel.component.bean |
The Bean Component which will look up the
bean name in the Spring ApplicationContext and use that to dispatch messages to a POJO
|
org.apache.camel.component.beanclass |
The Class Component for invoking Java classes from Camel
|
org.apache.camel.component.binding |
The Binding Component which is
a way of wrapping an Endpoint in a contract; such as a Data Format, a Content Enricher or validation step.
|
org.apache.camel.component.browse |
The Browse Component which is a simple in memory
component which maintains a list of all message exchanges which can be useful for debugging, tooling or visualistion.
|
org.apache.camel.component.controlbus |
The Control Bus Component which
allows to manage Camel at runtime.
|
org.apache.camel.component.dataformat |
The DataFormat Component
allows to use Data Format as a Camel Component.
|
org.apache.camel.component.dataset |
A DataSet Endpoint for testing of endpoints using defined DataSets
|
org.apache.camel.component.direct |
The Direct Component which synchronously invokes
all the consumers when a producer sends an exchange to the endpoint.
|
org.apache.camel.component.directvm |
The Direct VM Component which synchronously invokes
the consumer when a producer sends an exchange to the endpoint.
|
org.apache.camel.component.file |
The File Component for working with file systems.
|
org.apache.camel.component.file.ha | |
org.apache.camel.component.file.strategy |
Strategies for the File Component.
|
org.apache.camel.component.language |
The Language Component to send messages to language endpoints executing
the script.
|
org.apache.camel.component.log |
The Log Component uses Jakarta Commons Logging to log message exchanges.
|
org.apache.camel.component.mock |
The Mock Component which is used for testing of routing and mediation rules.
|
org.apache.camel.component.properties |
The Properties Component for lookup of property
placeholders for endpoint URI.
|
org.apache.camel.component.ref |
The Ref Component for lookup of existing
endpoints bound in the
Registry . |
org.apache.camel.component.rest |
The REST Component for defining REST services, supporting
the Camel Rest DSL.
|
org.apache.camel.component.scheduler |
The Scheduler Component to schedule routes
|
org.apache.camel.component.seda | |
org.apache.camel.component.stub |
The Stub Component which is used for stubbing endpoints.
|
org.apache.camel.component.test |
A Test Endpoint for Pattern Based Testing
|
org.apache.camel.component.timer |
The Timer Component provides a
simple timer
|
org.apache.camel.component.validator |
The Validator Component for validating XML against some schema
|
org.apache.camel.component.vm |
The VM Component for asynchronous
SEDA exchanges on a
BlockingQueue
within the current JVM; so across CamelContext instances.
|
org.apache.camel.component.xslt |
The XSLT Component for transforming messages with XSLT
|
org.apache.camel.ha |
Camel HA support
|
org.apache.camel.health |
Camel Health Check support
|
org.apache.camel.impl |
Default implementation classes for Camel Core
|
org.apache.camel.impl.cloud | |
org.apache.camel.impl.converter |
Default implementation classes the Type Conversion Strategies
|
org.apache.camel.impl.ha |
Base classes and Implementation for Camel HA
|
org.apache.camel.impl.health |
Camel Health Check implementations.
|
org.apache.camel.impl.transformer | |
org.apache.camel.impl.validator | |
org.apache.camel.language.simple |
Camel Simple language.
|
org.apache.camel.main |
Application level classes that can be used to instantiate camel.
|
org.apache.camel.management |
Camel management
|
org.apache.camel.management.mbean |
Camel management JMX MBeans
|
org.apache.camel.model |
The JAXB POJOs for the
XML Configuration
of the routing rules.
|
org.apache.camel.processor |
A collection of Processor
implementations which are used to implement the
Enterprise Integration Patterns
|
org.apache.camel.processor.aggregate |
Helper classes for the Aggregator pattern.
|
org.apache.camel.processor.binding |
Helper classes for the Binding concept on Endpoints.
|
org.apache.camel.processor.idempotent |
An implementation of the Idempotent Consumer
pattern.
|
org.apache.camel.processor.interceptor |
Helper classes for interceptors.
|
org.apache.camel.processor.loadbalancer |
Various load balancer processors
|
org.apache.camel.processor.validation |
Performs XML validation using JAXP for validating against XSD or
RelaxNG
|
org.apache.camel.runtimecatalog |
Runtime Camel Catalog
|
org.apache.camel.spi |
Service Provider Interfaces used internally by the Camel runtime which are plugin strategies.
|
org.apache.camel.support |
Base classes that help to implement the camel API and are expected to be extended by the user
|
org.apache.camel.util |
Utility classes used by the core of Camel.
|
org.apache.camel.util.component |
Base classes and utilities for API based components
|
org.apache.camel.util.toolbox |
Toolbox classes to create commonly used Aggregation Strategies in a fluent manner.
|
Modifier and Type | Interface and Description |
---|---|
interface |
AsyncEndpoint
Marks the
Endpoint as support asynchronous non-blocking routing in its consumer and producer. |
interface |
BatchConsumer
A consumer of a batch of message exchanges from an
Endpoint |
interface |
CamelContext
Interface used to represent the CamelContext used to configure routes and the
policies to use during message exchanges between endpoints.
|
interface |
Consumer
A consumer of message exchanges from an
Endpoint |
interface |
ConsumerTemplate
|
interface |
DelegateEndpoint
An interface to represent an
Endpoint which are delegated. |
interface |
Endpoint
An endpoint
implements the Message
Endpoint pattern and represents an endpoint that can send and receive
message exchanges
|
interface |
FluentProducerTemplate
|
interface |
PollingConsumer
Represents a Polling
Consumer where the caller polls for messages when it is ready.
|
interface |
Producer
Provides a channel on which clients can create and invoke message exchanges
on an
Endpoint |
interface |
ProducerTemplate
|
interface |
ShutdownableService
A
Service which is capable of being shut down. |
interface |
StatefulService
A
Service which has all the lifecycle events and offers details about its current state. |
interface |
StaticService
Marker for indicating the
Service is a static service (only one instance per CamelContext ). |
interface |
SuspendableService
A
Service which is also capable of suspending and resuming. |
Modifier and Type | Method and Description |
---|---|
List<Service> |
Route.getServices()
Returns the services for this particular route
|
Modifier and Type | Method and Description |
---|---|
void |
Route.addService(Service service)
Adds a service to this route
|
Modifier and Type | Method and Description |
---|---|
void |
Route.onStartingServices(List<Service> services)
A strategy callback allowing special initialization when services are starting.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultFluentProducerTemplate |
Modifier and Type | Class and Description |
---|---|
class |
XPathBuilder
Creates an XPath expression builder which creates a nodeset result by default.
|
Modifier and Type | Class and Description |
---|---|
class |
ResourceEndpoint
A useful base class for endpoints which depend on a resource
such as things like Velocity or XQuery based components.
|
Modifier and Type | Class and Description |
---|---|
class |
BeanComponent
The Bean Component is for invoking Java beans from Camel.
|
class |
BeanEndpoint
The bean component is for invoking Java beans from Camel.
|
class |
BeanProcessor |
class |
BeanProducer
Bean
Producer |
Modifier and Type | Class and Description |
---|---|
class |
ClassComponent
The Class Component is for binding JavaBeans to Camel message exchanges based on class name.
|
class |
ClassEndpoint
The Class Component is for invoking Java Classes (Java beans) from Camel.
|
Modifier and Type | Class and Description |
---|---|
class |
BindingComponent
Deprecated.
|
class |
BindingConsumerProcessor
Applies a
Binding to a consumer |
class |
BindingEndpoint
Deprecated.
use
Contract instead |
class |
BindingNameComponent
|
Modifier and Type | Class and Description |
---|---|
class |
BrowseComponent
The Browse Component provides a simple
BrowsableEndpoint for testing visualization or debugging.
|
class |
BrowseEndpoint
The browse component is used for viewing the messages received on endpoints that supports
BrowsableEndpoint . |
Modifier and Type | Class and Description |
---|---|
class |
ControlBusComponent
The Control Bus component allows sending messages to a control-bus endpoint to control the lifecycle of routes.
|
class |
ControlBusEndpoint
The controlbus component provides easy management of Camel applications based on the Control Bus EIP pattern.
|
class |
ControlBusProducer
The control bus producer.
|
Modifier and Type | Class and Description |
---|---|
class |
DataFormatComponent
The Data Format Component enables using Data Format as a component.
|
class |
DataFormatEndpoint
The dataformat component is used for working with Data Formats as if it was a regular Component supporting Endpoints and URIs.
|
Modifier and Type | Class and Description |
---|---|
class |
DataSetComponent
Component for DataSet.
|
class |
DataSetConsumer
DataSet consumer.
|
class |
DataSetEndpoint
The dataset component provides a mechanism to easily perform load & soak testing of your system.
|
Modifier and Type | Class and Description |
---|---|
class |
DirectBlockingProducer
The direct producer.
|
class |
DirectComponent
The Direct Component manages
DirectEndpoint and holds the list of named direct endpoints. |
class |
DirectConsumer
The direct consumer.
|
class |
DirectEndpoint
The direct component provides direct, synchronous call to another endpoint from the same CamelContext.
|
class |
DirectProducer
The direct producer.
|
Modifier and Type | Class and Description |
---|---|
class |
DirectVmBlockingProducer
The direct producer.
|
class |
DirectVmComponent
The Direct VM Component manages
DirectVmEndpoint and holds the list of named direct-vm endpoints. |
class |
DirectVmConsumer
The direct-vm consumer
|
class |
DirectVmEndpoint
The direct-vm component provides direct, synchronous call to another endpoint from any CamelContext in the same JVM.
|
class |
DirectVmProcessor |
class |
DirectVmProducer
The Direct-VM producer.
|
Modifier and Type | Class and Description |
---|---|
class |
FileComponent
* The File Component provides access to file systems.
|
class |
FileConsumer
File consumer.
|
class |
FileEndpoint
The file component is used for reading or writing files.
|
class |
GenericFileComponent<T>
Base class file component.
|
class |
GenericFileConsumer<T>
Base class for file consumers.
|
class |
GenericFileEndpoint<T>
Base class for file endpoints
|
class |
GenericFileProducer<T>
Generic file producer
|
Modifier and Type | Class and Description |
---|---|
class |
FileLockClusterService |
class |
FileLockClusterView |
Modifier and Type | Class and Description |
---|---|
class |
FileIdempotentChangedRepositoryReadLockStrategy
A file read lock that uses an
IdempotentRepository and changed as the lock strategy. |
class |
FileIdempotentRenameRepositoryReadLockStrategy
A file read lock that uses an
IdempotentRepository and rename as the lock strategy. |
class |
FileIdempotentRepositoryReadLockStrategy
A file read lock that uses an
IdempotentRepository as the lock strategy. |
Modifier and Type | Class and Description |
---|---|
class |
LanguageComponent
The Language component enables sending
Exchange s to a given language in order to have a script executed. |
class |
LanguageEndpoint
The language component allows you to send a message to an endpoint which executes a script by any of the supported Languages in Camel.
|
class |
LanguageProducer
Language producer.
|
Modifier and Type | Class and Description |
---|---|
class |
LogComponent
The Log Component
is for logging message exchanges via the underlying logging mechanism.
|
class |
LogEndpoint
The log component logs message exchanges to the underlying logging mechanism.
|
class |
LogProducer
Log producer.
|
Modifier and Type | Class and Description |
---|---|
class |
MockComponent
The Mock Component provides mock endpoints for testing.
|
class |
MockEndpoint
The mock component is used for testing routes and mediation rules using mocks.
|
Modifier and Type | Class and Description |
---|---|
class |
PropertiesComponent
The Properties Component allows you to use property placeholders when defining Endpoint URIs
|
class |
PropertiesEndpoint
The properties component is used for using property placeholders in endpoint uris.
|
Modifier and Type | Class and Description |
---|---|
class |
RefComponent
The Ref Component is for lookup of existing endpoints bound in the
Registry . |
class |
RefEndpoint
The ref component is used for lookup of existing endpoints bound in the Registry.
|
Modifier and Type | Class and Description |
---|---|
class |
RestApiComponent
Rest API component.
|
class |
RestApiEndpoint
The rest-api component is used for providing Swagger API of the REST services which has been defined using the rest-dsl in Camel.
|
class |
RestApiProducer |
class |
RestComponent
Rest component.
|
class |
RestEndpoint
The rest component is used for either hosting REST services (consumer) or calling external REST services (producer).
|
class |
RestProducer
Rest producer for calling remote REST services.
|
class |
RestProducerBindingProcessor
A
Processor that binds the REST producer request and reply messages
from sources of json or xml to Java Objects. |
Modifier and Type | Class and Description |
---|---|
class |
SchedulerComponent |
class |
SchedulerConsumer |
class |
SchedulerEndpoint
The scheduler component is used for generating message exchanges when a scheduler fires.
|
Modifier and Type | Class and Description |
---|---|
class |
CollectionProducer
Deprecated.
will be removed in a future Camel release
|
class |
SedaComponent
The SEDA Component is for asynchronous SEDA exchanges on a
BlockingQueue within a CamelContext |
class |
SedaConsumer
A Consumer for the SEDA component.
|
class |
SedaEndpoint
The seda component provides asynchronous call to another endpoint from any CamelContext in the same JVM.
|
class |
SedaPollingConsumer |
class |
SedaProducer |
Modifier and Type | Class and Description |
---|---|
class |
StubComponent
The Stub Component is for stubbing out endpoints while developing or testing.
|
class |
StubConsumer |
class |
StubEndpoint
The stub component provides a simple way to stub out any physical endpoints while in development or testing.
|
Modifier and Type | Class and Description |
---|---|
class |
TestComponent
The Test Component is for simplifying unit and integration tests.
|
class |
TestEndpoint
The test component extends the mock component by on startup to pull messages from another endpoint to set the expected message bodies.
|
Modifier and Type | Class and Description |
---|---|
class |
TimerComponent
The Timer Component is for generating message exchanges when a timer fires.
|
class |
TimerConsumer
The timer consumer.
|
class |
TimerEndpoint
The timer component is used for generating message exchanges when a timer fires.
|
Modifier and Type | Class and Description |
---|---|
class |
ValidatorComponent
The Validator Component is for validating XML against a schema
|
class |
ValidatorEndpoint
Validates the payload of a message using XML Schema and JAXP Validation.
|
class |
ValidatorProducer |
Modifier and Type | Class and Description |
---|---|
class |
VmComponent
The VM component is for asynchronous SEDA exchanges on a
BlockingQueue
within the classloader tree containing the camel-core.jar. |
class |
VmConsumer |
class |
VmEndpoint
The vm component provides asynchronous call to another endpoint from the same CamelContext.
|
Modifier and Type | Class and Description |
---|---|
class |
XsltComponent
The XSLT Component is for performing XSLT transformations of messages
|
class |
XsltEndpoint
Transforms the message using a XSLT template.
|
Modifier and Type | Interface and Description |
---|---|
interface |
CamelClusterService |
interface |
CamelClusterView
Represents the View of the cluster at some given period of time.
|
Modifier and Type | Interface and Description |
---|---|
interface |
HealthCheckService
An health check service that invokes the checks registered on the
HealthCheckRegistry
according to a schedule. |
Modifier and Type | Class and Description |
---|---|
class |
BaseSelectorProducer
A base class for selector-based producers.
|
class |
ConsumerCache
Cache containing created
Consumer . |
class |
DefaultAsyncProcessorAwaitManager |
class |
DefaultAsyncProducer
|
class |
DefaultCamelContext
Represents the context used to configure routes and the policies to use.
|
class |
DefaultComponent
Default component to use for base for components implementations.
|
class |
DefaultConsumer
A default consumer useful for implementation inheritance.
|
class |
DefaultConsumerTemplate
|
class |
DefaultDebugger
The default implementation of the
Debugger . |
class |
DefaultEndpoint
A default endpoint useful for implementation inheritance.
|
class |
DefaultEndpointRegistry
Default implementation of
EndpointRegistry |
class |
DefaultExecutorServiceManager
Default
ExecutorServiceManager . |
class |
DefaultExecutorServiceStrategy
Deprecated.
use
ExecutorServiceManager instead, will be removed in a future Camel release |
class |
DefaultInflightRepository
Default
InflightRepository . |
class |
DefaultPackageScanClassResolver
Default implement of
PackageScanClassResolver |
class |
DefaultPollingConsumerServicePool
Deprecated.
|
class |
DefaultPollingEndpoint
A base class for an endpoint which the default consumer mode is to use a
PollingConsumer |
class |
DefaultProducer
A default implementation of
Producer for implementation inheritance. |
class |
DefaultProducerServicePool
Deprecated.
|
class |
DefaultProducerTemplate
|
class |
DefaultRestRegistry |
class |
DefaultRoute
Default implementation of
Route . |
class |
DefaultRouteController |
class |
DefaultRuntimeEndpointRegistry |
class |
DefaultScheduledPollConsumer
A default implementation of an event driven
Consumer which uses the
PollingConsumer |
class |
DefaultScheduledPollConsumerScheduler
Default
ScheduledBatchPollingConsumer . |
class |
DefaultServicePool<Key,Service>
Deprecated.
|
class |
DefaultShutdownStrategy
Default
ShutdownStrategy which uses graceful shutdown. |
class |
DefaultStreamCachingStrategy
Default implementation of
StreamCachingStrategy |
class |
DefaultTransformerRegistry
Default implementation of
TransformerRegistry . |
class |
DefaultUnitOfWork
The default implementation of
UnitOfWork |
class |
DefaultValidatorRegistry
Default implementation of
ValidatorRegistry . |
class |
DeferProducer
A
Producer that defers being started, until CamelContext has been started, this
ensures that the producer is able to adapt to changes that may otherwise occur during starting
CamelContext. |
class |
DurationRoutePolicy
RoutePolicy which executes for a duration and then triggers an action. |
class |
EmptyConsumerCache
A
ConsumerCache which is always empty and does not cache any Consumer s. |
class |
EmptyProducerCache
A
ProducerCache which is always empty and does not cache any Producer s. |
class |
EventDrivenConsumerRoute
A
DefaultRoute which starts with an
Event Driven Consumer
Use the API from CamelContext to control the lifecycle of a route,
such as starting and stopping using the CamelContext.startRoute(String)
and CamelContext.stopRoute(String) methods. |
class |
EventDrivenPollingConsumer
A default implementation of the
PollingConsumer which uses the normal
asynchronous consumer mechanism along with a BlockingQueue to allow
the caller to pull messages on demand. |
class |
FileStateRepository
This
FileStateRepository class is a file-based implementation of a StateRepository . |
class |
FileWatcherReloadStrategy
A file based
ReloadStrategy which watches a file folder
for modified files and reload on file changes. |
class |
GzipDataFormat
GZip
DataFormat for reading/writing data using gzip. |
class |
HeaderFilterStrategyComponent
Base class for components to support configuring a
HeaderFilterStrategy . |
class |
HeaderSelectorProducer
A selector-based produced which uses an header value to determine which processor
should be invoked.
|
class |
InterceptSendToEndpoint
This is an endpoint when sending to it, is intercepted and is routed in a detour
|
class |
LimitedPollingConsumerPollStrategy
A
PollingConsumerPollStrategy which supports suspending consumers if they
failed for X number of times in a row. |
class |
MDCUnitOfWork
This unit of work supports MDC.
|
class |
MemoryStateRepository
This
MemoryStateRepository class is a memory-based implementation of a StateRepository . |
class |
PollingConsumerSupport
A useful base class for implementations of
PollingConsumer |
class |
ProcessorEndpoint
An endpoint which allows exchanges to be sent into it which just invokes a
given
Processor . |
class |
ProcessorPollingConsumer
A simple implementation of
PollingConsumer which just uses
a Processor . |
class |
ProducerCache
Cache containing created
Producer . |
class |
RouteService
Represents the runtime objects for a given
RouteDefinition so that it can be stopped independently
of other routes |
class |
ScheduledBatchPollingConsumer
A useful base class for any consumer which is polling batch based
|
class |
ScheduledPollConsumer
A useful base class for any consumer which is polling based
|
class |
ScheduledPollEndpoint
A base class for
Endpoint which creates a ScheduledPollConsumer |
class |
SerializationDataFormat
The data format
using Java Serialization.
|
class |
SharedPollingConsumerServicePool
Deprecated.
|
class |
SharedProducerServicePool
Deprecated.
|
class |
StringDataFormat
The text based data format supporting
charset encoding.
|
class |
SubscribeMethodProcessor
A
Processor which is used for POJO @Consume where you can have multiple @Consume on the same endpoint/consumer
and via predicate's can filter and call different methods. |
class |
SupervisingRouteController
A simple implementation of the
RouteController that delays the startup
of the routes after the camel context startup and retries to start failing routes. |
class |
SynchronousDelegateProducer
To process the delegated producer in synchronous mode.
|
class |
ThrottlingExceptionRoutePolicy
Modeled after the
CircuitBreakerLoadBalancer and ThrottlingInflightRoutePolicy
this RoutePolicy will stop consuming from an endpoint based on the type of exceptions that are
thrown and the threshold setting. |
class |
ThrottlingInflightRoutePolicy
A throttle based
RoutePolicy which is capable of dynamic
throttling a route based on number of current inflight exchanges. |
class |
UriEndpointComponent
Deprecated.
use
DefaultComponent |
class |
WebSpherePackageScanClassResolver
WebSphere specific resolver to handle loading annotated resources in JAR files.
|
class |
ZipDataFormat
"Deflate" compression data format.
|
Modifier and Type | Method and Description |
---|---|
List<Service> |
DefaultRouteStartupOrder.getServices() |
List<Service> |
DefaultRoute.getServices() |
Modifier and Type | Method and Description |
---|---|
void |
DeferServiceStartupListener.addService(Service service) |
void |
DefaultRoute.addService(Service service) |
boolean |
DefaultShutdownStrategy.forceShutdown(Service service) |
protected void |
CamelPostProcessorHelper.startService(Service service,
CamelContext camelContext,
Object bean,
String beanName)
Stats the given service
|
Modifier and Type | Method and Description |
---|---|
protected void |
EventDrivenConsumerRoute.addServices(List<Service> services)
Factory method to lazily create the complete list of services required for this route
such as adding the processor or consumer
|
protected void |
DefaultRoute.addServices(List<Service> services)
Strategy method to allow derived classes to lazily load services for the route
|
void |
DefaultRoute.onStartingServices(List<Service> services) |
protected void |
RouteService.startChildService(Route route,
List<Service> services) |
protected void |
RouteService.stopChildService(Route route,
Set<Service> services,
boolean shutdown) |
Constructor and Description |
---|
DefaultRoute(RouteContext routeContext,
Endpoint endpoint,
Service... services) |
Modifier and Type | Class and Description |
---|---|
class |
DefaultServiceCallProcessor |
class |
DefaultServiceDiscovery |
class |
DefaultServiceLoadBalancer |
class |
StaticServiceDiscovery
A static list of known servers Camel Service Call EIP.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseTypeConverterRegistry
Base implementation of a type converter registry used for
type converters in Camel.
|
class |
DefaultTypeConverter
Default implementation of a type converter registry used for
type converters in Camel.
|
class |
LazyLoadingTypeConverter
Deprecated.
will be removed in a future Camel release.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCamelClusterService<T extends CamelClusterView> |
class |
AbstractCamelClusterView |
class |
ClusteredRouteController |
class |
ClusteredRoutePolicy |
Modifier and Type | Class and Description |
---|---|
class |
DefaultHealthCheckService |
Modifier and Type | Class and Description |
---|---|
class |
DataFormatTransformer
A
Transformer implementation which leverages DataFormat to perform transformation. |
class |
ProcessorTransformer
A
Transformer implementation which leverages Processor to perform transformation. |
Modifier and Type | Class and Description |
---|---|
class |
ProcessorValidator
|
Modifier and Type | Class and Description |
---|---|
class |
FileLanguage |
class |
SimpleLanguage
A simple language
which maps simple property style notations to access headers and bodies.
|
Modifier and Type | Class and Description |
---|---|
class |
Main
A command line tool for booting up a CamelContext
|
class |
MainDurationEventNotifier
A
EventNotifier to trigger shutdown of the Main JVM
when maximum number of messages has been processed. |
class |
MainSupport
Base class for main implementations to allow starting up a JVM with Camel embedded.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultManagementAgent
Default implementation of the Camel JMX service agent
|
class |
DefaultManagementLifecycleStrategy
Default JMX managed lifecycle strategy that registered objects using the configured
ManagementStrategy . |
class |
DefaultManagementMBeanAssembler
An assembler to assemble a
ModelMBean which can be used
to register the object in JMX. |
class |
DefaultManagementStrategy
A default management strategy that does not manage.
|
class |
InstrumentationProcessor
JMX enabled processor or advice that uses the
ManagedCounter for instrumenting
processing of exchanges. |
class |
JmxNotificationEventNotifier
A JMX based
EventNotifier which broadcasts JMX Notification s. |
class |
LoggingEventNotifier
Logging event notifier that only notifies if INFO log level has
been configured for its logger.
|
class |
ManagedLoadTimer
The
TimerListenerManager used for tracking load statistics. |
class |
ManagedManagementStrategy
A JMX capable
ManagementStrategy that Camel by default uses if possible. |
class |
MBeanInfoAssembler
A Camel specific
MBeanInfo assembler that reads the
details from the ManagedResource , ManagedAttribute , ManagedOperation ,
ManagedNotification , and ManagedNotifications annotations. |
class |
PublishEventNotifier
|
Modifier and Type | Method and Description |
---|---|
Object |
DefaultManagementObjectStrategy.getManagedObjectForService(CamelContext context,
Service service) |
ObjectName |
DefaultManagementNamingStrategy.getObjectNameForService(CamelContext context,
Service service) |
void |
DefaultManagementLifecycleStrategy.onServiceAdd(CamelContext context,
Service service,
Route route) |
void |
DefaultManagementLifecycleStrategy.onServiceRemove(CamelContext context,
Service service,
Route route) |
Modifier and Type | Method and Description |
---|---|
Service |
ManagedService.getService() |
Constructor and Description |
---|
ManagedService(CamelContext context,
Service service) |
Modifier and Type | Interface and Description |
---|---|
interface |
ModelCamelContext
Model level interface for the
CamelContext |
Modifier and Type | Class and Description |
---|---|
class |
AOPProcessor
Deprecated.
|
class |
BatchProcessor
Deprecated.
may be removed in the future when we overhaul the resequencer EIP
|
class |
CamelInternalProcessor
Internal
Processor that Camel routing engine used during routing for cross cutting functionality such as:
Execute UnitOfWork
Keeping track which route currently is being routed
Execute RoutePolicy
Gather JMX performance statics
Tracing
Debugging
Message History
Stream Caching
Transformer
... |
class |
CamelLogger
Deprecated.
This class has been split up into org.apache.camel.util.CamelLogger and org.apache.camel.processor.CamelLogProcessor
|
class |
CatchProcessor
A processor which catches exceptions.
|
class |
ChoiceProcessor
Implements a Choice structure where one or more predicates are used which if
they are true their processors are used, with a default otherwise clause used
if none match.
|
class |
ConvertBodyProcessor
A processor which converts the payload of the input message to be of the given type
If the conversion fails an
InvalidPayloadException is thrown. |
class |
DeadLetterChannel
Implements a Dead Letter
Channel after attempting to redeliver the message using the
RedeliveryPolicy |
class |
DefaultErrorHandler
Default error handler
|
class |
Delayer
A Delayer which
delays processing the exchange until the correct amount of time has elapsed
using an expression to determine the delivery time.
|
class |
DelayProcessorSupport
A useful base class for any processor which provides some kind of throttling
or delayed processing.
|
class |
DelegateAsyncProcessor
A Delegate pattern which delegates processing to a nested
AsyncProcessor which can
be useful for implementation inheritance when writing an Policy
Important: This implementation does support the asynchronous routing engine. |
class |
DelegateProcessor
|
class |
DelegateSyncProcessor
|
class |
DynamicRouter
Implements a Dynamic Router pattern
where the destination(s) is computed at runtime.
|
class |
Enricher
A content enricher that enriches input data by first obtaining additional
data from a resource represented by an endpoint
producer
and second by aggregating input data and additional data. |
class |
ErrorHandlerSupport
Support class for
ErrorHandler implementations. |
class |
ExchangePatternProcessor
Processor to set
ExchangePattern on the Exchange . |
class |
FatalFallbackErrorHandler
An
ErrorHandler used as a safe fallback when
processing by other error handlers such as the OnExceptionDefinition . |
class |
FilterProcessor
The processor which implements the
Message Filter EIP pattern.
|
class |
FinallyProcessor
Processor to handle do finally supporting asynchronous routing engine
|
class |
InterceptEndpointProcessor
Endpoint intercept processor so we know the processor is supposed to intercept an endpoint.
|
class |
InterceptorToAsyncProcessorBridge
A bridge to have regular interceptors implemented as
Processor
work with the asynchronous routing engine without causing side effects. |
class |
LoggingErrorHandler
Deprecated.
use
DeadLetterChannel using a log endpoint instead |
class |
LogProcessor
A processor which evaluates an
Expression and logs it. |
class |
LoopProcessor
The processor which sends messages in a loop.
|
class |
MarshalProcessor
Marshals the body of the incoming message using the given
data format
|
class |
MulticastProcessor
Implements the Multicast pattern to send a message exchange to a number of
endpoints, each endpoint receiving a copy of the message exchange.
|
class |
OnCompletionProcessor
Processor implementing onCompletion.
|
class |
Pipeline
Creates a Pipeline pattern where the output of the previous step is sent as
input to the next step, reusing the same message exchanges
|
class |
PollEnricher
A content enricher that enriches input data by first obtaining additional
data from a resource represented by an endpoint
producer
and second by aggregating input data and additional data. |
class |
RecipientList
Implements a dynamic Recipient List
pattern where the list of actual endpoints to send a message exchange to are
dependent on some dynamic expression.
|
class |
RecipientListProcessor
Implements a dynamic Recipient List
pattern where the list of actual endpoints to send a message exchange to are
dependent on some dynamic expression.
|
class |
RedeliveryErrorHandler
Base redeliverable error handler that also supports a final dead letter queue in case
all redelivery attempts fail.
|
class |
RemoveHeaderProcessor
A processor which removes the header from the IN or OUT message
|
class |
RemoveHeadersProcessor
A processor which removes one ore more headers from the IN or OUT message
|
class |
RemovePropertiesProcessor
A processor which removes one ore more properties from the exchange
|
class |
RemovePropertyProcessor
A processor which removes the property from the exchange
|
class |
Resequencer
An implementation of the Resequencer
which can reorder messages within a batch.
|
class |
RollbackProcessor
Processor for marking an
Exchange to rollback. |
class |
RoutingSlip
Implements a Routing Slip
pattern where the list of actual endpoints to send a message exchange to are
dependent on the value of a message header.
|
class |
SamplingThrottler
A
SamplingThrottler is a special kind of throttler. |
class |
ScriptProcessor
A processor which executes the script as an expression and does not change the message body.
|
class |
SendDynamicProcessor
Processor for forwarding exchanges to a dynamic endpoint destination.
|
class |
SendProcessor
Processor for forwarding exchanges to a static endpoint destination.
|
class |
SetBodyProcessor
A processor which sets the body on the IN or OUT message with an
Expression |
class |
SetHeaderProcessor
A processor which sets the header on the IN or OUT message with an
Expression |
class |
SetPropertyProcessor
A processor which sets the property on the exchange with an
Expression |
class |
SortProcessor<T>
A processor that sorts the expression using a comparator
|
class |
Splitter
Implements a dynamic Splitter pattern
where an expression is evaluated to iterate through each of the parts of a
message and then each part is then send to some endpoint.
|
class |
StopProcessor
Stops continue processing the route and marks it as complete.
|
class |
StreamResequencer
A resequencer that re-orders a (continuous) stream of
Exchange s. |
class |
ThreadsProcessor
Threads processor that leverage a thread pool for continue processing the
Exchange s
using the asynchronous routing engine. |
class |
Throttler
A Throttler
will set a limit on the maximum number of message exchanges which can be sent
to a processor within a specific time period.
|
class |
ThroughputLogger
A logger for logging message throughput.
|
class |
ThrowExceptionProcessor
|
class |
TransformProcessor
A processor which sets the body on the OUT message with an
Expression . |
class |
TryProcessor
Implements try/catch/finally type processing
|
class |
UnitOfWorkProducer
Ensures a
Producer is executed within an UnitOfWork . |
class |
UnmarshalProcessor
Unmarshals the body of the incoming message using the given
data format
|
class |
WireTapProcessor
Processor for wire tapping exchanges to an endpoint destination.
|
class |
WrapProcessor
A processor which ensures wrapping processors is having lifecycle handled.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregateProcessor
An implementation of the Aggregator
pattern where a batch of messages are processed (up to a maximum amount or
until some timeout is reached) and messages for the same correlation key are
combined together using some kind of
AggregationStrategy
(by default the latest message is used) to compress many message exchanges
into a smaller number of exchanges. |
class |
AggregationStrategyBeanAdapter
An
AggregationStrategy that adapts to a POJO. |
class |
MemoryAggregationRepository
A memory based
AggregationRepository which stores Exchange s in memory only. |
class |
ShareUnitOfWorkAggregationStrategy
An
AggregationStrategy which are used when the option shareUnitOfWork is enabled
on EIPs such as multicast, splitter or recipientList. |
Modifier and Type | Class and Description |
---|---|
class |
DataFormatBinding
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
FileIdempotentRepository
A file based implementation of
IdempotentRepository . |
class |
IdempotentConsumer
An implementation of the Idempotent Consumer pattern.
|
class |
MemoryIdempotentRepository
A memory based implementation of
IdempotentRepository . |
Modifier and Type | Class and Description |
---|---|
class |
BacklogDebugger
A
Debugger that has easy debugging functionality which
can be used from JMX with ManagedBacklogDebuggerMBean . |
class |
BacklogTracer
A tracer used for message tracing, storing a copy of the message details in a backlog.
|
class |
DefaultChannel
DefaultChannel is the default
Channel . |
class |
DefaultTraceEventHandler
Deprecated.
|
class |
DelayInterceptor
Deprecated.
no longer in use, will be removed in next Camel release.
|
class |
HandleFaultInterceptor |
class |
StreamCachingInterceptor
Deprecated.
no longer in use, will be removed in next Camel release.
|
class |
TraceInterceptor
Deprecated.
|
class |
Tracer
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
CircuitBreakerLoadBalancer
Deprecated.
|
class |
FailOverLoadBalancer
This FailOverLoadBalancer will failover to use next processor when an exception occurred
This implementation mirrors the logic from the
Pipeline in the async variation
as the failover load balancer is a specialized pipeline. |
class |
LoadBalancerConsumer
Represents a consumer which on starting registers itself with a
LoadBalancer and on closing unregisters
itself with a load balancer |
class |
LoadBalancerSupport
A default base class for a
LoadBalancer implementation. |
class |
QueueLoadBalancer
A base class for
LoadBalancer implementations which choose a single
destination for each exchange (rather like JMS Queues) |
class |
RandomLoadBalancer
Implements the random load balancing policy
|
class |
RoundRobinLoadBalancer
Implements the round robin load balancing policy
|
class |
SimpleLoadBalancerSupport
A default base class for a
LoadBalancer implementation. |
class |
StickyLoadBalancer
Implements a sticky load balancer using an
Expression to calculate
a correlation key to perform the sticky load balancing; rather like jsessionid in the web
or JMSXGroupID in JMS. |
class |
TopicLoadBalancer
A
LoadBalancer implementations which sends to all destinations
(rather like JMS Topics). |
class |
WeightedLoadBalancer |
class |
WeightedRandomLoadBalancer |
class |
WeightedRoundRobinLoadBalancer |
Modifier and Type | Class and Description |
---|---|
class |
PredicateValidatingProcessor
A processor which validates the content of the inbound message body against a
Predicate . |
Modifier and Type | Interface and Description |
---|---|
interface |
RuntimeCamelCatalog
Runtime based CamelCatalog which are included in camel-core that can provided limit CamelCatalog capabilities
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultRuntimeCamelCatalog
Default
RuntimeCamelCatalog . |
Modifier and Type | Interface and Description |
---|---|
interface |
AsyncProcessorAwaitManager
A manager to handle async routing engine, when
Exchange s 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. |
interface |
BrowsableEndpoint
An optional interface an
Endpoint may choose to implement which allows it to
expose a way of browsing the exchanges available. |
interface |
Debugger
A debugger which allows tooling to attach breakpoints which is is being invoked
when
Exchange s is being routed. |
interface |
EndpointRegistry<K>
Registry to cache endpoints in memory.
|
interface |
ExchangeIdempotentRepository<E>
Access to a repository of Message IDs to implement the
Idempotent Consumer pattern.
|
interface |
ExecutorServiceManager
Strategy to create thread pools.
|
interface |
ExecutorServiceStrategy
Deprecated.
use
ExecutorServiceManager instead, will be removed in a future Camel release |
interface |
IdempotentRepository<E>
Access to a repository of Message IDs to implement the
Idempotent Consumer pattern.
|
interface |
InflightRepository
A repository which tracks in flight
Exchange s. |
interface |
ManagementAgent
Camel JMX service agent
|
interface |
ManagementStrategy
Strategy for management.
|
interface |
ReloadStrategy
SPI strategy for reloading Camel routes in an existing running
CamelContext |
interface |
RestRegistry
A registry of all REST services running within the
CamelContext which have been defined and created
using the Rest DSL. |
interface |
RouteController |
interface |
RuntimeEndpointRegistry
A registry which listen for runtime usage of
Endpoint during routing in Camel. |
interface |
ScheduledPollConsumerScheduler
A pluggable scheduler for
ScheduledPollConsumer consumers. |
interface |
ShutdownStrategy
Pluggable shutdown strategy executed during shutdown of routes.
|
interface |
StateRepository<K,V>
This
StateRepository holds a set of key/value pairs for defining a particular state of a component. |
interface |
StreamCachingStrategy
Strategy for using stream caching.
|
interface |
TransformerRegistry<K>
Registry to cache transformers in memory.
|
interface |
TypeConverterRegistry
Registry for type converters.
|
interface |
UnitOfWork
An object representing the unit of work processing an
Exchange
which allows the use of Synchronization hooks. |
interface |
ValidatorRegistry<K>
Registry to cache validators in memory.
|
Modifier and Type | Class and Description |
---|---|
class |
Transformer
Transformer
performs message transformation according to the declared data type.
|
class |
Validator
Validator
performs message content validation according to the declared data type.
|
Modifier and Type | Method and Description |
---|---|
List<Service> |
RouteStartupOrder.getServices()
Gets the services to this route.
|
Modifier and Type | Method and Description |
---|---|
boolean |
ShutdownStrategy.forceShutdown(Service service)
Whether a service is forced to shutdown.
|
Object |
ManagementObjectStrategy.getManagedObjectForService(CamelContext context,
Service service) |
ObjectName |
ManagementNamingStrategy.getObjectNameForService(CamelContext context,
Service service) |
void |
LifecycleStrategy.onServiceAdd(CamelContext context,
Service service,
Route route)
Notification on adding a
Service . |
void |
LifecycleStrategy.onServiceRemove(CamelContext context,
Service service,
Route route)
Notification on removing a
Service . |
Modifier and Type | Class and Description |
---|---|
class |
ChildServiceSupport
Base class to control lifecycle for a set of child
Service s. |
class |
DefaultTimeoutMap<K,V>
Default implementation of the
TimeoutMap . |
class |
EventNotifierSupport
Base class to extend for custom
EventNotifier implementations. |
class |
ReloadStrategySupport
Base class for implementing custom
ReloadStrategy SPI plugins. |
class |
RoutePolicySupport
A base class for developing custom
RoutePolicy implementations. |
class |
ServiceSupport
A useful base class which ensures that a service is only initialized once and
provides some helper methods for enquiring of its status.
|
class |
TimerListenerManager
A
TimerListener manager which triggers the
TimerListener listeners once every second. |
Modifier and Type | Method and Description |
---|---|
void |
LifecycleStrategySupport.onServiceAdd(CamelContext context,
Service service,
Route route) |
void |
LifecycleStrategySupport.onServiceRemove(CamelContext context,
Service service,
Route route) |
Modifier and Type | Method and Description |
---|---|
static Set<Service> |
ServiceHelper.getChildServices(Service service)
Gathers all child services by navigating the service to recursively gather all child services.
|
static Set<Service> |
ServiceHelper.getChildServices(Service service,
boolean includeErrorHandler)
Gathers all child services by navigating the service to recursively gather all child services.
|
Modifier and Type | Method and Description |
---|---|
static Set<Service> |
ServiceHelper.getChildServices(Service service)
Gathers all child services by navigating the service to recursively gather all child services.
|
static Set<Service> |
ServiceHelper.getChildServices(Service service,
boolean includeErrorHandler)
Gathers all child services by navigating the service to recursively gather all child services.
|
static void |
ServiceHelper.startService(Service service)
Starts the given
service . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractApiComponent<E extends Enum<E> & ApiName,T,S extends ApiCollection<E,T>>
Abstract base class for API Component Camel
Component classes. |
class |
AbstractApiConsumer<E extends Enum<E> & ApiName,T>
Abstract base class for API Component Consumers.
|
class |
AbstractApiEndpoint<E extends ApiName,T>
Abstract base class for API Component Endpoints.
|
class |
AbstractApiProducer<E extends Enum<E> & ApiName,T>
Base class for API based Producers
|
Modifier and Type | Class and Description |
---|---|
class |
XsltAggregationStrategy
The XSLT Aggregation Strategy enables you to use XSL stylesheets to aggregate messages.
|
Apache Camel