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

A

acquire() - Method in interface com.ibm.asyncutil.locks.AsyncSemaphore
Acquires 1 permit from the semaphore as if by calling AsyncSemaphore.acquire(long) with an argument of 1.
acquire(long) - Method in interface com.ibm.asyncutil.locks.AsyncSemaphore
Acquires the given number of permits from the semaphore, returning a stage which will complete when all of the permits are exclusively acquired.
acquire(long) - Method in class com.ibm.asyncutil.locks.FairAsyncSemaphore
Acquires the given number of permits using an acquisition-ordered fair queuing policy, i.e.
acquireLock() - Method in interface com.ibm.asyncutil.locks.AsyncLock
Exclusively acquires this lock.
acquireLock() - Method in class com.ibm.asyncutil.locks.FairAsyncLock
 
acquireLock(T) - Method in interface com.ibm.asyncutil.locks.AsyncNamedLock
Acquires the lock associated with the given name.
acquireLock(T) - Method in class com.ibm.asyncutil.locks.FairAsyncNamedLock
 
acquireReadLock() - Method in interface com.ibm.asyncutil.locks.AsyncReadWriteLock
Acquires this read lock.
acquireReadLock() - Method in class com.ibm.asyncutil.locks.FairAsyncReadWriteLock
 
acquireReadLock(T) - Method in interface com.ibm.asyncutil.locks.AsyncNamedReadWriteLock
Acquires the read lock associated with the given name.
acquireReadLock(T) - Method in class com.ibm.asyncutil.locks.FairAsyncNamedReadWriteLock
 
acquireWriteLock() - Method in interface com.ibm.asyncutil.locks.AsyncReadWriteLock
Exclusively acquires this write lock.
acquireWriteLock() - Method in class com.ibm.asyncutil.locks.FairAsyncReadWriteLock
 
acquireWriteLock(T) - Method in interface com.ibm.asyncutil.locks.AsyncNamedReadWriteLock
Exclusively acquires the write lock associated with the given name.
acquireWriteLock(T) - Method in class com.ibm.asyncutil.locks.FairAsyncNamedReadWriteLock
 
allOf(Collection<? extends CompletionStage<?>>) - Static method in class com.ibm.asyncutil.util.Combinators
Given a collection of stages, returns a new CompletionStage that is completed when all input stages are complete.
AsyncCloseable - Interface in com.ibm.asyncutil.util
An object that may hold resources that must be explicitly released, where the release may be performed asynchronously.
asyncDoWhile(Function<? super T, ? extends CompletionStage<T>>, T, Predicate<? super T>) - Static method in class com.ibm.asyncutil.iteration.AsyncTrampoline
Repeatedly applies an asynchronous function fn to a value until shouldContinue returns false, unconditionally applying fn to initialValue on the first iteration.
AsyncEpoch - Interface in com.ibm.asyncutil.locks
A concurrency mechanism which maintains a period of activity -- an epoch -- during which participants may successfully enter it, that later can be terminated.
AsyncEpoch.EpochToken - Interface in com.ibm.asyncutil.locks
A token signifying successful entry in the active epoch.
AsyncFunnel<T> - Class in com.ibm.asyncutil.locks
Enforces that a single asynchronous computation occurs at a time, allowing others to observe it.
AsyncFunnel() - Constructor for class com.ibm.asyncutil.locks.AsyncFunnel
 
