|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use SuspendableService | |
---|---|
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.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.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.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.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.support | Base classes that help to implement the camel API and are expected to be extended by the user |
Uses of SuspendableService in org.apache.camel |
---|
Subinterfaces of SuspendableService in org.apache.camel | |
---|---|
interface |
CamelContext
Interface used to represent the context used to configure routes and the policies to use during message exchanges between endpoints. |
interface |
StatefulService
A Service which has all the lifecycle events and offers details about its current state. |
Uses of SuspendableService in org.apache.camel.builder.xml |
---|
Classes in org.apache.camel.builder.xml that implement SuspendableService | |
---|---|
class |
XPathBuilder
Creates an XPath expression builder which creates a nodeset result by default. |
Uses of SuspendableService in org.apache.camel.component |
---|
Classes in org.apache.camel.component that implement SuspendableService | |
---|---|
class |
ResourceEndpoint
A useful base class for endpoints which depend on a resource such as things like Velocity or XQuery based components. |
Uses of SuspendableService in org.apache.camel.component.bean |
---|
Classes in org.apache.camel.component.bean that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.component.browse |
---|
Classes in org.apache.camel.component.browse that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.component.dataset |
---|
Classes in org.apache.camel.component.dataset that implement SuspendableService | |
---|---|
class |
DataSetComponent
Component for DataSet. |
class |
DataSetConsumer
DataSet consumer. |
class |
DataSetEndpoint
Endpoint for DataSet. |
Uses of SuspendableService in org.apache.camel.component.direct |
---|
Classes in org.apache.camel.component.direct that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.component.directvm |
---|
Classes in org.apache.camel.component.directvm that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.component.file |
---|
Classes in org.apache.camel.component.file that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.component.language |
---|
Classes in org.apache.camel.component.language that implement SuspendableService | |
---|---|
class |
LanguageComponent
The language component to send Exchange s to a given language and have the script being executed. |
class |
LanguageEndpoint
Language endpoint. |
class |
LanguageProducer
Language producer. |
Uses of SuspendableService in org.apache.camel.component.log |
---|
Classes in org.apache.camel.component.log that implement SuspendableService | |
---|---|
class |
LogComponent
The Log Component to log message exchanges to the underlying logging mechanism. |
class |
LogEndpoint
Logger endpoint. |
class |
LogProducer
Log producer. |
Uses of SuspendableService in org.apache.camel.component.mock |
---|
Classes in org.apache.camel.component.mock that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.component.properties |
---|
Classes in org.apache.camel.component.properties that implement SuspendableService | |
---|---|
class |
PropertiesComponent
The properties component. |
Uses of SuspendableService in org.apache.camel.component.ref |
---|
Classes in org.apache.camel.component.ref that implement SuspendableService | |
---|---|
class |
RefComponent
Component for lookup of existing endpoints bound in the Registry . |
Uses of SuspendableService in org.apache.camel.component.seda |
---|
Classes in org.apache.camel.component.seda that implement SuspendableService | |
---|---|
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 |
SedaProducer
|
Uses of SuspendableService in org.apache.camel.component.stub |
---|
Classes in org.apache.camel.component.stub that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.component.test |
---|
Classes in org.apache.camel.component.test that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.component.timer |
---|
Classes in org.apache.camel.component.timer that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.component.validator |
---|
Classes in org.apache.camel.component.validator that implement SuspendableService | |
---|---|
class |
ValidatorComponent
The Validator Component for validating XML against some schema |
Uses of SuspendableService in org.apache.camel.component.vm |
---|
Classes in org.apache.camel.component.vm that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.component.xslt |
---|
Classes in org.apache.camel.component.xslt that implement SuspendableService | |
---|---|
class |
XsltComponent
An XSLT Component for performing XSLT transforms of messages |
class |
XsltEndpoint
|
Uses of SuspendableService in org.apache.camel.impl |
---|
Classes in org.apache.camel.impl that implement SuspendableService | |
---|---|
class |
ConsumerCache
Cache containing created Consumer . |
class |
DefaultAsyncProducer
A default implementation of Producer for implementation inheritance,
which can process Exchange s 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 |
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 |
DefaultServicePool<Key,Service>
Default implementation to inherit for a basic service pool. |
class |
DefaultShutdownStrategy
Default ShutdownStrategy which uses graceful shutdown. |
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 |
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 |
ThrottlingInflightRoutePolicy
A throttle based RoutePolicy which is capable of dynamic
throttling a route based on number of current inflight exchanges. |
class |
WebSpherePackageScanClassResolver
WebSphere specific resolver to handle loading annotated resources in JAR files. |
Uses of SuspendableService in org.apache.camel.impl.converter |
---|
Classes in org.apache.camel.impl.converter that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.main |
---|
Classes in org.apache.camel.main that implement SuspendableService | |
---|---|
class |
Main
A command line tool for booting up a CamelContext |
class |
MainSupport
|
Uses of SuspendableService in org.apache.camel.management |
---|
Classes in org.apache.camel.management that implement SuspendableService | |
---|---|
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 |
InstrumentationProcessor
JMX enabled processor 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 |
PublishEventNotifier
A EventNotifier which publishes the EventObject to some
Endpoint . |
Uses of SuspendableService in org.apache.camel.model |
---|
Subinterfaces of SuspendableService in org.apache.camel.model | |
---|---|
interface |
ModelCamelContext
Model level interface for the CamelContext |
Uses of SuspendableService in org.apache.camel.processor |
---|
Classes in org.apache.camel.processor that implement SuspendableService | |
---|---|
class |
AOPProcessor
|
class |
BatchProcessor
Deprecated. may be removed in the future when we overhaul the resequencer EIP |
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 |
ChildUnitOfWorkProcessor
An UnitOfWorkProcessor that creates a child UnitOfWork that is
associated to a parent UnitOfWork . |
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 |
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 |
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 |
RouteContextProcessor
This processor tracks the current RouteContext while processing the Exchange . |
class |
RouteInflightRepositoryProcessor
This processor tracks the current RouteContext while processing the Exchange . |
class |
RoutePolicyProcessor
Processor which instruments the RoutePolicy . |
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 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 Exchange s. |
class |
SubUnitOfWorkProcessor
A processor that processes the processor in a SubUnitOfWork context. |
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
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 |
UnitOfWorkProcessor
Ensures the Exchange is routed under the boundaries of 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 SuspendableService in org.apache.camel.processor.aggregate |
---|
Classes in org.apache.camel.processor.aggregate that implement SuspendableService | |
---|---|
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 |
MemoryAggregationRepository
A memory based AggregationRepository which stores in memory only. |
Uses of SuspendableService in org.apache.camel.processor.idempotent |
---|
Classes in org.apache.camel.processor.idempotent that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.processor.interceptor |
---|
Classes in org.apache.camel.processor.interceptor that implement SuspendableService | |
---|---|
class |
DefaultChannel
DefaultChannel is the default Channel . |
class |
DelayInterceptor
An interceptor for delaying routes. |
class |
HandleFaultInterceptor
|
class |
StreamCachingInterceptor
An interceptor that converts streams messages into a re-readable format by wrapping the stream into a StreamCache . |
class |
TraceInterceptor
An interceptor for debugging and tracing routes |
Uses of SuspendableService in org.apache.camel.processor.loadbalancer |
---|
Classes in org.apache.camel.processor.loadbalancer that implement SuspendableService | |
---|---|
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 SuspendableService in org.apache.camel.processor.validation |
---|
Classes in org.apache.camel.processor.validation that implement SuspendableService | |
---|---|
class |
PredicateValidatingProcessor
A processor which validates the content of the inbound message body against a Predicate . |
Uses of SuspendableService in org.apache.camel.support |
---|
Classes in org.apache.camel.support that implement SuspendableService | |
---|---|
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. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |