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

A

addAll(Map<? extends K, ? extends V>) - Method in class com.atlassian.util.concurrent.CopyOnWriteMap.Builder
Views are live (reflecting concurrent updates) and mutator methods are supported.
addAll(Map<? extends K, ? extends V>) - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap.Builder
Views are live (reflecting concurrent updates) and mutator methods are supported.
apply(A) - Method in interface com.atlassian.util.concurrent.Effect
Perform the side-effect.
Assertions - Class in com.atlassian.util.concurrent
Design by contract assertions.
AsyncCompleter - Class in com.atlassian.util.concurrent
Convenient encapsulation of CompletionService usage that allows a collection of jobs to be issued to an Executor and return an Iterable of the results that is in the order that the results return.
AsyncCompleter.Builder - Class in com.atlassian.util.concurrent
For creating instances of AsyncCompleter.
AsyncCompleter.Builder(Executor) - Constructor for class com.atlassian.util.concurrent.AsyncCompleter.Builder
Create a Builder with the supplied Executor
AsyncCompleter.ExecutorCompletionServiceFactory - Interface in com.atlassian.util.concurrent
Extension point if a custom CompletionService is required, for instance to implement a custom concellation policy.
AtomicInteger - Class in com.atlassian.util.concurrent.atomic
AtomicInteger with richer functionality.
AtomicInteger() - Constructor for class com.atlassian.util.concurrent.atomic.AtomicInteger
Creates a new AtomicInteger with a zero initial value.
AtomicInteger(int) - Constructor for class com.atlassian.util.concurrent.atomic.AtomicInteger
Creates a new AtomicInteger with the given initial value.
AtomicLong - Class in com.atlassian.util.concurrent.atomic
AtomicLong with richer functionality.
AtomicLong() - Constructor for class com.atlassian.util.concurrent.atomic.AtomicLong
Creates a new AtomicLong with a zero initial value.
AtomicLong(long) - Constructor for class com.atlassian.util.concurrent.atomic.AtomicLong
Creates a new AtomicLong with the given initial value.
AtomicLongArray - Class in com.atlassian.util.concurrent.atomic
AtomicReferenceArray with richer functionality.
AtomicLongArray(int) - Constructor for class com.atlassian.util.concurrent.atomic.AtomicLongArray
Creates a new AtomicLongArray of given length.
AtomicLongArray(long[]) - Constructor for class com.atlassian.util.concurrent.atomic.AtomicLongArray
Creates a new AtomicLongArray with the same length as, and all elements copied from, the given array.
AtomicReference<V> - Class in com.atlassian.util.concurrent.atomic
AtomicReference with richer functionality.
AtomicReference() - Constructor for class com.atlassian.util.concurrent.atomic.AtomicReference
Creates a new AtomicReference with null initial value.
AtomicReference(V) - Constructor for class com.atlassian.util.concurrent.atomic.AtomicReference
Creates a new AtomicReference with the given initial value.
AtomicReferenceArray<E> - Class in com.atlassian.util.concurrent.atomic
AtomicReferenceArray with richer functionality.
AtomicReferenceArray(int) - Constructor for class com.atlassian.util.concurrent.atomic.AtomicReferenceArray
Creates a new AtomicReferenceArray of given length.
AtomicReferenceArray(E[]) - Constructor for class com.atlassian.util.concurrent.atomic.AtomicReferenceArray
Creates a new AtomicReferenceArray with the same length as, and all elements copied from, the given array.
AtomicReferenceUpdater<T> - Class in com.atlassian.util.concurrent.atomic
Experimental.
AtomicReferenceUpdater(AtomicReference<T>) - Constructor for class com.atlassian.util.concurrent.atomic.AtomicReferenceUpdater
 
Atomics - Class in com.atlassian.util.concurrent.atomic
Utility methods for handling the specifics of correctly using the CAS operations on AtomicReference classes and the like.
await() - Method in interface com.atlassian.util.concurrent.Awaitable
Await for the condition to become true.
await(long, TimeUnit) - Method in interface com.atlassian.util.concurrent.Awaitable
Await for the specified time for the condition to become true.
await() - Method in class com.atlassian.util.concurrent.BooleanLatch
Await for the condition to become true.
await(long, TimeUnit) - Method in class com.atlassian.util.concurrent.BooleanLatch
Await for the specified time for the condition to become true.
await() - Method in class com.atlassian.util.concurrent.PhasedLatch
Await the current phase.
await(long, TimeUnit) - Method in class com.atlassian.util.concurrent.PhasedLatch
Await the current phase for the specified period.
Awaitable - Interface in com.atlassian.util.concurrent
Something that can be awaited upon.
awaitPhase(int) - Method in class com.atlassian.util.concurrent.PhasedLatch
Await the specified phase.
awaitPhase(int, long, TimeUnit) - Method in class com.atlassian.util.concurrent.PhasedLatch
Await the specified phase for the specified period.

B

BlockingReference<V> - Class in com.atlassian.util.concurrent
A Reference with queue semantics where the current reference may be retrieved or taken instead, and if there is no current element then it will be block until the reference becomes available.
BlockingReference() - Constructor for class com.atlassian.util.concurrent.BlockingReference
Deprecated. use BlockingReference.newSRSW() instead.
BlockingReference(V) - Constructor for class com.atlassian.util.concurrent.BlockingReference
Deprecated. use BlockingReference.newSRSW() instead.
BooleanLatch - Class in com.atlassian.util.concurrent
A BooleanLatch is a reusable latch that resets after it is released and waited on.
BooleanLatch() - Constructor for class com.atlassian.util.concurrent.BooleanLatch
 
build() - Method in class com.atlassian.util.concurrent.AsyncCompleter.Builder
 
build() - Method in class com.atlassian.util.concurrent.ThreadFactories.Builder
 
builder() - Static method in class com.atlassian.util.concurrent.CopyOnWriteMap
Get a CopyOnWriteMap.Builder for a CopyOnWriteMap instance.
builder() - Static method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap
Get a CopyOnWriteSortedMap.Builder for a CopyOnWriteSortedMap instance.
bytes(long) - Static method in class com.atlassian.util.concurrent.Memory
Construct a Memory represented in bytes.
bytes() - Method in class com.atlassian.util.concurrent.Memory
The number of bytes represented by this instance.

C

cancel() - Method in class com.atlassian.util.concurrent.LazyReference
Cancel the initializing operation if it has not already run.
cancel() - Method in class com.atlassian.util.concurrent.ResettableLazyReference
Cancel the initializing operation if it has not already run.
cancel(boolean) - Method in class com.atlassian.util.concurrent.SettableFuture
 
checkCompletionServiceFutureIdentity() - Method in class com.atlassian.util.concurrent.AsyncCompleter.Builder
 
claim() - Method in class com.atlassian.util.concurrent.ForwardingPromise
 
claim() - Method in interface com.atlassian.util.concurrent.Promise
Blocks the thread waiting for a result.
clear() - Method in class com.atlassian.util.concurrent.BlockingReference
Clear the current reference.
com.atlassian.util.concurrent - package com.atlassian.util.concurrent
 
com.atlassian.util.concurrent.atomic - package com.atlassian.util.concurrent.atomic
 
comparator() - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap
 
compare(Memory, Memory) - Method in enum com.atlassian.util.concurrent.Memory.MemoryComparator
 
compare(Memory.Unit, Memory.Unit) - Method in enum com.atlassian.util.concurrent.Memory.UnitComparator
 
completionServiceFactory(AsyncCompleter.ExecutorCompletionServiceFactory) - Method in class com.atlassian.util.concurrent.AsyncCompleter.Builder
 
ConcurrentOperationMap<K,R> - Interface in com.atlassian.util.concurrent
This will allow you to submit an operation, encapsulated by a Callable, and keyed by an Object , such that the result of the Callable will be available to any concurrent callers with the same Object key.
ConcurrentOperationMapImpl<K,R> - Class in com.atlassian.util.concurrent
 
ConcurrentOperationMapImpl() - Constructor for class com.atlassian.util.concurrent.ConcurrentOperationMapImpl
 
consume(T) - Method in interface com.atlassian.util.concurrent.Sink
Consume the product.
copy(N) - Method in class com.atlassian.util.concurrent.CopyOnWriteMap
 
copy(N) - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap
 
CopyOnWriteMap<K,V> - Class in com.atlassian.util.concurrent
A thread-safe variant of Map in which all mutative operations (the "destructive" operations described by Map put, remove and so on) are implemented by making a fresh copy of the underlying map.
CopyOnWriteMap(Map<? extends K, ? extends V>) - Constructor for class com.atlassian.util.concurrent.CopyOnWriteMap
Deprecated. since 0.0.12 use the versions that explicitly specify View.Type
CopyOnWriteMap() - Constructor for class com.atlassian.util.concurrent.CopyOnWriteMap
Deprecated. since 0.0.12 use the versions that explicitly specify View.Type
CopyOnWriteMap(Map<? extends K, ? extends V>, AbstractCopyOnWriteMap.View.Type) - Constructor for class com.atlassian.util.concurrent.CopyOnWriteMap
Create a new CopyOnWriteMap with the supplied Map to initialize the values.
CopyOnWriteMap(AbstractCopyOnWriteMap.View.Type) - Constructor for class com.atlassian.util.concurrent.CopyOnWriteMap
Create a new empty CopyOnWriteMap.
CopyOnWriteMap.Builder<K,V> - Class in com.atlassian.util.concurrent
Build a CopyOnWriteMap and specify all the options.
CopyOnWriteMaps - Class in com.atlassian.util.concurrent
Deprecated. use the static factory methods is CopyOnWriteMap and CopyOnWriteSortedMap directly.
CopyOnWriteMaps() - Constructor for class com.atlassian.util.concurrent.CopyOnWriteMaps
Deprecated.  
CopyOnWriteSortedMap<K,V> - Class in com.atlassian.util.concurrent
A thread-safe variant of SortedMap in which all mutative operations (the "destructive" operations described by SortedMap put, remove and so on) are implemented by making a fresh copy of the underlying map.
CopyOnWriteSortedMap(AbstractCopyOnWriteMap.View.Type) - Constructor for class com.atlassian.util.concurrent.CopyOnWriteSortedMap
Create a new empty CopyOnWriteMap.
CopyOnWriteSortedMap(Map<? extends K, ? extends V>, AbstractCopyOnWriteMap.View.Type) - Constructor for class com.atlassian.util.concurrent.CopyOnWriteSortedMap
Create a new CopyOnWriteMap with the supplied Map to initialize the values.
CopyOnWriteSortedMap.Builder<K,V> - Class in com.atlassian.util.concurrent
Build a CopyOnWriteSortedMap and specify all the options.
create() - Method in interface com.atlassian.util.concurrent.AsyncCompleter.ExecutorCompletionServiceFactory
 
create() - Method in class com.atlassian.util.concurrent.LazyReference
The object factory method, guaranteed to be called once and only once.
create() - Method in class com.atlassian.util.concurrent.ResettableLazyReference
The object factory method, guaranteed to be called once and only once.
currentTime() - Method in interface com.atlassian.util.concurrent.Timeout.TimeSupplier
The time now.

D

delegate() - Method in class com.atlassian.util.concurrent.ForwardingPromise
 
done(Effect<? super A>) - Method in class com.atlassian.util.concurrent.ForwardingPromise
 
done(Effect<? super A>) - Method in interface com.atlassian.util.concurrent.Promise
Registers a callback to be called when the promised object is available.

