Uses of Interface
org.apache.storm.trident.tuple.TridentTuple
Package
Description
ElasticSearch Trident example classes.
-
Uses of TridentTuple in org.apache.storm.elasticsearch.trident
Modifier and TypeMethodDescriptionvoid
EsUpdater.updateState
(org.apache.storm.elasticsearch.trident.EsState state, List<TridentTuple> tuples, TridentCollector collector) Each tuple should have relevant fields (source, index, type, id) for EsState's tupleMapper to extract ES document. -
Uses of TridentTuple in org.apache.storm.hdfs.trident
Modifier and TypeMethodDescriptionvoid
HdfsState.HdfsFileOptions.execute
(List<TridentTuple> tuples) void
HdfsState.SequenceFileOptions.execute
(List<TridentTuple> tuples) void
HdfsState.updateState
(List<TridentTuple> tuples, TridentCollector tridentCollector) void
HdfsUpdater.updateState
(HdfsState state, List<TridentTuple> tuples, TridentCollector collector) -
Uses of TridentTuple in org.apache.storm.hdfs.trident.format
Modifier and TypeMethodDescriptionbyte[]
DelimitedRecordFormat.format
(TridentTuple tuple) byte[]
RecordFormat.format
(TridentTuple tuple) org.apache.hadoop.io.Writable
DefaultSequenceFormat.key
(TridentTuple tuple) org.apache.hadoop.io.Writable
SequenceFormat.key
(TridentTuple tuple) Given a tuple, return the key that should be written to the sequence file.org.apache.hadoop.io.Writable
DefaultSequenceFormat.value
(TridentTuple tuple) org.apache.hadoop.io.Writable
SequenceFormat.value
(TridentTuple tuple) Given a tuple, return the value that should be written to the sequence file. -
Uses of TridentTuple in org.apache.storm.hdfs.trident.rotation
Modifier and TypeMethodDescriptionboolean
FileRotationPolicy.mark
(TridentTuple tuple, long offset) Called for every tuple the HdfsBolt executes.boolean
FileSizeRotationPolicy.mark
(TridentTuple tuple, long offset) boolean
NoRotationPolicy.mark
(TridentTuple tuple, long offset) boolean
TimedRotationPolicy.mark
(TridentTuple tuple, long offset) Called for every tuple the HdfsBolt executes. -
Uses of TridentTuple in org.apache.storm.hdfs.trident.sync
Modifier and TypeMethodDescriptionboolean
CountSyncPolicy.mark
(TridentTuple tuple, long offset) boolean
SyncPolicy.mark
(TridentTuple tuple, long offset) Called for every tuple the HdfsBolt executes. -
Uses of TridentTuple in org.apache.storm.hive.bolt.mapper
Modifier and TypeMethodDescriptionDelimitedRecordHiveMapper.mapPartitions
(TridentTuple tuple) HiveMapper.mapPartitions
(TridentTuple tuple) Given a TridetnTuple, return a hive partition values list.JsonRecordHiveMapper.mapPartitions
(TridentTuple tuple) byte[]
DelimitedRecordHiveMapper.mapRecord
(TridentTuple tuple) byte[]
HiveMapper.mapRecord
(TridentTuple tuple) Given a TridentTuple, maps to a HiveRecord based on columnFields.byte[]
JsonRecordHiveMapper.mapRecord
(TridentTuple tuple) -
Uses of TridentTuple in org.apache.storm.hive.trident
Modifier and TypeMethodDescriptionvoid
HiveState.updateState
(List<TridentTuple> tuples, TridentCollector collector) void
HiveUpdater.updateState
(HiveState state, List<TridentTuple> tuples, TridentCollector collector) -
Uses of TridentTuple in org.apache.storm.jdbc.trident.state
Modifier and TypeMethodDescriptionvoid
JdbcQuery.execute
(TridentTuple tuples, List<Values> values, TridentCollector tridentCollector) Modifier and TypeMethodDescriptionJdbcQuery.batchRetrieve
(JdbcState jdbcState, List<TridentTuple> tridentTuples) JdbcState.batchRetrieve
(List<TridentTuple> tridentTuples) void
JdbcState.updateState
(List<TridentTuple> tuples, TridentCollector collector) void
JdbcUpdater.updateState
(JdbcState jdbcState, List<TridentTuple> tuples, TridentCollector collector) -
Uses of TridentTuple in org.apache.storm.jms.trident
Modifier and TypeMethodDescriptionvoid
JmsState.updateState
(List<TridentTuple> tuples, TridentCollector collector) void
JmsUpdater.updateState
(JmsState jmsState, List<TridentTuple> tuples, TridentCollector collector) -
Uses of TridentTuple in org.apache.storm.kafka.trident
Modifier and TypeMethodDescriptionvoid
TridentKafkaState.updateState
(List<TridentTuple> tuples, TridentCollector collector) Write the given tuples to Kafka.void
TridentKafkaStateUpdater.updateState
(TridentKafkaState<K, V> state, List<TridentTuple> tuples, TridentCollector collector) -
Uses of TridentTuple in org.apache.storm.kafka.trident.mapper
Modifier and TypeMethodDescriptionFieldNameBasedTupleToKafkaMapper.getKeyFromTuple
(TridentTuple tuple) TridentTupleToKafkaMapper.getKeyFromTuple
(TridentTuple tuple) FieldNameBasedTupleToKafkaMapper.getMessageFromTuple
(TridentTuple tuple) TridentTupleToKafkaMapper.getMessageFromTuple
(TridentTuple tuple) -
Uses of TridentTuple in org.apache.storm.kafka.trident.selector
Modifier and TypeMethodDescriptionDefaultTopicSelector.getTopic
(TridentTuple tuple) KafkaTopicSelector.getTopic
(TridentTuple tuple) -
Uses of TridentTuple in org.apache.storm.redis.trident
Modifier and TypeMethodDescriptionvoid
PrintFunction.execute
(TridentTuple tuple, TridentCollector tridentCollector) -
Uses of TridentTuple in org.apache.storm.redis.trident.state
Modifier and TypeMethodDescriptionvoid
AbstractRedisStateQuerier.execute
(TridentTuple tuple, List<Values> values, TridentCollector collector) Modifier and TypeMethodDescriptionAbstractRedisStateQuerier.batchRetrieve
(T state, List<TridentTuple> inputs) void
AbstractRedisStateUpdater.updateState
(T state, List<TridentTuple> inputs, TridentCollector collector) -
Uses of TridentTuple in org.apache.storm.starter.trident
Modifier and TypeMethodDescriptionvoid
TridentReach.ExpandList.execute
(TridentTuple tuple, TridentCollector collector) void
TridentWordCount.Split.execute
(TridentTuple tuple, TridentCollector collector) TridentReach.One.init
(TridentTuple tuple) -
Uses of TridentTuple in org.apache.storm.trident
Modifier and TypeMethodDescriptionStream.max
(Comparator<TridentTuple> comparator) This aggregator operation computes the maximum of tuples in a stream by using the givencomparator
withTridentTuple
s.Stream.min
(Comparator<TridentTuple> comparator) This aggregator operation computes the minimum of tuples in a stream by using the givencomparator
withTridentTuple
s. -
Uses of TridentTuple in org.apache.storm.trident.drpc
Modifier and TypeMethodDescriptionvoid
ReturnResultsReducer.execute
(ReturnResultsReducer.ReturnResultsState state, int streamIndex, TridentTuple input, TridentCollector collector) -
Uses of TridentTuple in org.apache.storm.trident.operation
Modifier and TypeMethodDescriptionvoid
Consumer.accept
(TridentTuple input) Performs the operation on the input trident tuple.void
Aggregator.aggregate
(T val, TridentTuple tuple, TridentCollector collector) void
GroupedMultiReducer.complete
(T state, TridentTuple group, TridentCollector collector) FlatMapFunction.execute
(TridentTuple input) Invoked by the framework for each trident tuple in a stream.void
Function.execute
(TridentTuple tuple, TridentCollector collector) Performs the function logic on an individual tuple and emits 0 or more tuples.void
GroupedMultiReducer.execute
(T state, int streamIndex, TridentTuple group, TridentTuple input, TridentCollector collector) MapFunction.execute
(TridentTuple input) Invoked by the framework for each trident tuple in a stream.void
MultiReducer.execute
(T state, int streamIndex, TridentTuple input, TridentCollector collector) CombinerAggregator.init
(TridentTuple tuple) GroupedMultiReducer.init
(TridentCollector collector, TridentTuple group) boolean
Filter.isKeep
(TridentTuple tuple) Determines if a tuple should be filtered out of a stream.ReducerAggregator.reduce
(T curr, TridentTuple tuple) -
Uses of TridentTuple in org.apache.storm.trident.operation.builtin
Modifier and TypeMethodDescriptionvoid
ComparisonAggregator.aggregate
(ComparisonAggregator.State state, TridentTuple tuple, TridentCollector collector) void
FirstN.FirstNAgg.aggregate
(org.apache.storm.trident.operation.builtin.FirstN.FirstNAgg.State val, TridentTuple tuple, TridentCollector collector) void
FirstN.FirstNSortedAgg.aggregate
(PriorityQueue state, TridentTuple tuple, TridentCollector collector) void
MapGet.execute
(TridentTuple tuple, Object result, TridentCollector collector) void
SnapshotGet.execute
(TridentTuple tuple, Object result, TridentCollector collector) void
TupleCollectionGet.execute
(TridentTuple tuple, Iterator<List<Object>> tuplesIterator, TridentCollector collector) Count.init
(TridentTuple tuple) Sum.init
(TridentTuple tuple) boolean
Debug.isKeep
(TridentTuple tuple) boolean
Equals.isKeep
(TridentTuple tuple) boolean
FilterNull.isKeep
(TridentTuple tuple) boolean
Negate.isKeep
(TridentTuple tuple) protected T
ComparisonAggregator.valueFromTuple
(TridentTuple tuple) Modifier and TypeMethodDescriptionMapGet.batchRetrieve
(ReadOnlyMapState map, List<TridentTuple> keys) SnapshotGet.batchRetrieve
(ReadOnlySnapshottable state, List<TridentTuple> args) TupleCollectionGet.batchRetrieve
(State state, List<TridentTuple> args) -
Uses of TridentTuple in org.apache.storm.trident.operation.impl
Modifier and TypeMethodDescriptionvoid
ChainedAggregatorImpl.aggregate
(ChainedResult val, TridentTuple tuple, TridentCollector collector) void
CombinerAggregatorCombineImpl.aggregate
(Result val, TridentTuple tuple, TridentCollector collector) void
GroupedAggregator.aggregate
(Object[] arr, TridentTuple tuple, TridentCollector collector) void
ReducerAggregatorImpl.aggregate
(Result val, TridentTuple tuple, TridentCollector collector) void
SingleEmitAggregator.aggregate
(org.apache.storm.trident.operation.impl.SingleEmitAggregator.SingleEmitState val, TridentTuple tuple, TridentCollector collector) void
JoinerMultiReducer.complete
(JoinState state, TridentTuple group, TridentCollector collector) void
PreservingFieldsOrderJoinerMultiReducer.complete
(JoinState state, TridentTuple group, TridentCollector collector) void
CombinerAggregatorInitImpl.execute
(TridentTuple tuple, TridentCollector collector) void
ConsumerExecutor.execute
(TridentTuple tuple, TridentCollector collector) void
FilterExecutor.execute
(TridentTuple tuple, TridentCollector collector) void
FlatMapFunctionExecutor.execute
(TridentTuple tuple, TridentCollector collector) void
GroupedMultiReducerExecutor.execute
(Map<TridentTuple, Object> state, int streamIndex, TridentTuple full, TridentCollector collector) void
IdentityMultiReducer.execute
(T state, int streamIndex, TridentTuple input, TridentCollector collector) void
JoinerMultiReducer.execute
(JoinState state, int streamIndex, TridentTuple group, TridentTuple input, TridentCollector collector) void
MapFunctionExecutor.execute
(TridentTuple tuple, TridentCollector collector) void
PreservingFieldsOrderJoinerMultiReducer.execute
(JoinState state, int streamIndex, TridentTuple group, TridentTuple input, TridentCollector collector) JoinerMultiReducer.init
(TridentCollector collector, TridentTuple group) PreservingFieldsOrderJoinerMultiReducer.init
(TridentCollector collector, TridentTuple group) boolean
TrueFilter.isKeep
(TridentTuple tuple) Modifier and TypeMethodDescriptionvoid
GroupedMultiReducerExecutor.complete
(Map<TridentTuple, Object> state, TridentCollector collector) void
GroupedMultiReducerExecutor.execute
(Map<TridentTuple, Object> state, int streamIndex, TridentTuple full, TridentCollector collector) void
CombinerAggStateUpdater.updateState
(Snapshottable state, List<TridentTuple> tuples, TridentCollector collector) void
ReducerAggStateUpdater.updateState
(Snapshottable state, List<TridentTuple> tuples, TridentCollector collector) -
Uses of TridentTuple in org.apache.storm.trident.planner
Modifier and TypeMethodDescriptionvoid
BridgeReceiver.execute
(ProcessorContext context, String streamId, TridentTuple tuple) void
TupleReceiver.execute
(ProcessorContext processorContext, String streamId, TridentTuple tuple) -
Uses of TridentTuple in org.apache.storm.trident.planner.processor
Modifier and TypeMethodDescriptionvoid
AggregateProcessor.execute
(ProcessorContext processorContext, String streamId, TridentTuple tuple) void
EachProcessor.execute
(ProcessorContext processorContext, String streamId, TridentTuple tuple) void
MapProcessor.execute
(ProcessorContext processorContext, String streamId, TridentTuple tuple) void
MultiReducerProcessor.execute
(ProcessorContext processorContext, String streamId, TridentTuple tuple) void
PartitionPersistProcessor.execute
(ProcessorContext processorContext, String streamId, TridentTuple tuple) void
ProjectedProcessor.execute
(ProcessorContext processorContext, String streamId, TridentTuple tuple) void
StateQueryProcessor.execute
(ProcessorContext processorContext, String streamId, TridentTuple tuple) void
AppendCollector.setContext
(ProcessorContext pc, TridentTuple t) -
Uses of TridentTuple in org.apache.storm.trident.state
Modifier and TypeMethodDescriptionvoid
QueryFunction.execute
(TridentTuple tuple, T result, TridentCollector collector) Modifier and TypeMethodDescriptionQueryFunction.batchRetrieve
(S state, List<TridentTuple> args) void
StateUpdater.updateState
(S state, List<TridentTuple> tuples, TridentCollector collector) ModifierConstructorDescriptionReducerValueUpdater
(ReducerAggregator agg, List<TridentTuple> tuples) -
Uses of TridentTuple in org.apache.storm.trident.state.map
Modifier and TypeMethodDescriptionvoid
MapCombinerAggStateUpdater.updateState
(MapState map, List<TridentTuple> tuples, TridentCollector collector) void
MapReducerAggStateUpdater.updateState
(MapState map, List<TridentTuple> tuples, TridentCollector collector) -
Uses of TridentTuple in org.apache.storm.trident.testing
Modifier and TypeMethodDescriptionvoid
CountAsAggregator.aggregate
(org.apache.storm.trident.testing.CountAsAggregator.State state, TridentTuple tuple, TridentCollector collector) void
Split.execute
(TridentTuple tuple, TridentCollector collector) void
StringLength.execute
(TridentTuple tuple, TridentCollector collector) void
TuplifyArgs.execute
(TridentTuple input, TridentCollector collector) boolean
TrueFilter.isKeep
(TridentTuple tuple) -
Uses of TridentTuple in org.apache.storm.trident.tuple
Modifier and TypeClassDescriptionclass
Extends AbstractList so that it can be emitted directly as Storm tuples.Modifier and TypeMethodDescriptionTridentTupleView.OperationOutputFactory.create
(TridentTupleView parent, List<Object> selfVals) TridentTupleView.ProjectionFactory.create
(TridentTuple parent) static TridentTuple
TridentTupleView.createFreshTuple
(Fields fields, Object... values) static TridentTuple
TridentTupleView.createFreshTuple
(Fields fields, List<Object> values) -
Uses of TridentTuple in org.apache.storm.trident.windowing
Modifier and TypeMethodDescriptionStoreBasedTridentWindowManager.collectTridentTupleOrKey
(TridentBatchTuple tridentBatchTuple, List<String> keys) Modifier and TypeMethodDescriptionprotected abstract List<TridentTuple>
AbstractTridentWindowManager.getTridentTuples
(List<T> tupleEvents) ReturnTridentTuple
s from giventupleEvents
.InMemoryTridentWindowManager.getTridentTuples
(List<TridentTuple> tridentBatchTuples) StoreBasedTridentWindowManager.getTridentTuples
(List<TridentBatchTuple> tridentBatchTuples) Modifier and TypeMethodDescriptionvoid
WindowTridentProcessor.execute
(ProcessorContext processorContext, String streamId, TridentTuple tuple) Modifier and TypeMethodDescriptionvoid
InMemoryTridentWindowManager.addTuplesBatch
(Object batchId, List<TridentTuple> tuples) void
ITridentWindowManager.addTuplesBatch
(Object batchId, List<TridentTuple> tuples) Add received batch of tuples to cache/store and add them toWindowManager
.void
StoreBasedTridentWindowManager.addTuplesBatch
(Object batchId, List<TridentTuple> tuples) InMemoryTridentWindowManager.getTridentTuples
(List<TridentTuple> tridentBatchTuples) void
InMemoryTridentWindowManager.onTuplesExpired
(List<TridentTuple> expiredTuples) void
WindowsStateUpdater.updateState
(WindowsState state, List<TridentTuple> tuples, TridentCollector collector) ModifierConstructorDescriptionTridentBatchTuple
(String effectiveBatchId, long timeStamp, int tupleIndex, TridentTuple tridentTuple)