Uses of Interface
org.apache.camel.Service

Packages that use Service
org.apache.camel The core Camel API. 
org.apache.camel.builder.xml Support for XPath based Expressions and Predicates as well as an XSLT processor 
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.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.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.seda The SEDA Component for asynchronous SEDA exchanges on a BlockingQueue within a single CamelContext 
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 extends the POJO component to provide 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.impl Default implementation classes for Camel Core 
org.apache.camel.impl.converter Default implementation classes the Type Conversion Strategies 
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.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. 
 

Uses of Service in org.apache.camel
 

Subinterfaces of Service in org.apache.camel
 interface BatchConsumer
          A consumer of a batch of message exchanges from an Endpoint
 interface CamelContext
          Interface used to represent the context 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
          Template for working with Camel and consuming Message instances in an Exchange from an Endpoint.
 interface Endpoint
          An endpoint implements the Message Endpoint pattern and represents an endpoint that can send and receive message exchanges
 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
          Template for working with Camel and sending Message instances in an Exchange to an Endpoint.
 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.
 

Methods in org.apache.camel that return types with arguments of type Service
 List<Service> Route.getServices()
          Returns the services for this particular route
 

Methods in org.apache.camel with parameters of type Service
 void Route.addService(Service service)
          Adds a service to this route
 

Method parameters in org.apache.camel with type arguments of type Service
 void Route.onStartingServices(List<Service> services)
          A strategy callback allowing special initialization when services are starting.
 

Uses of Service in org.apache.camel.builder.xml
 

Classes in org.apache.camel.builder.xml that implement Service
 class XPathBuilder
          Creates an XPath expression builder which creates a nodeset result by default.
 

Uses of Service in org.apache.camel.component
 

Classes in org.apache.camel.component that implement Service
 class ResourceEndpoint
          A useful base class for endpoints which depend on a resource such as things like Velocity or XQuery based components.
 

Uses of Service in org.apache.camel.component.bean
 

Classes in org.apache.camel.component.bean that implement Service
 class BeanComponent
          The Bean Component will look up the URI in the Registry and use that to handle message dispatching.
 class BeanEndpoint
          Endpoint for the bean component.
 class BeanProcessor
          A Processor which converts the inbound exchange to a method invocation on a POJO
 class ClassComponent
          The Class Component will create an instance of the class from the Registry and use that to handle message dispatching.
 

Uses of Service in org.apache.camel.component.binding
 

Classes in org.apache.camel.component.binding that implement Service
 class BindingComponent
          A composite Component which creates a BindingEndpoint from a configured Binding instance and using the optional BindingComponent.setUriPrefix(String) and BindingComponent.setUriPostfix(String) to create the underlying endpoint from the remaining URI
 class BindingConsumerProcessor
          Applies a Binding to a consumer
 class BindingEndpoint
          Applies 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 passed to the real consumer.
 class BindingNameComponent
          A Binding component using the URI form binding:nameOfBinding:endpointURI to extract the binding name which is then resolved from the registry and used to create a BindingEndpoint from the underlying Endpoint
 class BindingProducer
          A Producer which applies a Binding before invoking the underlying Producer on the Endpoint
 

Uses of Service in org.apache.camel.component.browse
 

Classes in org.apache.camel.component.browse that implement Service
 class BrowseComponent
          The browse component.
 class BrowseEndpoint
          An endpoint which maintains a List of Exchange instances which can be useful for tooling, debugging and visualising routes.
 

Uses of Service in org.apache.camel.component.controlbus
 

Classes in org.apache.camel.component.controlbus that implement Service
 class ControlBusComponent
          The control bus component.
 class ControlBusEndpoint
          The control bus endpoint.
 class ControlBusProducer
          The control bus producer.
 

Uses of Service in org.apache.camel.component.dataformat
 

Classes in org.apache.camel.component.dataformat that implement Service
 class DataFormatComponent
           
 class DataFormatEndpoint
           
 

Uses of Service in org.apache.camel.component.dataset
 

Classes in org.apache.camel.component.dataset that implement Service
 class DataSetComponent
          Component for DataSet.
 class DataSetConsumer
          DataSet consumer.
 class DataSetEndpoint
          Endpoint for DataSet.
 

Uses of Service in org.apache.camel.component.direct
 

