Uses of Interface
org.apache.storm.tuple.Tuple
Packages that use Tuple
Package
Description
ElasticSearch examples classes.
Shared code for example classes.
-
Uses of Tuple in org.apache.storm
Methods in org.apache.storm that return TupleModifier and TypeMethodDescriptionstatic Tuple
Create aTuple
for use with testing.static Tuple
Testing.testTuple
(List<Object> values, MkTupleParam param) Create aTuple
for use with testing.Methods in org.apache.storm with parameters of type Tuple -
Uses of Tuple in org.apache.storm.bolt
Methods in org.apache.storm.bolt with parameters of type TupleModifier and TypeMethodDescriptionprotected Object
JoinBolt.lookupField
(JoinBolt.FieldSelector fieldSelector, Tuple tuple) Method parameters in org.apache.storm.bolt with type arguments of type TupleModifier and TypeMethodDescriptionprotected JoinBolt.JoinAccumulator
JoinBolt.doInnerJoin
(JoinBolt.JoinAccumulator probe, Map<Object, ArrayList<Tuple>> buildInput, JoinBolt.JoinInfo joinInfo, boolean finalJoin) protected JoinBolt.JoinAccumulator
JoinBolt.doJoin
(JoinBolt.JoinAccumulator probe, HashMap<Object, ArrayList<Tuple>> buildInput, JoinBolt.JoinInfo joinInfo, boolean finalJoin) protected JoinBolt.JoinAccumulator
JoinBolt.doLeftJoin
(JoinBolt.JoinAccumulator probe, Map<Object, ArrayList<Tuple>> buildInput, JoinBolt.JoinInfo joinInfo, boolean finalJoin) JoinBolt.doProjection
(ArrayList<Tuple> tuples, JoinBolt.FieldSelector[] projectionFields) protected JoinBolt.JoinAccumulator
Constructors in org.apache.storm.bolt with parameters of type TupleModifierConstructorDescriptionResultRecord
(JoinBolt.ResultRecord lhs, Tuple rhs, boolean generateOutputFields) ResultRecord
(Tuple tuple, boolean generateOutputFields) -
Uses of Tuple in org.apache.storm.clojure
Classes in org.apache.storm.clojure that implement TupleMethods in org.apache.storm.clojure with parameters of type TupleConstructors in org.apache.storm.clojure with parameters of type Tuple -
Uses of Tuple in org.apache.storm.coordination
Methods in org.apache.storm.coordination with parameters of type TupleModifier and TypeMethodDescriptionvoid
void
void
void
void
void
void
void
CoordinatedBolt.CoordinatedOutputCollector.resetTimeout
(Tuple tuple) Method parameters in org.apache.storm.coordination with type arguments of type TupleModifier and TypeMethodDescriptionCoordinatedBolt.CoordinatedOutputCollector.emit
(String stream, Collection<Tuple> anchors, List<Object> tuple) void
CoordinatedBolt.CoordinatedOutputCollector.emitDirect
(int task, String stream, Collection<Tuple> anchors, List<Object> tuple) -
Uses of Tuple in org.apache.storm.daemon
Methods in org.apache.storm.daemon that return TupleMethods in org.apache.storm.daemon with parameters of type Tuple -
Uses of Tuple in org.apache.storm.drpc
Methods in org.apache.storm.drpc with parameters of type Tuple -
Uses of Tuple in org.apache.storm.elasticsearch.bolt
Methods in org.apache.storm.elasticsearch.bolt with parameters of type Tuple -
Uses of Tuple in org.apache.storm.elasticsearch.common
Methods in org.apache.storm.elasticsearch.common that return Tuple -
Uses of Tuple in org.apache.storm.executor.bolt
Methods in org.apache.storm.executor.bolt with parameters of type TupleModifier and TypeMethodDescriptionvoid
void
void
BoltOutputCollectorImpl.resetTimeout
(Tuple input) Method parameters in org.apache.storm.executor.bolt with type arguments of type TupleModifier and TypeMethodDescriptionvoid
BoltOutputCollectorImpl.emitDirect
(int taskId, String streamId, Collection<Tuple> anchors, List<Object> tuple) -
Uses of Tuple in org.apache.storm.flux.examples
Methods in org.apache.storm.flux.examples with parameters of type TupleModifier and TypeMethodDescriptionvoid
void
TestPrintBolt.execute
(Tuple tuple, BasicOutputCollector collector) void
WordCounter.execute
(Tuple input, BasicOutputCollector collector) -
Uses of Tuple in org.apache.storm.flux.wrappers.bolts
Methods in org.apache.storm.flux.wrappers.bolts with parameters of type TupleModifier and TypeMethodDescriptionvoid
LogInfoBolt.execute
(Tuple tuple, BasicOutputCollector basicOutputCollector) -
Uses of Tuple in org.apache.storm.hdfs.bolt
Methods in org.apache.storm.hdfs.bolt with parameters of type TupleModifier and TypeMethodDescriptionfinal void
void
void
protected org.apache.hadoop.fs.Path
AbstractHdfsBolt.getBasePathForNextFile
(Tuple tuple) protected abstract String
AbstractHdfsBolt.getWriterKey
(Tuple tuple) protected String
AvroGenericRecordBolt.getWriterKey
(Tuple tuple) AvroGenericRecordBolt must override this method because messages with different schemas cannot be written to the same file.protected String
HdfsBolt.getWriterKey
(Tuple tuple) protected String
SequenceFileBolt.getWriterKey
(Tuple tuple) protected abstract Writer
AbstractHdfsBolt.makeNewWriter
(org.apache.hadoop.fs.Path path, Tuple tuple) protected AbstractHDFSWriter
AvroGenericRecordBolt.makeNewWriter
(org.apache.hadoop.fs.Path path, Tuple tuple) protected AbstractHDFSWriter
HdfsBolt.makeNewWriter
(org.apache.hadoop.fs.Path path, Tuple tuple) protected AbstractHDFSWriter
SequenceFileBolt.makeNewWriter
(org.apache.hadoop.fs.Path path, Tuple tuple) long
-
Uses of Tuple in org.apache.storm.hdfs.bolt.format
Methods in org.apache.storm.hdfs.bolt.format with parameters of type TupleModifier and TypeMethodDescriptionbyte[]
byte[]
org.apache.hadoop.io.Writable
Given a tuple, return the key that should be written to the sequence file.org.apache.hadoop.io.Writable
Given a tuple, return the value that should be written to the sequence file. -
Uses of Tuple in org.apache.storm.hdfs.bolt.rotation
Methods in org.apache.storm.hdfs.bolt.rotation with parameters of type TupleModifier and TypeMethodDescriptionboolean
Called for every tuple the HdfsBolt executes.boolean
boolean
boolean
Called for every tuple the HdfsBolt executes. -
Uses of Tuple in org.apache.storm.hdfs.bolt.sync
Methods in org.apache.storm.hdfs.bolt.sync with parameters of type Tuple -
Uses of Tuple in org.apache.storm.hdfs.common
Methods in org.apache.storm.hdfs.common with parameters of type TupleModifier and TypeMethodDescriptionprotected abstract void
protected void
protected void
protected void
NullPartitioner.getPartitionPath
(Tuple tuple) Partitioner.getPartitionPath
(Tuple tuple) Return a relative path that the tuple should be written to.final long
-
Uses of Tuple in org.apache.storm.hdfs.spout
Methods in org.apache.storm.hdfs.spout with parameters of type Tuple -
Uses of Tuple in org.apache.storm.hive.bolt
Methods in org.apache.storm.hive.bolt with parameters of type Tuple -
Uses of Tuple in org.apache.storm.hive.bolt.mapper
Methods in org.apache.storm.hive.bolt.mapper with parameters of type TupleModifier and TypeMethodDescriptionDelimitedRecordHiveMapper.mapPartitions
(Tuple tuple) HiveMapper.mapPartitions
(Tuple tuple) Given a tuple, return a hive partition values list.JsonRecordHiveMapper.mapPartitions
(Tuple tuple) byte[]
byte[]
Given a tuple, maps to a HiveRecord based on columnFields.byte[]
void
DelimitedRecordHiveMapper.write
(org.apache.hive.hcatalog.streaming.TransactionBatch txnBatch, Tuple tuple) void
void
JsonRecordHiveMapper.write
(org.apache.hive.hcatalog.streaming.TransactionBatch txnBatch, Tuple tuple) -
Uses of Tuple in org.apache.storm.hooks.info
Fields in org.apache.storm.hooks.info declared as TupleConstructors in org.apache.storm.hooks.info with parameters of type TupleModifierConstructorDescriptionBoltAckInfo
(Tuple tuple, int ackingTaskId, Long processLatencyMs) BoltExecuteInfo
(Tuple tuple, int executingTaskId, Long executeLatencyMs) BoltFailInfo
(Tuple tuple, int failingTaskId, Long failLatencyMs) -
Uses of Tuple in org.apache.storm.jdbc.bolt
Methods in org.apache.storm.jdbc.bolt with parameters of type Tuple -
Uses of Tuple in org.apache.storm.jms.bolt
Methods in org.apache.storm.jms.bolt with parameters of type Tuple -
Uses of Tuple in org.apache.storm.jms.example
Methods in org.apache.storm.jms.example with parameters of type Tuple -
Uses of Tuple in org.apache.storm.kafka.bolt
Methods in org.apache.storm.kafka.bolt with parameters of type Tuple -
Uses of Tuple in org.apache.storm.kafka.bolt.mapper
Methods in org.apache.storm.kafka.bolt.mapper with parameters of type TupleModifier and TypeMethodDescriptionFieldNameBasedTupleToKafkaMapper.getKeyFromTuple
(Tuple tuple) TupleToKafkaMapper.getKeyFromTuple
(Tuple tuple) FieldNameBasedTupleToKafkaMapper.getMessageFromTuple
(Tuple tuple) TupleToKafkaMapper.getMessageFromTuple
(Tuple tuple) -
Uses of Tuple in org.apache.storm.kafka.bolt.selector
Methods in org.apache.storm.kafka.bolt.selector with parameters of type Tuple -
Uses of Tuple in org.apache.storm.kafka.spout
Methods in org.apache.storm.kafka.spout with parameters of type Tuple -
Uses of Tuple in org.apache.storm.lambda
Methods in org.apache.storm.lambda with parameters of type TupleModifier and TypeMethodDescriptionvoid
LambdaBiConsumerBolt.execute
(Tuple input, BasicOutputCollector collector) void
LambdaConsumerBolt.execute
(Tuple input, BasicOutputCollector collector) Constructor parameters in org.apache.storm.lambda with type arguments of type TupleModifierConstructorDescriptionLambdaBiConsumerBolt
(SerializableBiConsumer<Tuple, BasicOutputCollector> biConsumer, String[] fields) LambdaConsumerBolt
(SerializableConsumer<Tuple> consumer) -
Uses of Tuple in org.apache.storm.loadgen
Methods in org.apache.storm.loadgen with parameters of type TupleModifier and TypeMethodDescriptionvoid
void
ThroughputVsLatency.SplitSentence.execute
(Tuple tuple, BasicOutputCollector collector) void
ThroughputVsLatency.WordCount.execute
(Tuple tuple, BasicOutputCollector collector) -
Uses of Tuple in org.apache.storm.metric
Methods in org.apache.storm.metric with parameters of type Tuple -
Uses of Tuple in org.apache.storm.perf
Methods in org.apache.storm.perf with parameters of type Tuple -
Uses of Tuple in org.apache.storm.perf.bolt
Methods in org.apache.storm.perf.bolt with parameters of type TupleModifier and TypeMethodDescriptionvoid
CountBolt.execute
(Tuple tuple, BasicOutputCollector collector) void
void
void
SplitSentenceBolt.execute
(Tuple input, BasicOutputCollector collector) -
Uses of Tuple in org.apache.storm.perf.utils
Methods in org.apache.storm.perf.utils with parameters of type Tuple -
Uses of Tuple in org.apache.storm.redis.bolt
Methods in org.apache.storm.redis.bolt with parameters of type Tuple -
Uses of Tuple in org.apache.storm.redis.topology
Methods in org.apache.storm.redis.topology with parameters of type Tuple -
Uses of Tuple in org.apache.storm.serialization
Methods in org.apache.storm.serialization that return TupleMethods in org.apache.storm.serialization with parameters of type Tuple -
Uses of Tuple in org.apache.storm.spout
Methods in org.apache.storm.spout with parameters of type Tuple -
Uses of Tuple in org.apache.storm.sql.runtime.datasource.socket.bolt
Methods in org.apache.storm.sql.runtime.datasource.socket.bolt with parameters of type Tuple -
Uses of Tuple in org.apache.storm.sql.runtime.streams.functions
Methods in org.apache.storm.sql.runtime.streams.functions with parameters of type Tuple -
Uses of Tuple in org.apache.storm.st.topology.window.data
Methods in org.apache.storm.st.topology.window.data with parameters of type Tuple -
Uses of Tuple in org.apache.storm.starter
Methods in org.apache.storm.starter with parameters of type TupleModifier and TypeMethodDescriptionvoid
AnchoredWordCount.SplitSentence.execute
(Tuple tuple, BasicOutputCollector collector) void
AnchoredWordCount.WordCount.execute
(Tuple tuple, BasicOutputCollector collector) void
BasicDRPCTopology.ExclaimBolt.execute
(Tuple tuple, BasicOutputCollector collector) void
BlobStoreAPIWordCountTopology.FilterWords.execute
(Tuple tuple, BasicOutputCollector collector) void
void
FastWordCountTopology.SplitSentence.execute
(Tuple tuple, BasicOutputCollector collector) void
FastWordCountTopology.WordCount.execute
(Tuple tuple, BasicOutputCollector collector) void
InOrderDeliveryTest.Check.execute
(Tuple tuple, BasicOutputCollector collector) void
ManualDRPC.ExclamationBolt.execute
(Tuple tuple, BasicOutputCollector collector) void
void
void
void
ReachTopology.GetFollowers.execute
(Tuple tuple, BasicOutputCollector collector) void
ReachTopology.GetTweeters.execute
(Tuple tuple, BasicOutputCollector collector) void
void
void
StatefulTopology.PrinterBolt.execute
(Tuple tuple, BasicOutputCollector collector) void
WordCountTopologyNode.WordCount.execute
(Tuple tuple, BasicOutputCollector collector) -
Uses of Tuple in org.apache.storm.starter.bolt
Methods in org.apache.storm.starter.bolt with parameters of type TupleModifier and TypeMethodDescriptionfinal void
AbstractRankerBolt.execute
(Tuple tuple, BasicOutputCollector collector) This method functions as a template method (design pattern).void
PrinterBolt.execute
(Tuple tuple, BasicOutputCollector collector) void
void
void
void
WordCountBolt.execute
(Tuple tuple, BasicOutputCollector collector) -
Uses of Tuple in org.apache.storm.starter.tools
Methods in org.apache.storm.starter.tools with parameters of type TupleModifier and TypeMethodDescriptionstatic RankableObjectWithFields
Construct a new instance based on the providedTuple
. -
Uses of Tuple in org.apache.storm.state
Methods in org.apache.storm.state with parameters of type Tuple -
Uses of Tuple in org.apache.storm.streams
Methods in org.apache.storm.streams that return TupleMethods in org.apache.storm.streams that return types with arguments of type TupleModifier and TypeMethodDescriptionStreamBuilder.newStream
(IRichSpout spout) Creates a newStream
of tuples from the givenIRichSpout
.StreamBuilder.newStream
(IRichSpout spout, int parallelism) Creates a newStream
of tuples from the givenIRichSpout
with the given parallelism. -
Uses of Tuple in org.apache.storm.streams.operations.mappers
Methods in org.apache.storm.streams.operations.mappers with parameters of type Tuple -
Uses of Tuple in org.apache.storm.task
Methods in org.apache.storm.task with parameters of type TupleModifier and TypeMethodDescriptionvoid
void
Emits a new tuple to a specific stream with a single anchor.Emits a new tuple to the default stream anchored on a single tuple.void
OutputCollector.emitDirect
(int taskId, String streamId, Tuple anchor, List<Object> tuple) Emits a tuple directly to the specified task id on the specified stream.void
OutputCollector.emitDirect
(int taskId, Tuple anchor, List<Object> tuple) Emits a tuple directly to the specified task id on the default stream.void
Process a single tuple of input.void
void
void
void
IOutputCollector.resetTimeout
(Tuple input) void
OutputCollector.resetTimeout
(Tuple input) Resets the message timeout for any tuple trees to which the given tuple belongs.Method parameters in org.apache.storm.task with type arguments of type TupleModifier and TypeMethodDescriptionReturns the task ids that received the tuples.OutputCollector.emit
(Collection<Tuple> anchors, List<Object> tuple) Emits a new tuple to the default stream anchored on a group of input tuples.void
IOutputCollector.emitDirect
(int taskId, String streamId, Collection<Tuple> anchors, List<Object> tuple) void
OutputCollector.emitDirect
(int taskId, String streamId, Collection<Tuple> anchors, List<Object> tuple) void
OutputCollector.emitDirect
(int taskId, Collection<Tuple> anchors, List<Object> tuple) Emits a tuple directly to the specified task id on the default stream. -
Uses of Tuple in org.apache.storm.testing
Methods in org.apache.storm.testing with parameters of type TupleModifier and TypeMethodDescriptionvoid
IdentityBolt.execute
(Tuple input, BasicOutputCollector collector) void
void
PrepareBatchBolt.execute
(Tuple input, BasicOutputCollector collector) void
void
TestConfBolt.execute
(Tuple input, BasicOutputCollector collector) void
void
void
void
TestWordCounter.execute
(Tuple input, BasicOutputCollector collector) void
protected String
TestWordBytesCounter.getTupleValue
(Tuple t, int idx) protected String
TestWordCounter.getTupleValue
(Tuple t, int idx) -
Uses of Tuple in org.apache.storm.topology
Methods in org.apache.storm.topology that return types with arguments of type TupleModifier and TypeMethodDescriptionprotected WindowLifecycleListener<Tuple>
PersistentWindowedBoltExecutor.newWindowLifecycleListener()
protected WindowLifecycleListener<Tuple>
StatefulWindowedBoltExecutor.newWindowLifecycleListener()
protected WindowLifecycleListener<Tuple>
WindowedBoltExecutor.newWindowLifecycleListener()
Methods in org.apache.storm.topology with parameters of type TupleModifier and TypeMethodDescriptionvoid
void
void
IBasicBolt.execute
(Tuple input, BasicOutputCollector collector) Process the input tuple and optionally emit new tuples based on the input tuple.void
Analogue to bolt function.void
void
void
long
TupleFieldTimestampExtractor.extractTimestamp
(Tuple tuple) protected abstract void
BaseStatefulBoltExecutor.handleCheckpoint
(Tuple checkpointTuple, CheckPointState.Action action, long txid) Sub-classes can implement the logic for handling checkpoint tuple.protected void
CheckpointTupleForwarder.handleCheckpoint
(Tuple checkpointTuple, CheckPointState.Action action, long txid) Forwards the checkpoint tuple downstream.protected void
StatefulBoltExecutor.handleCheckpoint
(Tuple checkpointTuple, CheckPointState.Action action, long txid) protected abstract void
BaseStatefulBoltExecutor.handleTuple
(Tuple input) Sub-classes can implement the logic for handling the tuple.protected void
CheckpointTupleForwarder.handleTuple
(Tuple input) Hands off tuple to the wrapped bolt to execute.protected void
StatefulBoltExecutor.handleTuple
(Tuple input) void
BasicOutputCollector.resetTimeout
(Tuple tuple) Resets the message timeout for any tuple trees to which the given tuple belongs.void
IBasicOutputCollector.resetTimeout
(Tuple tuple) void
BasicOutputCollector.setContext
(Tuple inputTuple) Method parameters in org.apache.storm.topology with type arguments of type TupleModifier and TypeMethodDescriptionprotected void
WindowedBoltExecutor.boltExecute
(Supplier<Iterator<Tuple>> tuples, Supplier<Iterator<Tuple>> newTuples, Supplier<Iterator<Tuple>> expiredTuples, Long timestamp) protected void
WindowedBoltExecutor.boltExecute
(List<Tuple> tuples, List<Tuple> newTuples, List<Tuple> expiredTuples, Long timestamp) protected void
WindowedBoltExecutor.doPrepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector, Collection<Event<Tuple>> queue, boolean stateful) TopologyBuilder.setBolt
(String id, SerializableBiConsumer<Tuple, BasicOutputCollector> biConsumer, Number parallelismHint, String... fields) Define a new bolt in this topology.TopologyBuilder.setBolt
(String id, SerializableBiConsumer<Tuple, BasicOutputCollector> biConsumer, String... fields) Define a new bolt in this topology.TopologyBuilder.setBolt
(String id, SerializableConsumer<Tuple> consumer) Define a new bolt in this topology.TopologyBuilder.setBolt
(String id, SerializableConsumer<Tuple> consumer, Number parallelismHint) Define a new bolt in this topology. -
Uses of Tuple in org.apache.storm.topology.base
Methods in org.apache.storm.topology.base with parameters of type TupleModifier and TypeMethodDescriptionvoid
Process a single tuple of input.protected void
BaseTickTupleAwareRichBolt.onTickTuple
(Tuple tuple) Process a single tick tuple of input.protected abstract void
Process a single non-tick tuple of input. -
Uses of Tuple in org.apache.storm.trident.planner
Methods in org.apache.storm.trident.planner with parameters of type Tuple -
Uses of Tuple in org.apache.storm.trident.spout
Methods in org.apache.storm.trident.spout with parameters of type Tuple -
Uses of Tuple in org.apache.storm.trident.topology
Methods in org.apache.storm.trident.topology with parameters of type Tuple -
Uses of Tuple in org.apache.storm.trident.tuple
Methods in org.apache.storm.trident.tuple with parameters of type Tuple -
Uses of Tuple in org.apache.storm.tuple
Classes in org.apache.storm.tuple that implement TupleFields in org.apache.storm.tuple declared as TupleMethods in org.apache.storm.tuple that return TupleConstructors in org.apache.storm.tuple with parameters of type Tuple -
Uses of Tuple in org.apache.storm.utils
Methods in org.apache.storm.utils that return types with arguments of type TupleMethods in org.apache.storm.utils with parameters of type Tuple -
Uses of Tuple in org.apache.storm.windowing
Methods in org.apache.storm.windowing that return types with arguments of type TupleModifier and TypeMethodDescriptionTupleWindowImpl.get()
TupleWindowIterImpl.get()
TupleWindowImpl.getExpired()
TupleWindowIterImpl.getExpired()
TupleWindowIterImpl.getIter()
TupleWindowImpl.getNew()
TupleWindowIterImpl.getNew()
Methods in org.apache.storm.windowing with parameters of type TupleModifier and TypeMethodDescriptionlong
TimestampExtractor.extractTimestamp
(Tuple tuple) Return the tuple timestamp indicating the time when the event happened.Constructor parameters in org.apache.storm.windowing with type arguments of type TupleModifierConstructorDescriptionTupleWindowImpl
(List<Tuple> tuples, List<Tuple> newTuples, List<Tuple> expiredTuples, Long startTimestamp, Long endTimestamp) TupleWindowIterImpl
(Supplier<Iterator<Tuple>> tuplesIt, Supplier<Iterator<Tuple>> newTuplesIt, Supplier<Iterator<Tuple>> expiredTuplesIt, Long startTimestamp, Long endTimestamp)