<A,R> Stream<R> |
Stream.aggregate(CombinerAggregator<? super T,A,? extends R> aggregator) |
Aggregates the values in this stream using the aggregator.
|
<R> Stream<R> |
Stream.aggregate(R initialValue,
BiFunction<? super R,? super T,? extends R> accumulator,
BiFunction<? super R,? super R,? extends R> combiner) |
Aggregates the values in this stream using the given initial value, accumulator and combiner.
|
Stream<T>[] |
Stream.branch(Predicate<? super T>... predicates) |
Returns an array of streams by splitting the given stream into multiple branches based on the given predicates.
|
Stream<Long> |
Stream.count() |
Counts the number of values in this stream.
|
Stream<T> |
Stream.filter(Predicate<? super T> predicate) |
Returns a stream consisting of the elements of this stream that matches the given filter.
|
<R> Stream<R> |
Stream.flatMap(FlatMapFunction<? super T,? extends R> function) |
Returns a stream consisting of the results of replacing each value of this stream with the contents produced by applying the provided
mapping function to each value.
|
<R> Stream<R> |
Stream.map(Function<? super T,? extends R> function) |
Returns a stream consisting of the result of applying the given mapping function to the values of this stream.
|
Stream<Tuple> |
StreamBuilder.newStream(IRichSpout spout) |
|
Stream<Tuple> |
StreamBuilder.newStream(IRichSpout spout,
int parallelism) |
Creates a new Stream of tuples from the given IRichSpout with the given parallelism.
|
<T> Stream<T> |
StreamBuilder.newStream(IRichSpout spout,
TupleValueMapper<T> valueMapper) |
|
<T> Stream<T> |
StreamBuilder.newStream(IRichSpout spout,
TupleValueMapper<T> valueMapper,
int parallelism) |
|
protected Stream<T> |
Stream.partitionBy(Fields fields,
int parallelism) |
|
Stream<T> |
Stream.peek(Consumer<? super T> action) |
Returns a stream consisting of the elements of this stream, additionally performing the provided action on each element as they are
consumed from the resulting stream.
|
Stream<T> |
Stream.reduce(Reducer<T> reducer) |
Performs a reduction on the elements of this stream, by repeatedly applying the reducer.
|
Stream<T> |
Stream.repartition(int parallelism) |
Returns a new stream with the given value of parallelism.
|
Stream<T> |
Stream.window(Window<?,?> window) |
Returns a new stream consisting of the elements that fall within the window as specified by the window parameter.
|