A B C D E G H I M N O P R S T U

A

abort() - Method in class org.d_haven.event.impl.DefaultPipe.DefaultPreparedEnqueue
 
abort() - Method in class org.d_haven.event.impl.MultiCastSink.MultiCastPreparedEnqueue
 
abort() - Method in interface org.d_haven.event.PreparedEnqueue
Abort a previously prepared provisional enqueue operation (from the prepareEnqueue method).
AbstractEventHandler - Class in org.d_haven.event.impl
Created by IntelliJ IDEA.
AbstractEventHandler() - Constructor for class org.d_haven.event.impl.AbstractEventHandler
 
AbstractPipe - Class in org.d_haven.event.impl
Provides the base functionality for the other Pipe types.
AbstractPipe() - Constructor for class org.d_haven.event.impl.AbstractPipe
 
AbstractThreadPolicy - Class in org.d_haven.event.command
The AbstractThreadPolicy keeps track of wether the management thread is running or not, and stores the ThreadManager for future use.
AbstractThreadPolicy() - Constructor for class org.d_haven.event.command.AbstractThreadPolicy
 
accept(Object, Sink) - Method in class org.d_haven.event.command.SwitchedEnqueuePredicate
Tests the given element for acceptance onto the m_sink.
accept(Object[], Sink) - Method in class org.d_haven.event.command.SwitchedEnqueuePredicate
Tests the given element for acceptance onto the m_sink.
accept() - Method in class org.d_haven.event.command.SwitchedEnqueuePredicate
Tell this EnqueuePredicate to start allowing new events to be enqueued.
accept(Object, Sink) - Method in interface org.d_haven.event.EnqueuePredicate
Tests the given element for acceptance onto the m_sink.
accept(Object[], Sink) - Method in interface org.d_haven.event.EnqueuePredicate
Tests the given element for acceptance onto the m_sink.
accept(Object, Sink) - Method in class org.d_haven.event.impl.NullEnqueuePredicate
 
accept(Object[], Sink) - Method in class org.d_haven.event.impl.NullEnqueuePredicate
 
accept(Object, Sink) - Method in class org.d_haven.event.impl.RateLimitingPredicate
 
accept(Object[], Sink) - Method in class org.d_haven.event.impl.RateLimitingPredicate
 
accept(Object, Sink) - Method in class org.d_haven.event.impl.ThresholdEnqueuePredicate
Returns true if the Sink size + 1 (the element) is less than the threshold.
accept(Object[], Sink) - Method in class org.d_haven.event.impl.ThresholdEnqueuePredicate
Returns true if the Sink size + the number of elements is less than the threshold.
addPreparedEnqueue(PreparedEnqueue) - Method in class org.d_haven.event.impl.MultiCastSink.MultiCastPreparedEnqueue
Adds a prepared enqueue object to the list of prepared enqueues.
after(Source) - Method in interface org.d_haven.event.DequeueInterceptor
An operation executed after dequeing events from the queue.
after(Source) - Method in class org.d_haven.event.impl.NullDequeueInterceptor
An operation executed after dequeing events from the queue.

B

before(Source) - Method in interface org.d_haven.event.DequeueInterceptor
An operation executed before dequeing events from the queue.
before(Source) - Method in class org.d_haven.event.impl.NullDequeueInterceptor
An operation executed before dequeing events from the queue.
block() - Method in class org.d_haven.event.command.SwitchedEnqueuePredicate
Tell this EnqueuePredicate to start blocking new events to be enqueued.

C

checkAlreadyProcessed() - Method in class org.d_haven.event.impl.DefaultPipe.DefaultPreparedEnqueue
 
checkPipelineProvided() - Method in class org.d_haven.event.command.CommandEventHandler
 
clear() - Method in class org.d_haven.event.command.CommandEventPipeline
Run any remaining incoming commands and then clear out all the commands in the system.
clearHard() - Method in class org.d_haven.event.command.CommandEventPipeline
Remove all the commands from the system without running any of them.
Command - Interface in org.d_haven.event.command
A Command is a specific type of event that denotes an asynchronous execution unit that must be performed by the DefaultCommandManager.
CommandEventHandler - Class in org.d_haven.event.command
The CommandEventHandler is used by the DefaultCommandManager to actually process the events.
CommandEventHandler(CommandFailureHandler, SwitchedEnqueuePredicate) - Constructor for class org.d_haven.event.command.CommandEventHandler
Create the CommandEventHandler with the failure handler and the predicate provided.
CommandEventPipeline - Class in org.d_haven.event.command
Created by IntelliJ IDEA.
CommandEventPipeline(EnqueuePredicate, EventHandler) - Constructor for class org.d_haven.event.command.CommandEventPipeline
The CommandEventPipeline is used to manage the incomming queue of commands, the queue of commands to run later, and the event handler to pass the commands to.
CommandFailureHandler - Interface in org.d_haven.event.command
CommandFailureHandler is used by the DefaultCommandManager to handle any exceptions that might be thrown by a Command.
CommandManager - Interface in org.d_haven.event.command
Created by IntelliJ IDEA.
commit() - Method in class org.d_haven.event.impl.DefaultPipe.DefaultPreparedEnqueue
 
commit() - Method in class org.d_haven.event.impl.MultiCastSink.MultiCastPreparedEnqueue
 
commit() - Method in interface org.d_haven.event.PreparedEnqueue
Commit a previously prepared provisional enqueue operation (from the prepareEnqueue method).
createRunner(EventPipeline) - Method in class org.d_haven.event.command.OneThreadPolicy
 
createRunner(EventPipeline) - Method in class org.d_haven.event.command.ProcessorBoundThreadPolicy
 
createRunner(EventPipeline) - Method in interface org.d_haven.event.command.ThreadPolicy
Create the EventPipelineRunner that will be used to get events from the Sources to the EventHandler.

D

DEFAULT_WAIT_TIME - Static variable in class org.d_haven.event.command.ProcessorBoundThreadPolicy
 
DefaultCommandFailureHandler - Class in org.d_haven.event.command
DefaultCommandFailureHandler is used to do nothing if a command fails.
DefaultCommandFailureHandler() - Constructor for class org.d_haven.event.command.DefaultCommandFailureHandler
 
DefaultCommandManager - Class in org.d_haven.event.command
The DefaultCommandManager handles asynchronous commands from the rest of the system.
DefaultCommandManager(ThreadManager) - Constructor for class org.d_haven.event.command.DefaultCommandManager
Create the DefaultCommandManager using the supplied ThreadManager.
DefaultCommandManager.DelayedCommandInfo - Class in org.d_haven.event.command
This class encapsulates the information needed to keep track of our progress executing delayed and repeated commands.
DefaultCommandManager.DelayedCommandInfo() - Constructor for class org.d_haven.event.command.DefaultCommandManager.DelayedCommandInfo
 
DefaultPipe - Class in org.d_haven.event.impl
The default queue implementation is a variable size queue.
DefaultPipe() - Constructor for class org.d_haven.event.impl.DefaultPipe
Create an unbounded DefaultPipe.
DefaultPipe(int) - Constructor for class org.d_haven.event.impl.DefaultPipe
Construct a new DefaultPipe with the specified number of elements.
DefaultPipe(EnqueuePredicate) - Constructor for class org.d_haven.event.impl.DefaultPipe
Construct a new DefaultPipe with the supplied EnqueuePredicate.
DefaultPipe.DefaultPreparedEnqueue - Class in org.d_haven.event.impl
 
DefaultPipe.DefaultPreparedEnqueue(DefaultPipe, Object[]) - Constructor for class org.d_haven.event.impl.DefaultPipe.DefaultPreparedEnqueue
 
DefaultThreadManager - Class in org.d_haven.event.command
The DefaultThreadManager is a very flexible implementation that should be able to solve just about any need.
DefaultThreadManager() - Constructor for class org.d_haven.event.command.DefaultThreadManager
Create the DefaultThreadManager using the OneThreadPolicy as the way to run events through the pipelines.
DefaultThreadManager(ThreadPolicy) - Constructor for class org.d_haven.event.command.DefaultThreadManager
Create the DefaultThreadManager using the ThreadPolicy of your choice.
DelayedCommand - Interface in org.d_haven.event.command
A DelayedCommand is a specific type of Command that denotes a an execution unit that will be delayed at least X number of milliseconds.
dequeue() - Method in class org.d_haven.event.impl.AbstractPipe
Dequeues the next element, or null if there is nothing left on the queue or in case of a timeout while attempting to obtain the mutex.
dequeue(int) - Method in class org.d_haven.event.impl.AbstractPipe
Dequeues at most num available elements.
dequeue() - Method in interface org.d_haven.event.Source
Dequeues the next element, or null if there is nothing left on the queue or in case of a timeout while attempting to obtain the mutex.
dequeue(int) - Method in interface org.d_haven.event.Source
Dequeues at most num available elements.
dequeueAll() - Method in class org.d_haven.event.impl.AbstractPipe
Dequeues all available elements.
dequeueAll() - Method in interface org.d_haven.event.Source
Dequeues all available elements.
DequeueInterceptor - Interface in org.d_haven.event
The dequeue executable interface describes operations that are executed before and after elements are pulled from a queue.
doDequeue() - Method in class org.d_haven.event.impl.AbstractPipe
Abstract method to allow child classes to only focus on the part necessary to dequeue one event.
doDequeue(int) - Method in class org.d_haven.event.impl.AbstractPipe
Abstract method to allow child classes to only focus on the part necessary to dequeue the supplied number of events.
doDequeue(int) - Method in class org.d_haven.event.impl.DefaultPipe
 
doDequeue() - Method in class org.d_haven.event.impl.DefaultPipe
 
doDequeueAll() - Method in class org.d_haven.event.impl.AbstractPipe
Abstract method to allow child classes to only focus on the part necessary to dequeue the remaining events.
doDequeueAll() - Method in class org.d_haven.event.impl.DefaultPipe
 
doEnqueue(Object) - Method in class org.d_haven.event.impl.AbstractPipe
Abstract method provided to allow the child classes to focus only on the portion of code needed to enqueue one event.
doEnqueue(Object[]) - Method in class org.d_haven.event.impl.AbstractPipe
Abstract method provided to allow the child classes to focus only on the portion of code needed to enqueue the supplied events.
doEnqueue(Object[]) - Method in class org.d_haven.event.impl.DefaultPipe
 
doEnqueue(Object) - Method in class org.d_haven.event.impl.DefaultPipe
 
doPrepareEnqueue(Object[]) - Method in class org.d_haven.event.impl.AbstractPipe
Abstract method provided to allow the child classes to focus only on the portion of code needed to do a prepared enqueue for the supplied events.
doPrepareEnqueue(Object[]) - Method in class org.d_haven.event.impl.DefaultPipe
 

E

endLoop() - Method in class org.d_haven.event.command.AbstractThreadPolicy
Provide a hook to do further cleanup when we end the management loop.
endLoop() - Method in class org.d_haven.event.command.ProcessorBoundThreadPolicy
 
enqueue(Object) - Method in class org.d_haven.event.impl.AbstractPipe
Enqueues the given element onto the Sink.
enqueue(Object[]) - Method in class org.d_haven.event.impl.AbstractPipe
Given an array of elements, atomically enqueues all of the elements in the array.
enqueue(Object) - Method in class org.d_haven.event.impl.MultiCastSink
 
enqueue(Object[]) - Method in class org.d_haven.event.impl.MultiCastSink
 
enqueue(Object) - Method in interface org.d_haven.event.Sink
Enqueues the given element onto the Sink.
enqueue(Object[]) - Method in interface org.d_haven.event.Sink
Given an array of elements, atomically enqueues all of the elements in the array.
enqueueCommand(Command) - Method in interface org.d_haven.event.command.CommandManager
Add a command to the manager for it to execute.
enqueueCommand(Command) - Method in class org.d_haven.event.command.DefaultCommandManager
Get the Command Sink so that you can enqueue new commands.
EnqueuePredicate - Interface in org.d_haven.event
Enqueue predicates allow users to specify a method that will 'screen' elements being enqueued onto a sink, either accepting or rejecting them.
EnqueuePredicateFailedException - Exception in org.d_haven.event
If the EnqueuePredicate returns false, denying an event to the Sink, the Sink will throw this exception.
EnqueuePredicateFailedException(String) - Constructor for exception org.d_haven.event.EnqueuePredicateFailedException
Construct a new SinkException instance.
EnqueuePredicateFailedException(String, Exception) - Constructor for exception org.d_haven.event.EnqueuePredicateFailedException
Construct a new SinkException instance.
EventHandler - Interface in org.d_haven.event
An EventHandler takes care of processing specific events in an event-based architecture.
EventPipeline - Interface in org.d_haven.event.command
An EventPipeline is used by the ThreadManager to manage the event Pipe and EventHandler relationship.
EventPipelineRunner - Class in org.d_haven.event.command
Created by IntelliJ IDEA.
EventPipelineRunner(EventPipeline) - Constructor for class org.d_haven.event.command.EventPipelineRunner
Create an EventPipelineRunner with the supplied pipeline and a policy of dequeueing one entry at a time.
EventPipelineRunner(EventPipeline, int) - Constructor for class org.d_haven.event.command.EventPipelineRunner
Create an EventPipelineRunner with the supplied pipeline and number of events to dequeue at a time.
execute() - Method in interface org.d_haven.event.command.Command
The code to execute when the CommandManager acts on it.
executeLoop(ThreadManager) - Method in class org.d_haven.event.command.AbstractThreadPolicy
Take care of the standard checks that need to be in place, and then delegate to the AbstractThreadPolicy.startLoop() method to do any further initialization.
executeLoop(ThreadManager) - Method in interface org.d_haven.event.command.ThreadPolicy
Execute the management loop.

G

getBucketSize() - Method in class org.d_haven.event.impl.RateLimitingPredicate
Returns the number of tokens currently in the bucket.
getCommandFailureHandler() - Method in class org.d_haven.event.command.CommandEventHandler
Get the CommandFailureHandler in use for this event handler.
getCommandFailureHandler() - Method in class org.d_haven.event.command.DefaultCommandManager
Get the failure handler so that DefaultCommandManager can use it when a problem happens.
getDelayInterval() - Method in interface org.d_haven.event.command.DelayedCommand
Sets the initial delay for the Command.
getDepth() - Method in class org.d_haven.event.impl.RateLimitingPredicate
Returns the current depth.
getDequeueInterceptor() - Method in class org.d_haven.event.impl.AbstractPipe
Return the dequeue executable for this sink.
getDequeueInterceptor() - Method in interface org.d_haven.event.Pipe
Return the dequeue executable for this sink.
getEnqueuedCommandSize() - Method in class org.d_haven.event.command.DefaultCommandManager
Get the number of currently enqueued commands.
getEnqueuePredicate() - Method in class org.d_haven.event.impl.AbstractPipe
Return the EnqueuePredicate that is already set for this Pipe.
getEnqueuePredicate() - Method in interface org.d_haven.event.Pipe
Return the enqueue predicate for this sink.
getEventHandler() - Method in class org.d_haven.event.command.CommandEventPipeline
Used by the ThreadManager to get the EventHandler for the DefaultCommandManager.
getEventHandler() - Method in interface org.d_haven.event.command.EventPipeline
Returns the reference to the EventHandler that the events from all the Sinks get merged into.
getIncomingSink() - Method in class org.d_haven.event.command.CommandEventPipeline
Provide a way to get the Sink to send new Commands to.
getNumberOfRepeats() - Method in interface org.d_haven.event.command.RepeatedCommand
If the value is less than 1 (0 or negative), the command repeats for as long as the DefaultCommandManager is running.
getNumEntries() - Method in class org.d_haven.event.command.EventPipelineRunner
Return the number of entries to process at one time.
getNumThreads() - Method in class org.d_haven.event.command.ProcessorBoundThreadPolicy
Get the number of threads to use for running the pipelines.
getPipeline() - Method in class org.d_haven.event.command.EventPipelineRunner
Get the pipeline we are processing at this time.
getRecurringSink() - Method in class org.d_haven.event.command.CommandEventPipeline
Provide a way to get the Sink to requeue delayed Commands to.
getRegisteredPipelines() - Method in class org.d_haven.event.command.DefaultThreadManager
Return a copy of all the pipelines registered at this point.
getRegisteredPipelines() - Method in interface org.d_haven.event.command.ThreadManager
Get the collection of registered pipelines.
getRepeatInterval() - Method in interface org.d_haven.event.command.RepeatedCommand
Gets the repeat interval so that the CommandQueue keeps it for the specified amount of time before enqueuing it again.
getSources() - Method in class org.d_haven.event.command.CommandEventPipeline
Used by the Threadmanager to get the sources that are feeding the DefaultCommandManager.
getSources() - Method in interface org.d_haven.event.command.EventPipeline
There can be many different sources to merge into a pipeline.
getTargetRate() - Method in class org.d_haven.event.impl.RateLimitingPredicate
Returns the current rate limit.
getThreadFactory() - Method in class org.d_haven.event.command.ProcessorBoundThreadPolicy
Get the ThreadFactory used to create new threads.
getThreadManager() - Method in class org.d_haven.event.command.DefaultCommandManager
Get the ThreadManager we are using for this CommandManager.
getThreshold() - Method in class org.d_haven.event.impl.ThresholdEnqueuePredicate
Get the threshold size.
getWaitTime() - Method in class org.d_haven.event.command.ProcessorBoundThreadPolicy
Get the time we wait between runs of the pipeline.
GroupedThreadFactory - Class in org.d_haven.event.command
The GroupedThreadFactory is a convenience implementation for the concurrent utilitie's ThreadFactory.
GroupedThreadFactory() - Constructor for class org.d_haven.event.command.GroupedThreadFactory
Create a GroupedThreadFactory with the current thread's ThreadGroup.
GroupedThreadFactory(ThreadGroup) - Constructor for class org.d_haven.event.command.GroupedThreadFactory
Create a GroupedThreadFactory with the ThreadGroup supplied.

H

handleCommandFailure(Command, Throwable) - Method in interface org.d_haven.event.command.CommandFailureHandler
Handle a command failure.
handleCommandFailure(Command, Throwable) - Method in class org.d_haven.event.command.DefaultCommandFailureHandler
Handle a command failure.
handleCommandFailure(Command, Throwable) - Method in class org.d_haven.event.command.NullCommandFailureHandler
Handle a command failure.
handleEvent(Object) - Method in class org.d_haven.event.command.CommandEventHandler
 
handleEvent(Object) - Method in interface org.d_haven.event.EventHandler
Handle one event at a time.
handleEvents(Object[]) - Method in interface org.d_haven.event.EventHandler
Handle a whole array of events at a time.
handleEvents(Object[]) - Method in class org.d_haven.event.impl.AbstractEventHandler
 

I

isRunning() - Method in class org.d_haven.event.command.AbstractThreadPolicy
Returns whether this ThreadPolicy is currently running or not.
isRunning() - Method in interface org.d_haven.event.command.ThreadPolicy
Provides a way to tell if the management loop is currently running or not.

M

