Uses of Class
org.apache.storm.streams.Stream
Package
Description
-
Uses of Stream in org.apache.storm.sql
Modifier and TypeMethodDescriptionAbstractStreamsProcessor.outputStream()
Return final output stream of SQL topology structure. -
Uses of Stream in org.apache.storm.sql.planner.streams
-
Uses of Stream in org.apache.storm.streams
Modifier and TypeMethodDescription<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.Returns an array of streams by splitting the given stream into multiple branches based on the given predicates.Stream.count()
Counts the number of values in this stream.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>
Returns a stream consisting of the result of applying the given mapping function to the values of this stream.StreamBuilder.newStream
(IRichSpout spout) Creates a newStream
of tuples from the givenIRichSpout
.StreamBuilder.newStream
(IRichSpout spout, int parallelism) Creates a newStream
of tuples from the givenIRichSpout
with the given parallelism.<T> Stream<T>
StreamBuilder.newStream
(IRichSpout spout, TupleValueMapper<T> valueMapper) Creates a newStream
of values from the givenIRichSpout
by extracting field(s) from tuples via the suppliedTupleValueMapper
.<T> Stream<T>
StreamBuilder.newStream
(IRichSpout spout, TupleValueMapper<T> valueMapper, int parallelism) Creates a newStream
of values from the givenIRichSpout
by extracting field(s) from tuples via the suppliedTupleValueMapper
with the given parallelism.Stream.partitionBy
(Fields fields, int parallelism) 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.Performs a reduction on the elements of this stream, by repeatedly applying the reducer.Stream.repartition
(int parallelism) Returns a new stream with the given value of parallelism.Returns a new stream consisting of the elements that fall within the window as specified by the window parameter.