Uses of Interface
org.apache.storm.trident.operation.Operation
-
-
Uses of Operation in org.apache.storm.hdfs.trident
Classes in org.apache.storm.hdfs.trident that implement Operation Modifier and Type Class Description class
HdfsUpdater
-
Uses of Operation in org.apache.storm.hive.trident
Classes in org.apache.storm.hive.trident that implement Operation Modifier and Type Class Description class
HiveUpdater
Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of Operation in org.apache.storm.jdbc.trident.state
Classes in org.apache.storm.jdbc.trident.state that implement Operation Modifier and Type Class Description class
JdbcQuery
class
JdbcUpdater
-
Uses of Operation in org.apache.storm.jms.trident
Classes in org.apache.storm.jms.trident that implement Operation Modifier and Type Class Description class
JmsUpdater
-
Uses of Operation in org.apache.storm.kafka.trident
Classes in org.apache.storm.kafka.trident that implement Operation Modifier and Type Class Description class
TridentKafkaStateUpdater<K,V>
-
Uses of Operation in org.apache.storm.redis.trident
Classes in org.apache.storm.redis.trident that implement Operation Modifier and Type Class Description class
PrintFunction
-
Uses of Operation in org.apache.storm.redis.trident.state
Classes in org.apache.storm.redis.trident.state that implement Operation Modifier and Type Class Description class
AbstractRedisStateQuerier<T extends State>
AbstractRedisStateQuerier is base class of any RedisStateQuerier, which implements BaseQueryFunction.class
AbstractRedisStateUpdater<T extends State>
AbstractRedisStateUpdater is base class of any RedisStateUpdater, which implements BaseStateUpdater.class
RedisClusterStateQuerier
BaseQueryFunction implementation for Redis Cluster environment.class
RedisClusterStateUpdater
BaseStateUpdater implementation for Redis Cluster environment.class
RedisStateQuerier
BaseQueryFunction implementation for single Redis environment.class
RedisStateUpdater
BaseStateUpdater implementation for single Redis environment. -
Uses of Operation in org.apache.storm.starter.trident
Classes in org.apache.storm.starter.trident that implement Operation Modifier and Type Class Description static class
TridentReach.ExpandList
static class
TridentWordCount.Split
-
Uses of Operation in org.apache.storm.trident.operation
Subinterfaces of Operation in org.apache.storm.trident.operation Modifier and Type Interface Description interface
Aggregator<T>
interface
EachOperation
interface
Filter
Filters take in a tuple as input and decide whether or not to keep that tuple or not.interface
Function
A function takes in a set of input fields and emits zero or more tuples as output.interface
OperationAwareFlatMapFunction
A one to many transformation function which is aware of Operation (lifecycle of the Trident component).interface
OperationAwareMapFunction
A one-one transformation function which is aware of Operation (lifecycle of the Trident component).Classes in org.apache.storm.trident.operation that implement Operation Modifier and Type Class Description class
BaseAggregator<T>
class
BaseFilter
class
BaseFunction
class
BaseOperation
Convenience implementation of theOperation
interface. -
Uses of Operation in org.apache.storm.trident.operation.builtin
Classes in org.apache.storm.trident.operation.builtin that implement Operation Modifier and Type Class Description class
ComparisonAggregator<T>
AbstractAggregator
for comparing two values in a stream.class
Debug
Filter for debugging purposes.class
Equals
class
FilterNull
Simple `Filter` implementation that filters out any tuples that have fields with a value of `null`.static class
FirstN.FirstNAgg
static class
FirstN.FirstNSortedAgg
class
MapGet
class
Max
This aggregator computes the maximum of aggregated tuples in a stream.class
MaxWithComparator<T>
This aggregator computes the maximum of aggregated tuples in a stream.class
Min
This aggregator computes the minimum of aggregated tuples in a stream.class
MinWithComparator<T>
This aggregator computes the minimum of aggregated tuples in a stream.class
Negate
A `Filter` implementation that inverts another delegate `Filter`.class
SnapshotGet
class
TupleCollectionGet
-
Uses of Operation in org.apache.storm.trident.operation.impl
Classes in org.apache.storm.trident.operation.impl that implement Operation Modifier and Type Class Description class
ChainedAggregatorImpl
class
CombinerAggregatorCombineImpl
class
CombinerAggregatorInitImpl
class
CombinerAggStateUpdater
class
ConsumerExecutor
class
FilterExecutor
class
FlatMapFunctionExecutor
class
GroupedAggregator
class
MapFunctionExecutor
class
ReducerAggregatorImpl
class
ReducerAggStateUpdater
class
SingleEmitAggregator
class
TrueFilter
-
Uses of Operation in org.apache.storm.trident.state
Subinterfaces of Operation in org.apache.storm.trident.state Modifier and Type Interface Description interface
QueryFunction<S extends State,T>
interface
StateUpdater<S extends State>
Classes in org.apache.storm.trident.state that implement Operation Modifier and Type Class Description class
BaseQueryFunction<S extends State,T>
class
BaseStateUpdater<S extends State>
-
Uses of Operation in org.apache.storm.trident.state.map
Classes in org.apache.storm.trident.state.map that implement Operation Modifier and Type Class Description class
MapCombinerAggStateUpdater
class
MapReducerAggStateUpdater
-
Uses of Operation in org.apache.storm.trident.testing
Classes in org.apache.storm.trident.testing that implement Operation Modifier and Type Class Description class
CountAsAggregator
class
Split
class
StringLength
class
TrueFilter
class
TuplifyArgs
-
Uses of Operation in org.apache.storm.trident.windowing
Classes in org.apache.storm.trident.windowing that implement Operation Modifier and Type Class Description class
WindowsStateUpdater
StateUpdater<WindowState>
instance which removes successfully emitted triggers from store.
-