m_command - Variable in class org.d_haven.event.command.DefaultCommandManager.DelayedCommandInfo
The command we are keeping track of.
m_depth - Variable in class org.d_haven.event.impl.RateLimitingPredicate
 
m_elements - Variable in class org.d_haven.event.impl.DefaultPipe
 
m_elems - Variable in class org.d_haven.event.impl.DefaultPipe.DefaultPreparedEnqueue
 
m_enqueuePredicate - Variable in class org.d_haven.event.command.DefaultCommandManager
 
m_eventHandler - Variable in class org.d_haven.event.command.CommandEventPipeline
 
m_eventPipeline - Variable in class org.d_haven.event.command.CommandEventHandler
 
m_eventPipeline - Variable in class org.d_haven.event.command.DefaultCommandManager
 
m_executor - Variable in class org.d_haven.event.command.ProcessorBoundThreadPolicy
 
m_factory - Variable in class org.d_haven.event.command.OneThreadPolicy
 
m_failureHandler - Variable in class org.d_haven.event.command.CommandEventHandler
 
m_group - Variable in class org.d_haven.event.command.GroupedThreadFactory
 
m_incoming - Variable in class org.d_haven.event.command.CommandEventPipeline
 
m_interceptor - Variable in class org.d_haven.event.impl.AbstractPipe
The DequeueInterceptor used.
m_isAccepting - Variable in class org.d_haven.event.command.SwitchedEnqueuePredicate
 
m_lastTime - Variable in class org.d_haven.event.impl.RateLimitingPredicate
 
m_lock - Variable in class org.d_haven.event.impl.AbstractPipe
The lock used to delay entries.
m_manager - Variable in class org.d_haven.event.command.AbstractThreadPolicy
 
m_nextRunTime - Variable in class org.d_haven.event.command.DefaultCommandManager.DelayedCommandInfo
The next time this command is supposed to execute.
m_number - Variable in class org.d_haven.event.command.GroupedThreadFactory
 
m_numEntries - Variable in class org.d_haven.event.command.EventPipelineRunner
 
m_numExecutions - Variable in class org.d_haven.event.command.DefaultCommandManager.DelayedCommandInfo
The number of times the command has been run.
m_numThreads - Variable in class org.d_haven.event.command.ProcessorBoundThreadPolicy
 
m_parent - Variable in class org.d_haven.event.impl.DefaultPipe.DefaultPreparedEnqueue
 
m_pipeline - Variable in class org.d_haven.event.command.EventPipelineRunner
 
m_pipelines - Variable in class org.d_haven.event.command.DefaultThreadManager
 
m_policy - Variable in class org.d_haven.event.command.DefaultThreadManager
 
m_predicate - Variable in class org.d_haven.event.command.CommandEventHandler
 
m_predicate - Variable in class org.d_haven.event.impl.AbstractPipe
The EnqueuePredicate used.
m_preparedEnqueues - Variable in class org.d_haven.event.impl.MultiCastSink.MultiCastPreparedEnqueue
 
m_recurring - Variable in class org.d_haven.event.command.CommandEventPipeline
 
m_regenTimeMs - Variable in class org.d_haven.event.impl.RateLimitingPredicate
 
m_repeatable - Variable in class org.d_haven.event.command.DefaultCommandManager.DelayedCommandInfo
Whether this command is a repeating command or not.
m_reserve - Variable in class org.d_haven.event.impl.DefaultPipe
The number of reserve items.
m_runner - Variable in class org.d_haven.event.command.OneThreadPolicy
 
m_running - Variable in class org.d_haven.event.command.AbstractThreadPolicy
 
m_single - Variable in class org.d_haven.event.impl.MultiCastSink
Boolean value describing if one or all operations must succeed.
m_sinks - Variable in class org.d_haven.event.impl.MultiCastSink
A collection of sink arrays representing the sinks to enqueue to.
m_sources - Variable in class org.d_haven.event.command.CommandEventPipeline
 
m_targetRate - Variable in class org.d_haven.event.impl.RateLimitingPredicate
 
m_threads - Variable in class org.d_haven.event.command.DefaultCommandManager
 
m_threshold - Variable in class org.d_haven.event.impl.ThresholdEnqueuePredicate
 
m_timeout - Variable in class org.d_haven.event.impl.AbstractPipe
The number of milliseconds to wait.
m_tokenCount - Variable in class org.d_haven.event.impl.RateLimitingPredicate
 
m_waitTime - Variable in class org.d_haven.event.command.ProcessorBoundThreadPolicy
 
MultiCastSink - Class in org.d_haven.event.impl
This is a Sink implementation that multicasts enqueue operations to the contained and concrete sink objects.
MultiCastSink(Collection) - Constructor for class org.d_haven.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.d_haven.event.impl.MultiCastSink
This constructor creates a failure in-tolerant multicast sink based on the collection of sink arrays.
MultiCastSink.MultiCastPreparedEnqueue - Class in org.d_haven.event.impl
A prepared enqueue object that holds other prepared enqueue objects and allows to perform a commit / abort on all of these objects.
MultiCastSink.MultiCastPreparedEnqueue() - Constructor for class org.d_haven.event.impl.MultiCastSink.MultiCastPreparedEnqueue
 

