A B C D E F G H I L M N O P R S T V W

A

AbstractQueue - class org.apache.excalibur.event.impl.AbstractQueue.
Provides the base functionality for the other Queue types.
AbstractQueue() - Constructor for class org.apache.excalibur.event.impl.AbstractQueue
 
AbstractThreadManager - class org.apache.excalibur.event.command.AbstractThreadManager.
Abstract base class for a ThreadManager that has a single ThreadPool for all pipelines
AbstractThreadManager() - Constructor for class org.apache.excalibur.event.command.AbstractThreadManager
 
AbstractThreadManager.PipelineRunner - class org.apache.excalibur.event.command.AbstractThreadManager.PipelineRunner.
The PipelineRunner class pulls all the events from the Source, and puts them in the EventHandler.
AbstractThreadManager.PipelineRunner(EventPipeline) - Constructor for class org.apache.excalibur.event.command.AbstractThreadManager.PipelineRunner
Create a PipelineRunner.
accept(Object, Sink) - Method in class org.apache.excalibur.event.command.CommandManager
Tests the given element for acceptance onto the m_sink.
accept(Object[], Sink) - Method in class org.apache.excalibur.event.command.CommandManager
Tests the given element for acceptance onto the m_sink.
accept(Object, Sink) - Method in class org.apache.excalibur.event.impl.NullEnqueuePredicate
 
accept(Object[], Sink) - Method in class org.apache.excalibur.event.impl.NullEnqueuePredicate
 
accept(Object, Sink) - Method in class org.apache.excalibur.event.impl.RateLimitingPredicate
 
accept(Object[], Sink) - Method in class org.apache.excalibur.event.impl.RateLimitingPredicate
 
accept(Object, Sink) - Method in class org.apache.excalibur.event.impl.ThresholdEnqueuePredicate
Returns true if the Sink size + 1 (the element) is less than the threshold.
accept(Object[], Sink) - Method in class org.apache.excalibur.event.impl.ThresholdEnqueuePredicate
Returns true if the Sink size + the number of elements is less than the threshold.
acquire() - Method in class org.apache.excalibur.mpool.BlockingFixedSizePool
 
acquire() - Method in class org.apache.excalibur.mpool.FixedSizePool
 
acquire() - Method in class org.apache.excalibur.mpool.VariableSizePool
 
after(Source) - Method in class org.apache.excalibur.event.command.TPSPThreadManager.SourceDequeueInterceptor
An operation executed after dequeing events from the queue.
after(Source) - Method in class org.apache.excalibur.event.impl.NullDequeueInterceptor
An operation executed after dequeing events from the queue.
architecture() - Static method in class org.apache.excalibur.util.SystemUtil
Return the architecture name

B

BlockingFixedSizePool - class org.apache.excalibur.mpool.BlockingFixedSizePool.
This is an Pool that caches Poolable objects for reuse.
BlockingFixedSizePool(ObjectFactory, int) - Constructor for class org.apache.excalibur.mpool.BlockingFixedSizePool
 
BlockingFixedSizePool(ObjectFactory, int, long) - Constructor for class org.apache.excalibur.mpool.BlockingFixedSizePool
 
before(Source) - Method in class org.apache.excalibur.event.command.TPSPThreadManager.SourceDequeueInterceptor
An operation executed before dequeing events from the queue.
before(Source) - Method in class org.apache.excalibur.event.impl.NullDequeueInterceptor
An operation executed before dequeing events from the queue.
block(Object) - Method in class org.apache.excalibur.event.impl.AbstractQueue
Encapsulates the logic to block the Queue for the amount of time specified by the timeout.

C

CPUParser - interface org.apache.excalibur.util.CPUParser.
This interface is for CPUParser objects that are automagically loaded, and perform architecture dependant processing for determining the number of CPUs, and the generic infomation about them.
CommandManager - class org.apache.excalibur.event.command.CommandManager.
The CommandManager handles asynchronous commands from the rest of the system.
CommandManager() - Constructor for class org.apache.excalibur.event.command.CommandManager
Create the CommandManager
canAccept() - Method in class org.apache.excalibur.event.impl.AbstractQueue
Default for canAccept()
canAccept() - Method in class org.apache.excalibur.event.impl.LossyMultiCastSink
 
