Uses of Interface
org.apache.storm.tuple.Tuple
Package
Description
ElasticSearch examples classes.
-
Uses of Tuple in org.apache.storm
-
Uses of Tuple in org.apache.storm.bolt
Modifier and TypeMethodDescriptionprotected Object
JoinBolt.lookupField
(JoinBolt.FieldSelector fieldSelector, Tuple tuple) Modifier 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
ModifierConstructorDescriptionResultRecord
(JoinBolt.ResultRecord lhs, Tuple rhs, boolean generateOutputFields) ResultRecord
(Tuple tuple, boolean generateOutputFields) -
Uses of Tuple in org.apache.storm.clojure
-
Uses of Tuple in org.apache.storm.coordination
Modifier and TypeMethodDescriptionvoid
void
void
void
void
void
void
void
CoordinatedBolt.CoordinatedOutputCollector.resetTimeout
(Tuple tuple) Modifier 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
-
Uses of Tuple in org.apache.storm.drpc
-
Uses of Tuple in org.apache.storm.elasticsearch.bolt
-
Uses of Tuple in org.apache.storm.executor.bolt
Modifier and TypeMethodDescriptionvoid
void
void
BoltOutputCollectorImpl.resetTimeout
(Tuple input) Modifier and TypeMethodDescriptionvoid
BoltOutputCollectorImpl.emitDirect
(int taskId, String streamId, Collection<Tuple> anchors, List<Object> tuple) -
Uses of Tuple in org.apache.storm.flux.examples
Modifier 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
Modifier and TypeMethodDescriptionvoid
LogInfoBolt.execute
(Tuple tuple, BasicOutputCollector basicOutputCollector) -
Uses of Tuple in org.apache.storm.hdfs.bolt
Modifier 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
Modifier 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
Modifier 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
-
Uses of Tuple in org.apache.storm.hdfs.common
Modifier 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
-
Uses of Tuple in org.apache.storm.hive.bolt
-
Uses of Tuple in org.apache.storm.hive.bolt.mapper
Modifier 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
ModifierConstructorDescriptionBoltAckInfo
(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
-
Uses of Tuple in org.apache.storm.jms.bolt
-
Uses of Tuple in org.apache.storm.jms.example
-
Uses of Tuple in org.apache.storm.kafka.bolt
-
Uses of Tuple in org.apache.storm.kafka.bolt.mapper
Modifier 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
-
Uses of Tuple in org.apache.storm.kafka.spout
-
Uses of Tuple in org.apache.storm.lambda
Modifier and TypeMethodDescriptionvoid
LambdaBiConsumerBolt.execute
(Tuple input, BasicOutputCollector collector) void
LambdaConsumerBolt.execute
(Tuple input, BasicOutputCollector collector) ModifierConstructorDescriptionLambdaBiConsumerBolt
(SerializableBiConsumer<Tuple, BasicOutputCollector> biConsumer, String[] fields) LambdaConsumerBolt
(SerializableConsumer<Tuple> consumer) -
Uses of Tuple in org.apache.storm.loadgen
Modifier 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
-
Uses of Tuple in org.apache.storm.perf
-
Uses of Tuple in org.apache.storm.perf.bolt
Modifier 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
-
Uses of Tuple in org.apache.storm.redis.bolt
-
Uses of Tuple in org.apache.storm.redis.topology
-
Uses of Tuple in org.apache.storm.serialization
-
Uses of Tuple in org.apache.storm.spout
-
Uses of Tuple in org.apache.storm.sql.runtime.datasource.socket.bolt
-
Uses of Tuple in org.apache.storm.sql.runtime.streams.functions
-
Uses of Tuple in org.apache.storm.st.topology.window.data
-
Uses of Tuple in org.apache.storm.starter
Modifier 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
Modifier 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
Modifier and TypeMethodDescriptionstatic RankableObjectWithFields
Construct a new instance based on the providedTuple
. -
Uses of Tuple in org.apache.storm.state
-
Uses of Tuple in org.apache.storm.streams
Modifier 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
-
Uses of Tuple in org.apache.storm.task
Modifier 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.Modifier 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
Modifier 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
Modifier and TypeMethodDescriptionprotected WindowLifecycleListener<Tuple>
PersistentWindowedBoltExecutor.newWindowLifecycleListener()
protected WindowLifecycleListener<Tuple>
StatefulWindowedBoltExecutor.newWindowLifecycleListener()
protected WindowLifecycleListener<Tuple>
WindowedBoltExecutor.newWindowLifecycleListener()
Modifier 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) Modifier 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
Modifier 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
-
Uses of Tuple in org.apache.storm.trident.spout
-
Uses of Tuple in org.apache.storm.trident.topology
-
Uses of Tuple in org.apache.storm.trident.tuple
-
Uses of Tuple in org.apache.storm.tuple
-
Uses of Tuple in org.apache.storm.utils
-
Uses of Tuple in org.apache.storm.windowing
Modifier and TypeMethodDescriptionTupleWindowImpl.get()
TupleWindowIterImpl.get()
TupleWindowImpl.getExpired()
TupleWindowIterImpl.getExpired()
TupleWindowIterImpl.getIter()
TupleWindowImpl.getNew()
TupleWindowIterImpl.getNew()
Modifier and TypeMethodDescriptionlong
TimestampExtractor.extractTimestamp
(Tuple tuple) Return the tuple timestamp indicating the time when the event happened.ModifierConstructorDescriptionTupleWindowImpl
(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)