N

newThread(Runnable) - Method in class org.d_haven.event.command.GroupedThreadFactory
 
NullCommandFailureHandler - Class in org.d_haven.event.command
DefaultCommandFailureHandler is used to do nothing if a command fails.
NullCommandFailureHandler() - Constructor for class org.d_haven.event.command.NullCommandFailureHandler
 
NullDequeueInterceptor - Class in org.d_haven.event.impl
The dequeue executable interface describes operations that are executed before and after elements are pulled from a queue.
NullDequeueInterceptor() - Constructor for class org.d_haven.event.impl.NullDequeueInterceptor
 
NullEnqueuePredicate - Class in org.d_haven.event.impl
The NullEnqueuePredicate does nothing to limit a Pipe's ability to enqueue.
NullEnqueuePredicate() - Constructor for class org.d_haven.event.impl.NullEnqueuePredicate
 

O

OneThreadPolicy - Class in org.d_haven.event.command
Created by IntelliJ IDEA.
OneThreadPolicy() - Constructor for class org.d_haven.event.command.OneThreadPolicy
 
org.d_haven.event - package org.d_haven.event
 
org.d_haven.event.command - package org.d_haven.event.command
 
org.d_haven.event.impl - package org.d_haven.event.impl
 

P

Pipe - Interface in org.d_haven.event
A Source implements the side of an event queue where QueueElements are dequeued operations only.
PreparedEnqueue - Interface in org.d_haven.event
A PreparedEnqueue is an object returned from a prepareEnqueue method that allows you to either commit or abort the enqueue operation.
prepareEnqueue(Object[]) - Method in class org.d_haven.event.impl.AbstractPipe
Support for transactional enqueue.
prepareEnqueue(Object[]) - Method in class org.d_haven.event.impl.MultiCastSink
 
prepareEnqueue(Object[]) - Method in interface org.d_haven.event.Sink
Support for transactional enqueue.
process(Collection) - Method in class org.d_haven.event.command.AbstractThreadPolicy
Do the actual management logic that needs to be done in each time through the main loop.
process(Collection) - Method in class org.d_haven.event.command.OneThreadPolicy
 
process(Collection) - Method in class org.d_haven.event.command.ProcessorBoundThreadPolicy
 
ProcessorBoundThreadPolicy - Class in org.d_haven.event.command
The ProcessorBoundThreadPolicy is a ThreadPolicy designed to process pipelines in a number of threads that is a multiple of the number of threads in the system.
ProcessorBoundThreadPolicy() - Constructor for class org.d_haven.event.command.ProcessorBoundThreadPolicy
Create a new ProcessorBoundThreadPolicy with one thread per processor and a default wait time of one second between runs.
ProcessorBoundThreadPolicy(int) - Constructor for class org.d_haven.event.command.ProcessorBoundThreadPolicy
Create a new ProcessorBoundThreadPolicy with the number of threads equal to the number of processor multiplied by the supplied multiplier.
ProcessorBoundThreadPolicy(int, long) - Constructor for class org.d_haven.event.command.ProcessorBoundThreadPolicy
Create a new ProcessorBoundThreadPolicy with the number of threads equal to the number of processor multiplied by the supplied multiplier.

R

RateLimitingPredicate - Class in org.d_haven.event.impl
This enqueue predicate implements input rate policing.
RateLimitingPredicate(int) - Constructor for class org.d_haven.event.impl.RateLimitingPredicate
Create a new RateLimitingPredicate for the given sink, bucket depth and no rate limit.
RateLimitingPredicate(double, int) - Constructor for class org.d_haven.event.impl.RateLimitingPredicate
Create a new RateLimitingPredicate for the given sink, targetRate, and token bucket depth.
register(EventPipeline) - Method in class org.d_haven.event.command.DefaultThreadManager
Register an EventPipeline with the ThreadManager.
register(EventPipeline) - Method in interface org.d_haven.event.command.ThreadManager
Register an EventPipeline with the ThreadManager.
RepeatedCommand - Interface in org.d_haven.event.command
The RepeatedCommand is used to represent a command that operates at a specified interval over time.
retrieveElements(List, int) - Static method in class org.d_haven.event.impl.DefaultPipe
Removes the given number of elements from the given buf and returns them in an array.
run() - Method in class org.d_haven.event.command.AbstractThreadPolicy
Do the actual looping code.
run() - Method in class org.d_haven.event.command.EventPipelineRunner
The run method will process events once and then end.

S

SECOND - Static variable in class org.d_haven.event.impl.RateLimitingPredicate
 
