A B C D E F G H I J K L M N O P Q R S T U V W X Y

A

abortWhenBlocked() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Set the policy for blocked execution to be to throw a RuntimeException.
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.CountDown
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock.ReaderSync
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock.WriterSync
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.Latch
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.LayeredSync
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.Mutex
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.NullSync
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.ObservableSync
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.ReentrantLock
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.Semaphore
Wait until a permit is available, and take one
acquire() - Method in interface EDU.oswego.cs.dl.util.concurrent.Sync
Wait (possibly forever) until successful passage.
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.TimeoutSync
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.WaiterPreferenceSemaphore
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock.ReaderLock
 
acquire() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock.WriterLock
 
acquireRead() - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
 
acquireWrite() - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
 
active - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Record whether current thread may be processing a task (i.e., has been started and is not in an idle wait).
activeCount - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Number of threads that are not waiting for work
activeReaders_ - Variable in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
activeWriter_ - Variable in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
add(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWIterator
Not supported.
add(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList.COWSubListIterator
 
add(int, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
add(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Appends the specified element to the end of this list.
add(int, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Inserts the specified element at the specified position in this list.
add(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
add(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
add(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList.SyncCollectionListIterator
 
add(int, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
add(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Add amount to value (i.e., set value += amount)
add(char) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
Add amount to value (i.e., set value += amount)
add(double) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
Add amount to value (i.e., set value += amount)
add(float) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
Add amount to value (i.e., set value += amount)
add(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Add amount to value (i.e., set value += amount)
add(long) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Add amount to value (i.e., set value += amount)
add(short) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Add amount to value (i.e., set value += amount)
add(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
 
add(char) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableChar
 
add(double) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
 
add(float) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
 
add(int) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
 
add(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
 
add(short) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
 
addAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Appends all of the elements in the specified Collection to the end of this list, in the order that they are returned by the specified Collection's Iterator.
addAll(int, Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Inserts all of the elements in the specified Collection into this list, starting at the specified position.
addAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
addAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
addAll(int, Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
addAllAbsent(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Appends all of the elements in the specified Collection that are not already contained in this list, to the end of this list, in the order that they are returned by the specified Collection's Iterator.
addIfAbsent(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Append the element if not present.
addPropertyChangeListener(PropertyChangeListener) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Add a VetoableChangeListener to the listener list.
addPropertyChangeListener(String, PropertyChangeListener) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Add a PropertyChangeListener for a specific property.
addPropertyChangeListenerIfAbsent(PropertyChangeListener) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Add a PropertyChangeListener to the listener list if it is not already present.
addPropertyChangeListenerIfAbsent(String, PropertyChangeListener) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Add a PropertyChangeListener for a specific property, if it is not already registered.
addThread(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Create and start a thread to handle a new command.
addVetoableChangeListener(VetoableChangeListener) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Add a VetoableChangeListener to the listener list.
addVetoableChangeListener(String, VetoableChangeListener) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Add a VetoableChangeListener for a specific property.
addVetoableChangeListenerIfAbsent(VetoableChangeListener) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Add a PropertyChangeListener to the listener list if it is not already present.
addVetoableChangeListenerIfAbsent(String, VetoableChangeListener) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Add a VetoableChangeListener for a specific property, if it is not already registered.
afterRead(boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
Clean up after a reader operation
afterRead(boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
Clean up after a reader operation
al - Variable in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
allowReader() - Method in class EDU.oswego.cs.dl.util.concurrent.ReaderPreferenceReadWriteLock
 
allowReader() - Method in class EDU.oswego.cs.dl.util.concurrent.ReentrantWriterPreferenceReadWriteLock
 
allowReader() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
Override this method to change to reader preference
allowTake() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Notify a waiting take if needed
and(boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
Set value to value & b.
and(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Set value to value & b.
and(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Set value to value & b.
and(long) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Set value to value & b.
and(short) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Set value to value & b.
and(boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableBoolean
 
and(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
Set value to value & b.
and(int) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
Set value to value & b.
and(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
Set value to value & b.
and(short) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
Set value to value & b.
arg_ - Variable in class EDU.oswego.cs.dl.util.concurrent.ObservableSync
 
array - Variable in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWIterator
Snapshot of the array
array() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Accessor to the array intended to be called from within unsynchronized read-only methods
array_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
array_ - Variable in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
The held array.
attach(ObservableSync.SyncObserver) - Method in class EDU.oswego.cs.dl.util.concurrent.ObservableSync
Add obs to the set of observers
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.CountDown
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock.ReaderSync
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock.WriterSync
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.Latch
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.LayeredSync
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.Mutex
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.NullSync
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.ObservableSync
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.ReentrantLock
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.Semaphore
Wait at most msecs millisconds for a permit.
attempt(long) - Method in interface EDU.oswego.cs.dl.util.concurrent.Sync
Wait at most msecs to pass; report whether passed.
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.TimeoutSync
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaiterPreferenceSemaphore
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock.ReaderLock
 
attempt(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock.WriterLock
 
attemptBarrier(long) - Method in class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
Enter barrier and wait at most msecs for the other parties()-1 threads.
attemptRead(long) - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
 
attemptRendezvous(Object, long) - Method in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
Wait msecs to complete a rendezvous.
attemptWrite(long) - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
 
await() - Method in class EDU.oswego.cs.dl.util.concurrent.CondVar
Wait for notification.
awaitTermination() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup.InvokableFJTask
 
awaitTerminationAfterShutdown(long) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Wait for a shutdown pool to fully terminate, or until the timeout has expired.
awaitTerminationAfterShutdown() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Wait for a shutdown pool to fully terminate.

B

Barrier - Interface in EDU.oswego.cs.dl.util.concurrent
Barriers serve as synchronization points for groups of threads that must occasionally wait for each other.
BoundedBuffer - Class in EDU.oswego.cs.dl.util.concurrent
Efficient array-based bounded buffer class.
BoundedBuffer(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
Create a BoundedBuffer with the given capacity.
BoundedBuffer() - Constructor for class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
Create a buffer with the current default capacity
BoundedChannel - Interface in EDU.oswego.cs.dl.util.concurrent
A channel that is known to have a capacity, signifying that put operations may block when the capacity is reached.
BoundedLinkedQueue - Class in EDU.oswego.cs.dl.util.concurrent
A bounded variant of LinkedQueue class.
BoundedLinkedQueue(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Create a queue with the given capacity
BoundedLinkedQueue() - Constructor for class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Create a queue with the current default capacity
BoundedPriorityQueue - Class in EDU.oswego.cs.dl.util.concurrent
A heap-based priority queue, using semaphores for concurrency control.
BoundedPriorityQueue(int, Comparator) - Constructor for class EDU.oswego.cs.dl.util.concurrent.BoundedPriorityQueue
Create a priority queue with the given capacity and comparator
BoundedPriorityQueue(Comparator) - Constructor for class EDU.oswego.cs.dl.util.concurrent.BoundedPriorityQueue
Create a priority queue with the current default capacity and the given comparator
BoundedPriorityQueue(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.BoundedPriorityQueue
Create a priority queue with the given capacity, and relying on natural ordering.
BoundedPriorityQueue() - Constructor for class EDU.oswego.cs.dl.util.concurrent.BoundedPriorityQueue
Create a priority queue with the current default capacity and relying on natural ordering.
BoundedPriorityQueue(int, Comparator, Class) - Constructor for class EDU.oswego.cs.dl.util.concurrent.BoundedPriorityQueue
Create a priority queue with the given capacity and comparator, using the supplied Semaphore class for semaphores.
BrokenBarrierException - Exception in EDU.oswego.cs.dl.util.concurrent
Thrown by Barrier upon interruption of participant threads
BrokenBarrierException(int) - Constructor for exception EDU.oswego.cs.dl.util.concurrent.BrokenBarrierException
Constructs a BrokenBarrierException with given index
BrokenBarrierException(int, String) - Constructor for exception EDU.oswego.cs.dl.util.concurrent.BrokenBarrierException
Constructs a BrokenBarrierException with the specified index and detail message.
barrier() - Method in class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
Enter barrier and wait for the other parties()-1 threads.
barrier - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
An extra object to synchronize on in order to achieve a memory barrier.
barrierCommand_ - Variable in class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
 
barrierLock - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Lock used only for its memory effects.
base - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Current base of DEQ.
baseIterator_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SyncCollection.SyncCollectionIterator
 
baseList() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
baseListIterator() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList.SyncCollectionListIterator
 
baseSortedMap() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedMap
 
baseSortedSet() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedSet
 
beforeRead() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
Try to acquire sync before a reader operation; record failure
beforeRead() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
Try to acquire sync before a reader operation; record failure
bitcount(int) - Static method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Return the number of set bits in w.
blockedAction(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.AbortWhenBlocked
 
blockedAction(Runnable) - Method in interface EDU.oswego.cs.dl.util.concurrent.PooledExecutor.BlockedExecutionHandler
Return true if successfully handled so, execute should terminate; else return false if execute loop should be retried.
blockedAction(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.DiscardOldestWhenBlocked
 
blockedAction(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.DiscardWhenBlocked
 
blockedAction(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.RunWhenBlocked
 
blockedAction(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.WaitWhenBlocked
 
blockedExecutionHandler_ - Variable in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
The current handler for unserviceable requests.
broadcast() - Method in class EDU.oswego.cs.dl.util.concurrent.CondVar
Notify all waiting threads
broken() - Method in interface EDU.oswego.cs.dl.util.concurrent.Barrier
Returns true if the barrier has been compromised by threads leaving the barrier before a synchronization point (normally due to interruption or timeout).
broken() - Method in class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
 
broken() - Method in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
 
broken_ - Variable in class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
 
broken_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
 

C

CANCELLED - Static variable in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel
Special marker used in queue nodes to indicate that the thread waiting for a change in the node has timed out or been interrupted.
CASHead(WaitFreeQueue.Node, WaitFreeQueue.Node) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
Simulate CAS for head field, using 'this' lock
CASNext(WaitFreeQueue.Node, WaitFreeQueue.Node) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue.Node
Simulate a CAS operation for 'next' field
CASTail(WaitFreeQueue.Node, WaitFreeQueue.Node) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
Simulate CAS for tail field
CONCURRENCY_LEVEL - Static variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
The number of concurrency control segments.
Callable - Interface in EDU.oswego.cs.dl.util.concurrent
Interface for runnable actions that bear results and/or throw Exceptions.
Channel - Interface in EDU.oswego.cs.dl.util.concurrent
Main interface for buffers, queues, pipes, conduits, etc.
ClockDaemon - Class in EDU.oswego.cs.dl.util.concurrent
A general-purpose time-based daemon, vaguely similar in functionality to common system-level utilities such as at (and the associated crond) in Unix.
ClockDaemon() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
Create a new ClockDaemon
ClockDaemon.RunLoop - Class in EDU.oswego.cs.dl.util.concurrent
The runloop is isolated in its own Runnable class just so that the main class need not implement Runnable, which would allow others to directly invoke run, which is not supported.
ClockDaemon.RunLoop() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ClockDaemon.RunLoop
 
ClockDaemon.TaskNode - Class in EDU.oswego.cs.dl.util.concurrent
 
ConcurrentHashMap - Class in EDU.oswego.cs.dl.util.concurrent
A version of Hashtable supporting concurrency for both retrievals and updates: Retrievals Retrievals may overlap updates.
ConcurrentHashMap(int, float) - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Constructs a new, empty map with the specified initial capacity and the specified load factor.
ConcurrentHashMap(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Constructs a new, empty map with the specified initial capacity and default load factor.
ConcurrentHashMap() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Constructs a new, empty map with a default initial capacity and default load factor.
ConcurrentHashMap(Map) - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Constructs a new map with the same mappings as the given map.
ConcurrentHashMap.Entry - Class in EDU.oswego.cs.dl.util.concurrent
ConcurrentHashMap collision list entry.
ConcurrentHashMap.HashIterator - Class in EDU.oswego.cs.dl.util.concurrent
 
ConcurrentHashMap.HashIterator() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
ConcurrentHashMap.KeyIterator - Class in EDU.oswego.cs.dl.util.concurrent
 
ConcurrentHashMap.KeyIterator() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.KeyIterator
 
ConcurrentHashMap.Segment - Class in EDU.oswego.cs.dl.util.concurrent
Bookkeeping for each concurrency control segment.
ConcurrentHashMap.Segment() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Segment
 
ConcurrentHashMap.ValueIterator - Class in EDU.oswego.cs.dl.util.concurrent
 
ConcurrentHashMap.ValueIterator() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.ValueIterator
 
ConcurrentReaderHashMap - Class in EDU.oswego.cs.dl.util.concurrent
A version of Hashtable that supports mostly-concurrent reading, but exclusive writing.
ConcurrentReaderHashMap(int, float) - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Constructs a new, empty map with the specified initial capacity and the specified load factor.
ConcurrentReaderHashMap(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Constructs a new, empty map with the specified initial capacity and default load factor.
ConcurrentReaderHashMap() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Constructs a new, empty map with a default initial capacity and load factor.
ConcurrentReaderHashMap(Map) - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Constructs a new map with the same mappings as the given map.
ConcurrentReaderHashMap.BarrierLock - Class in EDU.oswego.cs.dl.util.concurrent
A Serializable class for barrier lock
ConcurrentReaderHashMap.BarrierLock() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.BarrierLock
 
ConcurrentReaderHashMap.Entry - Class in EDU.oswego.cs.dl.util.concurrent
ConcurrentReaderHashMap collision list entry.
ConcurrentReaderHashMap.HashIterator - Class in EDU.oswego.cs.dl.util.concurrent
 
ConcurrentReaderHashMap.HashIterator() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
ConcurrentReaderHashMap.KeyIterator - Class in EDU.oswego.cs.dl.util.concurrent
 
ConcurrentReaderHashMap.KeyIterator() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.KeyIterator
 
ConcurrentReaderHashMap.ValueIterator - Class in EDU.oswego.cs.dl.util.concurrent
 
ConcurrentReaderHashMap.ValueIterator() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.ValueIterator
 
CondVar - Class in EDU.oswego.cs.dl.util.concurrent
This class is designed for fans of POSIX pthreads programming.
CondVar(Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.CondVar
Create a new CondVar that relies on the given mutual exclusion lock.
CopyOnWriteArrayList - Class in EDU.oswego.cs.dl.util.concurrent
This class implements a variant of java.util.ArrayList in which all mutative operations (add, set, and so on) are implemented by making a fresh copy of the underlying array.
CopyOnWriteArrayList() - Constructor for class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Constructs an empty list
CopyOnWriteArrayList(Collection) - Constructor for class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Constructs an list containing the elements of the specified Collection, in the order they are returned by the Collection's iterator.
CopyOnWriteArrayList(Object[]) - Constructor for class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Create a new CopyOnWriteArrayList holding a copy of given array
CopyOnWriteArrayList.COWIterator - Class in EDU.oswego.cs.dl.util.concurrent
 
CopyOnWriteArrayList.COWIterator(Object[], int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWIterator
 
CopyOnWriteArrayList.COWSubList - Class in EDU.oswego.cs.dl.util.concurrent
 
CopyOnWriteArrayList.COWSubList(CopyOnWriteArrayList, int, int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
CopyOnWriteArrayList.COWSubList.COWSubListIterator - Class in EDU.oswego.cs.dl.util.concurrent
 
CopyOnWriteArrayList.COWSubList.COWSubListIterator(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList.COWSubListIterator
 
CopyOnWriteArraySet - Class in EDU.oswego.cs.dl.util.concurrent
This class implements a java.util.Set that uses a CopyOnWriteArrayList for all of its operations.
CopyOnWriteArraySet() - Constructor for class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
Constructs an empty set
CopyOnWriteArraySet(Collection) - Constructor for class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
Constructs a set containing all of the elements of the specified Collection.
CountDown - Class in EDU.oswego.cs.dl.util.concurrent
A CountDown can serve as a simple one-shot barrier.
CountDown(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.CountDown
Create a new CountDown with given count value
CyclicBarrier - Class in EDU.oswego.cs.dl.util.concurrent
A cyclic barrier is a reasonable choice for a barrier in contexts involving a fixed sized group of threads that must occasionally wait for each other.
CyclicBarrier(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
Create a CyclicBarrier for the indicated number of parties, and no command to run at each barrier.
CyclicBarrier(int, Runnable) - Constructor for class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
Create a CyclicBarrier for the indicated number of parties.
c_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
c_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
call() - Method in interface EDU.oswego.cs.dl.util.concurrent.Callable
Perform some action that returns a result or throws an exception
call() - Method in class EDU.oswego.cs.dl.util.concurrent.TimedCallable
 
cancel(Object) - Static method in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
Cancel a scheduled task that has not yet been run.
cancel() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Set the termination status of this task.
cancelledWaitingReader() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
cancelledWaitingWriter() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
capacity() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
capacity() - Method in interface EDU.oswego.cs.dl.util.concurrent.BoundedChannel
Return the maximum number of elements that can be held.
capacity() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Return the current capacity of this queue
capacity() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Return the number of slots in this table
capacity() - Method in class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
 
capacity() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel
 
capacity_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Number of elements allowed
capacity_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
 
cells_ - Variable in class EDU.oswego.cs.dl.util.concurrent.PrioritySemaphore.PriorityWaitQueue
An array of wait queues, one per priority
checkActive(FJTaskRunner, long) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Set active status of thread t to false, and then wait until: (a) there is a task in the entry queue, or (b) other threads are active, or (c) the current thread is interrupted.
checkForComodification() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
checkOverflow() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Adjust top and base, and grow DEQ if necessary.
children - Variable in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
HashMap for managing listeners for specific properties.
children - Variable in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
HashMap for managing listeners for specific properties.
clear() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Removes all mappings from this map.
clear() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Removes all mappings from this map.
clear() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Removes all of the elements from this list.
clear() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
clear() - Method in class EDU.oswego.cs.dl.util.concurrent.FutureResult
Clear the value and exception and set to not-ready, allowing this FutureResult to be reused.
clear() - Method in class EDU.oswego.cs.dl.util.concurrent.Heap
remove all elements
clear() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
clear() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
clearThread() - Method in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
set thread_ to null to indicate termination
clearThread() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
set thread_ to null to indicate termination
clone() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Returns a shallow copy of this ConcurrentHashMap instance: the keys and values themselves are not cloned.
clone() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Returns a shallow copy of this ConcurrentReaderHashMap instance: the keys and values themselves are not cloned.
clone() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns a shallow copy of this list.
cmp_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Heap
 
coInvoke(FJTask, FJTask) - Static method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Fork both tasks and then wait for their completion.
coInvoke(FJTask[]) - Static method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Fork all tasks in array, and await their completion.
coInvoke(FJTask, FJTask) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
A specialized expansion of w.fork(); invoke(v); w.join();
coInvoke(FJTask[]) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Array-based version of coInvoke
commit(boolean, boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
Set value to newValue only if it is currently assumedValue.
commit(byte, byte) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Set value to newValue only if it is currently assumedValue.
commit(char, char) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
Set value to newValue only if it is currently assumedValue.
commit(double, double) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
Set value to newValue only if it is currently assumedValue.
commit(float, float) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
Set value to newValue only if it is currently assumedValue.
commit(int, int) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Set value to newValue only if it is currently assumedValue.
commit(long, long) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Set value to newValue only if it is currently assumedValue.
commit(Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedRef
Set value to newValue only if it is currently assumedValue.
commit(short, short) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Set value to newValue only if it is currently assumedValue.
commit(boolean, boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableBoolean
 
commit(byte, byte) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
 
commit(char, char) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableChar
 
commit(double, double) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
 
commit(float, float) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
 
commit(int, int) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
 
commit(long, long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
 
commit(Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableRef
 
commit(short, short) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
 
comparator() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedMap
 
comparator() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedSet
 
compare(Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.Heap
perform element comaprisons using comparator or natural ordering
compareTo(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon.TaskNode
 
compareTo(boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
 
compareTo(SynchronizedBoolean) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
 
compareTo(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
 
compareTo(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
 
compareTo(SynchronizedByte) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
 
compareTo(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
 
compareTo(char) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
 
compareTo(SynchronizedChar) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
 
compareTo(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
 
compareTo(double) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
 
compareTo(SynchronizedDouble) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
 
compareTo(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
 
compareTo(float) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
 
compareTo(SynchronizedFloat) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
 
compareTo(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
 
compareTo(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
 
compareTo(SynchronizedInt) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
 
compareTo(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
 
compareTo(long) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
 
compareTo(SynchronizedLong) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
 
compareTo(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
 
compareTo(short) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
 
compareTo(SynchronizedShort) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
 
compareTo(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
 
complement() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
Set the value to its complement
complement() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Set the value to its complement
complement() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Set the value to its complement
complement() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Set the value to its complement
complement() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Set the value to its complement
complement() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableBoolean
 
complement() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
Set the value to its complement
complement() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
Set the value to its complement
complement() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
Set the value to its complement
complement() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
Set the value to its complement
confirmPop(int) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Check under synch lock if DEQ is really empty when doing pop.
confirmTake(int) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
double-check a potential take
contains(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Tests if some key maps into the specified value in this table.
contains(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Tests if some key maps into the specified value in this table.
contains(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns true if this list contains the specified element.
contains(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
contains(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
containsAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns true if this Collection contains all of the elements in the specified Collection.
containsAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
containsAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
containsKey(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Tests if the specified object is a key in this table.
containsKey(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Tests if the specified object is a key in this table.
containsKey(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
containsValue(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
copyIn(Object[], int, int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Replace the held array with a copy of the n elements of the provided array, starting at position first.
count - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Segment
The number of elements in this segment's region.
count - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
The total number of mappings in the hash table.
count_ - Variable in class EDU.oswego.cs.dl.util.concurrent.CountDown
 
count_ - Variable in class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
 
count_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Heap
 
createThreads(int) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Create and start up to numberOfThreads threads in the pool.
currentCount() - Method in class EDU.oswego.cs.dl.util.concurrent.CountDown
Return the current count value.
currentKey - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
currentKey - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
currentValue - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
currentValue - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
cursor - Variable in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWIterator
Index of element to be returned by subsequent call to next.

D

DEFAULT_INITIAL_CAPACITY - Static variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
The default initial number of table slots for this table (32).
DEFAULT_INITIAL_CAPACITY - Static variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
The default initial number of table slots for this table (32).
DEFAULT_KEEPALIVETIME - Static variable in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
The maximum time to keep worker threads alive waiting for new tasks; used if not otherwise specified.
DEFAULT_LOAD_FACTOR - Static variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
The default load factor for this table (0.75) Used when not otherwise specified in constructor.
DEFAULT_LOAD_FACTOR - Static variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
The default load factor for this table (1.0).
DEFAULT_MAXIMUMPOOLSIZE - Static variable in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
The maximum pool size; used if not otherwise specified.
DEFAULT_MINIMUMPOOLSIZE - Static variable in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
The minimum pool size; used if not otherwise specified.
DefaultChannelCapacity - Class in EDU.oswego.cs.dl.util.concurrent
A utility class to set the default capacity of BoundedChannel implementations that otherwise require a capacity argument
DefaultChannelCapacity() - Constructor for class EDU.oswego.cs.dl.util.concurrent.DefaultChannelCapacity
 
DirectExecutor - Class in EDU.oswego.cs.dl.util.concurrent
An implementation of Executor that invokes the run method of the supplied command and then returns.
DirectExecutor() - Constructor for class EDU.oswego.cs.dl.util.concurrent.DirectExecutor
 
decrement() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Decrement the value.
decrement() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Decrement the value.
decrement() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Decrement the value.
decrement() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Decrement the value.
decrement() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
 
decrement() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
 
decrement() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
 
decrement() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
 
departures_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
Number of threads that are permitted to depart rendezvous
deq - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
The DEQ array.
deq() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel.Queue
 
deqSize() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Current size of the task DEQ
detach(ObservableSync.SyncObserver) - Method in class EDU.oswego.cs.dl.util.concurrent.ObservableSync
Remove obs from the set of observers.
discardOldestWhenBlocked() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Set the policy for blocked execution to be to discard the oldest unhandled request
discardWhenBlocked() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Set the policy for blocked execution to be to return without executing the request.
divide(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Divide value by factor (i.e., set value /= factor)
divide(char) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
Divide value by factor (i.e., set value /= factor)
divide(double) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
Divide value by factor (i.e., set value /= factor)
divide(float) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
Divide value by factor (i.e., set value /= factor)
divide(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Divide value by factor (i.e., set value /= factor)
divide(long) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Divide value by factor (i.e., set value /= factor)
divide(short) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Divide value by factor (i.e., set value /= factor)
divide(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
 
divide(char) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableChar
 
divide(double) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
 
divide(float) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
 
divide(int) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
 
divide(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
 
divide(short) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
 
doBarrier(boolean, long) - Method in class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
 
doGet() - Method in class EDU.oswego.cs.dl.util.concurrent.FutureResult
internal utility: either get the value or throw the exception
doRendezvous(Object, boolean, long) - Method in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
 
doTimedWait(QueuedSemaphore, long) - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore.WaitQueue.WaitNode
 
doWait(QueuedSemaphore) - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore.WaitQueue.WaitNode
 
drain() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Remove all unprocessed tasks from pool queue, and return them in a java.util.List.
duration - Variable in exception EDU.oswego.cs.dl.util.concurrent.TimeoutException
The approximate time that the operation lasted before this timeout exception was thrown.

E

EDU.oswego.cs.dl.util.concurrent - package EDU.oswego.cs.dl.util.concurrent
Overview of package util.concurrent Release 1.3.4.
ENDTASK - Static variable in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
Special queue element to signal termination
Executor - Interface in EDU.oswego.cs.dl.util.concurrent
Interface for objects that execute Runnables, as well as various objects that can be wrapped as Runnables.
elements() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Returns an enumeration of the values in this table.
elements() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Returns an enumeration of the values in this table.
emptySlots_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
endRead() - Method in class EDU.oswego.cs.dl.util.concurrent.ReentrantWriterPreferenceReadWriteLock
 
endRead() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
Called upon termination of a read.
endWrite() - Method in class EDU.oswego.cs.dl.util.concurrent.ReentrantWriterPreferenceReadWriteLock
 
endWrite() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
Called upon termination of a write.
enq(LinkedNode) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel.Queue
 
entries_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
Number of threads that have entered rendezvous
entry - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
entry - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
entryGate_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
Incoming threads pile up on entry until last set done.
entryLock - Variable in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
Fair Semaphore serving as a kind of mutual exclusion lock.
entryQueue - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Group-wide queue for tasks entered via execute()
entrySet - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
 
entrySet() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Returns a collection view of the mappings contained in this map.
entrySet - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
 
entrySet() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Returns a collection view of the mappings contained in this map.
entrySet() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
eq(Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Check for equality of non-null references x and y.
eq(Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Check for equality of non-null references x and y.
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Entry
 
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.Entry
 
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Compares the specified Object with this List for equality.
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSet
 
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
 
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
 
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
 
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
 
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
 
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
 
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
 
equals(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
 
exception_ - Variable in class EDU.oswego.cs.dl.util.concurrent.FutureResult
the exception encountered by operation producing result
execute(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.DirectExecutor
Execute the given command directly in the current thread.
execute(Runnable) - Method in interface EDU.oswego.cs.dl.util.concurrent.Executor
Execute the given command.
execute(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Arrange for execution of the given task by placing it in a work queue.
execute(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.LockedExecutor
Execute the given command directly in the current thread, within the supplied lock.
execute(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Arrange for the given command to be executed by a thread in this pool.
execute(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
Arrange for execution of the command in the background thread by adding it to the queue.
execute(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedVariable
If current thread is not interrupted, execute the given command within this object's lock
execute(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.ThreadedExecutor
Execute the given command in a new thread.
executeAfterDelay(long, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
Excecute the given command after waiting for the given delay.
executeAt(Date, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
Execute the given command at the given time.
executePeriodically(long, Runnable, boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
Execute the given command every period milliseconds.
executeTask(FJTask) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Specialized form of execute called only from within FJTasks
expectedArray - Variable in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
exreaders - Variable in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
Number of threads that have exited read lock.
extract() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
extract() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Main mechanics for take/poll
extract() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedPriorityQueue
 
extract() - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOSemaphore.FIFOWaitQueue
 
extract() - Method in class EDU.oswego.cs.dl.util.concurrent.Heap
Return and remove least element, or null if empty
extract() - Method in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
Main mechanics for take/poll
extract() - Method in class EDU.oswego.cs.dl.util.concurrent.PrioritySemaphore.PriorityWaitQueue
 
extract() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore.WaitQueue
 
extract() - Method in class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
Internal mechanics of take.
extract() - Method in class EDU.oswego.cs.dl.util.concurrent.Slot
Take item known to exist
extract() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
Main dequeue algorithm, called by poll, take.

F

FIFOReadWriteLock - Class in EDU.oswego.cs.dl.util.concurrent
This class implements a policy for reader/writer locks in which threads contend in a First-in/First-out manner for access (modulo the limitations of FIFOSemaphore, which is used for queuing).
FIFOReadWriteLock() - Constructor for class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
 
FIFOReadWriteLock.ReaderSync - Class in EDU.oswego.cs.dl.util.concurrent
 
FIFOReadWriteLock.ReaderSync() - Constructor for class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock.ReaderSync
 
FIFOReadWriteLock.WriterSync - Class in EDU.oswego.cs.dl.util.concurrent
 
FIFOReadWriteLock.WriterSync() - Constructor for class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock.WriterSync
 
FIFOSemaphore - Class in EDU.oswego.cs.dl.util.concurrent
A First-in/First-out implementation of a Semaphore.
FIFOSemaphore(long) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FIFOSemaphore
Create a Semaphore with the given initial number of permits.
FIFOSemaphore.FIFOWaitQueue - Class in EDU.oswego.cs.dl.util.concurrent
Simple linked list queue used in FIFOSemaphore.
FIFOSemaphore.FIFOWaitQueue() - Constructor for class EDU.oswego.cs.dl.util.concurrent.FIFOSemaphore.FIFOWaitQueue
 
FJTask - Class in EDU.oswego.cs.dl.util.concurrent
Abstract base class for Fork/Join Tasks.
FJTask() - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask
 
FJTask.Par - Class in EDU.oswego.cs.dl.util.concurrent
A new Par, when executed, runs the tasks provided in the constructor in parallel using coInvoke(tasks).
FJTask.Par(FJTask[]) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask.Par
Construct a Seq that, when executed, will process each of the tasks in the tasks array in parallel
FJTask.Par(FJTask, FJTask) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask.Par
Two-task constructor, for compatibility with previous release.
FJTask.Par2 - Class in EDU.oswego.cs.dl.util.concurrent
A new Par(task1, task2), when executed, runs task1 and task2 in parallel using coInvoke(task1, task2).
FJTask.Par2(FJTask, FJTask) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask.Par2
 
FJTask.Seq - Class in EDU.oswego.cs.dl.util.concurrent
A new Seq, when executed, invokes each task provided in the constructor, in order.
FJTask.Seq(FJTask[]) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask.Seq
Construct a Seq that, when executed, will process each of the tasks in the tasks array in order
FJTask.Seq(FJTask, FJTask) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask.Seq
Two-task constructor, for compatibility with previous release.
FJTask.Seq2 - Class in EDU.oswego.cs.dl.util.concurrent
A new Seq2(task1, task2), when executed, invokes task1 and then task2, in order.
FJTask.Seq2(FJTask, FJTask) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask.Seq2
 
FJTask.Wrap - Class in EDU.oswego.cs.dl.util.concurrent
A FJTask that holds a Runnable r, and calls r.run when executed.
FJTask.Wrap(Runnable) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask.Wrap
 
FJTaskRunner - Class in EDU.oswego.cs.dl.util.concurrent
Specialized Thread subclass for running FJTasks.
FJTaskRunner(FJTaskRunnerGroup) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Constructor called only during FJTaskRunnerGroup initialization
FJTaskRunner.VolatileTaskRef - Class in EDU.oswego.cs.dl.util.concurrent
An object holding a single volatile reference to a FJTask.
FJTaskRunner.VolatileTaskRef() - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner.VolatileTaskRef
 
FJTaskRunnerGroup - Class in EDU.oswego.cs.dl.util.concurrent
A stripped down analog of a ThreadGroup used for establishing and managing FJTaskRunner threads.
FJTaskRunnerGroup(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Create a FJTaskRunnerGroup with the indicated number of FJTaskRunner threads.
FJTaskRunnerGroup.InvokableFJTask - Class in EDU.oswego.cs.dl.util.concurrent
Wrap wait/notify mechanics around a task so that invoke() can wait it out
FJTaskRunnerGroup.InvokableFJTask(Runnable) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup.InvokableFJTask
 
FutureResult - Class in EDU.oswego.cs.dl.util.concurrent
A class maintaining a single reference variable serving as the result of an operation.
FutureResult() - Constructor for class EDU.oswego.cs.dl.util.concurrent.FutureResult
Create an initially unset FutureResult
findAndRemoveEntry(Map.Entry) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Helper method for entrySet.remove
firePropertyChange(String, Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Report a bound property update to any registered listeners.
firePropertyChange(String, int, int) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Report an int bound property update to any registered listeners.
firePropertyChange(String, boolean, boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Report a boolean bound property update to any registered listeners.
firePropertyChange(PropertyChangeEvent) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Fire an existing PropertyChangeEvent to any registered listeners.
fireVetoableChange(String, Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Report a vetoable property update to any registered listeners.
fireVetoableChange(String, int, int) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Report a vetoable property update to any registered listeners.
fireVetoableChange(String, boolean, boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Report a vetoable property update to any registered listeners.
fireVetoableChange(PropertyChangeEvent) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Report a vetoable property update to any registered listeners.
first() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedSet
 
firstKey() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedMap
 
firstTask_ - Variable in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.Worker
 
fork() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Arrange for execution of a strictly dependent task.
fst - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTask.Par2
 
fst - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTask.Seq2
 

G

get(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Returns the value to which the specified key is mapped in this table.
get(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Returns the value to which the specified key is mapped in this table.
get(int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
get(int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns the element at the specified position in this list.
get() - Static method in class EDU.oswego.cs.dl.util.concurrent.DefaultChannelCapacity
Get the default capacity used in default (no-argument) constructor for BoundedChannels that otherwise require a capacity argument.
get() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner.VolatileTaskRef
Return the reference
get() - Method in class EDU.oswego.cs.dl.util.concurrent.FutureResult
Access the reference, waiting if necessary until it is ready.
get(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
get(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
get() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
Return the current value
get() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Return the current value
get() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
Return the current value
get() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
Return the current value
get() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
Return the current value
get() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Return the current value
get() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Return the current value
get() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedRef
Return the current value
get() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Return the current value
getActive(FJTaskRunner) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Return active status of t.
getActiveCount() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Return the number of threads that are not idly waiting for work.
getArray() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Return the array of threads in this group.
getBlockedExecutionHandler() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Get the handler for blocked execution
getChild(String) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Return the child associated with property, or null if no such
getChild(String) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Return the child associated with property, or null if no such
getCount() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Segment
Get the count under synch.
getException() - Method in class EDU.oswego.cs.dl.util.concurrent.FutureResult
Get the exception, or null if there isn't one (yet).
getFJTaskRunner() - Static method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Return the FJTaskRunner thread running the current FJTask.
getFJTaskRunnerGroup() - Static method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Return the FJTaskRunnerGroup of the thread running the current FJTask.
getGroup() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Return the FJTaskRunnerGroup of which this thread is a member
getKeepAliveTime() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Return the number of milliseconds to keep threads alive waiting for new commands.
getKey() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Entry
 
getKey() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.Entry
 
getLock() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedVariable
Return the lock used for all synchronization for this object
getMaximumPoolSize() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Return the maximum number of threads to simultaneously execute New unqueued requests will be handled according to the current blocking policy once this limit is exceeded.
getMinimumPoolSize() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Return the minimum number of threads to simultaneously execute.
getNotificationArgument() - Method in class EDU.oswego.cs.dl.util.concurrent.ObservableSync
Return the argument used for notifications
getPoolSize() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Return the current number of active threads in the pool.
getSignallee() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore
 
getTableForReading() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Get ref to table; the reference and the cells it accesses will be at least as fresh as from last use of barrierLock
getTask() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Get a task from the handoff queue, or null if shutting down.
getThread() - Method in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
Return the thread being used to process commands, or null if there is no such thread.
getThread() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
Return the thread being used to process commands, or null if there is no such thread.
getThreadFactory() - Method in class EDU.oswego.cs.dl.util.concurrent.ThreadFactoryUser
Get the factory for creating new threads.
getValue() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Entry
Get the value.
getValue() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.Entry
Get the value.
group - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
The group of which this FJTaskRunner is a member

H

Heap - Class in EDU.oswego.cs.dl.util.concurrent
A heap-based priority queue, without any concurrency control (i.e., no blocking on empty/full states).
Heap(int, Comparator) - Constructor for class EDU.oswego.cs.dl.util.concurrent.Heap
Create a Heap with the given initial capacity and comparator
Heap(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.Heap
Create a Heap with the given capacity, and relying on natural ordering.
handOff_ - Variable in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
The channel used to hand off the command to a thread in the pool.
hasListeners(String) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Check if there are any listeners for a specific property.
hasListeners(String) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Check if there are any listeners for a specific property.
hasMoreElements() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
hasMoreElements() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
hasNext() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
hasNext() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
hasNext() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWIterator
 
hasNext() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList.COWSubListIterator
 
hasNext() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection.SyncCollectionIterator
 
hasPrevious() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWIterator
 
hasPrevious() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList.COWSubListIterator
 
hasPrevious() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList.SyncCollectionListIterator
 
hash - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Entry
 
hash(Object) - Static method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Return hash code for Object x.
hash - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.Entry
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Entry
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.Entry
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns the hash code value for this List.
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSet
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
 
hashCode() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
 
head - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel.Queue
 
head - Variable in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
Head of list is always a dummy node
headMap(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedMap
 
headSet(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedSet
 
head_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Dummy header node of list.
head_ - Variable in class EDU.oswego.cs.dl.util.concurrent.FIFOSemaphore.FIFOWaitQueue
 
head_ - Variable in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
Dummy header node of list.
heap_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedPriorityQueue
 
heap_ - Variable in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
tasks are maintained in a standard priority queue
holds() - Method in class EDU.oswego.cs.dl.util.concurrent.ReentrantLock
Return the number of unreleased acquires performed by the current thread.
holds_ - Variable in class EDU.oswego.cs.dl.util.concurrent.ReentrantLock
 

I

INITIAL_CAPACITY - Static variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
FJTasks are held in an array-based DEQ with INITIAL_CAPACITY elements.
INITIAL_DEFAULT_CAPACITY - Static variable in class EDU.oswego.cs.dl.util.concurrent.DefaultChannelCapacity
The initial value of the default capacity is 1024
IONE - Static variable in class EDU.oswego.cs.dl.util.concurrent.ReentrantWriterPreferenceReadWriteLock
cache/reuse the special Integer value one to speed up readlocks
i - Variable in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList.COWSubListIterator
 
incEmptySlots() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
incUsedSlots() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
increment() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Increment the value.
increment() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Increment the value.
increment() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Increment the value.
increment() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Increment the value.
increment() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
 
increment() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
 
increment() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
 
increment() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
 
index - Variable in exception EDU.oswego.cs.dl.util.concurrent.BrokenBarrierException
The index that barrier would have returned upon normal return;
index - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
index - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
index - Variable in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList.COWSubListIterator
 
indexOf(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Searches for the first occurence of the given argument, testing for equality using the equals method.
indexOf(Object, Object[], int) - Static method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
static version allows repeated call without needed to grab lock for array each time
indexOf(Object, int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Searches for the first occurence of the given argument, beginning the search at index, and testing for equality using the equals method.
indexOf(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
initialCount() - Method in class EDU.oswego.cs.dl.util.concurrent.CountDown
Return the initial count value
initialCount_ - Variable in class EDU.oswego.cs.dl.util.concurrent.CountDown
 
initializeThreads() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Create all FJTaskRunner threads in this group.
inner_ - Variable in class EDU.oswego.cs.dl.util.concurrent.LayeredSync
 
insert(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
insert(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Create and insert a node.
insert(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedPriorityQueue
 
insert(QueuedSemaphore.WaitQueue.WaitNode) - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOSemaphore.FIFOWaitQueue
 
insert(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.Heap
insert an element, resize if necessary
insert(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
Main mechanics for put/offer
insert(QueuedSemaphore.WaitQueue.WaitNode) - Method in class EDU.oswego.cs.dl.util.concurrent.PrioritySemaphore.PriorityWaitQueue
 
insert(QueuedSemaphore.WaitQueue.WaitNode) - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore.WaitQueue
 
insert(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
Internal mechanics of put.
insert(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.Slot
Set the item in preparation for a take
interruptAll() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Try to shut down all FJTaskRunner threads in this group by interrupting them all.
interruptAll() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Interrupt all threads in the pool, causing them all to terminate.
inuse_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Mutex
The lock status
invoke(FJTask) - Static method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Immediately execute task t by calling its run method.
invoke(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Start a task and wait it out.
isDone() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Return true if current task has terminated or been cancelled.
isEmpty() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
 
isEmpty() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Tests if this list has no components.
isEmpty() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
isEmpty() - Method in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
 
isEmpty() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
isEmpty() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
isReady() - Method in class EDU.oswego.cs.dl.util.concurrent.FutureResult
Return whether the reference or exception have been set.
isTerminatedAfterShutdown() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Return true if a shutDown method has succeeded in terminating all threads.
item_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Slot
The slot
iterator() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
iterator() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns an Iterator over the elements contained in this collection.
iterator() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
iterator() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 

J

join() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Yield until this task isDone.

K

keepAliveTime_ - Variable in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
The maximum time for an idle thread to wait for new task.
key - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Entry
 
key - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.Entry
 
keySet - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
 
keySet() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Returns a set view of the keys contained in this map.
keySet - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
 
keySet() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Returns a set view of the keys contained in this map.
keySet() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
keys() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Returns an enumeration of the keys in this table.
keys() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Returns an enumeration of the keys in this table.

L

Latch - Class in EDU.oswego.cs.dl.util.concurrent
A latch is a boolean condition that is set at most once, ever.
Latch() - Constructor for class EDU.oswego.cs.dl.util.concurrent.Latch
 
LayeredSync - Class in EDU.oswego.cs.dl.util.concurrent
A class that can be used to compose Syncs.
LayeredSync(Sync, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.LayeredSync
Create a LayeredSync managing the given outer and inner Sync objects
LinkedNode - Class in EDU.oswego.cs.dl.util.concurrent
A standard linked list node used in various queue classes
LinkedNode() - Constructor for class EDU.oswego.cs.dl.util.concurrent.LinkedNode
 
LinkedNode(Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.LinkedNode
 
LinkedNode(Object, LinkedNode) - Constructor for class EDU.oswego.cs.dl.util.concurrent.LinkedNode
 
LinkedQueue - Class in EDU.oswego.cs.dl.util.concurrent
A linked list based channel implementation.
LinkedQueue() - Constructor for class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
 
LockedExecutor - Class in EDU.oswego.cs.dl.util.concurrent
An implementation of Executor that invokes the run method of the supplied command within a synchronization lock and then returns.
LockedExecutor(Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.LockedExecutor
Create a new LockedExecutor that relies on the given mutual exclusion lock.
l - Variable in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
last() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedSet
 
last - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel.Queue
 
lastIndexOf(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns the index of the last occurrence of the specified object in this list.
lastIndexOf(Object, Object[], int) - Static method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
 
lastIndexOf(Object, int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Searches backwards for the specified object, starting from the specified index, and returns an index to it.
lastIndexOf(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
lastKey() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedMap
 
lastReturned - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
lastReturned - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
lastWrite - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
field written to only to guarantee lock ordering.
last_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
The last node of list.
last_ - Variable in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
The last node of list.
latched_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Latch
 
left(int) - Method in class EDU.oswego.cs.dl.util.concurrent.Heap
 
listIterator(int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
listIterator() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns an Iterator of the elements in this List (in proper sequence).
listIterator(int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns a ListIterator of the elements in this List (in proper sequence), starting at the specified position in the List.
listIterator() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
listIterator(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
listeners - Variable in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
The array of listeners.
listeners - Variable in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
The array of listeners.
loadFactor - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
The load factor for the hash table.
loadFactor - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
The load factor for the hash table.
loadFactor() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Return the load factor
lock_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronizedVariable
 

M

MAX_CAPACITY - Static variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
The maximum supported DEQ capacity.
Mutex - Class in EDU.oswego.cs.dl.util.concurrent
A simple non-reentrant mutual exclusion lock.
Mutex() - Constructor for class EDU.oswego.cs.dl.util.concurrent.Mutex
 
maxIndex_ - Variable in class EDU.oswego.cs.dl.util.concurrent.PrioritySemaphore.PriorityWaitQueue
The index of the highest priority cell that may need to be signalled, or -1 if none.
maximumPoolSize_ - Variable in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
The maximum number of threads allowed in pool.
minimumPoolSize_ - Variable in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
The minumum number of threads to maintain in pool.
multicast(PropertyChangeEvent) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Helper method to relay evt to all listeners.
multicast(PropertyChangeEvent) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Helper method to relay evt to all listeners.
multiply(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Multiply value by factor (i.e., set value *= factor)
multiply(char) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
Multiply value by factor (i.e., set value *= factor)
multiply(double) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
Multiply value by factor (i.e., set value *= factor)
multiply(float) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
Multiply value by factor (i.e., set value *= factor)
multiply(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Multiply value by factor (i.e., set value *= factor)
multiply(long) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Multiply value by factor (i.e., set value *= factor)
multiply(short) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Multiply value by factor (i.e., set value *= factor)
multiply(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
 
multiply(char) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableChar
 
multiply(double) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
 
multiply(float) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
 
multiply(int) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
 
multiply(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
 
multiply(short) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
 
mutex_ - Variable in class EDU.oswego.cs.dl.util.concurrent.CondVar
The mutex
mutex_ - Variable in class EDU.oswego.cs.dl.util.concurrent.LockedExecutor
The mutex

N

NullSync - Class in EDU.oswego.cs.dl.util.concurrent
A No-Op implementation of Sync.
NullSync() - Constructor for class EDU.oswego.cs.dl.util.concurrent.NullSync
 
negate() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Set the value to the negative of its old value
negate() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Set the value to the negative of its old value
negate() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Set the value to the negative of its old value
negate() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Set the value to the negative of its old value
newArray(int) - Static method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner.VolatileTaskRef
Initialization utility for constructing arrays.
newTable(int) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Create table array and set the per-segment threshold
newThread(Runnable) - Method in interface EDU.oswego.cs.dl.util.concurrent.ThreadFactory
Create a new thread that will run the given command when started
newThread(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.ThreadFactoryUser.DefaultThreadFactory
 
next - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Entry
 
next() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
next - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.Entry
 
next() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
next() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWIterator
 
next() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList.COWSubListIterator
 
next - Variable in class EDU.oswego.cs.dl.util.concurrent.LinkedNode
 
next() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection.SyncCollectionIterator
 
next - Variable in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue.Node
 
nextElement() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
nextElement() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
nextIndex() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWIterator
 
nextIndex() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList.COWSubListIterator
 
nextIndex() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList.SyncCollectionListIterator
 
nextTask() - Method in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
Return the next task to execute, or null if thread is interrupted
nodes_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Heap
 
nstarted - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Number of threads that have been started.

O

ONE_CENTURY - Static variable in interface EDU.oswego.cs.dl.util.concurrent.Sync
One century in milliseconds; convenient as a time-out value
ONE_DAY - Static variable in interface EDU.oswego.cs.dl.util.concurrent.Sync
One day, in milliseconds; convenient as a time-out value
ONE_HOUR - Static variable in interface EDU.oswego.cs.dl.util.concurrent.Sync
One hour, in milliseconds; convenient as a time-out value
ONE_MINUTE - Static variable in interface EDU.oswego.cs.dl.util.concurrent.Sync
One minute, in milliseconds; convenient as a time-out value
ONE_SECOND - Static variable in interface EDU.oswego.cs.dl.util.concurrent.Sync
One second, in milliseconds; convenient as a time-out value
ONE_WEEK - Static variable in interface EDU.oswego.cs.dl.util.concurrent.Sync
One week, in milliseconds; convenient as a time-out value
ONE_YEAR - Static variable in interface EDU.oswego.cs.dl.util.concurrent.Sync
One year in milliseconds; convenient as a time-out value
ObservableSync - Class in EDU.oswego.cs.dl.util.concurrent
The ObservableSync class performs no synchronization itself, but invokes event-style messages to other observer objects upon invocation of Sync methods.
ObservableSync(Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.ObservableSync
Create an ObservableSync that uses the supplied argument for all notifications.
ObservableSync.SyncObserver - Interface in EDU.oswego.cs.dl.util.concurrent
Interface for objects that observe ObservableSyncs.
observers() - Method in class EDU.oswego.cs.dl.util.concurrent.ObservableSync
Return an iterator that can be used to traverse through current set of observers
observers_ - Variable in class EDU.oswego.cs.dl.util.concurrent.ObservableSync
 
offer(Object, long) - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
offer(Object, long) - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
 
offer(Object, long) - Method in interface EDU.oswego.cs.dl.util.concurrent.Channel
Place item in channel only if it can be accepted within msecs milliseconds.
offer(Object, long) - Method in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
 
offer(Object, long) - Method in interface EDU.oswego.cs.dl.util.concurrent.Puttable
Place item in channel only if it can be accepted within msecs milliseconds.
offer(Object, long) - Method in class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
 
offer(Object, long) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel
 
offer(Object, long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
 
offset - Variable in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
onAcquire(Object) - Method in interface EDU.oswego.cs.dl.util.concurrent.ObservableSync.SyncObserver
Method called upon acquire or successful attempt of Sync
onRelease(Object) - Method in interface EDU.oswego.cs.dl.util.concurrent.ObservableSync.SyncObserver
Method called upon release of Sync.
or(boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
Set value to value | b.
or(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Set value to value | b.
or(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Set value to value | b.
or(long) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Set value to value | b.
or(short) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Set value to value | b.
or(boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableBoolean
 
or(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
Set value to value | b.
or(int) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
Set value to value | b.
or(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
Set value to value | b.
or(short) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
Set value to value | b.
outer_ - Variable in class EDU.oswego.cs.dl.util.concurrent.LayeredSync
 
owner_ - Variable in class EDU.oswego.cs.dl.util.concurrent.ReentrantLock
 

P

PooledExecutor - Class in EDU.oswego.cs.dl.util.concurrent
A tunable, extensible thread pool class.
PooledExecutor() - Constructor for class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Create a new pool with all default settings
PooledExecutor(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Create a new pool with all default settings except for maximum pool size.
PooledExecutor(Channel) - Constructor for class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Create a new pool that uses the supplied Channel for queuing, and with all default parameter settings.
PooledExecutor(Channel, int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Create a new pool that uses the supplied Channel for queuing, and with all default parameter settings except for maximum pool size.
PooledExecutor.AbortWhenBlocked - Class in EDU.oswego.cs.dl.util.concurrent
Class defining Abort action.
PooledExecutor.AbortWhenBlocked() - Constructor for class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.AbortWhenBlocked
 
PooledExecutor.BlockedExecutionHandler - Interface in EDU.oswego.cs.dl.util.concurrent
Class for actions to take when execute() blocks.
PooledExecutor.DiscardOldestWhenBlocked - Class in EDU.oswego.cs.dl.util.concurrent
Class defining DiscardOldest action.
PooledExecutor.DiscardOldestWhenBlocked() - Constructor for class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.DiscardOldestWhenBlocked
 
PooledExecutor.DiscardWhenBlocked - Class in EDU.oswego.cs.dl.util.concurrent
Class defining Discard action.
PooledExecutor.DiscardWhenBlocked() - Constructor for class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.DiscardWhenBlocked
 
PooledExecutor.RunWhenBlocked - Class in EDU.oswego.cs.dl.util.concurrent
Class defining Run action.
PooledExecutor.RunWhenBlocked() - Constructor for class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.RunWhenBlocked
 
PooledExecutor.WaitWhenBlocked - Class in EDU.oswego.cs.dl.util.concurrent
Class defining Wait action.
PooledExecutor.WaitWhenBlocked() - Constructor for class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.WaitWhenBlocked
 
PooledExecutor.Worker - Class in EDU.oswego.cs.dl.util.concurrent
Class defining the basic run loop for pooled threads.
PooledExecutor.Worker(Runnable) - Constructor for class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.Worker
 
PrioritySemaphore - Class in EDU.oswego.cs.dl.util.concurrent
A Semaphore that grants requests to threads with higher Thread priority rather than lower priority when there is contention.
PrioritySemaphore(long) - Constructor for class EDU.oswego.cs.dl.util.concurrent.PrioritySemaphore
Create a Semaphore with the given initial number of permits.
PrioritySemaphore.PriorityWaitQueue - Class in EDU.oswego.cs.dl.util.concurrent
 
PrioritySemaphore.PriorityWaitQueue() - Constructor for class EDU.oswego.cs.dl.util.concurrent.PrioritySemaphore.PriorityWaitQueue
 
PropertyChangeMulticaster - Class in EDU.oswego.cs.dl.util.concurrent
This class is interoperable with java.beans.PropertyChangeSupport, but relies on a streamlined copy-on-write scheme similar to that used in CopyOnWriteArrayList.
PropertyChangeMulticaster(Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Constructs a PropertyChangeMulticaster object.
Puttable - Interface in EDU.oswego.cs.dl.util.concurrent
This interface exists to enable stricter type checking for channels.
par(FJTask[]) - Static method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Construct and return a FJTask object that, when executed, will invoke the tasks in the tasks array in parallel using coInvoke
par(FJTask, FJTask) - Static method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Construct and return a FJTask object that, when executed, will invoke task1 and task2, in parallel
parent(int) - Method in class EDU.oswego.cs.dl.util.concurrent.Heap
 
parties() - Method in interface EDU.oswego.cs.dl.util.concurrent.Barrier
Return the number of parties that must meet per barrier point.
parties() - Method in class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
 
parties() - Method in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
 
parties_ - Variable in class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
 
parties_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
 
peek() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
peek() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
 
peek() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedPriorityQueue
 
peek() - Method in interface EDU.oswego.cs.dl.util.concurrent.Channel
Return, but do not remove object at head of Channel, or null if it is empty.
peek() - Method in class EDU.oswego.cs.dl.util.concurrent.FutureResult
Access the reference, even if not ready
peek() - Method in class EDU.oswego.cs.dl.util.concurrent.Heap
Return least element without removing it, or null if empty
peek() - Method in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
 
peek() - Method in class EDU.oswego.cs.dl.util.concurrent.Slot
 
peek() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel
 
peek() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
 
permits() - Method in class EDU.oswego.cs.dl.util.concurrent.Semaphore
Return the current number of available permits.
permits_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Semaphore
current number of available permits
poll(long) - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
poll(long) - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
 
poll(long) - Method in interface EDU.oswego.cs.dl.util.concurrent.Channel
Return and remove an item from channel only if one is available within msecs milliseconds.
poll(long) - Method in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
 
poll(long) - Method in class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
 
poll(long) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel
 
poll(long) - Method in interface EDU.oswego.cs.dl.util.concurrent.Takable
Return and remove an item from channel only if one is available within msecs milliseconds.
poll(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
Spin until poll returns a non-null value or time elapses.
pollEntryQueue() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Return a task from entry queue, or null if empty.
poolSize_ - Variable in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Current pool size.
pop() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Return a popped task, or null if DEQ is empty.
precheck() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore
 
previous() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWIterator
 
previous() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList.COWSubListIterator
 
previous() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList.SyncCollectionListIterator
 
previousIndex() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWIterator
 
previousIndex() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList.COWSubListIterator
 
previousIndex() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList.SyncCollectionListIterator
 
push(FJTask) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Push a task onto DEQ.
put(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
put(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
 
put(Object) - Method in interface EDU.oswego.cs.dl.util.concurrent.Channel
Place item in the channel, possibly waiting indefinitely until it can be accepted.
put(Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Maps the specified key to the specified value in this table.
put(Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Maps the specified key to the specified value in this table.
put(FJTask) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner.VolatileTaskRef
Set the reference
put(FJTask) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Enqueue task at base of DEQ.
put(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
 
put(Object) - Method in interface EDU.oswego.cs.dl.util.concurrent.Puttable
Place item in the channel, possibly waiting indefinitely until it can be accepted.
put(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
 
put(Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
put(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel
 
put(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
 
putAll(Map) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Copies all of the mappings from the specified map to this one.
putAll(Map) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Copies all of the mappings from the specified map to this one.
putAll(Map) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
putGuard_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Helper monitor.
putGuard_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
 
putLock_ - Variable in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
Helper monitor for managing access to last node.
putMonitor_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
Helper monitor to handle puts.
putPtr_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
putSidePutPermits_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
One side of a split permit count.

Q

QueuedExecutor - Class in EDU.oswego.cs.dl.util.concurrent
An implementation of Executor that queues incoming requests until they can be processed by a single background thread.
QueuedExecutor(Channel) - Constructor for class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
Construct a new QueuedExecutor that uses the supplied Channel as its queue.
QueuedExecutor() - Constructor for class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
Construct a new QueuedExecutor that uses a BoundedLinkedQueue with the current DefaultChannelCapacity as its queue.
QueuedExecutor.RunLoop - Class in EDU.oswego.cs.dl.util.concurrent
The runloop is isolated in its own Runnable class just so that the main class need not implement Runnable, which would allow others to directly invoke run, which would never make sense here.
QueuedExecutor.RunLoop() - Constructor for class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor.RunLoop
 
QueuedSemaphore - Class in EDU.oswego.cs.dl.util.concurrent
Abstract base class for semaphores relying on queued wait nodes.
QueuedSemaphore.WaitQueue - Class in EDU.oswego.cs.dl.util.concurrent
Base class for internal queue classes for semaphores, etc.
QueuedSemaphore.WaitQueue() - Constructor for class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore.WaitQueue
 
QueuedSemaphore.WaitQueue.WaitNode - Class in EDU.oswego.cs.dl.util.concurrent
 
QueuedSemaphore.WaitQueue.WaitNode() - Constructor for class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore.WaitQueue.WaitNode
 
queue_ - Variable in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
The queue

R

ReadWriteLock - Interface in EDU.oswego.cs.dl.util.concurrent
ReadWriteLocks maintain a pair of associated locks.
ReaderPreferenceReadWriteLock - Class in EDU.oswego.cs.dl.util.concurrent
A ReadWriteLock that prefers waiting readers over waiting writers when there is contention.
ReaderPreferenceReadWriteLock() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ReaderPreferenceReadWriteLock
 
ReentrantLock - Class in EDU.oswego.cs.dl.util.concurrent
A lock with the same semantics as builtin Java synchronized locks: Once a thread has a lock, it can re-obtain it any number of times without blocking.
ReentrantLock() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ReentrantLock
 
ReentrantWriterPreferenceReadWriteLock - Class in EDU.oswego.cs.dl.util.concurrent
A writer-preference ReadWriteLock that allows both readers and writers to reacquire read or write locks in the style of a ReentrantLock.
ReentrantWriterPreferenceReadWriteLock() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ReentrantWriterPreferenceReadWriteLock
 
Rendezvous - Class in EDU.oswego.cs.dl.util.concurrent
A rendezvous is a barrier that: Unlike a CyclicBarrier, is not restricted to use with fixed-sized groups of threads.
Rendezvous(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.Rendezvous
Create a Barrier for the indicated number of parties, and the default Rotator function to run at each barrier point.
Rendezvous(int, Rendezvous.RendezvousFunction) - Constructor for class EDU.oswego.cs.dl.util.concurrent.Rendezvous
Create a Barrier for the indicated number of parties.
Rendezvous.RendezvousFunction - Interface in EDU.oswego.cs.dl.util.concurrent
Interface for functions run at rendezvous points
Rendezvous.Rotator - Class in EDU.oswego.cs.dl.util.concurrent
The default rendezvous function.
Rendezvous.Rotator() - Constructor for class EDU.oswego.cs.dl.util.concurrent.Rendezvous.Rotator
 
rangeCheck(int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
rangeCheck(int, int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Check if the given index is in range.
rd_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
rd_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
readLock() - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
 
readLock() - Method in interface EDU.oswego.cs.dl.util.concurrent.ReadWriteLock
get the readLock
readLock() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
readerLock_ - Variable in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
readerSync - Variable in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
 
readerSync() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
Return the Sync object managing read-only operations
readerSync() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
Return the Sync object managing read-only operations
readers - Variable in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
Number of threads that have entered read lock.
readers_ - Variable in class EDU.oswego.cs.dl.util.concurrent.ReentrantWriterPreferenceReadWriteLock
Number of acquires on read lock by any reader thread
ready_ - Variable in class EDU.oswego.cs.dl.util.concurrent.FutureResult
Status -- true after first set
recheck(QueuedSemaphore.WaitQueue.WaitNode) - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore
 
reconcilePutPermits() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Move put permits from take side to put side; return the number of put side permits that are available.
recordModification(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Force a memory synchronization that will cause all readers to see table.
ref - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner.VolatileTaskRef
The reference
rehash() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Rehashes the contents of this map into a new table with a larger capacity.
rehash() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Rehashes the contents of this map into a new table with a larger capacity.
release() - Method in class EDU.oswego.cs.dl.util.concurrent.CountDown
Decrement the count.
release() - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock.ReaderSync
 
release() - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock.WriterSync
 
release() - Method in class EDU.oswego.cs.dl.util.concurrent.Latch
Enable all current and future acquires to pass
release() - Method in class EDU.oswego.cs.dl.util.concurrent.LayeredSync
 
release() - Method in class EDU.oswego.cs.dl.util.concurrent.Mutex
 
release() - Method in class EDU.oswego.cs.dl.util.concurrent.NullSync
 
release() - Method in class EDU.oswego.cs.dl.util.concurrent.ObservableSync
 
release() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore
 
release(long) - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore
Release N permits
release() - Method in class EDU.oswego.cs.dl.util.concurrent.ReentrantLock
Release the lock.
release(long) - Method in class EDU.oswego.cs.dl.util.concurrent.ReentrantLock
Release the lock N times.
release() - Method in class EDU.oswego.cs.dl.util.concurrent.Semaphore
Release a permit
release(long) - Method in class EDU.oswego.cs.dl.util.concurrent.Semaphore
Release N permits.
release() - Method in interface EDU.oswego.cs.dl.util.concurrent.Sync
Potentially enable others to pass.
release() - Method in class EDU.oswego.cs.dl.util.concurrent.TimeoutSync
 
release() - Method in class EDU.oswego.cs.dl.util.concurrent.WaiterPreferenceSemaphore
 
release(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaiterPreferenceSemaphore
Release N permits
release() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock.ReaderLock
 
release() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock.WriterLock
 
releaseRead() - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
 
releaseWrite() - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
 
remove() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
remove(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Removes the key (and its corresponding value) from this table.
remove(Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Removes the (key, value) pair from this table.
remove() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
remove(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Removes the key (and its corresponding value) from this table.
remove() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWIterator
Not supported.
remove() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList.COWSubListIterator
 
remove(int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
remove(int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Removes the element at the specified position in this list.
remove(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Removes a single instance of the specified element from this Collection, if it is present (optional operation).
remove(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
remove() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection.SyncCollectionIterator
 
remove(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
remove(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
remove(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
removeAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Removes from this Collection all of its elements that are contained in the specified Collection.
removeAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
removeAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
removePropertyChangeListener(PropertyChangeListener) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Remove a PropertyChangeListener from the listener list.
removePropertyChangeListener(String, PropertyChangeListener) - Method in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
Remove a PropertyChangeListener for a specific property.
removeRange(int, int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Removes from this List all of the elements whose index is between fromIndex, inclusive and toIndex, exclusive.
removeVetoableChangeListener(VetoableChangeListener) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Remove an occurrence of a VetoableChangeListener from the listener list.
removeVetoableChangeListener(String, VetoableChangeListener) - Method in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Remove a VetoableChangeListener for a specific property.
rendezvous(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
Enter a rendezvous; returning after all other parties arrive.
rendezvousFunction(Object[]) - Method in interface EDU.oswego.cs.dl.util.concurrent.Rendezvous.RendezvousFunction
Perform some function on the objects presented at a rendezvous.
rendezvousFunction(Object[]) - Method in class EDU.oswego.cs.dl.util.concurrent.Rendezvous.Rotator
Rotate the array
rendezvousFunction_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
The function to run at rendezvous point
reset() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Clear the termination status of this task.
resets_ - Variable in class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
 
resize(int, ConcurrentHashMap.Entry[]) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Gather all locks in order to call rehash, by recursing within synch blocks for each segment index.
restart() - Method in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
Start (or restart) a thread to process commands, or wake up an existing thread if one is already running.
restart() - Method in class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
Reset to initial state.
restart() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
Start (or restart) the background thread to process commands.
restart() - Method in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
Reset to initial state.
retainAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Retains only the elements in this Collection that are contained in the specified Collection (optional operation).
retainAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
retainAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
returnValueOfNext() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
returnValueOfNext() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.KeyIterator
 
returnValueOfNext() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.ValueIterator
 
returnValueOfNext() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
returnValueOfNext() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.KeyIterator
 
returnValueOfNext() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.ValueIterator
 
right(int) - Method in class EDU.oswego.cs.dl.util.concurrent.Heap
 
run() - Method in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon.RunLoop
 
run() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask.Par
 
run() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask.Par2
 
run() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask.Seq
 
run() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask.Seq2
 
run() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask.Wrap
 
run() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Main runloop
run() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup.InvokableFJTask
 
run() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.Worker
 
run() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor.RunLoop
 
runLoop_ - Variable in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
 
runLoop_ - Variable in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
 
runPriority - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Priority to use while running tasks
runWhenBlocked() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Set the policy for blocked execution to be that the current thread executes the command if there are no available threads in the pool.
runnable - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTask.Wrap
 
runs - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Total number of tasks run

S

SEGMENT_MASK - Static variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Mask value for indexing into segments
Semaphore - Class in EDU.oswego.cs.dl.util.concurrent
Base class for counting semaphores.
Semaphore(long) - Constructor for class EDU.oswego.cs.dl.util.concurrent.Semaphore
Create a Semaphore with the given initial number of permits.
SemaphoreControlledChannel - Class in EDU.oswego.cs.dl.util.concurrent
Abstract class for channels that use Semaphores to control puts and takes.
SemaphoreControlledChannel(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
Create a channel with the given capacity and default semaphore implementation
SemaphoreControlledChannel(int, Class) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
Create a channel with the given capacity and semaphore implementations instantiated from the supplied class
Slot - Class in EDU.oswego.cs.dl.util.concurrent
A one-slot buffer, using semaphores to control access.
Slot(Class) - Constructor for class EDU.oswego.cs.dl.util.concurrent.Slot
Create a buffer with the given capacity, using the supplied Semaphore class for semaphores.
Slot() - Constructor for class EDU.oswego.cs.dl.util.concurrent.Slot
Create a new Slot using default Semaphore implementations
Sync - Interface in EDU.oswego.cs.dl.util.concurrent
Main interface for locks, gates, and conditions.
SyncCollection - Class in EDU.oswego.cs.dl.util.concurrent
SyncCollections wrap Sync-based control around java.util.Collections.
SyncCollection(Collection, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncCollection
Create a new SyncCollection protecting the given collection, and using the given sync to control both reader and writer methods.
SyncCollection(Collection, ReadWriteLock) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncCollection
Create a new SyncCollection protecting the given collection, and using the given ReadWriteLock to control reader and writer methods.
SyncCollection(Collection, Sync, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncCollection
Create a new SyncCollection protecting the given collection, and using the given pair of locks to control reader and writer methods.
SyncCollection.SyncCollectionIterator - Class in EDU.oswego.cs.dl.util.concurrent
 
SyncList - Class in EDU.oswego.cs.dl.util.concurrent
SyncLists wrap Sync-based control around java.util.Lists.
SyncList(List, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncList
Create a new SyncList protecting the given collection, and using the given sync to control both reader and writer methods.
SyncList(List, ReadWriteLock) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncList
Create a new SyncList protecting the given list, and using the given ReadWriteLock to control reader and writer methods.
SyncList(List, Sync, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncList
Create a new SyncList protecting the given list, and using the given pair of locks to control reader and writer methods.
SyncList.SyncCollectionListIterator - Class in EDU.oswego.cs.dl.util.concurrent
 
SyncMap - Class in EDU.oswego.cs.dl.util.concurrent
SyncMaps wrap Sync-based control around java.util.Maps.
SyncMap(Map, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncMap
Create a new SyncMap protecting the given map, and using the given sync to control both reader and writer methods.
SyncMap(Map, ReadWriteLock) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncMap
Create a new SyncMap protecting the given map, and using the given ReadWriteLock to control reader and writer methods.
SyncMap(Map, Sync, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncMap
Create a new SyncMap protecting the given map, and using the given pair of locks to control reader and writer methods.
SyncSet - Class in EDU.oswego.cs.dl.util.concurrent
SyncSets wrap Sync-based control around java.util.Sets.
SyncSet(Set, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncSet
Create a new SyncSet protecting the given collection, and using the given sync to control both reader and writer methods.
SyncSet(Set, ReadWriteLock) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncSet
Create a new SyncSet protecting the given set, and using the given ReadWriteLock to control reader and writer methods.
SyncSet(Set, Sync, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncSet
Create a new SyncSet protecting the given set, and using the given pair of locks to control reader and writer methods.
SyncSortedMap - Class in EDU.oswego.cs.dl.util.concurrent
SyncSortedMaps wrap Sync-based control around java.util.SortedMaps.
SyncSortedMap(SortedMap, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncSortedMap
Create a new SyncSortedMap protecting the given map, and using the given sync to control both reader and writer methods.
SyncSortedMap(SortedMap, ReadWriteLock) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncSortedMap
Create a new SyncSortedMap protecting the given map, and using the given ReadWriteLock to control reader and writer methods.
SyncSortedMap(SortedMap, Sync, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncSortedMap
Create a new SyncSortedMap protecting the given map, and using the given pair of locks to control reader and writer methods.
SyncSortedSet - Class in EDU.oswego.cs.dl.util.concurrent
SyncSortedSets wrap Sync-based control around java.util.SortedSets.
SyncSortedSet(SortedSet, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncSortedSet
Create a new SyncSortedSet protecting the given collection, and using the given sync to control both reader and writer methods.
SyncSortedSet(SortedSet, ReadWriteLock) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncSortedSet
Create a new SyncSortedSet protecting the given set, and using the given ReadWriteLock to control reader and writer methods.
SyncSortedSet(SortedSet, Sync, Sync) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SyncSortedSet
Create a new SyncSortedSet protecting the given set, and using the given pair of locks to control reader and writer methods.
SynchronizedBoolean - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading synch for boolean instance variables.
SynchronizedBoolean(boolean) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
Make a new SynchronizedBoolean with the given initial value, and using its own internal lock.
SynchronizedBoolean(boolean, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
Make a new SynchronizedBoolean with the given initial value, and using the supplied lock.
SynchronizedByte - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading synch for byte instance variables.
SynchronizedByte(byte) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Make a new SynchronizedByte with the given initial value, and using its own internal lock.
SynchronizedByte(byte, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Make a new SynchronizedByte with the given initial value, and using the supplied lock.
SynchronizedChar - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading synch for char instance variables.
SynchronizedChar(char) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
Make a new SynchronizedChar with the given initial value, and using its own internal lock.
SynchronizedChar(char, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
Make a new SynchronizedChar with the given initial value, and using the supplied lock.
SynchronizedDouble - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading synch for double instance variables.
SynchronizedDouble(double) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
Make a new SynchronizedDouble with the given initial value, and using its own internal lock.
SynchronizedDouble(double, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
Make a new SynchronizedDouble with the given initial value, and using the supplied lock.
SynchronizedFloat - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading synch for float instance variables.
SynchronizedFloat(float) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
Make a new SynchronizedFloat with the given initial value, and using its own internal lock.
SynchronizedFloat(float, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
Make a new SynchronizedFloat with the given initial value, and using the supplied lock.
SynchronizedInt - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading synch for int instance variables.
SynchronizedInt(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Make a new SynchronizedInt with the given initial value, and using its own internal lock.
SynchronizedInt(int, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Make a new SynchronizedInt with the given initial value, and using the supplied lock.
SynchronizedLong - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading synch for long instance variables.
SynchronizedLong(long) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Make a new SynchronizedLong with the given initial value, and using its own internal lock.
SynchronizedLong(long, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Make a new SynchronizedLong with the given initial value, and using the supplied lock.
SynchronizedRef - Class in EDU.oswego.cs.dl.util.concurrent
A simple class maintaining a single reference variable that is always accessed and updated under synchronization.
SynchronizedRef(Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedRef
Create a SynchronizedRef initially holding the given reference and using its own internal lock.
SynchronizedRef(Object, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedRef
Make a new SynchronizedRef with the given initial value, and using the supplied lock.
SynchronizedShort - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading synch for short instance variables.
SynchronizedShort(short) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Make a new SynchronizedShort with the given initial value, and using its own internal lock.
SynchronizedShort(short, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Make a new SynchronizedShort with the given initial value, and using the supplied lock.
SynchronizedVariable - Class in EDU.oswego.cs.dl.util.concurrent
Base class for simple, small classes maintaining single values that are always accessed and updated under synchronization.
SynchronizedVariable(Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedVariable
Create a SynchronizedVariable using the supplied lock
SynchronizedVariable() - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronizedVariable
Create a SynchronizedVariable using itself as the lock
SynchronousChannel - Class in EDU.oswego.cs.dl.util.concurrent
A rendezvous channel, similar to those used in CSP and Ada.
SynchronousChannel() - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel
 
SynchronousChannel.Queue - Class in EDU.oswego.cs.dl.util.concurrent
Simple FIFO queue class to hold waiting puts/takes.
SynchronousChannel.Queue() - Constructor for class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel.Queue
 
scan(FJTask) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Do all but the pop() part of yield or join, by traversing all DEQs in our group looking for a task to steal.
scanPriority - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Priority to use while scanning for work
scanWhileIdling() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Same as scan, but called when current thread is idling.
scans - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Total number of queues scanned for work
segments - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
The array of concurrency control segments.
seq(FJTask[]) - Static method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Construct and return a FJTask object that, when executed, will invoke the tasks in the tasks array in array order
seq(FJTask, FJTask) - Static method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Construct and return a FJTask object that, when executed, will invoke task1 and task2, in order
set(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWIterator
Not supported.
set(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList.COWSubListIterator
 
set(int, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
set(int, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Replaces the element at the specified position in this list with the specified element.
set(int) - Static method in class EDU.oswego.cs.dl.util.concurrent.DefaultChannelCapacity
Set the default capacity used in default (no-argument) constructor for BoundedChannels that otherwise require a capacity argument.
set(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.FutureResult
Set the reference, and signal that it is ready.
set(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList.SyncCollectionListIterator
 
set(int, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
set(boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
Set to newValue.
set(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Set to newValue.
set(char) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
Set to newValue.
set(double) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
Set to newValue.
set(float) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
Set to newValue.
set(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Set to newValue.
set(long) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Set to newValue.
set(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedRef
Set to newValue.
set(short) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Set to newValue.
set(boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableBoolean
 
set(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
 
set(char) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableChar
 
set(double) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
 
set(float) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
 
set(int) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
 
set(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
 
set(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableRef
 
set(short) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
 
setActive(FJTaskRunner) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Set active status of thread t to true, and notify others that might be waiting for work.
setBarrierCommand(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.CyclicBarrier
Set the command to run at the point at which all threads reach the barrier.
setBlockedExecutionHandler(PooledExecutor.BlockedExecutionHandler) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Set the handler for blocked execution
setCapacity(int) - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Reset the capacity of this queue.
setDone() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Indicate termination.
setException(Throwable) - Method in class EDU.oswego.cs.dl.util.concurrent.FutureResult
Set the exception field, also setting ready status.
setInactive(FJTaskRunner) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Set active status of thread t to false.
setKeepAliveTime(long) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Set the number of milliseconds to keep threads alive waiting for new commands.
setMaximumPoolSize(int) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Set the maximum number of threads to use.
setMinimumPoolSize(int) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Set the minimum number of threads to use.
setNotificationArgument(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ObservableSync
Set the argument used for notifications.
setRendezvousFunction(Rendezvous.RendezvousFunction) - Method in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
Set the function to call at the point at which all threads reach the rendezvous.
setRunPriorities(int) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Set the priority to use while a FJTaskRunner is actively running tasks.
setRunPriority(int) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Set the priority to use while running tasks.
setScanPriorities(int) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Set the priority to use while a FJTaskRunner is polling for new tasks to perform.
setScanPriority(int) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Set the priority to use while scanning.
setTerminated() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup.InvokableFJTask
 
setThreadFactory(ThreadFactory) - Method in class EDU.oswego.cs.dl.util.concurrent.ThreadFactoryUser
Set the factory for creating new threads.
setValue(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Entry
Set the value of this entry.
setValue(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.Entry
Set the value of this entry.
setter(Callable) - Method in class EDU.oswego.cs.dl.util.concurrent.FutureResult
Return a Runnable object that, when run, will set the result value.
shutDown() - Method in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
Cancel all tasks and interrupt the background thread executing the current task, if any.
shutdownAfterProcessingCurrentTask() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
Terminate background thread after it processes the current task, removing other queued tasks and leaving them unprocessed.
shutdownAfterProcessingCurrentlyQueuedTasks() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Terminate threads after processing all elements currently in queue.
shutdownAfterProcessingCurrentlyQueuedTasks(PooledExecutor.BlockedExecutionHandler) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Terminate threads after processing all elements currently in queue.
shutdownAfterProcessingCurrentlyQueuedTasks() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
Terminate background thread after it processes all elements currently in queue.
shutdownNow() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Interrupt all threads and disable construction of new threads.
shutdownNow(PooledExecutor.BlockedExecutionHandler) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Interrupt all threads and disable construction of new threads.
shutdownNow() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
Terminate background thread even if it is currently processing a task.
shutdown_ - Variable in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Shutdown flag - latches true when a shutdown method is called in order to disable queuing/handoffs of new tasks.
shutdown_ - Variable in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
true if thread should shut down after processing current task
signal() - Method in class EDU.oswego.cs.dl.util.concurrent.CondVar
Notify a waiting thread.
signal() - Method in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore.WaitQueue.WaitNode
 
signalNewTask() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Start or wake up any threads waiting for work
size() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
Return the number of elements in the buffer.
size() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Return the number of elements in the queue.
size() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Returns the number of key-value mappings in this map.
size() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Returns the number of key-value mappings in this map.
size - Variable in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
size() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
size() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns the number of components in this list.
size() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
size() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Return the number of FJTaskRunner threads in this group
size() - Method in class EDU.oswego.cs.dl.util.concurrent.Heap
Return number of elements
size() - Method in class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
Return the number of elements in the buffer.
size() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
size() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
slots_ - Variable in class EDU.oswego.cs.dl.util.concurrent.Rendezvous
Temporary holder for items in exchange
slowCoInvoke(FJTask, FJTask) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Backup to handle noninlinable cases of coInvoke
slowCoInvoke(FJTask[]) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Backup to handle atypical or noninlinable cases of coInvoke
slowPush(FJTask) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Handle slow case for push
snd - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTask.Par2
 
snd - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTask.Seq2
 
source - Variable in class EDU.oswego.cs.dl.util.concurrent.PropertyChangeMulticaster
The object to be provided as the "source" for any generated events.
source - Variable in class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
The object to be provided as the "source" for any generated events.
sput(Object, Object, int) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Continuation of put(), called only when synch lock is held and interference has been detected.
sremove(Object, int) - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Continuation of remove(), called only when synch lock is held and interference has been detected.
start() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Execute this task.
startRead() - Method in class EDU.oswego.cs.dl.util.concurrent.ReentrantWriterPreferenceReadWriteLock
 
startRead() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
startReadFromNewReader() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
startReadFromWaitingReader() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
startWrite() - Method in class EDU.oswego.cs.dl.util.concurrent.ReentrantWriterPreferenceReadWriteLock
 
startWrite() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
startWriteFromNewWriter() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
startWriteFromWaitingWriter() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
stats() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
Prints various snapshot statistics to System.out.
steals - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Total number of tasks obtained via scan
subList(int, int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList.COWSubList
 
subList(int, int) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns a view of the portion of this List between fromIndex, inclusive, and toIndex, exclusive.
subList(int, int) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
subMap(Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedMap
 
subSet(Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedSet
 
subtract(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Subtract amount from value (i.e., set value -= amount)
subtract(char) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
Subtract amount from value (i.e., set value -= amount)
subtract(double) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
Subtract amount from value (i.e., set value -= amount)
subtract(float) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
Subtract amount from value (i.e., set value -= amount)
subtract(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Subtract amount from value (i.e., set value -= amount)
subtract(long) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Subtract amount from value (i.e., set value -= amount)
subtract(short) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Subtract amount from value (i.e., set value -= amount)
subtract(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
 
subtract(char) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableChar
 
subtract(double) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
 
subtract(float) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
 
subtract(int) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
 
subtract(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
 
subtract(short) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
 
swap(SynchronizedBoolean) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
Atomically swap values with another SynchronizedBoolean.
swap(SynchronizedByte) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Atomically swap values with another SynchronizedByte.
swap(SynchronizedChar) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
Atomically swap values with another SynchronizedChar.
swap(SynchronizedDouble) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
Atomically swap values with another SynchronizedDouble.
swap(SynchronizedFloat) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
Atomically swap values with another SynchronizedFloat.
swap(SynchronizedInt) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Atomically swap values with another SynchronizedInt.
swap(SynchronizedLong) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Atomically swap values with another SynchronizedLong.
swap(SynchronizedRef) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedRef
Atomically swap values with another SynchronizedRef.
swap(SynchronizedShort) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Atomically swap values with another SynchronizedShort.
syncFailures() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
Return the number of synchronization failures for read-only operations
syncFailures() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
Return the number of synchronization failures for read-only operations
syncFailures_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
syncFailures_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
sync_ - Variable in class EDU.oswego.cs.dl.util.concurrent.TimeoutSync
 
synch() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Segment
Force a synchronization

T

Takable - Interface in EDU.oswego.cs.dl.util.concurrent
This interface exists to enable stricter type checking for channels.
ThreadFactory - Interface in EDU.oswego.cs.dl.util.concurrent
Interface describing any class that can generate new Thread objects.
ThreadFactoryUser - Class in EDU.oswego.cs.dl.util.concurrent
Base class for Executors and related classes that rely on thread factories.
ThreadFactoryUser() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ThreadFactoryUser
 
ThreadFactoryUser.DefaultThreadFactory - Class in EDU.oswego.cs.dl.util.concurrent
 
ThreadFactoryUser.DefaultThreadFactory() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ThreadFactoryUser.DefaultThreadFactory
 
ThreadedExecutor - Class in EDU.oswego.cs.dl.util.concurrent
An implementation of Executor that creates a new Thread that invokes the run method of the supplied command.
ThreadedExecutor() - Constructor for class EDU.oswego.cs.dl.util.concurrent.ThreadedExecutor
 
TimedCallable - Class in EDU.oswego.cs.dl.util.concurrent
TimedCallable runs a Callable function for a given length of time.
TimedCallable(Callable, long) - Constructor for class EDU.oswego.cs.dl.util.concurrent.TimedCallable
 
TimeoutException - Exception in EDU.oswego.cs.dl.util.concurrent
Thrown by synchronization classes that report timeouts via exceptions.
TimeoutException(long) - Constructor for exception EDU.oswego.cs.dl.util.concurrent.TimeoutException
Constructs a TimeoutException with given duration value.
TimeoutException(long, String) - Constructor for exception EDU.oswego.cs.dl.util.concurrent.TimeoutException
Constructs a TimeoutException with the specified duration value and detail message.
TimeoutSync - Class in EDU.oswego.cs.dl.util.concurrent
A TimeoutSync is an adaptor class that transforms all calls to acquire to instead invoke attempt with a predetermined timeout value.
TimeoutSync(Sync, long) - Constructor for class EDU.oswego.cs.dl.util.concurrent.TimeoutSync
Create a TimeoutSync using the given Sync object, and using the given timeout value for all calls to acquire.
tab - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.HashIterator
 
tab - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.HashIterator
 
table - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
The hash table data.
table - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
The hash table data.
tail - Variable in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
Pointer to last node on list
tailLock - Variable in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
Lock for simulating CAS for tail field
tailMap(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedMap
 
tailSet(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncSortedSet
 
tail_ - Variable in class EDU.oswego.cs.dl.util.concurrent.FIFOSemaphore.FIFOWaitQueue
 
take() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
take() - Method in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
 
take() - Method in interface EDU.oswego.cs.dl.util.concurrent.Channel
Return and remove an item from channel, possibly waiting indefinitely until such an item exists.
take() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner.VolatileTaskRef
Return the reference and clear it
take() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Take a task from the base of the DEQ.
take() - Method in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
 
take() - Method in class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
 
take() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel
 
take() - Method in interface EDU.oswego.cs.dl.util.concurrent.Takable
Return and remove an item from channel, possibly waiting indefinitely until such an item exists.
take() - Method in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
Spin until poll returns a non-null value.
takeGuard_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Helper monitor.
takeGuard_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SemaphoreControlledChannel
 
takePtr_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 
takeSidePutPermits_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedLinkedQueue
Number of takes since last reconcile
taskJoin(FJTask) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Process tasks until w is done.
taskYield() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Execute a task in this thread.
tasks - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTask.Par
 
tasks - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTask.Seq
 
terminated - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup.InvokableFJTask
 
threadFactory_ - Variable in class EDU.oswego.cs.dl.util.concurrent.ThreadFactoryUser
 
thread_ - Variable in class EDU.oswego.cs.dl.util.concurrent.ClockDaemon
The thread used to process commands
thread_ - Variable in class EDU.oswego.cs.dl.util.concurrent.QueuedExecutor
The thread used to process commands
threads - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup
The threads in this group
threads_ - Variable in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
The set of active threads, declared as a map from workers to their threads.
threshold - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Per-segment resize threshold.
threshold - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
The table is rehashed when its size exceeds this threshold.
timedGet(long) - Method in class EDU.oswego.cs.dl.util.concurrent.FutureResult
Wait at most msecs to access the reference.
timedwait(long) - Method in class EDU.oswego.cs.dl.util.concurrent.CondVar
Wait for at most msecs for notification.
timeout_ - Variable in class EDU.oswego.cs.dl.util.concurrent.TimeoutSync
 
toArray() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns an array containing all of the elements in this list in the correct order.
toArray(Object[]) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns an array containing all of the elements in this list in the correct order.
toArray() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
toArray(Object[]) - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArraySet
 
toArray() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
toArray(Object[]) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
toString() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Entry
 
toString() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.Entry
 
toString() - Method in class EDU.oswego.cs.dl.util.concurrent.CopyOnWriteArrayList
Returns a string representation of this Collection, containing the String representation of each element.
toString() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
 
toString() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
 
toString() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
 
toString() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
 
toString() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
 
toString() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
 
toString() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
 
toString() - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
 
top - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Current top of DEQ.

U

unprotectedIterator() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
Return the base iterator of the underlying collection
unprotectedListIterator() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
unprotectedListIterator(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
 
usedSlots_ - Variable in class EDU.oswego.cs.dl.util.concurrent.BoundedBuffer
 

V

VetoableChangeMulticaster - Class in EDU.oswego.cs.dl.util.concurrent
This class is interoperable with java.beans.VetoableChangeSupport, but relies on a streamlined copy-on-write scheme similar to that used in CopyOnWriteArrayList.
VetoableChangeMulticaster(Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.VetoableChangeMulticaster
Constructs a VetoableChangeMulticaster object.
value - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap.Entry
 
value - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap.Entry
 
value - Variable in class EDU.oswego.cs.dl.util.concurrent.LinkedNode
 
value - Variable in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue.Node
 
value_ - Variable in class EDU.oswego.cs.dl.util.concurrent.FutureResult
The result of the operation
value_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
 
value_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
 
value_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronizedChar
 
value_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronizedDouble
 
value_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronizedFloat
 
value_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
 
value_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
 
value_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronizedRef
The maintained reference
value_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
 
values - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
 
values() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Returns a collection view of the values contained in this map.
values - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
 
values() - Method in class EDU.oswego.cs.dl.util.concurrent.ConcurrentReaderHashMap
Returns a collection view of the values contained in this map.
values() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
victimRNG - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
Random starting point generator for scan()
votesForResize - Variable in class EDU.oswego.cs.dl.util.concurrent.ConcurrentHashMap
Number of segments voting for resize.

W

WaitFreeQueue - Class in EDU.oswego.cs.dl.util.concurrent
A wait-free linked list based queue implementation.
WaitFreeQueue() - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
 
WaitFreeQueue.Node - Class in EDU.oswego.cs.dl.util.concurrent
List nodes for Queue
WaitFreeQueue.Node(Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue.Node
Make a new node with indicated item, and null link
WaitableBoolean - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading synch for boolean instance variables.
WaitableBoolean(boolean) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableBoolean
Make a new WaitableBoolean with the given initial value
WaitableBoolean(boolean, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableBoolean
Make a new WaitableBoolean with the given initial value, and using the supplied lock.
WaitableByte - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading waiting and signalling operations on single byte variables.
WaitableByte(byte) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableByte
Make a new WaitableByte with the given initial value, and using its own internal lock.
WaitableByte(byte, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableByte
Make a new WaitableByte with the given initial value, and using the supplied lock.
WaitableChar - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading waiting and signalling operations on single char variables.
WaitableChar(char) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableChar
Make a new WaitableChar with the given initial value, and using its own internal lock.
WaitableChar(char, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableChar
Make a new WaitableChar with the given initial value, and using the supplied lock.
WaitableDouble - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading waiting and signalling operations on single double variables.
WaitableDouble(double) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
Make a new WaitableDouble with the given initial value, and using its own internal lock.
WaitableDouble(double, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
Make a new WaitableDouble with the given initial value, and using the supplied lock.
WaitableFloat - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading waiting and signalling operations on single float variables.
WaitableFloat(float) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
Make a new WaitableFloat with the given initial value, and using its own internal lock.
WaitableFloat(float, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
Make a new WaitableFloat with the given initial value, and using the supplied lock.
WaitableInt - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading waiting and signalling operations on single int variables.
WaitableInt(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableInt
Make a new WaitableInt with the given initial value, and using its own internal lock.
WaitableInt(int, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableInt
Make a new WaitableInt with the given initial value, and using the supplied lock.
WaitableLong - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading waiting and signalling operations on single long variables.
WaitableLong(long) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableLong
Make a new WaitableLong with the given initial value, and using its own internal lock.
WaitableLong(long, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableLong
Make a new WaitableLong with the given initial value, and using the supplied lock.
WaitableRef - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading synch for Object reference instance variables.
WaitableRef(Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableRef
Create a WaitableRef initially holding the given reference and using its own internal lock.
WaitableRef(Object, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableRef
Make a new WaitableRef with the given initial value, and using the supplied lock.
WaitableShort - Class in EDU.oswego.cs.dl.util.concurrent
A class useful for offloading waiting and signalling operations on single short variables.
WaitableShort(short) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableShort
Make a new WaitableShort with the given initial value, and using its own internal lock.
WaitableShort(short, Object) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaitableShort
Make a new WaitableShort with the given initial value, and using the supplied lock.
WaiterPreferenceSemaphore - Class in EDU.oswego.cs.dl.util.concurrent
An implementation of counting Semaphores that enforces enough fairness for applications that need to avoid indefinite overtaking without necessarily requiring FIFO ordered access.
WaiterPreferenceSemaphore(long) - Constructor for class EDU.oswego.cs.dl.util.concurrent.WaiterPreferenceSemaphore
Create a Semaphore with the given initial number of permits.
WriterPreferenceReadWriteLock - Class in EDU.oswego.cs.dl.util.concurrent
A ReadWriteLock that prefers waiting writers over waiting readers when there is contention.
WriterPreferenceReadWriteLock() - Constructor for class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
WriterPreferenceReadWriteLock.ReaderLock - Class in EDU.oswego.cs.dl.util.concurrent
 
WriterPreferenceReadWriteLock.ReaderLock() - Constructor for class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock.ReaderLock
 
WriterPreferenceReadWriteLock.Signaller - Class in EDU.oswego.cs.dl.util.concurrent
Reader and Writer requests are maintained in two different wait sets, by two different objects.
WriterPreferenceReadWriteLock.Signaller() - Constructor for class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock.Signaller
 
WriterPreferenceReadWriteLock.WriterLock - Class in EDU.oswego.cs.dl.util.concurrent
 
WriterPreferenceReadWriteLock.WriterLock() - Constructor for class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock.WriterLock
 
waitWhenBlocked() - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Set the policy for blocked execution to be to wait until a thread is available, unless the pool has been shut down, in which case the action is discarded.
waitingForTake_ - Variable in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
The number of threads waiting for a take.
waitingPuts - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel
 
waitingReaders_ - Variable in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
waitingTakes - Variable in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel
 
waitingWriters_ - Variable in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
waits_ - Variable in class EDU.oswego.cs.dl.util.concurrent.WaiterPreferenceSemaphore
Number of waiting threads
whenEqual(boolean, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableBoolean
Wait until value equals c, then run action if nonnull.
whenEqual(byte, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
Wait until value equals c, then run action if nonnull.
whenEqual(char, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableChar
Wait until value equals c, then run action if nonnull.
whenEqual(double, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
Wait until value equals c, then run action if nonnull.
whenEqual(float, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
Wait until value equals c, then run action if nonnull.
whenEqual(int, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
Wait until value equals c, then run action if nonnull.
whenEqual(long, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
Wait until value equals c, then run action if nonnull.
whenEqual(Object, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableRef
Wait until value equals c, then run action if nonnull.
whenEqual(short, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
Wait until value equals c, then run action if nonnull.
whenFalse(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableBoolean
Wait until value is false, then run action if nonnull.
whenGreater(byte, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
wait until value greater than c, then run action if nonnull.
whenGreater(char, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableChar
wait until value greater than c, then run action if nonnull.
whenGreater(double, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
wait until value greater than c, then run action if nonnull.
whenGreater(float, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
wait until value greater than c, then run action if nonnull.
whenGreater(int, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
wait until value greater than c, then run action if nonnull.
whenGreater(long, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
wait until value greater than c, then run action if nonnull.
whenGreater(short, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
wait until value greater than c, then run action if nonnull.
whenGreaterEqual(byte, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
wait until value greater than or equal to c, then run action if nonnull.
whenGreaterEqual(char, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableChar
wait until value greater than or equal to c, then run action if nonnull.
whenGreaterEqual(double, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
wait until value greater than or equal to c, then run action if nonnull.
whenGreaterEqual(float, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
wait until value greater than or equal to c, then run action if nonnull.
whenGreaterEqual(int, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
wait until value greater than or equal to c, then run action if nonnull.
whenGreaterEqual(long, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
wait until value greater than or equal to c, then run action if nonnull.
whenGreaterEqual(short, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
wait until value greater than or equal to c, then run action if nonnull.
whenLess(byte, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
wait until value less than c, then run action if nonnull.
whenLess(char, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableChar
wait until value less than c, then run action if nonnull.
whenLess(double, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
wait until value less than c, then run action if nonnull.
whenLess(float, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
wait until value less than c, then run action if nonnull.
whenLess(int, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
wait until value less than c, then run action if nonnull.
whenLess(long, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
wait until value less than c, then run action if nonnull.
whenLess(short, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
wait until value less than c, then run action if nonnull.
whenLessEqual(byte, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
wait until value less than or equal to c, then run action if nonnull.
whenLessEqual(char, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableChar
wait until value less than or equal to c, then run action if nonnull.
whenLessEqual(double, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
wait until value less than or equal to c, then run action if nonnull.
whenLessEqual(float, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
wait until value less than or equal to c, then run action if nonnull.
whenLessEqual(int, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
wait until value less than or equal to c, then run action if nonnull.
whenLessEqual(long, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
wait until value less than or equal to c, then run action if nonnull.
whenLessEqual(short, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
wait until value less than or equal to c, then run action if nonnull.
whenNotEqual(boolean, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableBoolean
wait until value not equal to c, then run action if nonnull.
whenNotEqual(byte, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
wait until value not equal to c, then run action if nonnull.
whenNotEqual(char, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableChar
wait until value not equal to c, then run action if nonnull.
whenNotEqual(double, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableDouble
wait until value not equal to c, then run action if nonnull.
whenNotEqual(float, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableFloat
wait until value not equal to c, then run action if nonnull.
whenNotEqual(int, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
wait until value not equal to c, then run action if nonnull.
whenNotEqual(long, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
wait until value not equal to c, then run action if nonnull.
whenNotEqual(Object, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableRef
wait until value not equal to c, then run action if nonnull.
whenNotEqual(short, Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
wait until value not equal to c, then run action if nonnull.
whenNotNull(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableRef
wait until value is nonnull, then run action if nonnull.
whenNull(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableRef
Wait until value is null, then run action if nonnull.
whenTrue(Runnable) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableBoolean
wait until value is true, then run action if nonnull.
workerDone(PooledExecutor.Worker) - Method in class EDU.oswego.cs.dl.util.concurrent.PooledExecutor
Cleanup method called upon termination of worker thread.
wq_ - Variable in class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore
 
wr_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
 
wr_ - Variable in class EDU.oswego.cs.dl.util.concurrent.SyncMap
 
wrapped - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunnerGroup.InvokableFJTask
 
writeHolds_ - Variable in class EDU.oswego.cs.dl.util.concurrent.ReentrantWriterPreferenceReadWriteLock
Number of acquires on write lock by activeWriter_ thread
writeLock() - Method in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
 
writeLock() - Method in interface EDU.oswego.cs.dl.util.concurrent.ReadWriteLock
get the writeLock
writeLock() - Method in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
writerLock_ - Variable in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
 
writerSync - Variable in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
 
writerSync() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
Return the Sync object managing mutative operations
writerSync() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
Return the Sync object managing mutative operations

X

xor(boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedBoolean
Set value to value ^ b.
xor(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedByte
Set value to value ^ b.
xor(int) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedInt
Set value to value ^ b.
xor(long) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedLong
Set value to value ^ b.
xor(short) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronizedShort
Set value to value ^ b.
xor(boolean) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableBoolean
 
xor(byte) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableByte
Set value to value ^ b.
xor(int) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableInt
Set value to value ^ b.
xor(long) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableLong
Set value to value ^ b.
xor(short) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitableShort
Set value to value ^ b.

Y

yield() - Static method in class EDU.oswego.cs.dl.util.concurrent.FJTask
Allow the current underlying FJTaskRunner thread to process other tasks.

A B C D E F G H I J K L M N O P Q R S T U V W X Y