canAccept() - Method in class org.apache.excalibur.event.impl.MultiCastSink
 
cpuInfo() - Method in interface org.apache.excalibur.util.CPUParser
Return the cpu info for the processors (assuming symetric multiprocessing which means that all CPUs are identical).
cpuInfo() - Static method in class org.apache.excalibur.util.SystemUtil
 
cpuInfo() - Method in class org.apache.excalibur.util.system.Linux
Return the cpu info for the processors (assuming symetric multiprocessing which means that all CPUs are identical).
cpuInfo() - Method in class org.apache.excalibur.util.system.Windows2000
Return the cpu info for the processors (assuming symetric multiprocessing which means that all CPUs are identical).
cpuInfo() - Method in class org.apache.excalibur.util.system.Windows95
Return the cpu info for the processors (assuming symetric multiprocessing which means that all CPUs are identical).
cpuInfo() - Method in class org.apache.excalibur.util.system.Windows98
Return the cpu info for the processors (assuming symetric multiprocessing which means that all CPUs are identical).
cpuInfo() - Method in class org.apache.excalibur.util.system.WindowsNT
Return the cpu info for the processors (assuming symetric multiprocessing which means that all CPUs are identical).
cpuInfo() - Method in class org.apache.excalibur.util.system.WindowsXP
Return the cpu info for the processors (assuming symetric multiprocessing which means that all CPUs are identical).

D

DefaultPoolManager - class org.apache.excalibur.mpool.DefaultPoolManager.
This interface is for a PoolManager that creates pools that are managed asynchronously.
DefaultPoolManager() - Constructor for class org.apache.excalibur.mpool.DefaultPoolManager
 
DefaultPoolManager(Sink) - Constructor for class org.apache.excalibur.mpool.DefaultPoolManager
 
DefaultQueue - class org.apache.excalibur.event.impl.DefaultQueue.
The default queue implementation is a variable size queue.
DefaultQueue(int) - Constructor for class org.apache.excalibur.event.impl.DefaultQueue
Construct a new DefaultQueue with the specified number of elements.
DefaultQueue(EnqueuePredicate) - Constructor for class org.apache.excalibur.event.impl.DefaultQueue
 
DefaultQueue() - Constructor for class org.apache.excalibur.event.impl.DefaultQueue
Create an unbounded DefaultQueue.
DefaultThreadManager - class org.apache.excalibur.event.command.DefaultThreadManager.
A ThreadManager that will use an external ThreadPool.
DefaultThreadManager(Executor) - Constructor for class org.apache.excalibur.event.command.DefaultThreadManager
Create a new ThreadManager with the associated ThreadPool.
dequeue(int) - Method in class org.apache.excalibur.event.impl.DefaultQueue
 
dequeue() - Method in class org.apache.excalibur.event.impl.DefaultQueue
 
dequeue(int) - Method in class org.apache.excalibur.event.impl.FixedSizeQueue
Deprecated.  
dequeue() - Method in class org.apache.excalibur.event.impl.FixedSizeQueue
Deprecated.  
dequeueAll() - Method in class org.apache.excalibur.event.impl.DefaultQueue
 
dequeueAll() - Method in class org.apache.excalibur.event.impl.FixedSizeQueue
Deprecated.  
deregister(EventPipeline) - Method in class org.apache.excalibur.event.command.AbstractThreadManager
Deregister an EventPipeline with the ThreadManager
deregister(EventPipeline) - Method in class org.apache.excalibur.event.command.TPSPThreadManager
Deregister an EventPipeline with the ThreadManager
deregisterAll() - Method in class org.apache.excalibur.event.command.AbstractThreadManager
Deregisters all EventPipelines from this ThreadManager
deregisterAll() - Method in class org.apache.excalibur.event.command.TPSPThreadManager
Deregisters all EventPipelines from this ThreadManager
deregisterSignalHandler(Signal, EventHandler) - Method in class org.apache.excalibur.event.command.CommandManager
Deregister a Signal with an EventHandler.
dispose() - Method in class org.apache.excalibur.event.command.AbstractThreadManager
Get rid of the ThreadManager.
dispose() - Method in class org.apache.excalibur.event.command.CommandManager
When you are done with CommandManager, call this and it will clean up all its resources.
dispose() - Method in class org.apache.excalibur.mpool.BlockingFixedSizePool
 