AsyncIterator<T> - Interface in com.ibm.asyncutil.iteration
A mechanism for asynchronously generating and consuming values
AsyncIterator.End - Enum in com.ibm.asyncutil.iteration
A marker enum that indicates there are no elements left in the iterator.
AsyncLock - Interface in com.ibm.asyncutil.locks
An asynchronously acquirable mutual exclusion lock.
AsyncLock.LockToken - Interface in com.ibm.asyncutil.locks
A lock token indicating that the associated lock has been exclusively acquired.
AsyncNamedLock<T> - Interface in com.ibm.asyncutil.locks
A mechanism used to acquire mutual exclusion locks shared by a common name.
AsyncNamedReadWriteLock<T> - Interface in com.ibm.asyncutil.locks
A mechanism used to acquire read-write locks shared by a common name.
AsyncQueue<T> - Interface in com.ibm.asyncutil.iteration
An unbounded async multi-producer-single-consumer queue.
AsyncQueues - Class in com.ibm.asyncutil.iteration
Methods to construct various multi-producer-single-consumer (mpsc) AsyncQueues.
AsyncReadWriteLock - Interface in com.ibm.asyncutil.locks
An asynchronously acquirable read-write lock.
AsyncReadWriteLock.ReadLockToken - Interface in com.ibm.asyncutil.locks
A lock token indicating that the associated lock has been acquired for reader access.
AsyncReadWriteLock.WriteLockToken - Interface in com.ibm.asyncutil.locks
A lock token indicating that the associated lock has been exclusively acquired for writer access.
AsyncSemaphore - Interface in com.ibm.asyncutil.locks
An asynchronously acquirable counting semaphore
AsyncStampedLock - Interface in com.ibm.asyncutil.locks
An asynchronously acquirable read-write lock which additionally provides an optimistic read mode.
AsyncStampedLock.Stamp - Interface in com.ibm.asyncutil.locks
An object indicating a successful optimistic read attempt.
AsyncTrampoline - Class in com.ibm.asyncutil.iteration
Static methods for asynchronous looping procedures without exhausting the stack.
asyncWhile(Predicate<? super T>, Function<? super T, ? extends CompletionStage<T>>, T) - Static method in class com.ibm.asyncutil.iteration.AsyncTrampoline
Repeatedly applies an asynchronous function fn to a value until shouldContinue returns false.
asyncWhile(Supplier<? extends CompletionStage<Boolean>>) - Static method in class com.ibm.asyncutil.iteration.AsyncTrampoline
Repeatedly uses the function fn to produce a CompletionStage of a boolean, stopping when then boolean is false.
awaitCompletion() - Method in interface com.ibm.asyncutil.locks.AsyncEpoch
Waits for the epoch to complete, returning a stage that completes after the epoch has been terminated and all participants have exited.

B

