Package | Description |
---|---|
org.apache.storm.sql | |
org.apache.storm.sql.planner.streams | |
org.apache.storm.streams |
Modifier and Type | Field and Description |
---|---|
protected Stream<Values> |
AbstractStreamsProcessor.outputStream |
Modifier and Type | Method and Description |
---|---|
Stream<Values> |
AbstractStreamsProcessor.outputStream()
Return final output stream of SQL topology structure.
|
Modifier and Type | Method and Description |
---|---|
Stream<Values> |
StreamsPlanCreator.pop() |
Modifier and Type | Method and Description |
---|---|
void |
StreamsPlanCreator.addStream(Stream<Values> stream) |
Modifier and Type | Class and Description |
---|---|
class |
PairStream<K,V>
Represents a stream of key-value pairs.
|
Modifier and Type | Method and Description |
---|---|
<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)
Creates a new
Stream of tuples from the given IRichSpout . |
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)
Creates a new
Stream of values from the given IRichSpout by extracting field(s) from tuples via the supplied TupleValueMapper . |
<T> Stream<T> |
StreamBuilder.newStream(IRichSpout spout,
TupleValueMapper<T> valueMapper,
int parallelism)
Creates a new
Stream of values from the given IRichSpout by extracting field(s) from tuples via the supplied TupleValueMapper with the given 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.
|
Copyright © 2022 The Apache Software Foundation. All rights reserved.