dispose() - Method in class org.apache.excalibur.mpool.FixedSizePool
 
dispose() - Method in class org.apache.excalibur.mpool.VariableSizePool
 
doDispose() - Method in class org.apache.excalibur.event.command.AbstractThreadManager
 
doDispose() - Method in class org.apache.excalibur.event.command.TPCThreadManager
 

E

EMPTY_ARRAY - Static variable in class org.apache.excalibur.event.impl.AbstractQueue
An empty array used as a return value when the Queue is empty
enqueue(Object[]) - Method in class org.apache.excalibur.event.impl.DefaultQueue
 
enqueue(Object) - Method in class org.apache.excalibur.event.impl.DefaultQueue
 
enqueue(Object[]) - Method in class org.apache.excalibur.event.impl.FixedSizeQueue
Deprecated.  
enqueue(Object) - Method in class org.apache.excalibur.event.impl.FixedSizeQueue
Deprecated.  
enqueue(Object) - Method in class org.apache.excalibur.event.impl.LossyMultiCastSink
 
enqueue(Object[]) - Method in class org.apache.excalibur.event.impl.LossyMultiCastSink
 
enqueue(Object) - Method in class org.apache.excalibur.event.impl.MultiCastSink
 
enqueue(Object[]) - Method in class org.apache.excalibur.event.impl.MultiCastSink
 

F

FixedSizePool - class org.apache.excalibur.mpool.FixedSizePool.
This is an Pool that caches Poolable objects for reuse.
FixedSizePool(ObjectFactory, int) - Constructor for class org.apache.excalibur.mpool.FixedSizePool
 
FixedSizeQueue - class org.apache.excalibur.event.impl.FixedSizeQueue.
Deprecated. Use the DefaultQueue as it properly supports the EnqueuePredicates
FixedSizeQueue(int) - Constructor for class org.apache.excalibur.event.impl.FixedSizeQueue
Deprecated. Create a FixedSizedQueue with the specified maximum size.

G

getBucketSize() - Method in class org.apache.excalibur.event.impl.RateLimitingPredicate
Returns the number of tokens currently in the bucket.
getCommandFailureHandler() - Method in class org.apache.excalibur.event.command.CommandManager
Get the failure handler so that CommandManager can use it when a problem happens.
getCommandSink() - Method in class org.apache.excalibur.event.command.CommandManager
Get the Command Sink so that you can enqueue new commands.
getDepth() - Method in class org.apache.excalibur.event.impl.RateLimitingPredicate
Returns the current depth.
getDequeueInterceptor() - Method in class org.apache.excalibur.event.impl.AbstractQueue
Return the dequeue executable for this sink.
getEnqueuePredicate() - Method in class org.apache.excalibur.event.impl.AbstractQueue
Return the EnqueuePredicate that is already set for this Queue.
getEventHandler() - Method in class org.apache.excalibur.event.command.CommandManager
Used by the ThreadManager to get the EventHandler for the CommandManager.
getManagedPool(ObjectFactory, int) - Method in class org.apache.excalibur.mpool.DefaultPoolManager
Return a managed pool that has a controller.
getSleepTime() - Method in class org.apache.excalibur.event.command.AbstractThreadManager
Get the current amount of sleep time.
getSource() - Method in class org.apache.excalibur.event.command.TPSPThreadManager.SourceRunner
Get a reference to the Source.
getSources() - Method in class org.apache.excalibur.event.command.CommandManager
Used by the Threadmanager to get the sources that are feeding the CommandManager.
getTargetRate() - Method in class org.apache.excalibur.event.impl.RateLimitingPredicate
Returns the current rate limit.
grow(int, long) - Method in class org.apache.excalibur.mpool.VariableSizePool
 