batch(Collector<? super T, A, R>, int) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
A convenience method provided to invoke AsyncIterator.batch(Collector, BiPredicate) with a predicate that limits batches to a fixed size.
batch(Collector<? super T, A, R>, BiPredicate<? super A, ? super T>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Collects the results of this iterator in batches, returning an iterator of those batched collections.
bounded() - Static method in class com.ibm.asyncutil.iteration.AsyncQueues
Creates a bounded AsyncQueue.
BoundedAsyncQueue<T> - Interface in com.ibm.asyncutil.iteration
A version of AsyncQueue that provides a mechanism for backpressure.
buffered(int) - Static method in class com.ibm.asyncutil.iteration.AsyncQueues
Creates a buffered AsyncQueue.

C

close() - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Relinquishes any resources associated with this iterator.
close() - Method in interface com.ibm.asyncutil.locks.AsyncEpoch.EpochToken
Exits the epoch that was previously entered.
close() - Method in interface com.ibm.asyncutil.locks.AsyncLock.LockToken
Releases this lock, allowing others to acquire it.
close() - Method in interface com.ibm.asyncutil.util.AsyncCloseable
Relinquishes any resources associated with this object.
collect(Collection<? extends CompletionStage<T>>) - Static method in class com.ibm.asyncutil.util.Combinators
Given a collection of stages all of the same type, returns a new CompletionStage that is completed with a collection of the results of all input stages when all stages complete.
collect(Collection<? extends CompletionStage<T>>, Collector<? super T, A, R>) - Static method in class com.ibm.asyncutil.util.Combinators
Applies a collector to the results of all stages after all complete, returning a CompletionStage of the collected result.
collect(Supplier<R>, BiConsumer<R, ? super T>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Performs a mutable reduction operation and return a CompletionStage of the result.
collect(Collector<? super T, A, R>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Performs a mutable reduction operation using collector and return a CompletionStage of the result.
com.ibm.asyncutil.flow - package com.ibm.asyncutil.flow
 
com.ibm.asyncutil.iteration - package com.ibm.asyncutil.iteration
Provides support for asynchronous loop constructs.
com.ibm.asyncutil.locks - package com.ibm.asyncutil.locks
Provides asynchronous analogues of synchronization primitives.
com.ibm.asyncutil.util - package com.ibm.asyncutil.util
Provides general purpose utilities for using CompletionStage.
Combinators - Class in com.ibm.asyncutil.util
Utility methods for combining more than one CompletionStage into a single CompletionStage
completedStage(T) - Static method in class com.ibm.asyncutil.util.StageSupport
Creates a CompletionStage that is already completed with the given value.
concat(AsyncIterator<AsyncIterator<T>>) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Flattens an AsyncIterator of AsyncIterators into a single AsyncIterator
concat(Iterator<? extends AsyncIterator<T>>) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Flattens an Iterator of AsyncIterators into a single AsyncIterator.
consume() - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Forces the eager evaluation of the entire iterator, stopping only when this iterator is out of elements or an exception is encountered.
create() - Static method in interface com.ibm.asyncutil.locks.AsyncLock
Creates an AsyncLock
create() - Static method in interface com.ibm.asyncutil.locks.AsyncNamedLock
Creates an AsyncNamedLock
create() - Static method in interface com.ibm.asyncutil.locks.AsyncNamedReadWriteLock
create() - Static method in interface com.ibm.asyncutil.locks.AsyncReadWriteLock
create() - Static method in interface com.ibm.asyncutil.locks.AsyncStampedLock
Creates an AsyncStampedLock
createFair() - Static method in interface com.ibm.asyncutil.locks.AsyncLock
Creates a fair AsyncLock
createFair() - Static method in interface com.ibm.asyncutil.locks.AsyncNamedLock
Creates a fair AsyncNamedLock
createFair() - Static method in interface com.ibm.asyncutil.locks.AsyncNamedReadWriteLock
createFair() - Static method in interface com.ibm.asyncutil.locks.AsyncReadWriteLock
Creates a fair AsyncReadWriteLock
createFair() - Static method in interface com.ibm.asyncutil.locks.AsyncStampedLock
Creates a fair AsyncStampedLock

D

doOrGet(Supplier<CompletionStage<T>>) - Method in class com.ibm.asyncutil.locks.AsyncFunnel
Runs the provided action, or returns an existing CompletionStage if an action is already running.
downgradeLock() - Method in interface com.ibm.asyncutil.locks.AsyncReadWriteLock.WriteLockToken
Downgrades this write lock acquisition to a read lock acquisition without any intermediate release.
drainPermits() - Method in interface com.ibm.asyncutil.locks.AsyncSemaphore
Acquires all permits that are immediately available.
drainPermits() - Method in class com.ibm.asyncutil.locks.FairAsyncSemaphore
 

E

Either<L,R> - Interface in com.ibm.asyncutil.util
A container type that contains either an L or an R type object.
empty() - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Creates an empty AsyncIterator.
end() - Static method in enum com.ibm.asyncutil.iteration.AsyncIterator.End
An Either instance which contains the AsyncIterator.End enum.
END - com.ibm.asyncutil.iteration.AsyncIterator.End
 
endStage() - Static method in enum com.ibm.asyncutil.iteration.AsyncIterator.End
A CompletionStage which is already complete, and contains the AsyncIterator.End.end() instance as its value.
enter() - Method in interface com.ibm.asyncutil.locks.AsyncEpoch
Attempts to secure a position in the active epoch, failing if it has already been terminated.
error(Throwable) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Creates an AsyncIterator for which all downstream operations will be completed with an exception.
exceptionally(Function<Throwable, ? extends T>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Returns an AsyncIterator where any exception produced by this iterator will be transformed with the provided function.
exceptionalStage(Throwable) - Static method in class com.ibm.asyncutil.util.StageSupport
Creates a CompletionStage that is already completed exceptionally.

F

FairAsyncLock - Class in com.ibm.asyncutil.locks
An AsyncLock which enforces fairness in its acquisition ordering
FairAsyncLock() - Constructor for class com.ibm.asyncutil.locks.FairAsyncLock
 
FairAsyncNamedLock<T> - Class in com.ibm.asyncutil.locks
An implementation of the AsyncNamedLock interface which enforces fair ordering in lock acquisition.
FairAsyncNamedLock() - Constructor for class com.ibm.asyncutil.locks.FairAsyncNamedLock
 
FairAsyncNamedReadWriteLock<T> - Class in com.ibm.asyncutil.locks
An implementation of the AsyncNamedReadWriteLock interface which enforces fair acquisitions (i.e.
FairAsyncNamedReadWriteLock() - Constructor for class com.ibm.asyncutil.locks.FairAsyncNamedReadWriteLock
 
FairAsyncReadWriteLock - Class in com.ibm.asyncutil.locks
An implementation of the AsyncReadWriteLock interface which enforces reader/writer fairness -- i.e.
FairAsyncReadWriteLock() - Constructor for class com.ibm.asyncutil.locks.FairAsyncReadWriteLock
 
FairAsyncSemaphore - Class in com.ibm.asyncutil.locks
An AsyncSemaphore implementation which is strictly fair: if the permits requested by an FairAsyncSemaphore.acquire(long) cannot be fulfilled immediately, all subsequent acquires must wait for their predecessor to be fulfilled.
FairAsyncSemaphore(long) - Constructor for class com.ibm.asyncutil.locks.FairAsyncSemaphore
Creates a new asynchronous semaphore with the given initial number of permits.
FairAsyncStampedLock - Class in com.ibm.asyncutil.locks
An AsyncStampedLock implementation which provides fair ordering of acquisitions, like that of FairAsyncReadWriteLock.
FairAsyncStampedLock() - Constructor for class com.ibm.asyncutil.locks.FairAsyncStampedLock
 
filter(Predicate<? super T>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Transforms the AsyncIterator into one which will only produce results that match predicate.
filterApply(Function<? super T, Optional<U>>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Applies a transformation and filters this AsyncIterator at the same time.
filterCompose(Function<? super T, ? extends CompletionStage<Optional<U>>>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Composes and filters an AsyncIterator at the same time.
find(Predicate<? super T>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Gets the first element that satisfies predicate, or empty if no such element exists
flatMap(Function<? super R, ? extends Either<L, V>>) - Method in interface com.ibm.asyncutil.util.Either
Transforms the right type of this, producing a right Either of type V if this was right and f produced a right Either, or a left Either otherwise.
FlowAdapter - Class in com.ibm.asyncutil.flow
Adapters to convert between Flow.Publisher and AsyncIterator.
fold(Function<? super L, ? extends V>, Function<? super R, ? extends V>) - Method in interface com.ibm.asyncutil.util.Either
Applies exactly one of the two provided functions to produce a value of type V.
fold(T, BinaryOperator<T>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Sequentially accumulates the elements of type T in this iterator into a single T value.
fold(U, BiFunction<U, ? super T, U>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Sequentially accumulates the elements of type T in this iterator into a U.
forEach(Consumer<? super L>, Consumer<? super R>) - Method in interface com.ibm.asyncutil.util.Either
Calls exactly one of the two provided functions with an L or an R
forEach(Consumer<? super T>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Performs the side effecting action until the end of iteration is reached
fromIterator(Iterator<? extends T>) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Creates an AsyncIterator from an Iterator
fuse() - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Fuses the iterator to the AsyncIterator.End result after iteration has stopped.

G

generate(Supplier<? extends CompletionStage<T>>) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Creates an infinite AsyncIterator of type T.
getAvailablePermits() - Method in interface com.ibm.asyncutil.locks.AsyncSemaphore
Gets the number of currently available permits.
getAvailablePermits() - Method in class com.ibm.asyncutil.locks.FairAsyncSemaphore
 
getQueueLength() - Method in interface com.ibm.asyncutil.locks.AsyncSemaphore
Gets the number of unfulfilled acquisitions waiting on this semaphore's permits.
getQueueLength() - Method in class com.ibm.asyncutil.locks.FairAsyncSemaphore
 

I

infiniteRange(long) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Creates an infinite AsyncIterator starting at start.
isLeft() - Method in interface com.ibm.asyncutil.util.Either
Whether this container holds an L type
isRight() - Method in interface com.ibm.asyncutil.util.Either
Whether this container holds an R type
isTerminated() - Method in interface com.ibm.asyncutil.locks.AsyncEpoch
Returns true if this epoch has been terminated.

K

keyedAll(Map<K, ? extends CompletionStage<V>>) - Static method in class com.ibm.asyncutil.util.Combinators
Given a Map from some key type K to CompletionStages of values, returns a CompletionStage which completes with a Map<K, V> when all the CompletionStages in the input map have completed.

L

left() - Method in interface com.ibm.asyncutil.util.Either
Optionally gets the left value of this if it exists
left(A) - Static method in interface com.ibm.asyncutil.util.Either
Constructs an Either with a left value

M

map(Function<? super L, ? extends A>, Function<? super R, ? extends B>) - Method in interface com.ibm.asyncutil.util.Either
Creates a new Either possibly of two new and distinct types, by applying the provided transformation functions.
map(Function<? super R, ? extends V>) - Method in interface com.ibm.asyncutil.util.Either
Transforms the right type of this, producing an Either of the transformed value if this contained right, or an Either of the original left value otherwise.
MAX_PERMITS - Static variable in class com.ibm.asyncutil.locks.FairAsyncSemaphore
The greatest number of permits with which this semaphore implementation can be initialized and can be acquired or released with a single operation.
MIN_PERMITS - Static variable in class com.ibm.asyncutil.locks.FairAsyncSemaphore
The greatest deficit of permits with which this semaphore implementation can be initialized.

N

newEpoch() - Static method in interface com.ibm.asyncutil.locks.AsyncEpoch
 
newTerminatedEpoch() - Static method in interface com.ibm.asyncutil.locks.AsyncEpoch
 
nextStage() - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Returns a stage that will be completed with the next element of this iterator when it becomes available, or AsyncIterator.End if there are no more elements.

O

once(T) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Creates an AsyncIterator of one element.

P

poll() - Method in interface com.ibm.asyncutil.iteration.AsyncQueue
Gets a result from the queue if one is immediately available.
poll() - Method in interface com.ibm.asyncutil.iteration.BoundedAsyncQueue
Gets a result from the queue if one is immediately available.

R

range(long, long) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Creates an AsyncIterator for a range.
release() - Method in interface com.ibm.asyncutil.locks.AsyncSemaphore
Releases 1 permit from the semaphore as if by calling AsyncSemaphore.release(long) with an argument of 1.
release(long) - Method in interface com.ibm.asyncutil.locks.AsyncSemaphore
Releases the given number of permits to the semaphore.
release(long) - Method in class com.ibm.asyncutil.locks.FairAsyncSemaphore
 
releaseLock() - Method in interface com.ibm.asyncutil.locks.AsyncLock.LockToken
Releases this lock, allowing others to acquire it.
releaseLock() - Method in interface com.ibm.asyncutil.locks.AsyncReadWriteLock.ReadLockToken
Releases this read lock, possibly allowing writers to enter once all read locks have been released.
releaseLock() - Method in interface com.ibm.asyncutil.locks.AsyncReadWriteLock.WriteLockToken
Releases this write lock, allowing readers or other writers to acquire it.
repeat(T) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Creates an infinite AsyncIterator of the same value.
right() - Method in interface com.ibm.asyncutil.util.Either
Optionally gets the right value of this if it exists
right(B) - Static method in interface com.ibm.asyncutil.util.Either
Constructs an Either with a right value

S

send(T) - Method in interface com.ibm.asyncutil.iteration.AsyncQueue
Sends a value into this queue that can be consumed via the AsyncIterator interface.
send(T) - Method in interface com.ibm.asyncutil.iteration.BoundedAsyncQueue
Sends a value into this queue that can be consumed via the AsyncIterator interface.
StageSupport - Class in com.ibm.asyncutil.util
Utility methods for creating and composing CompletionStages
supply(Supplier<? extends CompletionStage<Either<AsyncIterator.End, T>>>) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Creates an AsyncIterator of type T

T

take(long) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Returns an AsyncIterator that will return only the first n elements of this AsyncIterator.
takeWhile(Predicate<? super T>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Returns an AsyncIterator that returns elements from the backing iterator until coming across an element that does not satisfy the predicate.
terminate() - Method in interface com.ibm.asyncutil.iteration.AsyncQueue
Terminates the queue, disabling AsyncQueue.send(T).
terminate() - Method in interface com.ibm.asyncutil.iteration.BoundedAsyncQueue
Terminates the queue.
terminate() - Method in interface com.ibm.asyncutil.locks.AsyncEpoch
Atomically ends the active epoch, preventing new entrants from successfully entering and returning a CompletionStage that triggers once all active participants have exited.
thenApply(Function<? super T, ? extends U>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Transforms this into a new AsyncIterator that iterates over the results of fn applied to the outcomes of stages in this iterator when they complete normally.
thenApplyAsync(Function<? super T, ? extends U>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Transforms this into a new AsyncIterator that iterates over the results of fn applied to the outcomes of stages in this iterator when they complete normally.
thenApplyAsync(Function<? super T, ? extends U>, Executor) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Transforms this into a new AsyncIterator that iterates over the results of fn applied to the outcomes of stages in this iterator when they complete normally.
thenCompose(Function<? super T, ? extends CompletionStage<U>>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Transforms this into a new AsyncIterator using the produced stages of fn applied to the output from the stages of this.
thenComposeAhead(Function<? super T, ? extends CompletionStage<U>>, int) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Applies a transformation to this iterator with parallelism.
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Transforms this into a new AsyncIterator using the produced stages of fn applied to the output from the stages of this.
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>, Executor) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Transforms this into a new AsyncIterator using the produced stages of fn applied to the output from the stages of this.
thenComposeOrRecover(CompletionStage<T>, BiFunction<? super T, Throwable, ? extends CompletionStage<U>>) - Static method in class com.ibm.asyncutil.util.StageSupport
Uses the possibly exceptional result of stage to produce a new stage.
thenFlatten(Function<? super T, ? extends AsyncIterator<U>>) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Composes fn with the stages of this iterator to produce new AsyncIterators, and flattens the resulting iterator of iterators.
thenFlattenAhead(Function<? super T, ? extends CompletionStage<? extends AsyncIterator<U>>>, int) - Method in interface com.ibm.asyncutil.iteration.AsyncIterator
Applies a transformation and flattening to this iterator with parallelism.
toAsyncIterator(Flow.Publisher<? extends T>) - Static method in class com.ibm.asyncutil.flow.FlowAdapter
Convert a Flow.Publisher into an AsyncIterator.
toPublisher(AsyncIterator<? extends T>) - Static method in class com.ibm.asyncutil.flow.FlowAdapter
Convert an AsyncIterator into a Flow.Publisher.
toPublisher(Supplier<AsyncIterator<? extends T>>) - Static method in class com.ibm.asyncutil.flow.FlowAdapter
toString() - Method in enum com.ibm.asyncutil.iteration.AsyncIterator.End
 
toString() - Method in class com.ibm.asyncutil.locks.FairAsyncSemaphore
 
tryAcquire() - Method in interface com.ibm.asyncutil.locks.AsyncSemaphore
Attempts to acquire 1 permit from the semaphore as if by calling AsyncSemaphore.tryAcquire(long) with an argument of 1.
tryAcquire(long) - Method in interface com.ibm.asyncutil.locks.AsyncSemaphore
Attempts to acquire the given number of permits from the semaphore, returning a boolean indicating whether all of the permits were immediately available and have been exclusively acquired.
tryAcquire(long) - Method in class com.ibm.asyncutil.locks.FairAsyncSemaphore
Attempts to acquire the given number of permits if they are immediately available.
tryComposeWith(CompletionStage<R>, Function<? super R, ? extends CompletionStage<T>>) - Static method in class com.ibm.asyncutil.util.StageSupport
Performs an asynchronous function with an asynchronously acquired AutoCloseable, ensuring that the resource is closed after the stage returned by the function completes.
tryComposeWith(R, Function<? super R, ? extends CompletionStage<T>>) - Static method in class com.ibm.asyncutil.util.StageSupport
Performs an asynchronous function with an AsyncCloseable resource, ensuring that the resource is AsyncCloseable.close() closed} after the stage returned by the function completes.
tryLock() - Method in interface com.ibm.asyncutil.locks.AsyncLock
Attempts to immediately acquire the lock, returning a populated Optional if the lock is not currently held.
tryLock() - Method in class com.ibm.asyncutil.locks.FairAsyncLock
 
tryLock(T) - Method in interface com.ibm.asyncutil.locks.AsyncNamedLock
Attempts to immediately acquire the lock associated with the given name, returning a populated Optional if the lock is not currently held.
tryLock(T) - Method in class com.ibm.asyncutil.locks.FairAsyncNamedLock
 
tryOptimisticRead() - Method in interface com.ibm.asyncutil.locks.AsyncStampedLock
Attempts to acquire a AsyncStampedLock.Stamp in optimistic-read mode if the lock is not already write-locked.
tryOptimisticRead() - Method in class com.ibm.asyncutil.locks.FairAsyncStampedLock
 
tryReadLock() - Method in interface com.ibm.asyncutil.locks.AsyncReadWriteLock
Attempts to immediately acquire the read lock, returning a populated Optional if the lock is not currently held by a writer.
tryReadLock() - Method in class com.ibm.asyncutil.locks.FairAsyncReadWriteLock
Attempt to immediately acquire the read lock, returning a populated Optional if the lock is not currently held by a writer and there are no writers queued in waiting (i.e.
tryReadLock(T) - Method in interface com.ibm.asyncutil.locks.AsyncNamedReadWriteLock
Attempts to acquire the read lock associated with the given name.
tryReadLock(T) - Method in class com.ibm.asyncutil.locks.FairAsyncNamedReadWriteLock
 
tryWith(CompletionStage<R>, Function<? super R, ? extends T>) - Static method in class com.ibm.asyncutil.util.StageSupport
Performs a function with an asynchronously acquired auto closeable, ensuring that the resource is closed after the function runs.
tryWith(R, Function<? super R, ? extends T>) - Static method in class com.ibm.asyncutil.util.StageSupport
Performs a function with an AsyncCloseable resource, ensuring that the resource is AsyncCloseable.close() closed} after the function completes.
tryWriteLock() - Method in interface com.ibm.asyncutil.locks.AsyncReadWriteLock
Attempts to immediately acquire the write lock, returning a populated Optional if the lock is not currently held by a writer or any readers.
tryWriteLock() - Method in class com.ibm.asyncutil.locks.FairAsyncReadWriteLock
 
tryWriteLock(T) - Method in interface com.ibm.asyncutil.locks.AsyncNamedReadWriteLock
Attempts to acquire the write lock associated with the given name.
tryWriteLock(T) - Method in class com.ibm.asyncutil.locks.FairAsyncNamedReadWriteLock
 

U

unbounded() - Static method in class com.ibm.asyncutil.iteration.AsyncQueues
Creates an unbounded AsyncQueue.
unfold(T, Function<? super T, ? extends CompletionStage<Either<AsyncIterator.End, T>>>) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Successively applies the asynchronous function f to the seed until the stage returned by f contains an empty optional or returns an exception.
unordered(Collection<? extends CompletionStage<T>>) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Creates an AsyncIterator from a collection of CompletionStages.

V

validate() - Method in interface com.ibm.asyncutil.locks.AsyncStampedLock.Stamp
Checks whether the associated lock's write mode has been acquired in the time after this stamp was issued.
valueOf(String) - Static method in enum com.ibm.asyncutil.iteration.AsyncIterator.End
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.ibm.asyncutil.iteration.AsyncIterator.End
Returns an array containing the constants of this enum type, in the order they are declared.
voided(CompletionStage<T>) - Static method in class com.ibm.asyncutil.util.StageSupport
Creates a CompletionStage that completes when stage completes but ignores the result.
voidStage() - Static method in class com.ibm.asyncutil.util.StageSupport
Gets an already completed CompletionStage of Void.

Z

zipWith(AsyncIterator<T>, AsyncIterator<U>, BiFunction<? super T, ? super U, V>) - Static method in interface com.ibm.asyncutil.iteration.AsyncIterator
Creates an iterator that is the result of fn applied to iteration elements returned by tIt and uI.
A B C D E F G I K L M N O P R S T U V Z 
Skip navigation links

Copyright © 2018. All rights reserved.