E

Effect<A> - Interface in com.atlassian.util.concurrent
Contains the a side-effect that may be applied
Effect.Applicant<A> - Interface in com.atlassian.util.concurrent
A thing upon which side-effects may be applied.
Effects - Class in com.atlassian.util.concurrent
Useful Effect related static methods.
equals(Object) - Method in class com.atlassian.util.concurrent.Memory
 
ExceptionPolicy - Interface in com.atlassian.util.concurrent
Represents an exception handling policy.
ExceptionPolicy.Policies - Enum in com.atlassian.util.concurrent
Default exception handling policies

F

fail(Effect<Throwable>) - Method in class com.atlassian.util.concurrent.ForwardingPromise
 
fail(Effect<Throwable>) - Method in interface com.atlassian.util.concurrent.Promise
Registers a callback to be called when an exception is thrown.
firstKey() - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap
 
flatMap(Function<? super A, ? extends Promise<? extends B>>) - Method in class com.atlassian.util.concurrent.ForwardingPromise
 
flatMap(Function<? super A, ? extends Promise<? extends B>>) - Method in interface com.atlassian.util.concurrent.Promise
Transforms this promise from one type to another by way of a transformation function that returns a new Promise, leaving the strategy for that promise production up to the function.
fold(Function<Throwable, ? extends B>, Function<? super A, ? extends B>) - Method in class com.atlassian.util.concurrent.ForwardingPromise
 
fold(Function<Throwable, ? extends B>, Function<? super A, ? extends B>) - Method in interface com.atlassian.util.concurrent.Promise
Transform this promise from one type to another, also providing a strategy for dealing with any exceptions encountered.
foreach(Effect<A>) - Method in interface com.atlassian.util.concurrent.Effect.Applicant
Perform the given side-effect for each contained element.
forFuture(Future<A>) - Static method in class com.atlassian.util.concurrent.Promises
Creates a promise from the given future.
forListenableFuture(ListenableFuture<A>) - Static method in class com.atlassian.util.concurrent.Promises
Creates a promise from the given future.
ForwardingPromise<A> - Class in com.atlassian.util.concurrent
A promise which forwards all its method calls to another promise.
ForwardingPromise() - Constructor for class com.atlassian.util.concurrent.ForwardingPromise
Constructor for use by subclasses.
fromFunction(D, Function<D, T>) - Static method in class com.atlassian.util.concurrent.Suppliers
A Supplier that asks the argument function for the result using the input argument.
fromGoogleSupplier(Supplier<T>) - Static method in class com.atlassian.util.concurrent.Suppliers
Map from a google-collections Supplier.
fromSupplier(Supplier<R>) - Static method in class com.atlassian.util.concurrent.Functions
Get a function that uses the Supplier as a factory for all inputs.
Function<D,R> - Interface in com.atlassian.util.concurrent
A Function that resolves Descriptors (of type D) to a Resource (of type R).
Functions - Class in com.atlassian.util.concurrent
 
futureCallback(Effect<? super A>, Effect<Throwable>) - Static method in class com.atlassian.util.concurrent.Promises
Create a FutureCallback by composing two Effects.

G

get() - Method in class com.atlassian.util.concurrent.BlockingReference
Gets the current element if it is not null, if it is null then this method blocks and waits until it is not null.
get(long, TimeUnit) - Method in class com.atlassian.util.concurrent.BlockingReference
Gets the current element if it is not null, if it is null then this method blocks and waits until it is not null.
get(D) - Method in interface com.atlassian.util.concurrent.Function
Resolves an output where an input is given.
get() - Method in class com.atlassian.util.concurrent.LazyReference
Get the lazily loaded reference in a non-cancellable manner.
get() - Method in class com.atlassian.util.concurrent.ResettableLazyReference
Get the lazily loaded reference in a non-cancellable manner.
get() - Method in class com.atlassian.util.concurrent.SettableFuture
 
get(long, TimeUnit) - Method in class com.atlassian.util.concurrent.SettableFuture
 
get() - Method in interface com.atlassian.util.concurrent.Supplier
Produce an object.
getAndSetIf(AtomicReference<T>, T, Supplier<T>) - Static method in class com.atlassian.util.concurrent.atomic.Atomics
Get the current value of the reference but if it matches the oldValue argument, compare-and-set it to one created by the new value supplier.
getAndSetIf(AtomicReference<T>, T, T) - Static method in class com.atlassian.util.concurrent.atomic.Atomics
Check the current value of the reference and if it matches the old value argument, compare-and-set it to the new value and return that instead.
getAndSetIf(AtomicReferenceArray<T>, int, T, Supplier<T>) - Static method in class com.atlassian.util.concurrent.atomic.Atomics
Get the current value of the array reference but if it matches the oldValue argument, compare-and-set it to one created by the new value supplier.
getAndSetIf(AtomicReferenceArray<T>, int, T, T) - Static method in class com.atlassian.util.concurrent.atomic.Atomics
Get the current value of the array reference but if it matches the oldValue argument, compare-and-set it the new value.
getAndSetIf(AtomicLong, long, long) - Static method in class com.atlassian.util.concurrent.atomic.Atomics
Get the current value of the reference but if it matches the oldValue argument, compare-and-set it the new value.
getAndSetIf(AtomicInteger, int, int) - Static method in class com.atlassian.util.concurrent.atomic.Atomics
Get the current value of the reference but if it matches the oldValue argument, compare-and-set it to one created by the newValue Supplier.
getAndSetIf(AtomicBoolean, boolean, boolean) - Static method in class com.atlassian.util.concurrent.atomic.Atomics
Get the current value of the reference but if it matches the oldValue argument, compare-and-set it to one created by the newValue Supplier.
getAndSetIfNull(AtomicReference<T>, Supplier<T>) - Static method in class com.atlassian.util.concurrent.atomic.Atomics
Get the current value of the reference but if it is null, compare-and-set it to one created by the new value Supplier.
getAndSetIfNull(AtomicReference<T>, T) - Static method in class com.atlassian.util.concurrent.atomic.Atomics
Get the current value of the reference but if it is null, compare-and-set it the new value.
getAndSetIfNull(AtomicReferenceArray<T>, int, Supplier<T>) - Static method in class com.atlassian.util.concurrent.atomic.Atomics
Get the current value of the array reference but if it is null, compare-and-set it to one created by the new value Supplier.
getAndSetIfNull(AtomicReferenceArray<T>, int, T) - Static method in class com.atlassian.util.concurrent.atomic.Atomics
Get the current value of the array reference but if it is null, compare-and-set it the new value
getCause() - Method in exception com.atlassian.util.concurrent.RuntimeInterruptedException
 