H

handleCommandFailure(Command, Throwable) - Method in class org.apache.excalibur.event.command.NullCommandFailureHandler
Handle a command failure.

I

initialize() - Method in class org.apache.excalibur.event.command.AbstractThreadManager
Set up the ThreadManager.
initialize() - Method in class org.apache.excalibur.event.command.TPCThreadManager
 
initialize() - Method in class org.apache.excalibur.mpool.BlockingFixedSizePool
 
isFull() - Method in class org.apache.excalibur.event.impl.AbstractQueue
Check to see if the Queue is full.
isFull() - Method in class org.apache.excalibur.event.impl.LossyMultiCastSink
 
isFull() - Method in class org.apache.excalibur.event.impl.MultiCastSink
 
isInitialized() - Method in class org.apache.excalibur.event.command.AbstractThreadManager
Return whether the thread manager has been initialized or not

L

Linux - class org.apache.excalibur.util.system.Linux.
Parses the Linux environment--Uses the proc filesystem to determine all the CPU information.
Linux() - Constructor for class org.apache.excalibur.util.system.Linux
 
LossyMultiCastSink - class org.apache.excalibur.event.impl.LossyMultiCastSink.
This is a org.apache.excalibur.event.seda.event.Sink implementation that multicasts enqueue operations to the contained and concrete sink objects.
LossyMultiCastSink(Collection) - Constructor for class org.apache.excalibur.event.impl.LossyMultiCastSink
This constructor creates a failure tolerant sink based on the collection of sink arrays.
LossyMultiCastSink(Collection, boolean) - Constructor for class org.apache.excalibur.event.impl.LossyMultiCastSink
This constructor creates a failure tolerant sink based on the collection of sink arrays.

M

MultiCastSink - class org.apache.excalibur.event.impl.MultiCastSink.
This is a org.apache.excalibur.event.seda.event.Sink implementation that multicasts enqueue operations to the contained and concrete sink objects.
MultiCastSink(Collection) - Constructor for class org.apache.excalibur.event.impl.MultiCastSink
This constructor creates a failure in-tolerant multicast sink based on the collection of sink arrays.
MultiCastSink(Collection, boolean) - Constructor for class org.apache.excalibur.event.impl.MultiCastSink
This constructor creates a failure in-tolerant multicast sink based on the collection of sink arrays.
m_interceptor - Variable in class org.apache.excalibur.event.impl.AbstractQueue
 
m_predicate - Variable in class org.apache.excalibur.event.impl.AbstractQueue
 
m_reserve - Variable in class org.apache.excalibur.event.impl.DefaultQueue
 
m_reserve - Variable in class org.apache.excalibur.event.impl.FixedSizeQueue
Deprecated.  
m_semaphore - Variable in class org.apache.excalibur.mpool.BlockingFixedSizePool
The semaphor we synchronize on
m_timeout - Variable in class org.apache.excalibur.event.impl.AbstractQueue
The number of milliseconds to wait
maxSize() - Method in class org.apache.excalibur.event.impl.AbstractQueue
Default maxSize to -1 which is unbounded
maxSize() - Method in class org.apache.excalibur.event.impl.DefaultQueue
Return the maximum number of elements that will fit in the Queue.
maxSize() - Method in class org.apache.excalibur.event.impl.FixedSizeQueue
Deprecated.  
maxSize() - Method in class org.apache.excalibur.event.impl.LossyMultiCastSink
 
maxSize() - Method in class org.apache.excalibur.event.impl.MultiCastSink
 

N

NullCommandFailureHandler - class org.apache.excalibur.event.command.NullCommandFailureHandler.
NullCommandFailureHandler is used to do nothing if a command fails.
NullCommandFailureHandler() - Constructor for class org.apache.excalibur.event.command.NullCommandFailureHandler
 
NullDequeueInterceptor - class org.apache.excalibur.event.impl.NullDequeueInterceptor.
The dequeue executable interface describes operations that are executed before and after elements are pulled from a queue.
NullDequeueInterceptor() - Constructor for class org.apache.excalibur.event.impl.NullDequeueInterceptor
 