Classes in org.apache.camel.component.direct that implement Service
 class DirectBlockingProducer
          The direct producer.
 class DirectComponent
          Represents the component that manages DirectEndpoint.
 class DirectConsumer
          The direct consumer.
 class DirectEndpoint
          Represents a direct endpoint that synchronously invokes the consumer of the endpoint when a producer sends a message to it.
 class DirectProducer
          The direct producer.
 

Uses of Service in org.apache.camel.component.directvm
 

Classes in org.apache.camel.component.directvm that implement Service
 class DirectVmBlockingProducer
          The direct producer.
 class DirectVmComponent
          Represents the component that manages DirectVmEndpoint.
 class DirectVmConsumer
          The direct-vm consumer
 class DirectVmEndpoint
          The direct-vm endpoint.
 class DirectVmProcessor
           
 class DirectVmProducer
          The direct-vm producer
 

Uses of Service in org.apache.camel.component.file
 

Classes in org.apache.camel.component.file that implement Service
 class FileComponent
          File component.
 class FileConsumer
          File consumer.
 class FileEndpoint
          File endpoint.
 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
 

Uses of Service in org.apache.camel.component.language
 

Classes in org.apache.camel.component.language that implement Service
 class LanguageComponent
          The language component to send Exchanges to a given language and have the script being executed.
 class LanguageEndpoint
          Language endpoint.
 class LanguageProducer
          Language producer.
 

Uses of Service in org.apache.camel.component.log
 

Classes in org.apache.camel.component.log that implement Service
 class LogComponent
          The Log Component to log message exchanges to the underlying logging mechanism.
 class LogEndpoint
          Logger endpoint.
 class LogProducer
          Log producer.
 

Uses of Service in org.apache.camel.component.mock
 

Classes in org.apache.camel.component.mock that implement Service
 class MockComponent
          A factory of MockEndpoint instances
 class MockEndpoint
          A Mock endpoint which provides a literate, fluent API for testing routes using a JMock style API.
 

Uses of Service in org.apache.camel.component.properties
 

Classes in org.apache.camel.component.properties that implement Service
 class PropertiesComponent
          The properties component.
 

Uses of Service in org.apache.camel.component.ref
 

Classes in org.apache.camel.component.ref that implement Service
 class RefComponent
          Component for lookup of existing endpoints bound in the Registry.
 

Uses of Service in org.apache.camel.component.seda
 

Classes in org.apache.camel.component.seda that implement Service
 class CollectionProducer
          Deprecated. will be removed in a future Camel release
 class SedaComponent
          An implementation of the SEDA components for asynchronous SEDA exchanges on a BlockingQueue within a CamelContext
 class SedaConsumer
          A Consumer for the SEDA component.
 class SedaEndpoint
          An implementation of the Queue components for asynchronous SEDA exchanges on a BlockingQueue within a CamelContext
 class SedaPollingConsumer
           
 class SedaProducer
           
 

Uses of Service in org.apache.camel.component.stub
 

Classes in org.apache.camel.component.stub that implement Service
 class StubComponent
          Allows you to easily stub out a middleware transport by prefixing the URI with "stub:" which is handy for testing out routes, or isolating bits of middleware.
 

Uses of Service in org.apache.camel.component.test
 

Classes in org.apache.camel.component.test that implement Service
 class TestComponent
          Test Component.
 class TestEndpoint
          A Test Endpoint is a Mock Endpoint for testing but it will pull all messages from the nested endpoint and use those as expected message body assertions.
 

Uses of Service in org.apache.camel.component.timer
 

Classes in org.apache.camel.component.timer that implement Service
 class TimerComponent
          Represents the component that manages TimerEndpoint.
 class TimerConsumer
          The timer consumer.
 class TimerEndpoint
          Represents a timer endpoint that can generate periodic inbound exchanges triggered by a timer.
 

Uses of Service in org.apache.camel.component.validator
 

Classes in org.apache.camel.component.validator that implement Service
 class ValidatorComponent
          The Validator Component for validating XML against some schema
 

Uses of Service in org.apache.camel.component.vm
 

Classes in org.apache.camel.component.vm that implement Service
 class VmComponent
          An implementation of the VM components for asynchronous SEDA exchanges on a BlockingQueue within the classloader tree containing the camel-core.jar.
 

Uses of Service in org.apache.camel.component.xslt
 

Classes in org.apache.camel.component.xslt that implement Service
 class XsltComponent
          An XSLT Component for performing XSLT transforms of messages
 class XsltEndpoint
           
 