getCause() - Method in exception com.atlassian.util.concurrent.RuntimeTimeoutException
 
getInterruptibly() - Method in class com.atlassian.util.concurrent.LazyReference
Get the lazily loaded reference in a cancellable manner.
getInterruptibly() - Method in class com.atlassian.util.concurrent.ResettableLazyReference
Get the lazily loaded reference in a cancellable manner.
getMillisTimeout(long, TimeUnit) - Static method in class com.atlassian.util.concurrent.Timeout
Get a Timeout that uses millisecond precision.
getNanosTimeout(long, TimeUnit) - Static method in class com.atlassian.util.concurrent.Timeout
Get a Timeout that uses nanosecond precision.
getOrSetAndGetIf(int, int) - Method in class com.atlassian.util.concurrent.atomic.AtomicInteger
Check the current value and if it matches the old value argument, set it to the new value and return that instead.
getOrSetAndGetIf(long, long) - Method in class com.atlassian.util.concurrent.atomic.AtomicLong
Check the current value and if it matches the old value argument, set it to the new value and return that instead.
getOrSetAndGetIf(int, long, long) - Method in class com.atlassian.util.concurrent.atomic.AtomicLongArray
Check the current value and if it matches the old value argument, set it to the new value and return that instead.
getOrSetAndGetIf(V, Supplier<V>) - Method in class com.atlassian.util.concurrent.atomic.AtomicReference
Check the current value and if it matches the old value argument, set it to the one created by the new value supplier and return that instead.
getOrSetAndGetIf(V, V) - Method in class com.atlassian.util.concurrent.atomic.AtomicReference
Check the current value and if it matches the old value argument, set it to the new value and return that instead.
getOrSetAndGetIf(int, E, Supplier<E>) - Method in class com.atlassian.util.concurrent.atomic.AtomicReferenceArray
Check the current value and if it matches the old value argument, set it to the one created by the new value supplier and return that instead.
getOrSetAndGetIf(int, E, E) - Method in class com.atlassian.util.concurrent.atomic.AtomicReferenceArray
Check the current value and if it matches the old value argument, set it to the new value and return that instead.
getPhase() - Method in class com.atlassian.util.concurrent.PhasedLatch
 
getTime() - Method in class com.atlassian.util.concurrent.Timeout
 
getTimeoutException() - Method in class com.atlassian.util.concurrent.Timeout
 
getTimeoutPeriod() - Method in class com.atlassian.util.concurrent.Timeout
The original timeout period expressed in units
getUnit() - Method in class com.atlassian.util.concurrent.Timeout
 
gigabytes(long) - Static method in class com.atlassian.util.concurrent.Memory
Construct a Memory represented in gigabytes.

H

handleExceptions(ExceptionPolicy) - Method in class com.atlassian.util.concurrent.AsyncCompleter.Builder
 
handler() - Method in interface com.atlassian.util.concurrent.ExceptionPolicy
Handle a supplier which may or may not throw an Exception.
hashCode() - Method in class com.atlassian.util.concurrent.Memory
 
headMap(K) - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap
 

I

identity() - Static method in class com.atlassian.util.concurrent.Functions
Get a function that always returns the input.
ignoreExceptions() - Method in class com.atlassian.util.concurrent.AsyncCompleter.Builder
Ignore exceptions thrown by any Callables, note will cause nulls in the resulting iterable!
invokeAll(Iterable<? extends Callable<T>>) - Method in class com.atlassian.util.concurrent.AsyncCompleter
Queue the jobs on the contained Executor and return a lazily evaluated Iterable of the results in the order they return in (fastest first).
invokeAll(Iterable<? extends Callable<T>>, long, TimeUnit) - Method in class com.atlassian.util.concurrent.AsyncCompleter
Version of AsyncCompleter.invokeAll(Iterable) that supports a timeout.
isCancelled() - Method in class com.atlassian.util.concurrent.SettableFuture
 
isDone() - Method in class com.atlassian.util.concurrent.SettableFuture
 
isEmpty() - Method in class com.atlassian.util.concurrent.BlockingReference
Whether or not the current value is null or not.
isExpired() - Method in class com.atlassian.util.concurrent.Timeout
Has this timeout expired
isInitialized() - Method in class com.atlassian.util.concurrent.LazyReference
Has the LazyReference.create() reference been initialized.
isInitialized() - Method in class com.atlassian.util.concurrent.ResettableLazyReference
  Has the ResettableLazyReference.create() reference been initialized.
isTrue(String, boolean) - Static method in class com.atlassian.util.concurrent.Assertions
 

K

kilobytes(long) - Static method in class com.atlassian.util.concurrent.Memory
Construct a Memory represented in kilobytes.

L

lastKey() - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap
 
Lazy - Class in com.atlassian.util.concurrent
Factory for creating lazily populated references.
Lazy() - Constructor for class com.atlassian.util.concurrent.Lazy
 