NullEnqueuePredicate - class org.apache.excalibur.event.impl.NullEnqueuePredicate.
The NullEnqueuePredicate does nothing to limit a Queue's ability to enqueue.
NullEnqueuePredicate() - Constructor for class org.apache.excalibur.event.impl.NullEnqueuePredicate
 
newInstance() - Method in class org.apache.excalibur.mpool.BlockingFixedSizePool
 
newInstance() - Method in class org.apache.excalibur.mpool.FixedSizePool
 
newInstance() - Method in class org.apache.excalibur.mpool.VariableSizePool
 
numProcessors() - Method in interface org.apache.excalibur.util.CPUParser
Return the number of processors available on the machine
numProcessors() - Static method in class org.apache.excalibur.util.SystemUtil
Return the number of processors available on this machine.
numProcessors() - Method in class org.apache.excalibur.util.system.Linux
Return the number of processors available on the machine
numProcessors() - Method in class org.apache.excalibur.util.system.Windows2000
Return the number of processors available on the machine
numProcessors() - Method in class org.apache.excalibur.util.system.Windows95
Return the number of processors available on the machine
numProcessors() - Method in class org.apache.excalibur.util.system.Windows98
Return the number of processors available on the machine
numProcessors() - Method in class org.apache.excalibur.util.system.WindowsNT
Return the number of processors available on the machine
numProcessors() - Method in class org.apache.excalibur.util.system.WindowsXP
Return the number of processors available on the machine

O

operatingSystem() - Static method in class org.apache.excalibur.util.SystemUtil
Return the Operating System name
org.apache.excalibur.event.command - package org.apache.excalibur.event.command
 
org.apache.excalibur.event.impl - package org.apache.excalibur.event.impl
 
org.apache.excalibur.mpool - package org.apache.excalibur.mpool
 
org.apache.excalibur.util - package org.apache.excalibur.util
 
org.apache.excalibur.util.system - package org.apache.excalibur.util.system
 
osVersion() - Static method in class org.apache.excalibur.util.SystemUtil
Return the Operating System version

P

PoolUtil - class org.apache.excalibur.mpool.PoolUtil.
The PoolUtil class performs the reflection magic that is necessary to work with the legacy Recyclable interface in the Pool package.
parameterize(Parameters) - Method in class org.apache.excalibur.event.command.TPCThreadManager
The following parameters can be set for this class: Name Description Default Value processors Number of processors (autodetected if less than one) Results from SystemUtil.numProcessors() threads-per-processor Threads per processor to use (Rewritten to 1 if less than one) 1 sleep-time Time (in milliseconds) to wait between queue pipeline processing runs 1000 keep-alive-time Time (in milliseconds) that idle threads should remain in the threadpool 300000 force-shutdown At shutdown time, allow currently queued tasks to finish, or immediately quit false
prepareEnqueue(Object[]) - Method in class org.apache.excalibur.event.impl.DefaultQueue
 
prepareEnqueue(Object[]) - Method in class org.apache.excalibur.event.impl.FixedSizeQueue
Deprecated.  
prepareEnqueue(Object[]) - Method in class org.apache.excalibur.event.impl.LossyMultiCastSink
 
prepareEnqueue(Object[]) - Method in class org.apache.excalibur.event.impl.MultiCastSink
 

R

RateLimitingPredicate - class org.apache.excalibur.event.impl.RateLimitingPredicate.
This enqueue predicate implements input rate policing.
RateLimitingPredicate(int) - Constructor for class org.apache.excalibur.event.impl.RateLimitingPredicate
Create a new RateLimitingPredicate for the given sink, bucket depth and no rate limit.
RateLimitingPredicate(double, int) - Constructor for class org.apache.excalibur.event.impl.RateLimitingPredicate
Create a new RateLimitingPredicate for the given sink, targetRate, and token bucket depth.
recycle(Object) - Static method in class org.apache.excalibur.mpool.PoolUtil
This method will either call "reset" on Resettable objects, or it will call "recycle" on Recyclable objects.
register(EventPipeline) - Method in class org.apache.excalibur.event.command.AbstractThreadManager
Register an EventPipeline with the ThreadManager.
register(EventPipeline) - Method in class org.apache.excalibur.event.command.TPSPThreadManager
Register an EventPipeline with the ThreadManager.
registerSignalHandler(Signal, EventHandler) - Method in class org.apache.excalibur.event.command.CommandManager
Register a Signal with an EventHandler.
release(Object) - Method in class org.apache.excalibur.mpool.BlockingFixedSizePool
 