Uses of Service in org.apache.camel.impl
 

Classes in org.apache.camel.impl that implement Service
 class ConsumerCache
          Cache containing created Consumer.
 class DefaultAsyncProducer
          A default implementation of Producer for implementation inheritance, which can process Exchanges asynchronously.
 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
          Template (named like Spring's TransactionTemplate & JmsTemplate et al) for working with Camel and consuming Message instances in an Exchange from an Endpoint.
 class DefaultDebugger
          The default implementation of the Debugger.
 class DefaultEndpoint
          A default endpoint useful for implementation inheritance.
 class DefaultExecutorServiceManager
           
 class DefaultExecutorServiceStrategy
          Deprecated. use ExecutorServiceManager instead, will be removed in a future Camel release
 class DefaultInflightRepository
          Default implement which just uses a counter
 class DefaultPackageScanClassResolver
          Default implement of PackageScanClassResolver
 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
          A service pool for Producer.
 class DefaultProducerTemplate
          Template (named like Spring's TransactionTemplate & JmsTemplate et al) for working with Camel and sending Message instances in an Exchange to an Endpoint.
 class DefaultRoute
          Default implementation of Route.
 class DefaultScheduledPollConsumer
          A default implementation of an event driven Consumer which uses the PollingConsumer
 class DefaultScheduledPollConsumerScheduler
           
 class DefaultServicePool<Key,Service>
          Default implementation to inherit for a basic service pool.
 class DefaultShutdownStrategy
          Default ShutdownStrategy which uses graceful shutdown.
 class DefaultStreamCachingStrategy
          Default implementation of StreamCachingStrategy
 class DefaultUnitOfWork
          The default implementation of UnitOfWork
 class EndpointRegistry
          Endpoint registry which is a based on a LRUSoftCache.
 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 HeaderFilterStrategyComponent
           
 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 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 RoutePolicySupport
          A base class for developing custom RoutePolicy implementations.
 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 SharedProducerServicePool
          A shared DefaultProducerServicePool which is used by CamelContext by default.
 class SynchronousDelegateProducer
          To process the delegated producer in synchronous mode.
 class ThrottlingInflightRoutePolicy
          A throttle based RoutePolicy which is capable of dynamic throttling a route based on number of current inflight exchanges.
 class UriEndpointComponent
          A component implementation for endpoints which are annotated with UriEndpoint to describe their configurable parameters via annotations
 class WebSpherePackageScanClassResolver
          WebSphere specific resolver to handle loading annotated resources in JAR files.
 

Methods in org.apache.camel.impl that return types with arguments of type Service
 List<Service> DefaultRoute.getServices()
           
 List<Service> DefaultRouteStartupOrder.getServices()
           
 

Methods in org.apache.camel.impl with parameters of type Service
 void DefaultRoute.addService(Service service)
           
 boolean DefaultShutdownStrategy.forceShutdown(Service service)
           
protected  void CamelPostProcessorHelper.startService(Service service, Object bean, String beanName)
          Stats the given service
 

Method parameters in org.apache.camel.impl with type arguments of type Service
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)
           
 

Constructors in org.apache.camel.impl with parameters of type Service
DefaultRoute(RouteContext routeContext, Endpoint endpoint, Service... services)
           
 

Uses of Service in org.apache.camel.impl.converter
 

Classes in org.apache.camel.impl.converter that implement Service
 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.
 

Uses of Service in org.apache.camel.main
 

Classes in org.apache.camel.main that implement Service
 class Main
          A command line tool for booting up a CamelContext
 class MainSupport
           
 

Uses of Service in org.apache.camel.management
 

Classes in org.apache.camel.management that implement Service
 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 DefaultManagementStrategy
          A default management strategy that does not manage.
 class InstrumentationProcessor
          JMX enabled processor that uses the ManagedCounter for instrumenting processing of exchanges.
 class JmxNotificationEventNotifier
          A JMX based EventNotifier which broadcasts JMX Notifications.
 class LoggingEventNotifier
          Logging event notifier that only notifies if INFO log level has been configured for its logger.
 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
          A EventNotifier which publishes the EventObject to some Endpoint.
 

Methods in org.apache.camel.management with parameters of type Service
 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)
           
 

Uses of Service in org.apache.camel.management.mbean
 

