Uses of Interface
org.apache.storm.streams.operations.Operation
-
-
Uses of Operation in org.apache.storm.sql.runtime.streams.functions
Classes in org.apache.storm.sql.runtime.streams.functions that implement Operation Modifier and Type Class Description class
EvaluationCalc
class
EvaluationFilter
class
EvaluationFunction
class
StreamInsertMapToPairFunction
class
StreamsScanTupleValueMapper
-
Uses of Operation in org.apache.storm.streams.operations
Subinterfaces of Operation in org.apache.storm.streams.operations Modifier and Type Interface Description interface
BiFunction<T,U,R>
a function that accepts two arguments and produces a result.interface
CombinerAggregator<T,A,R>
Interface for aggregating values.interface
Consumer<T>
Represents an operation that accepts a single input argument and returns no result.interface
FlatMapFunction<T,R>
A function that accepts one argument and returns anIterable
of elements as its result.interface
Function<T,R>
Represents a function that accepts one argument and produces a result.interface
PairFlatMapFunction<T,K,V>
interface
PairFunction<T,K,V>
A function that accepts an argument and produces a key-value Pair.interface
Predicate<T>
Represents a predicate (boolean-valued function) of a value.interface
Reducer<T>
TheReducer
performs an operation on two values of the same type producing a result of the same type.interface
StateUpdater<T,S>
Interface for updating state.interface
ValueJoiner<V1,V2,R>
An interface for joining two values to produce a result.Classes in org.apache.storm.streams.operations that implement Operation Modifier and Type Class Description class
IdentityFunction<T>
AFunction
that returns the input argument itself as the result.class
PairValueJoiner<V1,V2>
AValueJoiner
that joins two values to produce aPair
of the two values as the result.class
PrintConsumer<T>
A consumer that prints the input to stdout. -
Uses of Operation in org.apache.storm.streams.operations.aggregators
Classes in org.apache.storm.streams.operations.aggregators that implement Operation Modifier and Type Class Description class
Count<T>
Computes the count of values.class
LongSum
Computes the long sum of the input values. -
Uses of Operation in org.apache.storm.streams.operations.mappers
Subinterfaces of Operation in org.apache.storm.streams.operations.mappers Modifier and Type Interface Description interface
TupleValueMapper<T>
A generic interface for mapping aTuple
to typed values.Classes in org.apache.storm.streams.operations.mappers that implement Operation Modifier and Type Class Description class
PairValueMapper<K,V>
Extracts a typed key-value pair from a tuple.class
ValueMapper<T>
Extracts a single typed value from a tuple.class
ValuesMapper
-