- 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
-
- Callable - Interface in EDU.oswego.cs.dl.util.concurrent
-
Interface for runnable actions that bear results and/or throw Exceptions.
- 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.
- 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.
- 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.misc.CVBuffer
-
- capacity() - Method in class EDU.oswego.cs.dl.util.concurrent.misc.FIFOSlot
-
- 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
-
- 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
- cells_ - Variable in class EDU.oswego.cs.dl.util.concurrent.PrioritySemaphore.PriorityWaitQueue
-
An array of wait queues, one per priority
- Channel - Interface in EDU.oswego.cs.dl.util.concurrent
-
Main interface for buffers, queues, pipes, conduits, etc.
- 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.
- checkOverflow() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
-
Adjust top and base, and grow DEQ if necessary.
- 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
- 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.TaskNode - Class in EDU.oswego.cs.dl.util.concurrent
-
- clone() - Method in class EDU.oswego.cs.dl.util.concurrent.misc.Fraction
-
- 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(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.misc.Fraction
-
return a number less, equal, or greater than zero
reflecting whether this Fraction is less, equal or greater than
the value of Fraction other.
- compareTo(long) - Method in class EDU.oswego.cs.dl.util.concurrent.misc.Fraction
-
return a number less, equal, or greater than zero
reflecting whether this Fraction is less, equal or greater than n.
- 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
- 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.
- 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
- construct() - Method in class EDU.oswego.cs.dl.util.concurrent.misc.SwingWorker
-
Computes the value to be returned by the get
method.
- contains(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
-
- containsAll(Collection) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncCollection
-
- containsKey(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
-
- containsValue(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
-
- 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
-
- 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
- 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.
- CVBuffer - Class in EDU.oswego.cs.dl.util.concurrent.misc
-
- CVBuffer(int) - Constructor for class EDU.oswego.cs.dl.util.concurrent.misc.CVBuffer
-
- CVBuffer() - Constructor for class EDU.oswego.cs.dl.util.concurrent.misc.CVBuffer
-
- 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.
- 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
- 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
- Par(FJTask, FJTask) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask.Par
-
Two-task constructor, for compatibility with previous release.
- Par2(FJTask, FJTask) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask.Par2
-
- 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.misc.CVBuffer
-
- peek() - Method in class EDU.oswego.cs.dl.util.concurrent.misc.FIFOSlot
-
- peek() - Method in class EDU.oswego.cs.dl.util.concurrent.misc.PipedChannel
-
Stubbed out for now
- 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
- PipedChannel - Class in EDU.oswego.cs.dl.util.concurrent.misc
-
A channel based on a java.io.PipedInputStream and
java.io.PipedOutputStream.
- PipedChannel() - Constructor for class EDU.oswego.cs.dl.util.concurrent.misc.PipedChannel
-
- plus(Fraction) - Method in class EDU.oswego.cs.dl.util.concurrent.misc.Fraction
-
return a Fraction representing this Fraction plus b
- plus(long) - Method in class EDU.oswego.cs.dl.util.concurrent.misc.Fraction
-
return a Fraction representing this Fraction plus n
- 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.misc.CVBuffer
-
- poll(long) - Method in class EDU.oswego.cs.dl.util.concurrent.misc.FIFOSlot
-
- 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.
- 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.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.DiscardWhenBlocked - Class in EDU.oswego.cs.dl.util.concurrent
-
Class defining Discard action.
- PooledExecutor.RunWhenBlocked - Class in EDU.oswego.cs.dl.util.concurrent
-
Class defining Run action.
- PooledExecutor.WaitWhenBlocked - Class in EDU.oswego.cs.dl.util.concurrent
-
Class defining Wait action.
- PooledExecutor.Worker - Class in EDU.oswego.cs.dl.util.concurrent
-
Class defining the basic run loop for pooled threads.
- 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.SyncList.SyncCollectionListIterator
-
- previousIndex() - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList.SyncCollectionListIterator
-
- 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
-
- PriorityWaitQueue() - Constructor for class EDU.oswego.cs.dl.util.concurrent.PrioritySemaphore.PriorityWaitQueue
-
- 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(FJTask) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
-
Enqueue task at base of DEQ.
- put(FJTask) - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner.VolatileTaskRef
-
Set the reference
- put(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.LinkedQueue
-
- put(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.misc.CVBuffer
-
- put(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.misc.FIFOSlot
-
- 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) - Method in class EDU.oswego.cs.dl.util.concurrent.SynchronousChannel
-
- put(Object, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncMap
-
- put(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.WaitFreeQueue
-
- 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.
- Puttable - Interface in EDU.oswego.cs.dl.util.concurrent
-
This interface exists to enable stricter type checking
for channels.
- 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
- scans - Variable in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
-
Total number of queues scanned for work
- scanWhileIdling() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTaskRunner
-
Same as scan, but called when current thread is idling.
- 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
- 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
- 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
- Seq(FJTask, FJTask) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask.Seq
-
Two-task constructor, for compatibility with previous release.
- Seq2(FJTask, FJTask) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask.Seq2
-
- 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(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(int, Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList
-
- set(Object) - Method in class EDU.oswego.cs.dl.util.concurrent.SyncList.SyncCollectionListIterator
-
- 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.
- 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.
- setter(Callable) - Method in class EDU.oswego.cs.dl.util.concurrent.FutureResult
-
Return a Runnable object that, when run, will set the result value.
- 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.
- 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.
- 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
- 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.
- 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.
- 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.
- 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
-
- Signaller() - Constructor for class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock.Signaller
-
- 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.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
-
- 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
- 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
-
- start() - Method in class EDU.oswego.cs.dl.util.concurrent.FJTask
-
Execute this task.
- start() - Method in class EDU.oswego.cs.dl.util.concurrent.misc.SwingWorker
-
Starts the worker thread.
- 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.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.
- SwingWorker - Class in EDU.oswego.cs.dl.util.concurrent.misc
-
An abstract class that you subclass to perform GUI-related work
in a dedicated thread.
- SwingWorker() - Constructor for class EDU.oswego.cs.dl.util.concurrent.misc.SwingWorker
-
Creates new SwingWorker with no timeout.
- SwingWorker(long) - Constructor for class EDU.oswego.cs.dl.util.concurrent.misc.SwingWorker
-
Creates new SwingWorker with specified timeout.
- SwingWorker(ThreadFactory, long) - Constructor for class EDU.oswego.cs.dl.util.concurrent.misc.SwingWorker
-
Creates new SwingWorker with specified thread factory and timeout.
- Sync - Interface in EDU.oswego.cs.dl.util.concurrent
-
Main interface for locks, gates, and conditions.
- sync_ - Variable in class EDU.oswego.cs.dl.util.concurrent.TimeoutSync
-
- 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
-
- 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
-
- SynchronizationTimer - Class in EDU.oswego.cs.dl.util.concurrent.misc
-
This program records times for various fine-grained synchronization
schemes, and provides some ways of measuring them over different
context parameters.
- SynchronizationTimer() - Constructor for class EDU.oswego.cs.dl.util.concurrent.misc.SynchronizationTimer
-
- 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.
- 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.
- 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.
- 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
- 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
-
- WaitNode() - Constructor for class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore.WaitQueue.WaitNode
-
- WaitQueue() - Constructor for class EDU.oswego.cs.dl.util.concurrent.QueuedSemaphore.WaitQueue
-
- waits_ - Variable in class EDU.oswego.cs.dl.util.concurrent.WaiterPreferenceSemaphore
-
Number of waiting threads
- 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.
- WaitWhenBlocked() - Constructor for class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.WaitWhenBlocked
-
- 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.
- Worker(Runnable) - Constructor for class EDU.oswego.cs.dl.util.concurrent.PooledExecutor.Worker
-
- 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
-
- Wrap(Runnable) - Constructor for class EDU.oswego.cs.dl.util.concurrent.FJTask.Wrap
-
- 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() - Constructor for class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock.WriterLock
-
- writerLock_ - Variable in class EDU.oswego.cs.dl.util.concurrent.WriterPreferenceReadWriteLock
-
- 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.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.WriterLock - Class in EDU.oswego.cs.dl.util.concurrent
-
- writerSync - Variable in class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock
-
- WriterSync() - Constructor for class EDU.oswego.cs.dl.util.concurrent.FIFOReadWriteLock.WriterSync
-
- 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