Package org.apache.camel.spi
Service Provider Interfaces used by the Camel runtime which are plugin strategies.
-
Interface Summary Interface Description AggregationRepository Access to a repository to store aggregated exchanges to support pluggable implementations.AnnotationBasedProcessorFactory Factory to createProcessor
for annotation based EIPs.AnnotationScanTypeConverters ATypeConverter
which is capable of annotation scanning forConverter
classes and add these as type converters.AsyncProcessorAwaitManager A manager to handle async routing engine, whenExchange
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.AsyncProcessorAwaitManager.AwaitThread Information about the thread and exchange that are inflight.AsyncProcessorAwaitManager.Statistics Utilization statistics of the this manager.AuthorizationPolicy A marker for defining the policy to be used for applying authorization to routes.BeanIntrospection Used for introspecting beans properties via Java reflection; such as extracting current property values, or updating one or more properties etc.BeanProcessorFactory Factory for creating aProcessor
that can invoke a method on a bean and supporting using Camel bean parameter bindings.BeanProxyFactory A factory for creating aProxy
for a bean.BeanRepository Represents a bean repository used to lookup components by name and type.Breakpoint Breakpoint
are used by theDebugger
API.BrowsableEndpoint An optional interface anEndpoint
may choose to implement which allows it to expose a way of browsing the exchanges available.CamelBeanPostProcessor Bean post processor.CamelContextNameStrategy Strategy for assigning name to aCamelContext
.CamelContextTracker.Filter CamelEvent This interface is implemented by all events.CamelEvent.CamelContextEvent CamelEvent.CamelContextResumedEvent CamelEvent.CamelContextResumeFailureEvent CamelEvent.CamelContextResumingEvent CamelEvent.CamelContextRoutesStartedEvent CamelEvent.CamelContextRoutesStartingEvent CamelEvent.CamelContextRoutesStoppedEvent CamelEvent.CamelContextRoutesStoppingEvent CamelEvent.CamelContextStartedEvent CamelEvent.CamelContextStartingEvent CamelEvent.CamelContextStartupFailureEvent CamelEvent.CamelContextStopFailureEvent CamelEvent.CamelContextStoppedEvent CamelEvent.CamelContextStoppingEvent CamelEvent.CamelContextSuspendedEvent CamelEvent.CamelContextSuspendingEvent CamelEvent.ExchangeCompletedEvent CamelEvent.ExchangeCreatedEvent CamelEvent.ExchangeEvent CamelEvent.ExchangeFailedEvent CamelEvent.ExchangeFailureEvent CamelEvent.ExchangeFailureHandledEvent CamelEvent.ExchangeFailureHandlingEvent CamelEvent.ExchangeRedeliveryEvent CamelEvent.ExchangeSendingEvent CamelEvent.ExchangeSentEvent CamelEvent.FailureEvent This interface is implemented by all events that contain an exception and is used to retrieve the exception in a universal way.CamelEvent.RouteAddedEvent CamelEvent.RouteEvent CamelEvent.RouteRemovedEvent CamelEvent.RouteStartedEvent CamelEvent.RouteStoppedEvent CamelEvent.ServiceEvent CamelEvent.ServiceStartupFailureEvent CamelEvent.ServiceStopFailureEvent CamelEvent.StepCompletedEvent CamelEvent.StepEvent CamelEvent.StepFailedEvent CamelEvent.StepStartedEvent CamelInternalProcessorAdvice<T> An advice (before and after) to execute cross cutting functionality in the Camel routing engine.CircuitBreakerConstants ClaimCheckRepository Access to a repository of keys to implement the Claim Check pattern.ClassResolver A class resolver for loading classes in a loosly coupled manner to cater for different platforms such as standalone, web container, j2ee container and OSGi platforms.ComponentCustomizer<T extends Component> ComponentNameResolver Discovers which components are available on the classpath.ComponentResolver Represents a resolver of components from a URI to be able to auto-load them using some discovery mechanism likeorg.apache.camel.impl.DefaultComponentResolver
Condition A condition to define when a givenExchange
matches when is being routed.ConfigurerResolver A pluggable strategy for resolving different configurers in a loosely coupled mannerConsumerCache Cache containing createdPollingConsumer
.DataFormat Represents a data format used to marshal objects to and from streams such as Java Serialization or using JAXB2 to encode/decode objects using XML or using SOAP encoding.DataFormatContentTypeHeader Special accessor for a DataFormatDataFormatCustomizer<T extends DataFormat> DataFormatFactory A factory to createDataFormat
.DataFormatName The name of theDataFormat
which allows to know which kind of data format the implementation is.DataFormatResolver Represents a resolver of data formats.DataTypeAware Debugger A debugger which allows tooling to attach breakpoints which is is being invoked whenExchange
s is being routed.DeferServiceFactory Factory to create services such asProducer
s and defer starting the created service, untilCamelContext
has been started.EndpointRegistry<K> Registry to cache endpoints in memory.EndpointStrategy Endpoint strategy with callback invoked when anEndpoint
is about to be registered to the endpoint registry inCamelContext
.EndpointUtilizationStatistics Various statistics about endpoint utilization, such as from EIP patterns that uses dynamic endpoints.EventFactory Factory to createevents
that are emitted when such an event occur.EventNotifier Notifier to sendevents
.ExceptionHandler A Strategy pattern for handling exceptions; particularly in asynchronous processes such as consumers.ExchangeFormatter A plugin used to turn anExchange
into a String representation usually to be used for logging or tracing purposes.ExecutorServiceManager Strategy to create thread pools.ExpressionResultTypeAware Represents anExpression
orPredicate
that supports a result type.FactoryFinder Finder to find factories from the resource classpath, usually META-INF/services/org/apache/camel/.FactoryFinderResolver Represents a resolver forFactoryFinder
GeneratedPropertyConfigurer A auto generatedPropertyConfigurer
for fast configuration of Camel components & endpoints.GroupAware To allow objects to be injected with an group.HasCamelContext A simple marker interface for an object which holds a CamelContextHasGroup A simple marker interface for an object which has belongs to a group Group which is useful for group related operation such as clustering, JMX style APIHasId A simple marker interface for an object which has a unique ID which is useful for referring to objects in REST or JMX style APIsHeaderFilterStrategy Interface to allow plug-able implementation to filter header to and from Camel message.HeaderFilterStrategyAware An interface to represent an object which can make use of injectedHeaderFilterStrategy
.HeadersMapFactory IdAware To allow objects to be injected with an id, such as EIPProcessor
s which has been defined from Camel routes.IdempotentRepository Access to a repository of Message IDs to implement the Idempotent Consumer pattern.InflightRepository A repository which tracks in flightExchange
s.InflightRepository.InflightExchange Information about the inflight exchange.Injector A pluggable strategy for creating and possibly dependency injecting objects which could be implemented using straight forward reflection or using Spring or CDI to perform dependency injection.InterceptSendToEndpoint This is an endpoint when sending to it, is intercepted and is routed in a detour, with the following flow: before, send to original endpoint (can be skipped), after (optional).InterceptStrategy The purpose of this interface is to allow an implementation to wrap processors in a route with interceptors.Language Represents a language to be used forExpression
orPredicate
instancesLanguageCustomizer<T extends Language> LanguageResolver A pluggable strategy for resolving different languages in a loosely coupled mannerLifecycleStrategy Strategy for lifecycle notifications.LoadablePropertiesSource A source for properties that can be loaded all at once during initialization, such as loading .properties files.LogListener An event listener SPI for logging.ManagementAgent Camel JMX service agentManagementInterceptStrategy ManagementInterceptStrategy.InstrumentationProcessor<T> ManagementMBeanAssembler An assembler to assemble aRequiredModelMBean
which can be used to register the object in JMX.ManagementNameStrategy Strategy for assigning the name part of theObjectName
for a managedCamelContext
.ManagementObjectNameStrategy Strategy for computingObjectName
names for the various beans that Camel register for management.ManagementObjectStrategy Strategy for creating the managed object for the various beans Camel register for management.ManagementStrategy Strategy for management.ManagementStrategyFactory Service Factory for ManagementStrategyMaskingFormatter A plugin used to mask a log String, for example security information like password or passphrase.MessageHistoryFactory A factory to createMessageHistory
instances.ModelJAXBContextFactory Factory to abstract the creation of the Model's javax.xml.bind.JAXBContext.ModelToXMLDumper SPI for dumping model definitions into XML representation.NamespaceAware Represents an object which is aware of the namespaces in which its used such as XPath and XQuery type expressions so that the current namespace context can be injectedNodeIdFactory Factory to generate unique ids for model nodes.NormalizedEndpointUri An Uri which has been normalized.NotifyBuilderMatcher Allows to be used in combination with NotifyBuilder as external predicate implementations to compute if the exchange matches.OnCamelContextEvent Marker interface used to make it easy to discoverCamelContext
related event handlers from the registry.OnCamelContextInitialized Notification on initializing aCamelContext
.OnCamelContextStart Notification on starting aCamelContext
.OnCamelContextStop Notification on stopping aCamelContext
.OptimisticLockingAggregationRepository A specializedAggregationRepository
which also supports optimistic locking.PackageScanClassResolver A resolver that can find classes based on package scanning.PackageScanFilter Filter that can be used with thePackageScanClassResolver
resolver.PackageScanResourceResolver A resolver that can find resources based on package scanning.Policy A strategy capable of applying interceptors to a processor.PollingConsumerPollStrategy Strategy for aPollingConsumer
when polling anEndpoint
.ProcessorFactory A factory to createProcessor
based on thedefinition
.ProducerCache Cache containing createdProducer
.ProducerCache.AsyncProducerCallback Callback for sending a exchange message to a endpoint using anAsyncProcessor
capable producer.PropertiesComponent Component for property placeholders and loading properties from sources (such as .properties file from classpath or file system)PropertiesFunction A function that is applied instead of looking up a property placeholder.PropertiesSource A source for properties.PropertyConfigurer A marker interface to identify the object as being configurable via a configurer class.PropertyConfigurerAware An interface to represent an object which is capable of configuring viaPropertyConfigurer
.PropertyConfigurerGetter A marker interface to identify the object as being a configurer which can provide details about the options the configurer supports.ReactiveExecutor SPI to plugin different reactive engines in the Camel routing engine.RecoverableAggregationRepository A specializedAggregationRepository
which also supports recovery.Registry Represents aBeanRepository
which may also be capable of binding beans to its repository.RestApiConsumerFactory Allows SPI to plugin aRestApiConsumerFactory
that creates the CamelConsumer
responsible for handling incoming HTTP GET requests from clients that request to access the REST API documentation.RestApiProcessorFactory Allows SPI to plugin aRestApiProcessorFactory
that creates the CamelProcessor
responsible for servicing and generating the REST API documentation.RestBindingJaxbDataFormatFactory SPI for setting up XML data format (JAXB) for rest-dsl.RestConsumerFactory Allows SPI to plugin aRestConsumerFactory
that creates the CamelConsumer
responsible for handling incoming HTTP requests from clients that request to access REST services which has been created using the rest-dsl.RestProducerFactory Allows SPI to plugin aRestProducerFactory
that creates the CamelProducer
responsible for performing HTTP requests to call a remote REST service.RestRegistry A registry of all REST services running within theCamelContext
which have been defined and created using the Rest DSL.RestRegistry.RestService Details about the REST serviceRestRegistryFactory A factory forRestRegistry
.RouteController Controller for managing the lifecycle of all theRoute
's.RouteError RouteIdAware To allow objects to be injected with the route idRoutePolicy Policy for aRoute
which allows controlling the route at runtime.RoutePolicyFactory A factory to createRoutePolicy
and assign to routes automatic.RouteStartupOrder Information about a route to be started where we want to control the order in which they are started byCamelContext
.RuntimeEndpointRegistry A registry which listen for runtime usage ofEndpoint
during routing in Camel.RuntimeEndpointRegistry.Statistic Statistics gathered about the endpoint.ScheduledPollConsumerScheduler A pluggable scheduler fororg.apache.camel.support.ScheduledPollConsumer
consumers.SendDynamicAware ShutdownAware AllowsConsumer
to fine grained control on shutdown which mostly have to cater for in-memory based components.ShutdownPrepared Allows aService
to prepare for shutdown.ShutdownStrategy Pluggable shutdown strategy executed during shutdown of routes.StateRepository<K,V> ThisStateRepository
holds a set of key/value pairs for defining a particular state of a component.StreamCachingStrategy Strategy for using stream caching.StreamCachingStrategy.SpoolRule Rule for determine if stream caching should be spooled to disk or kept in-memory.StreamCachingStrategy.Statistics Utilization statistics of stream caching.SupervisingRouteController A supervising capableRouteController
that delays the startup of the routes after the camel context startup and takes control of starting the routes in a safe manner.Synchronization Provides a hook for customProcessor
orComponent
instances to respond to completed or failed processing of anExchange
rather like Spring's TransactionSynchronizationSynchronizationRouteAware An extendedSynchronization
which is route aware.SynchronizationVetoable A vetoableSynchronization
.ThreadPoolFactory Creates ExecutorService and ScheduledExecutorService objects that work with a thread pool for a given ThreadPoolProfile and ThreadFactory.Tracer SPI for tracing messages.TransactedPolicy A marker for defining the policy to be used for applying transaction to routes.TransformerRegistry<K> Registry to cache transformers in memory.TypeConverterLoader A pluggable strategy to load type converters into aTypeConverterRegistry
from some kind of mechanism.TypeConverterRegistry Registry for type converters.TypeConverterRegistry.Statistics Utilization statistics of the this registry.UnitOfWork An object representing the unit of work processing anExchange
which allows the use ofSynchronization
hooks.UnitOfWorkFactory Factory to createUnitOfWork
.UuidGenerator Generator to generate UUID strings.ValidatorRegistry<K> Registry to cache validators in memory.XMLRoutesDefinitionLoader SPI for loading routes/rests from XML input streams and parsing this to model definition classes. -
Class Summary Class Description BeanIntrospection.ClassInfo Structure of an introspected class.BeanIntrospection.MethodInfo Structure of an introspected method.CamelContextTracker ACamelContext
creation and destruction tracker.CamelLogger A logger which logs to a slf4jLogger
.Contract DataType Represents the data type URN which is used for message data type contract.ReifierStrategy Strategy for reifiers.RestConfiguration Configuration use byRestConsumerFactory
andRestApiConsumerFactory
for Camel components to support the Camelrest
DSL.SendDynamicAware.DynamicAwareEntry An entry of detailed information from the recipient uri, which allows theSendDynamicAware
implementation to prepare pre- and post- processor and the static uri to be used for the optimised dynamic to.ThreadPoolProfile A profile which defines thread pool settings.Transformer Transformer performs message transformation according to the declared data type.Validator Validator performs message content validation according to the declared data type. -
Enum Summary Enum Description Breakpoint.State State of the breakpoint as either active or suspended.CamelEvent.Type HeaderFilterStrategy.Direction The direction is either IN or OUT.RestConfiguration.RestBindingMode RestConfiguration.RestHostNameResolver RouteError.Phase StreamCachingStrategy.SpoolUsedHeapMemoryLimit Used for selecting if the memory limit is committed or maximum heap memory setting. -
Exception Summary Exception Description OptimisticLockingAggregationRepository.OptimisticLockingException Exception
used by anAggregationRepository
to indicate that an optimistic update error has occurred and that the operation should be retried by the caller. -
Annotation Types Summary Annotation Type Description AsEndpointUri Indicates that the Camel string/expression should be used as an endpoint uri.AsPredicate Indicates that the Camel language/expression should be used as predicate.Configurer An annotation used to mark classes to indicate code capable of configuring its options via a getter/setters that can be called via CamelsPropertyConfigurer
.InvokeOnHeader Marks a method as being invoked for a specific header value.InvokeOnHeaders Marks a method as being invoked for a specific header value.Metadata Meta data for EIPs, components, data formats and other Camel conceptsUriEndpoint Represents an annotated Camel Endpoint which can have its properties (and the properties on its consumer) injected from the Camel URI path and its query parametersUriParam Represents an injection point of a Camel Uri parameter value on an Endpoint or Consumer, usually configured via a URI style query parameter in a URIUriParams Used to annotate a nested configuration parameter type (such as a nested Configuration object) which can then be used on a Component, Endpoint and/or Consumer and then be configured via Camel URI query arguments.UriPath Represents an injection point of a Camel Uri path value (the remaining part of a Camel URI without any query arguments)