release(Object) - Method in class org.apache.excalibur.mpool.FixedSizePool
 
release(Object) - Method in class org.apache.excalibur.mpool.VariableSizePool
 
run() - Method in class org.apache.excalibur.event.command.AbstractThreadManager.PipelineRunner
The code that actually pulls the events from the Sources and sends them to the event handler
run() - Method in class org.apache.excalibur.event.command.AbstractThreadManager
The code that is run in the background to manage the ThreadPool and the EventPipelines
run() - Method in class org.apache.excalibur.event.command.TPSPThreadManager.SourceRunner
Called by the PooledExecutor to ensure all components are working.

S

SHARED_INSTANCE - Static variable in class org.apache.excalibur.event.command.NullCommandFailureHandler
 
SystemUtil - class org.apache.excalibur.util.SystemUtil.
A set of utility operations that provide necessary information about the architecture of the machine that the system is running on.
setCommandFailureHandler(CommandFailureHandler) - Method in class org.apache.excalibur.event.command.CommandManager
Set the failure handler that the application can use to override what happens when a command failure happens.
setDepth(int) - Method in class org.apache.excalibur.event.impl.RateLimitingPredicate
Allows to set the bucket depth.
setDequeueInterceptor(DequeueInterceptor) - Method in class org.apache.excalibur.event.impl.AbstractQueue
Set the dequeue executable for this sink.
setEnqueuePredicate(EnqueuePredicate) - Method in class org.apache.excalibur.event.impl.AbstractQueue
Set the EnqueuePredicate to limit entries into this Queue.
setExecutor(Executor) - Method in class org.apache.excalibur.event.command.AbstractThreadManager
Set the executor we are using
setSleepTime(long) - Method in class org.apache.excalibur.event.command.AbstractThreadManager
Set the amount of time to sleep between checks on the queue
setTargetRate(double) - Method in class org.apache.excalibur.event.impl.RateLimitingPredicate
Allows to set the rate limit.
setTimeout(long) - Method in class org.apache.excalibur.event.impl.AbstractQueue
Set the timeout for the Queue in milliseconds.
shrink(int, long) - Method in class org.apache.excalibur.mpool.VariableSizePool
 
size() - Method in class org.apache.excalibur.event.impl.DefaultQueue
Return the number of elements currently in the Queue.
size() - Method in class org.apache.excalibur.event.impl.FixedSizeQueue
Deprecated.  
size() - Method in class org.apache.excalibur.event.impl.LossyMultiCastSink
 
size() - Method in class org.apache.excalibur.event.impl.MultiCastSink
 
size(long) - Method in class org.apache.excalibur.mpool.VariableSizePool
 
stop() - Method in class org.apache.excalibur.event.command.TPSPThreadManager.SourceDequeueInterceptor
Ensure all event runners are stopped for this partial pipeline.
stop() - Method in class org.apache.excalibur.event.command.TPSPThreadManager.SourceRunner
Stop the runner nicely.

T

TPCThreadManager - class org.apache.excalibur.event.command.TPCThreadManager.
This is a ThreadManager that uses a certain number of threads per processor.
TPCThreadManager() - Constructor for class org.apache.excalibur.event.command.TPCThreadManager
 