LazyReference<T> - Class in com.atlassian.util.concurrent
Lazily loaded reference that is not constructed until required.
LazyReference() - Constructor for class com.atlassian.util.concurrent.LazyReference
 
LazyReference.InitializationException - Exception in com.atlassian.util.concurrent
If the factory LazyReference.create() method threw an exception, this wraps it.
limitParallelExecutionTo(int) - Method in class com.atlassian.util.concurrent.AsyncCompleter.Builder
Create a AsyncCompleter that limits the number of jobs executed to the underlying executor to a hard limit.
liveViews() - Method in class com.atlassian.util.concurrent.CopyOnWriteMap.Builder
Views are live (reflecting concurrent updates) and mutator methods are supported.
liveViews() - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap.Builder
Views are live (reflecting concurrent updates) and mutator methods are supported.
LockManager<T> - Interface in com.atlassian.util.concurrent
Deprecated. use a Function that returns a ManagedLock instead.
LockManager.ReadWrite<T> - Interface in com.atlassian.util.concurrent
Deprecated. Maintains two lock managers that internally use the same map of read/write locks
LockManagers - Class in com.atlassian.util.concurrent
Deprecated. since 0.0.7 use ManagedLocks instead
LockManagers() - Constructor for class com.atlassian.util.concurrent.LockManagers
Deprecated.  

M

manage(Lock) - Static method in class com.atlassian.util.concurrent.ManagedLocks
Get a ManagedLock that manages the supplied Lock.
ManagedLock - Interface in com.atlassian.util.concurrent
ManagedLock allows callables, runnables and suppliers to be run under a lock that is resolved against an input object.
ManagedLock.ReadWrite - Interface in com.atlassian.util.concurrent
Maintains two managed locks that internally use the same read/write locks
ManagedLocks - Class in com.atlassian.util.concurrent
Static factory for producing ManagedLock and ManagedLock.ReadWrite instances.
manageReadWrite(ReadWriteLock) - Static method in class com.atlassian.util.concurrent.ManagedLocks
Get a ManagedLock.ReadWrite that manages the supplied ReadWriteLock.
map(Function<? super A, ? extends B>) - Method in class com.atlassian.util.concurrent.ForwardingPromise
 
map(Function<? super A, ? extends B>) - Method in interface com.atlassian.util.concurrent.Promise
Transforms this Promise from one type to another by way of a transformation function.
megabytes(long) - Static method in class com.atlassian.util.concurrent.Memory
Construct a Memory represented in megabytes.
memoize(T) - Static method in class com.atlassian.util.concurrent.Suppliers
A Supplier that always returns the supplied source.
Memory - Class in com.atlassian.util.concurrent
Value representing an amount of Memory, as measured in memory units.
Memory.MemoryComparator - Enum in com.atlassian.util.concurrent
Comparator for units.
Memory.Unit - Enum in com.atlassian.util.concurrent
Units in which memory is expressed.
Memory.UnitComparator - Enum in com.atlassian.util.concurrent
Comparator for units.

N

name(String) - Method in class com.atlassian.util.concurrent.ThreadFactories.Builder
 
named(String) - Static method in class com.atlassian.util.concurrent.ThreadFactories
Get a ThreadFactories.Builder with the required name prefix.
namedThreadFactory(String) - Static method in class com.atlassian.util.concurrent.ThreadFactories
Get a ThreadFactory with the required name prefix.
namedThreadFactory(String, ThreadFactories.Type) - Static method in class com.atlassian.util.concurrent.ThreadFactories
Get a ThreadFactory with the required name prefix and type (user or daemon).
namedThreadFactory(String, ThreadFactories.Type, int) - Static method in class com.atlassian.util.concurrent.ThreadFactories
Get a ThreadFactory with the required name prefix, type and priority.
newHashMap() - Method in class com.atlassian.util.concurrent.CopyOnWriteMap.Builder
 
newHashMap() - Static method in class com.atlassian.util.concurrent.CopyOnWriteMap
Creates a new CopyOnWriteMap with an underlying HashMap.
newHashMap(Map<? extends K, ? extends V>) - Static method in class com.atlassian.util.concurrent.CopyOnWriteMap
Creates a new CopyOnWriteMap with an underlying HashMap using the supplied map as the initial values.
newHashMap() - Static method in class com.atlassian.util.concurrent.CopyOnWriteMaps
Deprecated. use the CopyOnWriteMap.newHashMap() instead.
newHashMap(Map<? extends K, ? extends V>) - Static method in class com.atlassian.util.concurrent.CopyOnWriteMaps
Deprecated. use the CopyOnWriteMap.newHashMap(Map) instead.
newLinkedMap() - Method in class com.atlassian.util.concurrent.CopyOnWriteMap.Builder
 
