Uses of Class
org.apache.camel.impl.ServiceSupport

Packages that use ServiceSupport
org.apache.camel The core Camel API 
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.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.file The File Component for working with file systems. 
org.apache.camel.component.jmx The JMX Component for monitoring JMX Attributes uisng a CounterMonitor. 
org.apache.camel.component.list The List 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.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.ref   
org.apache.camel.component.seda The SEDA Component for asynchronous SEDA exchanges on a BlockingQueue within a single CamelContext 
org.apache.camel.component.timer The Timer Component extends the POJO component to provide a simple timer 
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.impl Default implementation classes for Camel Core 
org.apache.camel.impl.converter Default implementation classes the Type Conversion Strategies 
org.apache.camel.management Camel JMX export services. 
org.apache.camel.processor A collection of Processor implementations which are used to implement the Enterprise Integration Patterns 
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.util Utility classes used by the core of Camel and useful for Camel component developers 
 

Uses of ServiceSupport in org.apache.camel
 

Subclasses of ServiceSupport in org.apache.camel
 class CamelTemplate<E extends Exchange>
          A client helper object (named like Spring's TransactionTemplate & JmsTemplate et al) for working with Camel and sending Message instances in an Exchange to an Endpoint.
 

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

Subclasses of ServiceSupport in org.apache.camel.component.bean
 class BeanComponent
          An alternative to the POJO Component which implements the Bean Component which will look up the URI in the Spring ApplicationContext and use that to handle message dispatching.
 class BeanProcessor
          A Processor which converts the inbound exchange to a method invocation on a POJO
 

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

Subclasses of ServiceSupport in org.apache.camel.component.dataset
 class DataSetComponent
           
 class DataSetConsumer
           
 

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

Subclasses of ServiceSupport in org.apache.camel.component.direct
 class DirectComponent<E extends Exchange>
          Represents the component that manages DirectEndpoint.
 class DirectProducer<E extends Exchange>
           
 

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

Subclasses of ServiceSupport in org.apache.camel.component.file
 class FileComponent
          The File Component for working with file systems
 class FileConsumer
          For consuming files.
 class FileProducer
          A Producer implementation for File
 

Uses of ServiceSupport in org.apache.camel.component.jmx
 

Subclasses of ServiceSupport in org.apache.camel.component.jmx
 class JMXComponent
          The JMX Component for monitoring jmx attributes
 class JMXConsumer
          Generate an Exchange after getting a JMX Notification
 

Uses of ServiceSupport in org.apache.camel.component.list
 

Subclasses of ServiceSupport in org.apache.camel.component.list
 class ListComponent
           
 

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

Subclasses of ServiceSupport in org.apache.camel.component.log
 class LogComponent
          The Log Component to log message exchanges to the underlying logging mechanism.
 

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

Subclasses of ServiceSupport in org.apache.camel.component.mock
 class MockComponent
          A factory of MockEndpoint instances
 

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

Subclasses of ServiceSupport in org.apache.camel.component.ref
 class RefComponent
          Component for lookup of existing endpoints bound in the Registry.
 

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

Subclasses of ServiceSupport in org.apache.camel.component.seda
 class CollectionProducer
          A simple Producer which just appends to a Collection the Exchange object.
 class ListPollingConsumer
           
 class QueueComponent
          An implementation of the Queue components for asynchronous SEDA exchanges on a BlockingQueue within a CamelContext
 class SedaComponent
          An implementation of the SEDA components for asynchronous SEDA exchanges on a BlockingQueue within a CamelContext
 class SedaConsumer
           
 

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

Subclasses of ServiceSupport in org.apache.camel.component.timer
 class TimerComponent
          Represents the component that manages TimerEndpoint.
 class TimerConsumer
           
 

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

Subclasses of ServiceSupport in org.apache.camel.component.vm
 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 ServiceSupport in org.apache.camel.impl
 

Subclasses of ServiceSupport in org.apache.camel.impl
 class DefaultCamelContext
          Represents the context used to configure routes and the policies to use.
 class DefaultComponent<E extends Exchange>
          Default component to use for base for components implementations.
 class DefaultConsumer<E extends Exchange>
           
 class DefaultProducer<E extends Exchange>
          A default implementation of @{link Producer} for implementation inheritence
 class DefaultScheduledPollConsumer<E extends Exchange>
          A default implementation of an event driven Consumer which uses the PollingConsumer
 class EventDrivenPollingConsumer<E extends Exchange>
          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 PollingConsumerSupport<E extends Exchange>
          A useful base class for implementations of PollingConsumer
 class ProcessorPollingConsumer
          A simple implementation of PollingConsumer which just uses a Processor.
 class ScheduledPollConsumer<E extends Exchange>
          A useful base class for any consumer which is polling based
 

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

Subclasses of ServiceSupport in org.apache.camel.impl.converter
static class AsyncProcessorTypeConverter.ProcessorToAsynProcessorBridge
           
 

Uses of ServiceSupport in org.apache.camel.management
 

Subclasses of ServiceSupport in org.apache.camel.management
 class InstrumentationAgentImpl
           
 class InstrumentationProcessor
           
 

Constructors in org.apache.camel.management with parameters of type ServiceSupport
ManagedService(ServiceSupport service)
           
 

Uses of ServiceSupport in org.apache.camel.processor
 

Subclasses of ServiceSupport in org.apache.camel.processor
 class Aggregator
          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 BatchProcessor
          A base class for any kind of Processor which implements some kind of batch processing.
 class CatchProcessor
           
 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 CompositeProcessor
          Represents a composite pattern, aggregating a collection of processors together as a single processor
 class DeadLetterChannel
          Implements a Dead Letter Channel after attempting to redeliver the message using the RedeliveryPolicy
 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
 class DelegateProcessor
          A Delegate pattern which delegates processing to a nested processor which can be useful for implementation inheritance when writing an Policy
 class ErrorHandlerSupport
          Support class for ErrorHandler implementations.
 class FilterProcessor
           
 class HandleFaultProcessor
           
 class Interceptor
          An interceptor which provides the processing logic as a pluggable processor which allows the DelegateProcessor.proceed(Exchange) method to be called at some point
 class LoggingErrorHandler
          An ErrorHandler which uses commons-logging to dump the error
 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 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 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 Resequencer
          An implementation of the Resequencer which can reorder messages within a batch.
 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 SendProcessor
           
 class SetHeaderProcessor
          A processor which sets the header on the IN message
 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 StreamResequencer
          A resequencer that re-orders a (continuous) stream of Exchanges.
 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 TransformProcessor
          A processor which sets the body on the OUT message with an expression
 class TryProcessor
          Implements try/catch/finally type processing
 class UnitOfWorkProcessor
          Handles calling the UnitOfWork.done() method when processing of an exchange is complete.
 

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

Subclasses of ServiceSupport in org.apache.camel.processor.idempotent
 class IdempotentConsumer
          An implementation of the Idempotent Consumer pattern.
 

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

Subclasses of ServiceSupport in org.apache.camel.processor.interceptor
 class StreamCachingInterceptor
          Interceptor that converts a message into a re-readable format
 

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

Subclasses of ServiceSupport in org.apache.camel.processor.loadbalancer
 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 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)
 

Uses of ServiceSupport in org.apache.camel.util
 

Subclasses of ServiceSupport in org.apache.camel.util
 class ProducerCache<E extends Exchange>
           
 



Copyright © 2008 IONA Open Source Community. All Rights Reserved.