Uses of Interface
org.apache.storm.streams.operations.Operation
Packages that use Operation
Package
Description
-
Uses of Operation in org.apache.storm.sql.runtime.streams.functions
Classes in org.apache.storm.sql.runtime.streams.functions that implement OperationModifier and TypeClassDescriptionclass
class
class
class
class
-
Uses of Operation in org.apache.storm.streams.operations
Subinterfaces of Operation in org.apache.storm.streams.operationsModifier and TypeInterfaceDescriptioninterface
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 OperationModifier and TypeClassDescriptionclass
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
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 -
Uses of Operation in org.apache.storm.streams.operations.mappers
Subinterfaces of Operation in org.apache.storm.streams.operations.mappersModifier and TypeInterfaceDescriptioninterface
A generic interface for mapping aTuple
to typed values.Classes in org.apache.storm.streams.operations.mappers that implement OperationModifier and TypeClassDescriptionclass
PairValueMapper<K,
V> Extracts a typed key-value pair from a tuple.class
ValueMapper<T>
Extracts a single typed value from a tuple.class