newLinkedMap() - Static method in class com.atlassian.util.concurrent.CopyOnWriteMap
Creates a new CopyOnWriteMap with an underlying LinkedHashMap.
newLinkedMap(Map<? extends K, ? extends V>) - Static method in class com.atlassian.util.concurrent.CopyOnWriteMap
Creates a new CopyOnWriteMap with an underlying LinkedHashMap using the supplied map as the initial values.
newLinkedMap() - Static method in class com.atlassian.util.concurrent.CopyOnWriteMaps
Deprecated. use the CopyOnWriteMap.newLinkedMap() instead.
newLinkedMap(Map<? extends K, ? extends V>) - Static method in class com.atlassian.util.concurrent.CopyOnWriteMaps
Deprecated. use the CopyOnWriteMap.newLinkedMap(Map) instead.
newManagedLock() - Static method in class com.atlassian.util.concurrent.ManagedLocks
Get a ManagedLock that manages a ReentrantLock.
newMRSW() - Static method in class com.atlassian.util.concurrent.BlockingReference
Create a BlockingReference best suited to multi-reader/single-writer situations.
newMRSW(V) - Static method in class com.atlassian.util.concurrent.BlockingReference
Create a BlockingReference best suited to multi-reader/single-writer situations.
newSRSW() - Static method in class com.atlassian.util.concurrent.BlockingReference
Create a BlockingReference best suited to single-reader/single-writer situations.
newSRSW(V) - Static method in class com.atlassian.util.concurrent.BlockingReference
Create a BlockingReference best suited to single-reader/single-writer situations.
newTreeMap() - Static method in class com.atlassian.util.concurrent.CopyOnWriteMaps
Deprecated. use CopyOnWriteSortedMap.newTreeMap() instead.
newTreeMap(Map<? extends K, ? extends V>) - Static method in class com.atlassian.util.concurrent.CopyOnWriteMaps
Deprecated. use CopyOnWriteSortedMap.newTreeMap(Map) instead.
newTreeMap(Comparator<? super K>) - Static method in class com.atlassian.util.concurrent.CopyOnWriteMaps
Deprecated. use CopyOnWriteSortedMap.newTreeMap(Comparator) instead.
newTreeMap(Map<? extends K, ? extends V>, Comparator<? super K>) - Static method in class com.atlassian.util.concurrent.CopyOnWriteMaps
Deprecated. use CopyOnWriteSortedMap.newTreeMap(Map, Comparator) instead.
newTreeMap() - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap.Builder
 
newTreeMap() - Static method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap
Create a new CopyOnWriteSortedMap where the underlying map instances are TreeMap and the sort uses the key's natural order.
newTreeMap(Map<? extends K, ? extends V>) - Static method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap
Create a new CopyOnWriteSortedMap where the underlying map instances are TreeMap, the sort uses the key's natural order and the initial values are supplied.
newTreeMap(Comparator<? super K>) - Static method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap
Create a new CopyOnWriteSortedMap where the underlying map instances are TreeMap.
newTreeMap(Map<? extends K, ? extends V>, Comparator<? super K>) - Static method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap
Create a new CopyOnWriteSortedMap where the underlying map instances are TreeMap, the sort uses the key's natural order and the initial values are supplied.
noop() - Static method in class com.atlassian.util.concurrent.Effects
 
notNull(String, T) - Static method in class com.atlassian.util.concurrent.Assertions
 
number() - Method in class com.atlassian.util.concurrent.Memory
The number of units this represents.

O

of(long, Memory.Unit) - Static method in class com.atlassian.util.concurrent.Memory
Construct a Memory represented in the supplied unit type.
onFailureDo(Effect<Throwable>) - Static method in class com.atlassian.util.concurrent.Promises
Create a FutureCallback from an Effect to be run if there is a failure.
onReset(LazyReference<T>) - Method in class com.atlassian.util.concurrent.ResettableLazyReference
Template extension method for providing custom reset behavior.
onSuccessDo(Effect<? super A>) - Static method in class com.atlassian.util.concurrent.Promises
Create a FutureCallback from an Effect to be run if there is a success.
ordering(Comparator<? super K>) - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap.Builder
Use the specified comparator.
orderingNatural() - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap.Builder
Use the keys natural ordering.

P

peek() - Method in class com.atlassian.util.concurrent.BlockingReference
Return the current value whether is null or not.
PhasedLatch - Class in com.atlassian.util.concurrent
A PhasedLatch is a shared latch that resets after it is released and can be reused.
PhasedLatch() - Constructor for class com.atlassian.util.concurrent.PhasedLatch
 
precision() - Method in interface com.atlassian.util.concurrent.Timeout.TimeSupplier
The precision that the time is expressed in.
priority(int) - Method in class com.atlassian.util.concurrent.ThreadFactories.Builder
 
Promise<A> - Interface in com.atlassian.util.concurrent
A promise that presents a nicer interface to Future.
promise(A) - Static method in class com.atlassian.util.concurrent.Promises
Creates a new, resolved promise for the specified concrete value.
Promises - Class in com.atlassian.util.concurrent
Library of utility Promise functions

R

read() - Method in interface com.atlassian.util.concurrent.LockManager.ReadWrite
Deprecated. For performing operations that require read locks
read() - Method in interface com.atlassian.util.concurrent.ManagedLock.ReadWrite
For performing operations that require read locks
recover(Function<Throwable, ? extends A>) - Method in class com.atlassian.util.concurrent.ForwardingPromise
 
recover(Function<Throwable, ? extends A>) - Method in interface com.atlassian.util.concurrent.Promise
Recover from an exception using the supplied exception strategy
reject(SettableFuture<?>) - Static method in class com.atlassian.util.concurrent.Promises
Creates a new Effect that forwards a promise's fail events to the specified future delegate's SettableFuture.setException(Throwable) method -- that is, the new callback rejects the delegate future if invoked.
rejected(Throwable, Class<A>) - Static method in class com.atlassian.util.concurrent.Promises
Deprecated. Use Promises.rejected(Throwable)
rejected(Throwable) - Static method in class com.atlassian.util.concurrent.Promises
Creates a new, rejected promise from the given Throwable and result type.
release() - Method in class com.atlassian.util.concurrent.BooleanLatch
Release the latch, releasing one or more threads that are waiting on it.
release() - Method in class com.atlassian.util.concurrent.PhasedLatch
Release the current phase.
release() - Method in interface com.atlassian.util.concurrent.ReusableLatch
Release the latch, releasing one or more threads that are waiting on it.
reset() - Method in class com.atlassian.util.concurrent.ResettableLazyReference
Reset the internal reference.
resets() - Method in class com.atlassian.util.concurrent.ResettableLazyReference
Reset the internal reference and returns a LazyReference of the old value.
ResettableLazyReference<T> - Class in com.atlassian.util.concurrent
Lazily loaded reference that is not constructed until required.
ResettableLazyReference() - Constructor for class com.atlassian.util.concurrent.ResettableLazyReference
 
