Uses of Class
org.apache.storm.trident.TridentState
Packages that use TridentState
-
Uses of TridentState in org.apache.storm.trident
Methods in org.apache.storm.trident that return TridentStateModifier and TypeMethodDescriptionTridentState.addSharedMemory
(SharedMemory request) protected TridentState
TridentTopology.addSourcedStateNode
(List<Stream> sources, Node newNode) protected TridentState
TridentTopology.addSourcedStateNode
(Stream source, Node newNode) TridentTopology.newStaticState
(StateFactory factory) TridentTopology.newStaticState
(StateSpec spec) TridentState.parallelismHint
(int parallelism) Stream.partitionPersist
(StateFactory stateFactory, StateUpdater updater) Stream.partitionPersist
(StateFactory stateFactory, StateUpdater updater, Fields functionFields) Stream.partitionPersist
(StateFactory stateFactory, Fields inputFields, StateUpdater updater) Stream.partitionPersist
(StateFactory stateFactory, Fields inputFields, StateUpdater updater, Fields functionFields) Stream.partitionPersist
(StateSpec stateSpec, StateUpdater updater) Stream.partitionPersist
(StateSpec stateSpec, StateUpdater updater, Fields functionFields) Stream.partitionPersist
(StateSpec stateSpec, Fields inputFields, StateUpdater updater) Stream.partitionPersist
(StateSpec stateSpec, Fields inputFields, StateUpdater updater, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, CombinerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, ReducerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, CombinerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, ReducerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateSpec spec, CombinerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateSpec spec, ReducerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateSpec spec, Fields inputFields, CombinerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateSpec spec, Fields inputFields, ReducerAggregator agg, Fields functionFields) TridentState.setCPULoad
(Number load) TridentState.setMemoryLoad
(Number onHeap) TridentState.setMemoryLoad
(Number onHeap, Number offHeap) Methods in org.apache.storm.trident with parameters of type TridentStateModifier and TypeMethodDescriptionStream.stateQuery
(TridentState state, QueryFunction function, Fields functionFields) Stream.stateQuery
(TridentState state, Fields inputFields, QueryFunction function, Fields functionFields) -
Uses of TridentState in org.apache.storm.trident.fluent
Methods in org.apache.storm.trident.fluent that return TridentStateModifier and TypeMethodDescriptionGroupedStream.persistentAggregate
(StateFactory stateFactory, CombinerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateFactory stateFactory, ReducerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, CombinerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, ReducerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateSpec spec, CombinerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateSpec spec, ReducerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateSpec spec, Fields inputFields, CombinerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateSpec spec, Fields inputFields, ReducerAggregator agg, Fields functionFields) Methods in org.apache.storm.trident.fluent with parameters of type TridentStateModifier and TypeMethodDescriptionGroupedStream.stateQuery
(TridentState state, QueryFunction function, Fields functionFields) GroupedStream.stateQuery
(TridentState state, Fields inputFields, QueryFunction function, Fields functionFields)