Methods in org.apache.camel.management.mbean that return Service
 Service ManagedService.getService()
           
 

Constructors in org.apache.camel.management.mbean with parameters of type Service
ManagedService(CamelContext context, Service service)
           
 

Uses of Service in org.apache.camel.model
 

Subinterfaces of Service in org.apache.camel.model
 interface ModelCamelContext
          Model level interface for the CamelContext
 

Uses of Service in org.apache.camel.processor
 

Classes in org.apache.camel.processor that implement Service
 class AOPProcessor
           
 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 ...
 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
          A Delegate pattern which delegates processing to a nested Processor which can be useful for implementation inheritance when writing an Policy

Important: This implementation does not support the asynchronous routing engine.

 class DelegateSyncProcessor
          A Delegate pattern which delegates synchronous processing to a nested Processor which can be useful for implementation inheritance when writing an Policy

Important: This implementation does support the asynchronous routing engine, only.

 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
           
 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
          An ErrorHandler which uses commons-logging to dump the error
 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
           
 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 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 SendProcessor
          Processor for forwarding exchanges to an endpoint destination.
 class SetBodyProcessor
          A processor which sets the body on the IN or OUT message 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 Exchanges.
 class ThreadsProcessor
          Threads processor that leverage a thread pool for continue processing the Exchanges 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
          The processor which sets an Exception on the Exchange
 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.
 

Uses of Service in org.apache.camel.processor.aggregate
 

Classes in org.apache.camel.processor.aggregate that implement Service
 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 Exchanges in memory only.
 

Uses of Service in org.apache.camel.processor.binding
 

Classes in org.apache.camel.processor.binding that implement Service
 class DataFormatBinding
          Represents a Binding which Marshals the message in the ProduceProcessor and Unmarshals the message in the ConsumeProcessor
 

Uses of Service in org.apache.camel.processor.idempotent
 

Classes in org.apache.camel.processor.idempotent that implement Service
 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.
 

Uses of Service in org.apache.camel.processor.interceptor
 

Classes in org.apache.camel.processor.interceptor that implement Service
 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
           
 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
          An interceptor for debugging and tracing routes
 class Tracer
          An interceptor strategy for tracing routes
 

Uses of Service in org.apache.camel.processor.loadbalancer
 

Classes in org.apache.camel.processor.loadbalancer that implement Service
 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
           
 

Uses of Service in org.apache.camel.processor.validation
 

Classes in org.apache.camel.processor.validation that implement Service
 class PredicateValidatingProcessor
          A processor which validates the content of the inbound message body against a Predicate.
 

Uses of Service in org.apache.camel.spi
 

Subinterfaces of Service in org.apache.camel.spi
 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 Exchanges is being routed.
 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 Exchanges.
 interface ManagementAgent
          Camel JMX service agent
 interface ManagementStrategy
          Strategy for management.
 interface ScheduledPollConsumerScheduler
          A pluggable scheduler for ScheduledPollConsumer consumers.
 interface ShutdownStrategy
          Pluggable shutdown strategy executed during shutdown of routes.
 interface StreamCachingStrategy
          Strategy for using stream caching.
 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.
 

Methods in org.apache.camel.spi that return types with arguments of type Service
 List<Service> RouteStartupOrder.getServices()
          Gets the services to this route.
 

Methods in org.apache.camel.spi with parameters of type Service
 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.
 

Uses of Service in org.apache.camel.support
 

Classes in org.apache.camel.support that implement Service
 class ChildServiceSupport
           
 class DefaultTimeoutMap<K,V>
          Default implementation of the TimeoutMap.
 class EventNotifierSupport
          Base class to extend for custom EventNotifier 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.
 

Methods in org.apache.camel.support with parameters of type Service
 void LifecycleStrategySupport.onServiceAdd(CamelContext context, Service service, Route route)
           
 void LifecycleStrategySupport.onServiceRemove(CamelContext context, Service service, Route route)
           
 

Uses of Service in org.apache.camel.util
 

Methods in org.apache.camel.util that return types with arguments of type Service
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.
 

Methods in org.apache.camel.util with parameters of type Service
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 boolean ServiceHelper.resumeService(Service service)
          Resumes the given service.
static void ServiceHelper.startService(Service service)
          Starts the given service.
static boolean ServiceHelper.suspendService(Service service)
          Suspends the given service.
 



Apache Camel