setCommandEventPipeline(CommandEventPipeline) - Method in class org.d_haven.event.command.CommandEventHandler
Provide the CommandEventPipeline to use for requeueing delayed and repeating commands.
setCommandFailureHandler(CommandFailureHandler) - Method in class org.d_haven.event.command.CommandEventHandler
Set the CommandFailureHandler to use with this event handler.
setCommandFailureHandler(CommandFailureHandler) - Method in interface org.d_haven.event.command.CommandManager
Set the failure handler that the application can use to override what happens when a command failure happens.
setCommandFailureHandler(CommandFailureHandler) - Method in class org.d_haven.event.command.DefaultCommandManager
Set the failure handler that the application can use to override what happens when a command failure happens.
setDepth(int) - Method in class org.d_haven.event.impl.RateLimitingPredicate
Allows to set the bucket depth.
setDequeueInterceptor(DequeueInterceptor) - Method in class org.d_haven.event.impl.AbstractPipe
Set the dequeue executable for this sink.
setDequeueInterceptor(DequeueInterceptor) - Method in interface org.d_haven.event.Pipe
Set the dequeue executable for this sink.
setEnqueuePredicate(EnqueuePredicate) - Method in class org.d_haven.event.impl.AbstractPipe
Set the EnqueuePredicate to limit entries into this Pipe.
setEnqueuePredicate(EnqueuePredicate) - Method in interface org.d_haven.event.Pipe
Set the enqueue predicate for this sink.
setTargetRate(double) - Method in class org.d_haven.event.impl.RateLimitingPredicate
Allows to set the rate limit.
setThreadFactory(ThreadFactory) - Method in class org.d_haven.event.command.OneThreadPolicy
 
setThreadFactory(ThreadFactory) - Method in class org.d_haven.event.command.ProcessorBoundThreadPolicy
 
setThreadFactory(ThreadFactory) - Method in interface org.d_haven.event.command.ThreadPolicy
Set the ThreadFactory for the policy to use.
setTimeout(long) - Method in class org.d_haven.event.impl.AbstractPipe
Set the timeout for the Pipe in milliseconds.
setTimeout(long) - Method in interface org.d_haven.event.Source
Sets the timeout on a blocking Source.
Sink - Interface in org.d_haven.event
A Sink implements the end of a finite-length event queue where elements are enqueued.
SinkClosedException - Exception in org.d_haven.event
A SinkClosedException is thrown when an enqueue operation occurs on a queue that is already closed.
SinkClosedException(String) - Constructor for exception org.d_haven.event.SinkClosedException
Create a SinkClosedException with an associated message.
SinkClosedException(String, Exception) - Constructor for exception org.d_haven.event.SinkClosedException
Create a SinkClosedException with an associated message and the original exception that caused the problem.
SinkException - Exception in org.d_haven.event
A SourceException is thrown when an enqueue operation fails.
SinkException(String) - Constructor for exception org.d_haven.event.SinkException
Construct a new SinkException instance.
SinkException(String, Exception) - Constructor for exception org.d_haven.event.SinkException
Construct a new SinkException instance.
SinkFullException - Exception in org.d_haven.event
A SinkException is thrown when an enqueue operation occurs on a queue that is already full.
SinkFullException(String) - Constructor for exception org.d_haven.event.SinkFullException
Create a SinkFullException with an associated message.
SinkFullException(String, Exception) - Constructor for exception org.d_haven.event.SinkFullException
Create a SinkClosedException with an associated message and the original exception that caused the problem.
size() - Method in class org.d_haven.event.impl.DefaultPipe
Return the number of elements currently in the Pipe.
size() - Method in class org.d_haven.event.impl.MultiCastSink
 
size() - Method in interface org.d_haven.event.Sink
Returns the number of elements waiting in this Sink.
size() - Method in interface org.d_haven.event.Source
Returns the number of elements waiting in this Source.
Source - Interface in org.d_haven.event
A Source implements the side of an event queue where QueueElements are dequeued operations only.
start() - Method in interface org.d_haven.event.command.CommandManager
Start or restart the CommandManager so that it can accept more commands.
start() - Method in class org.d_haven.event.command.DefaultCommandManager
 
startLoop() - Method in class org.d_haven.event.command.AbstractThreadPolicy
Provide a hook to do further initialization when we start the management loop.
startLoop() - Method in class org.d_haven.event.command.OneThreadPolicy
 
startLoop() - Method in class org.d_haven.event.command.ProcessorBoundThreadPolicy
 
stop(boolean) - Method in interface org.d_haven.event.command.CommandManager
Stop the CommandManager so that it can stop accepting commands.
stop(boolean) - Method in class org.d_haven.event.command.DefaultCommandManager
 
