Uses of Interface
org.apache.storm.streams.operations.BiFunction
-
Uses of BiFunction in org.apache.storm.streams
Modifier and TypeMethodDescription<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.<R> PairStream<K,
R> PairStream.aggregateByKey
(R initialValue, BiFunction<? super R, ? super V, ? extends R> accumulator, BiFunction<? super R, ? super R, ? extends R> combiner) Aggregates the values for each key of this stream using the given initial value, accumulator and combiner.<R> StreamState<K,
R> PairStream.updateStateByKey
(R initialValue, BiFunction<? super R, ? super V, ? extends R> stateUpdateFn) Update the state by applying the given state update function to the previous state of the key and the new value for the key. -
Uses of BiFunction in org.apache.storm.streams.operations
Modifier and TypeInterfaceDescriptioninterface
Reducer<T>
TheReducer
performs an operation on two values of the same type producing a result of the same type.Modifier and TypeMethodDescriptionstatic <T,
R> CombinerAggregator<T, R, R> CombinerAggregator.of
(R initialValue, BiFunction<? super R, ? super T, ? extends R> accumulator, BiFunction<? super R, ? super R, ? extends R> combiner) A static factory to create aCombinerAggregator
based on initial value, accumulator and combiner.static <T,
S> StateUpdater<T, S> StateUpdater.of
(S initialValue, BiFunction<? super S, ? super T, ? extends S> stateUpdateFn) A static factory to create aStateUpdater
based on an initial value of the state and a state update function.