ReusableLatch - Interface in com.atlassian.util.concurrent
A Latch that may be reused, unlike a CountDownLatch.
runOperation(K, Callable<R>) - Method in interface com.atlassian.util.concurrent.ConcurrentOperationMap
The operation will be keyed on the name .
runOperation(K, Callable<R>) - Method in class com.atlassian.util.concurrent.ConcurrentOperationMapImpl
 
RuntimeExecutionException - Exception in com.atlassian.util.concurrent
Convenience class for re-throwing ExecutionException.
RuntimeExecutionException(ExecutionException) - Constructor for exception com.atlassian.util.concurrent.RuntimeExecutionException
 
RuntimeExecutionException(String, ExecutionException) - Constructor for exception com.atlassian.util.concurrent.RuntimeExecutionException
 
RuntimeInterruptedException - Exception in com.atlassian.util.concurrent
Convenience class for re-throwing InterruptedException.
RuntimeInterruptedException(InterruptedException) - Constructor for exception com.atlassian.util.concurrent.RuntimeInterruptedException
 
RuntimeInterruptedException(String, InterruptedException) - Constructor for exception com.atlassian.util.concurrent.RuntimeInterruptedException
 
RuntimeTimeoutException - Exception in com.atlassian.util.concurrent
Convenience class for re-throwing TimeoutException as an unchecked exception.
RuntimeTimeoutException(TimeoutException) - Constructor for exception com.atlassian.util.concurrent.RuntimeTimeoutException
 
RuntimeTimeoutException(String, TimeoutException) - Constructor for exception com.atlassian.util.concurrent.RuntimeTimeoutException
 
RuntimeTimeoutException(long, TimeUnit) - Constructor for exception com.atlassian.util.concurrent.RuntimeTimeoutException
 

S

set(V) - Method in class com.atlassian.util.concurrent.BlockingReference
Set the value of this reference.
set(T) - Method in class com.atlassian.util.concurrent.SettableFuture
Set the value returned by SettableFuture.get() and SettableFuture.get(long, TimeUnit)
setException(Throwable) - Method in class com.atlassian.util.concurrent.SettableFuture
Set the exception thrown as the causal exception of an ExecutionException by SettableFuture.get() and SettableFuture.get(long, TimeUnit)
SettableFuture<T> - Class in com.atlassian.util.concurrent
SettableFuture is a Future implementation where the responsibility for producing the result is external to the future instance, unlike FutureTask where the future holds the operation (a Callable or Runnable instance) and the first thread that calls FutureTask.run() executes the operation.
SettableFuture() - Constructor for class com.atlassian.util.concurrent.SettableFuture
 
Sink<T> - Interface in com.atlassian.util.concurrent
Consume the object a Supplier produces.
stableViews() - Method in class com.atlassian.util.concurrent.CopyOnWriteMap.Builder
Views are stable (fixed in time) and unmodifiable.
stableViews() - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap.Builder
Views are stable (fixed in time) and unmodifiable.
subMap(K, K) - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap
 
supplier(Supplier<T>) - Static method in class com.atlassian.util.concurrent.Lazy
Memoizing reference that is lazily computed using the supplied factory.
Supplier<T> - Interface in com.atlassian.util.concurrent
A Supplier of objects of a single type.
Suppliers - Class in com.atlassian.util.concurrent
Useful Supplier implementations.

T

tailMap(K) - Method in class com.atlassian.util.concurrent.CopyOnWriteSortedMap
 
take() - Method in class com.atlassian.util.concurrent.BlockingReference
Takes the current element if it is not null and replaces it with null.
take(long, TimeUnit) - Method in class com.atlassian.util.concurrent.BlockingReference
Takes the current element if it is not null and replaces it with null.
terabytes(long) - Static method in class com.atlassian.util.concurrent.Memory
Construct a Memory represented in terabytes.
then(FutureCallback<? super A>) - Method in class com.atlassian.util.concurrent.ForwardingPromise
 
then(FutureCallback<? super A>) - Method in interface com.atlassian.util.concurrent.Promise
Registers a FutureCallback to handle both success and failure (exception) cases.
ThreadFactories - Class in com.atlassian.util.concurrent
Factory for creating ThreadFactory instances.
ThreadFactories.Builder - Class in com.atlassian.util.concurrent
Simple builder for ThreadFactory instances
ThreadFactories.Type - Enum in com.atlassian.util.concurrent
 
throwTimeoutException() - Method in class com.atlassian.util.concurrent.Timeout
Always throws a TimeoutException.
TimedOutException - Exception in com.atlassian.util.concurrent
Convenience exception that takes a time and a unit and produces a meaningful error message.
TimedOutException(long, TimeUnit) - Constructor for exception com.atlassian.util.concurrent.TimedOutException
 
Timeout - Class in com.atlassian.util.concurrent
Automatically calculates elapsed time from when it is created.
Timeout.TimeSupplier - Interface in com.atlassian.util.concurrent
Supply time and precision to a Timeout.
timeoutFactory(long, TimeUnit, Timeout.TimeSupplier) - Static method in class com.atlassian.util.concurrent.Timeout
Factory for creating timeouts of the specified duration.
timeToIdle(Supplier<T>, long, TimeUnit) - Static method in class com.atlassian.util.concurrent.Lazy
Memoizing reference that expires the specified amount of time after the last time it was accessed.
timeToLive(Supplier<T>, long, TimeUnit) - Static method in class com.atlassian.util.concurrent.Lazy
Memoizing reference that expires the specified amount of time after creation.
to(Memory.Unit) - Method in class com.atlassian.util.concurrent.Memory
Convert to the supplied unit representation.
toGoogleFunction(Function<T, R>) - Static method in class com.atlassian.util.concurrent.Functions
Map to a google-collections Function.
toGoogleSupplier(Supplier<T>) - Static method in class com.atlassian.util.concurrent.Suppliers
Map to a google-collections Supplier.
toRejectedPromise(Throwable, Class<A>) - Static method in class com.atlassian.util.concurrent.Promises
Deprecated. Use Promises.toRejectedPromise(Throwable)
toRejectedPromise(Throwable) - Static method in class com.atlassian.util.concurrent.Promises
Creates a new, rejected promise from the given Throwable and result type.
toResolvedPromise(A) - Static method in class com.atlassian.util.concurrent.Promises
Creates a new, resolved promise for the specified concrete value.
toString() - Method in class com.atlassian.util.concurrent.Memory
 