stop() - Method in class org.d_haven.event.command.DefaultThreadManager
Stop the ThreadManager from running the pipelines.
stop() - Method in interface org.d_haven.event.command.ThreadManager
Stop managing the pipelines, and shut down all threads in use.
SwitchedEnqueuePredicate - Class in org.d_haven.event.command
The SwitchedEnqueuePredicate provides a mechanism where we can explicitly tell the queue whether we are accepting new events or not.
SwitchedEnqueuePredicate() - Constructor for class org.d_haven.event.command.SwitchedEnqueuePredicate
Create a SwitchedEnqueuePredicate.

T

terminateLoop() - Method in class org.d_haven.event.command.AbstractThreadPolicy
Stops the loop and calls the AbstractThreadPolicy.endLoop() method to do any further tear down.
terminateLoop() - Method in interface org.d_haven.event.command.ThreadPolicy
Stops the management loop.
testRate(int) - Method in class org.d_haven.event.impl.RateLimitingPredicate
 
testThreshold(Sink, int) - Method in class org.d_haven.event.impl.ThresholdEnqueuePredicate
 
ThreadManager - Interface in org.d_haven.event.command
A ThreadManager handles the thread policies for EventPipelines.
ThreadPolicy - Interface in org.d_haven.event.command
The ThreadPolicy is used to control how the EventPipelineRunner is set up, and how new threads are created and destroyed over the life of the system.
ThresholdEnqueuePredicate - Class in org.d_haven.event.impl
The ThresholdEnqueuePredicate limits the elements that can be enqueued based on the size of the Pipe.
ThresholdEnqueuePredicate(int) - Constructor for class org.d_haven.event.impl.ThresholdEnqueuePredicate
Create a new ThresholdEnqueuePredicate with the supplied limit.
timeToRequeue(DefaultCommandManager.DelayedCommandInfo) - Method in class org.d_haven.event.command.CommandEventHandler
 
toString() - Method in class org.d_haven.event.command.CommandEventHandler
Provide a debug string for this class.
toString() - Method in class org.d_haven.event.command.CommandEventPipeline
Provide a string representation of the pipeline for debugging purposes.
toString() - Method in class org.d_haven.event.command.DefaultCommandFailureHandler
 
toString() - Method in class org.d_haven.event.command.DefaultCommandManager.DelayedCommandInfo
 
toString() - Method in class org.d_haven.event.command.DefaultCommandManager
 
toString() - Method in class org.d_haven.event.command.DefaultThreadManager
 
toString() - Method in class org.d_haven.event.command.EventPipelineRunner
 
toString() - Method in class org.d_haven.event.command.GroupedThreadFactory
 
toString() - Method in class org.d_haven.event.command.NullCommandFailureHandler
 
toString() - Method in class org.d_haven.event.command.OneThreadPolicy
 
toString() - Method in class org.d_haven.event.command.ProcessorBoundThreadPolicy
 
toString() - Method in class org.d_haven.event.command.SwitchedEnqueuePredicate
 
toString() - Method in exception org.d_haven.event.EnqueuePredicateFailedException
 
toString() - Method in class org.d_haven.event.impl.DefaultPipe.DefaultPreparedEnqueue
 
toString() - Method in class org.d_haven.event.impl.DefaultPipe
Get the string representation of this Pipe.
toString() - Method in class org.d_haven.event.impl.MultiCastSink.MultiCastPreparedEnqueue
 
toString() - Method in class org.d_haven.event.impl.MultiCastSink
 
toString() - Method in class org.d_haven.event.impl.NullDequeueInterceptor
 
toString() - Method in class org.d_haven.event.impl.NullEnqueuePredicate
 
toString() - Method in class org.d_haven.event.impl.RateLimitingPredicate
 
toString() - Method in class org.d_haven.event.impl.ThresholdEnqueuePredicate
 
toString() - Method in exception org.d_haven.event.SinkClosedException
 
toString() - Method in exception org.d_haven.event.SinkException
Get the string representation of this exception.
toString() - Method in exception org.d_haven.event.SinkFullException
 
tryEnqueue(Object) - Method in class org.d_haven.event.impl.AbstractPipe
Tries to enqueue an event, but instead of throwing exceptions, it returns a boolean value of whether the attempt was successful.
tryEnqueue(Object) - Method in class org.d_haven.event.impl.MultiCastSink
 
tryEnqueue(Object) - Method in interface org.d_haven.event.Sink
Tries to enqueue an event, but instead of throwing exceptions, it returns a boolean value of whether the attempt was successful.

U

unregister(EventPipeline) - Method in class org.d_haven.event.command.DefaultThreadManager
Unregister an EventPipeline with the ThreadManager.
unregister(EventPipeline) - Method in interface org.d_haven.event.command.ThreadManager
Deregister an EventPipeline with the ThreadManager.
unregisterAll() - Method in class org.d_haven.event.command.DefaultThreadManager
Unregisters all EventPipelines from this ThreadManager.
unregisterAll() - Method in interface org.d_haven.event.command.ThreadManager
Deregisters all EventPipelines from this ThreadManager.

A B C D E G H I M N O P R S T U