TPSPThreadManager - class org.apache.excalibur.event.command.TPSPThreadManager.
This is a ThreadManager which provides a threadpool per Sink per EventPipeline.
TPSPThreadManager() - Constructor for class org.apache.excalibur.event.command.TPSPThreadManager
The default constructor assumes there is a system property named "os.arch.cpus" that has a default for the number of CPUs on a system.
TPSPThreadManager(int, int) - Constructor for class org.apache.excalibur.event.command.TPSPThreadManager
Constructor provides a specified number of threads per processor.
TPSPThreadManager(int, int, int) - Constructor for class org.apache.excalibur.event.command.TPSPThreadManager
Constructor provides a specified number of threads per processor.
TPSPThreadManager.SourceDequeueInterceptor - class org.apache.excalibur.event.command.TPSPThreadManager.SourceDequeueInterceptor.
This is used to plug into Queues so that we can intercept calls to the dequeue operation.
TPSPThreadManager.SourceDequeueInterceptor(TPSPThreadManager.SourceRunner, EventHandler, PooledExecutor, int, int) - Constructor for class org.apache.excalibur.event.command.TPSPThreadManager.SourceDequeueInterceptor
Create a new SourceDequeueInterceptor.
TPSPThreadManager.SourceRunner - class org.apache.excalibur.event.command.TPSPThreadManager.SourceRunner.
The SourceRunner is used to dequeue events one at a time.
TPSPThreadManager.SourceRunner(Source, EventHandler) - Constructor for class org.apache.excalibur.event.command.TPSPThreadManager.SourceRunner
Create a new SourceRunner.
ThresholdEnqueuePredicate - class org.apache.excalibur.event.impl.ThresholdEnqueuePredicate.
The ThresholdEnqueuePredicate limits the elements that can be enqueued based on the size of the Queue.
ThresholdEnqueuePredicate(int) - Constructor for class org.apache.excalibur.event.impl.ThresholdEnqueuePredicate
Create a new ThresholdEnqueuePredicate with the supplied limit.
tryEnqueue(Object) - Method in class org.apache.excalibur.event.impl.DefaultQueue
 
tryEnqueue(Object) - Method in class org.apache.excalibur.event.impl.FixedSizeQueue
Deprecated.  
tryEnqueue(Object) - Method in class org.apache.excalibur.event.impl.LossyMultiCastSink
 
tryEnqueue(Object) - Method in class org.apache.excalibur.event.impl.MultiCastSink
 

V

VariableSizePool - class org.apache.excalibur.mpool.VariableSizePool.
This is an Pool that caches Poolable objects for reuse.
VariableSizePool(ObjectFactory, int) - Constructor for class org.apache.excalibur.mpool.VariableSizePool
Constructor for an unmanaged pool
VariableSizePool(ObjectFactory, int, long) - Constructor for class org.apache.excalibur.mpool.VariableSizePool
Constructor for a managed pool

W

Windows2000 - class org.apache.excalibur.util.system.Windows2000.
Parses the Windows 2000 environment--the same class should work for other Windows versions, but I only have one to test.
Windows2000() - Constructor for class org.apache.excalibur.util.system.Windows2000
 
Windows95 - class org.apache.excalibur.util.system.Windows95.
Parses the Windows 95 environment--the same class should work for other Windows versions, but I only have one to test.
Windows95() - Constructor for class org.apache.excalibur.util.system.Windows95
 
Windows98 - class org.apache.excalibur.util.system.Windows98.
Parses the Windows 98 environment--the same class should work for other Windows versions, but I only have one to test.
Windows98() - Constructor for class org.apache.excalibur.util.system.Windows98
 
WindowsNT - class org.apache.excalibur.util.system.WindowsNT.
Parses the Windows 2000 environment--the same class should work for other Windows versions, but I only have one to test.
WindowsNT() - Constructor for class org.apache.excalibur.util.system.WindowsNT
 
WindowsXP - class org.apache.excalibur.util.system.WindowsXP.
Parses the Windows XP environment.
WindowsXP() - Constructor for class org.apache.excalibur.util.system.WindowsXP
Create this instance of CPUParser and gather information from the Windows XP system.

A B C D E F G H I L M N O P R S T V W

Copyright © {inceptionYear}-2007 Apache Software Foundation. All Rights Reserved.