type(ThreadFactories.Type) - Method in class com.atlassian.util.concurrent.ThreadFactories.Builder
 

U

uncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class com.atlassian.util.concurrent.ThreadFactories.Builder
 
unit() - Method in class com.atlassian.util.concurrent.Memory
The memory Memory.Unit this is represented in.
update(Function<Integer, Integer>) - Method in class com.atlassian.util.concurrent.atomic.AtomicInteger
Do the actual update.
update(Function<Long, Long>) - Method in class com.atlassian.util.concurrent.atomic.AtomicLong
Do the actual update.
update(int, Function<Long, Long>) - Method in class com.atlassian.util.concurrent.atomic.AtomicLongArray
Do the actual update.
update(Function<V, V>) - Method in class com.atlassian.util.concurrent.atomic.AtomicReference
Do the actual update.
update(int, Function<E, E>) - Method in class com.atlassian.util.concurrent.atomic.AtomicReferenceArray
Do the actual update.
update() - Method in class com.atlassian.util.concurrent.atomic.AtomicReferenceUpdater
Do the actual update.

V

valueOf(String) - Static method in enum com.atlassian.util.concurrent.ExceptionPolicy.Policies
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.atlassian.util.concurrent.Memory.MemoryComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.atlassian.util.concurrent.Memory.Unit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.atlassian.util.concurrent.Memory.UnitComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.atlassian.util.concurrent.ThreadFactories.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.atlassian.util.concurrent.ExceptionPolicy.Policies
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.atlassian.util.concurrent.Memory.MemoryComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.atlassian.util.concurrent.Memory.Unit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.atlassian.util.concurrent.Memory.UnitComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.atlassian.util.concurrent.ThreadFactories.Type
Returns an array containing the constants of this enum type, in the order they are declared.

W

weakLockManager() - Static method in class com.atlassian.util.concurrent.LockManagers
Deprecated. use ManagedLocks.weakManagedLockFactory() instead.
weakLockManager(Function<T, D>) - Static method in class com.atlassian.util.concurrent.LockManagers
Deprecated. use ManagedLocks.weakManagedLockFactory(Function) instead.
weakManagedLockFactory(Function<T, D>, Supplier<Lock>) - Static method in class com.atlassian.util.concurrent.ManagedLocks
Create a Function for resolving managed locks .
weakManagedLockFactory(Function<T, D>) - Static method in class com.atlassian.util.concurrent.ManagedLocks
Convenience method that simply calls ManagedLocks.weakManagedLockFactory(Function, Supplier) with the default lock factory.
weakManagedLockFactory() - Static method in class com.atlassian.util.concurrent.ManagedLocks
Convenience method that calls ManagedLocks.weakManagedLockFactory(Function) using the identity function for striping, essentially meaning that unique input will have its own lock.
weakReadWriteManagedLockFactory(Function<T, D>, Supplier<ReadWriteLock>) - Static method in class com.atlassian.util.concurrent.ManagedLocks
Create a Function for resolving managed read-write locks.
weakReadWriteManagedLockFactory(Function<T, D>) - Static method in class com.atlassian.util.concurrent.ManagedLocks
A convenience method for calling ManagedLocks.weakReadWriteManagedLockFactory(Function, Supplier) that uses default locks
weakReadWriteManagedLockFactory() - Static method in class com.atlassian.util.concurrent.ManagedLocks
A convenience method for calling ManagedLocks.weakReadWriteManagedLockFactory(Function) that uses the identity function for striping, essentially meaning that unique input will have its own lock.
when(Promise<? extends A>...) - Static method in class com.atlassian.util.concurrent.Promises
Returns a new Promise representing the status of a list of other promises.
when(Iterable<? extends Promise<? extends A>>) - Static method in class com.atlassian.util.concurrent.Promises
Returns a new Promise representing the status of a list of other promises.
withLock(T, Supplier<R>) - Method in interface com.atlassian.util.concurrent.LockManager
Deprecated. Execute the supplied Supplier under a lock determined by the descriptor.
withLock(T, Callable<R>) - Method in interface com.atlassian.util.concurrent.LockManager
Deprecated. Execute the supplied Callable under a lock determined by the descriptor.
withLock(T, Runnable) - Method in interface com.atlassian.util.concurrent.LockManager
Deprecated. Execute the supplied Runnable under a lock determined by the descriptor.
withLock(Callable<R>) - Method in interface com.atlassian.util.concurrent.ManagedLock
Execute the supplied Callable under a lock determined by the descriptor.
withLock(Supplier<R>) - Method in interface com.atlassian.util.concurrent.ManagedLock
Execute the supplied Supplier under a lock determined by the descriptor.
withLock(Runnable) - Method in interface com.atlassian.util.concurrent.ManagedLock
Execute the supplied Runnable under a lock determined by the descriptor.
write() - Method in interface com.atlassian.util.concurrent.LockManager.ReadWrite
Deprecated. For performing operations that require write locks
write() - Method in interface com.atlassian.util.concurrent.ManagedLock.ReadWrite
For performing operations that require write locks

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

Copyright © 2014 Atlassian. All Rights Reserved.