- AbstractDoubleSpliterator(long, int) - Constructor for class java8.util.Spliterators.AbstractDoubleSpliterator
-
Creates a spliterator reporting the given estimated size and
characteristics.
- AbstractIntSpliterator(long, int) - Constructor for class java8.util.Spliterators.AbstractIntSpliterator
-
Creates a spliterator reporting the given estimated size and
characteristics.
- AbstractLongSpliterator(long, int) - Constructor for class java8.util.Spliterators.AbstractLongSpliterator
-
Creates a spliterator reporting the given estimated size and
characteristics.
- AbstractSpliterator(long, int) - Constructor for class java8.util.Spliterators.AbstractSpliterator
-
Creates a spliterator reporting the given estimated size and
additionalCharacteristics.
- accept(double) - Method in class java8.util.DoubleSummaryStatistics
-
Records another value into the summary information.
- accept(T, U) - Method in interface java8.util.function.BiConsumer
-
Performs this operation on the given arguments.
- accept(T) - Method in interface java8.util.function.Consumer
-
Performs this operation on the given argument.
- accept(double) - Method in interface java8.util.function.DoubleConsumer
-
Performs this operation on the given argument.
- accept(int) - Method in interface java8.util.function.IntConsumer
-
Performs this operation on the given argument.
- accept(long) - Method in interface java8.util.function.LongConsumer
-
Performs this operation on the given argument.
- accept(T, double) - Method in interface java8.util.function.ObjDoubleConsumer
-
Performs this operation on the given arguments.
- accept(T, int) - Method in interface java8.util.function.ObjIntConsumer
-
Performs this operation on the given arguments.
- accept(T, long) - Method in interface java8.util.function.ObjLongConsumer
-
Performs this operation on the given arguments.
- accept(int) - Method in class java8.util.IntSummaryStatistics
-
Records a new value into the summary information
- accept(int) - Method in class java8.util.LongSummaryStatistics
-
Records a new int
value into the summary information.
- accept(long) - Method in class java8.util.LongSummaryStatistics
-
Records a new long
value into the summary information.
- accept(double) - Method in interface java8.util.stream.DoubleStream.Builder
-
Adds an element to the stream being built.
- accept(int) - Method in interface java8.util.stream.IntStream.Builder
-
Adds an element to the stream being built.
- accept(long) - Method in interface java8.util.stream.LongStream.Builder
-
Adds an element to the stream being built.
- accept(T) - Method in interface java8.util.stream.Stream.Builder
-
Adds an element to the stream being built.
- acceptEither(CompletionStage<? extends T>, Consumer<? super T>) - Method in class java8.util.concurrent.CompletableFuture
-
- acceptEither(CompletionStage<? extends T>, Consumer<? super T>) - Method in interface java8.util.concurrent.CompletionStage
-
Returns a new CompletionStage that, when either this or the
other given stage complete normally, is executed with the
corresponding result as argument to the supplied action.
- acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>) - Method in class java8.util.concurrent.CompletableFuture
-
- acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>, Executor) - Method in class java8.util.concurrent.CompletableFuture
-
- acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>) - Method in interface java8.util.concurrent.CompletionStage
-
Returns a new CompletionStage that, when either this or the
other given stage complete normally, is executed using this
stage's default asynchronous execution facility, with the
corresponding result as argument to the supplied action.
- acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>, Executor) - Method in interface java8.util.concurrent.CompletionStage
-
Returns a new CompletionStage that, when either this or the
other given stage complete normally, is executed using the
supplied executor, with the corresponding result as argument to
the supplied function.
- accumulate(double) - Method in class java8.util.concurrent.atomic.DoubleAccumulator
-
Updates with the given value.
- accumulate(long) - Method in class java8.util.concurrent.atomic.LongAccumulator
-
Updates with the given value.
- accumulator() - Method in interface java8.util.stream.Collector
-
A function that folds a value into a mutable result container.
- adapt(Runnable) - Static method in class java8.util.concurrent.ForkJoinTask
-
Returns a new
ForkJoinTask
that performs the
run
method of the given
Runnable
as its action, and returns
a null result upon
ForkJoinTask.join()
.
- adapt(Runnable, T) - Static method in class java8.util.concurrent.ForkJoinTask
-
Returns a new
ForkJoinTask
that performs the
run
method of the given
Runnable
as its action, and returns
the given result upon
ForkJoinTask.join()
.
- adapt(Callable<? extends T>) - Static method in class java8.util.concurrent.ForkJoinTask
-
Returns a new
ForkJoinTask
that performs the
call
method of the given
Callable
as its action, and returns
its result upon
ForkJoinTask.join()
, translating any checked exceptions
encountered into
RuntimeException
.
- add(double) - Method in class java8.util.concurrent.atomic.DoubleAdder
-
Adds the given value.
- add(long) - Method in class java8.util.concurrent.atomic.LongAdder
-
Adds the given value.
- add(DoubleStream.Builder, double) - Static method in class java8.util.stream.DoubleStreams.J8Builder
-
Adds an element to the stream being built.
- add(IntStream.Builder, int) - Static method in class java8.util.stream.IntStreams.J8Builder
-
Adds an element to the stream being built.
- add(LongStream.Builder, long) - Static method in class java8.util.stream.LongStreams.J8Builder
-
Adds an element to the stream being built.
- add(T) - Method in interface java8.util.stream.Stream.Builder
-
Adds an element to the stream being built.
- add(Stream.Builder<T>, T) - Static method in class java8.util.stream.StreamSupport
-
Adds an element to the stream being built represented by the Stream.Builder
argument.
- add(CharSequence) - Method in class java8.util.StringJoiner
-
Adds a copy of the given CharSequence
value as the next
element of the StringJoiner
value.
- addToPendingCount(int) - Method in class java8.util.concurrent.CountedCompleter
-
Adds (atomically) the given value to the pending count.
- allMatch(DoublePredicate) - Method in interface java8.util.stream.DoubleStream
-
Returns whether all elements of this stream match the provided predicate.
- allMatch(IntPredicate) - Method in interface java8.util.stream.IntStream
-
Returns whether all elements of this stream match the provided predicate.
- allMatch(LongPredicate) - Method in interface java8.util.stream.LongStream
-
Returns whether all elements of this stream match the provided predicate.
- allMatch(Predicate<? super T>) - Method in interface java8.util.stream.Stream
-
Returns whether all elements of this stream match the provided predicate.
- allOf(CompletableFuture<?>...) - Static method in class java8.util.concurrent.CompletableFuture
-
Returns a new CompletableFuture that is completed when all of
the given CompletableFutures complete.
- and(BiPredicate<? super T, ? super U>, BiPredicate<? super T, ? super U>) - Static method in class java8.util.function.BiPredicates
-
Returns a composed predicate that represents a short-circuiting logical
AND of the this_
predicate and another.
- and(DoublePredicate, DoublePredicate) - Static method in class java8.util.function.DoublePredicates
-
Returns a composed predicate that represents a short-circuiting logical
AND of the this_
predicate and another.
- and(IntPredicate, IntPredicate) - Static method in class java8.util.function.IntPredicates
-
Returns a composed predicate that represents a short-circuiting logical
AND of the this_
predicate and another.
- and(LongPredicate, LongPredicate) - Static method in class java8.util.function.LongPredicates
-
Returns a composed predicate that represents a short-circuiting logical
AND of the this_
predicate and another.
- and(Predicate<? super T>, Predicate<? super T>) - Static method in class java8.util.function.Predicates
-
Returns a composed predicate that represents a short-circuiting logical
AND of the this_
predicate and another.
- andThen(BiConsumer<? super T, ? super U>, BiConsumer<? super T, ? super U>) - Static method in class java8.util.function.BiConsumers
-
Returns a composed BiConsumer
that performs, in sequence, this_
operation followed by the after
operation.
- andThen(BiFunction<? super T, ? super U, ? extends R>, Function<? super R, ? extends V>) - Static method in class java8.util.function.BiFunctions
-
Returns a composed function that first applies the this_
function to
its inputs, and then applies the after
function to the result.
- andThen(Consumer<? super T>, Consumer<? super T>) - Static method in class java8.util.function.Consumers
-
Returns a composed Consumer
that performs, in sequence, the this_
operation followed by the after
operation.
- andThen(DoubleConsumer, DoubleConsumer) - Static method in class java8.util.function.DoubleConsumers
-
Returns a composed DoubleConsumer
that performs, in sequence, the this_
operation followed by the after
operation.
- andThen(DoubleUnaryOperator, DoubleUnaryOperator) - Static method in class java8.util.function.DoubleUnaryOperators
-
Returns a composed operator that first applies the this_
operator to
its input, and then applies the after
operator to the result.
- andThen(Function<? super T, ? extends R>, Function<? super R, ? extends V>) - Static method in class java8.util.function.Functions
-
Returns a composed function that first applies the this_
function to
its input, and then applies the after
function to the result.
- andThen(IntConsumer, IntConsumer) - Static method in class java8.util.function.IntConsumers
-
Returns a composed IntConsumer
that performs, in sequence, the this_
operation followed by the after
operation.
- andThen(IntUnaryOperator, IntUnaryOperator) - Static method in class java8.util.function.IntUnaryOperators
-
Returns a composed operator that first applies the this_
operator to
its input, and then applies the after
operator to the result.
- andThen(LongConsumer, LongConsumer) - Static method in class java8.util.function.LongConsumers
-
Returns a composed LongConsumer
that performs, in sequence, the this_
operation followed by the after
operation.
- andThen(LongUnaryOperator, LongUnaryOperator) - Static method in class java8.util.function.LongUnaryOperators
-
Returns a composed operator that first applies the this_
operator to
its input, and then applies the after
operator to the result.
- anyMatch(DoublePredicate) - Method in interface java8.util.stream.DoubleStream
-
Returns whether any elements of this stream match the provided
predicate.
- anyMatch(IntPredicate) - Method in interface java8.util.stream.IntStream
-
Returns whether any elements of this stream match the provided
predicate.
- anyMatch(LongPredicate) - Method in interface java8.util.stream.LongStream
-
Returns whether any elements of this stream match the provided
predicate.
- anyMatch(Predicate<? super T>) - Method in interface java8.util.stream.Stream
-
Returns whether any elements of this stream match the provided
predicate.
- anyOf(CompletableFuture<?>...) - Static method in class java8.util.concurrent.CompletableFuture
-
Returns a new CompletableFuture that is completed when any of
the given CompletableFutures complete, with the same result.
- apply(T, U) - Method in interface java8.util.function.BiFunction
-
Applies this function to the given arguments.
- apply(double) - Method in interface java8.util.function.DoubleFunction
-
Applies this function to the given argument.
- apply(T) - Method in interface java8.util.function.Function
-
Applies this function to the given argument.
- apply(int) - Method in interface java8.util.function.IntFunction
-
Applies this function to the given argument.
- apply(long) - Method in interface java8.util.function.LongFunction
-
Applies this function to the given argument.
- applyAsDouble(double, double) - Method in interface java8.util.function.DoubleBinaryOperator
-
Applies this operator to the given operands.
- applyAsDouble(double) - Method in interface java8.util.function.DoubleUnaryOperator
-
Applies this operator to the given operand.
- applyAsDouble(int) - Method in interface java8.util.function.IntToDoubleFunction
-
Applies this function to the given argument.
- applyAsDouble(long) - Method in interface java8.util.function.LongToDoubleFunction
-
Applies this function to the given argument.
- applyAsDouble(T, U) - Method in interface java8.util.function.ToDoubleBiFunction
-
Applies this function to the given arguments.
- applyAsDouble(T) - Method in interface java8.util.function.ToDoubleFunction
-
Applies this function to the given argument.
- applyAsInt(double) - Method in interface java8.util.function.DoubleToIntFunction
-
Applies this function to the given argument.
- applyAsInt(int, int) - Method in interface java8.util.function.IntBinaryOperator
-
Applies this operator to the given operands.
- applyAsInt(int) - Method in interface java8.util.function.IntUnaryOperator
-
Applies this operator to the given operand.
- applyAsInt(long) - Method in interface java8.util.function.LongToIntFunction
-
Applies this function to the given argument.
- applyAsInt(T, U) - Method in interface java8.util.function.ToIntBiFunction
-
Applies this function to the given arguments.
- applyAsInt(T) - Method in interface java8.util.function.ToIntFunction
-
Applies this function to the given argument.
- applyAsLong(double) - Method in interface java8.util.function.DoubleToLongFunction
-
Applies this function to the given argument.
- applyAsLong(int) - Method in interface java8.util.function.IntToLongFunction
-
Applies this function to the given argument.
- applyAsLong(long, long) - Method in interface java8.util.function.LongBinaryOperator
-
Applies this operator to the given operands.
- applyAsLong(long) - Method in interface java8.util.function.LongUnaryOperator
-
Applies this operator to the given operand.
- applyAsLong(T, U) - Method in interface java8.util.function.ToLongBiFunction
-
Applies this function to the given arguments.
- applyAsLong(T) - Method in interface java8.util.function.ToLongFunction
-
Applies this function to the given argument.
- applyToEither(CompletionStage<? extends T>, Function<? super T, U>) - Method in class java8.util.concurrent.CompletableFuture
-
- applyToEither(CompletionStage<? extends T>, Function<? super T, U>) - Method in interface java8.util.concurrent.CompletionStage
-
Returns a new CompletionStage that, when either this or the
other given stage complete normally, is executed with the
corresponding result as argument to the supplied function.
- applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>) - Method in class java8.util.concurrent.CompletableFuture
-
- applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>, Executor) - Method in class java8.util.concurrent.CompletableFuture
-
- applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>) - Method in interface java8.util.concurrent.CompletionStage
-
Returns a new CompletionStage that, when either this or the
other given stage complete normally, is executed using this
stage's default asynchronous execution facility, with the
corresponding result as argument to the supplied function.
- applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>, Executor) - Method in interface java8.util.concurrent.CompletionStage
-
Returns a new CompletionStage that, when either this or the
other given stage complete normally, is executed using the
supplied executor, with the corresponding result as argument to
the supplied function.
- arrive() - Method in class java8.util.concurrent.Phaser
-
Arrives at this phaser, without waiting for others to arrive.
- arriveAndAwaitAdvance() - Method in class java8.util.concurrent.Phaser
-
Arrives at this phaser and awaits others.
- arriveAndDeregister() - Method in class java8.util.concurrent.Phaser
-
Arrives at this phaser and deregisters from it without waiting
for others to arrive.
- asDoubleStream() - Method in interface java8.util.stream.IntStream
-
Returns a DoubleStream
consisting of the elements of this stream,
converted to double
.
- asDoubleStream() - Method in interface java8.util.stream.LongStream
-
Returns a DoubleStream
consisting of the elements of this stream,
converted to double
.
- asLongStream() - Method in interface java8.util.stream.IntStream
-
Returns a LongStream
consisting of the elements of this stream,
converted to long
.
- average() - Method in interface java8.util.stream.DoubleStream
-
Returns an OptionalDouble
describing the arithmetic
mean of elements of this stream, or an empty optional if this
stream is empty.
- average() - Method in interface java8.util.stream.IntStream
-
Returns an OptionalDouble
describing the arithmetic mean of elements of
this stream, or an empty optional if this stream is empty.
- average() - Method in interface java8.util.stream.LongStream
-
Returns an OptionalDouble
describing the arithmetic mean of elements of
this stream, or an empty optional if this stream is empty.
- averagingDouble(ToDoubleFunction<? super T>) - Static method in class java8.util.stream.Collectors
-
Returns a Collector
that produces the arithmetic mean of a double-valued
function applied to the input elements.
- averagingInt(ToIntFunction<? super T>) - Static method in class java8.util.stream.Collectors
-
Returns a Collector
that produces the arithmetic mean of an integer-valued
function applied to the input elements.
- averagingLong(ToLongFunction<? super T>) - Static method in class java8.util.stream.Collectors
-
Returns a Collector
that produces the arithmetic mean of a long-valued
function applied to the input elements.
- awaitAdvance(int) - Method in class java8.util.concurrent.Phaser
-
Awaits the phase of this phaser to advance from the given phase
value, returning immediately if the current phase is not equal
to the given phase value or this phaser is terminated.
- awaitAdvanceInterruptibly(int) - Method in class java8.util.concurrent.Phaser
-
Awaits the phase of this phaser to advance from the given phase
value, throwing InterruptedException
if interrupted
while waiting, or returning immediately if the current phase is
not equal to the given phase value or this phaser is
terminated.
- awaitAdvanceInterruptibly(int, long, TimeUnit) - Method in class java8.util.concurrent.Phaser
-
Awaits the phase of this phaser to advance from the given phase
value or the given timeout to elapse, throwing InterruptedException
if interrupted while waiting, or
returning immediately if the current phase is not equal to the
given phase value or this phaser is terminated.
- awaitQuiescence(long, TimeUnit) - Method in class java8.util.concurrent.ForkJoinPool
-
- awaitTermination(long, TimeUnit) - Method in class java8.util.concurrent.ForkJoinPool
-
Blocks until all tasks have completed execution after a
shutdown request, or the timeout occurs, or the current thread
is interrupted, whichever happens first.