Uses of Interface
org.apache.storm.tuple.Tuple
Packages that use Tuple
Package
Description
- 
Uses of Tuple in org.apache.stormMethods in org.apache.storm that return TupleModifier and TypeMethodDescriptionstatic TupleCreate aTuplefor use with testing.static TupleTesting.testTuple(List<Object> values, MkTupleParam param) Create aTuplefor use with testing.Methods in org.apache.storm with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.boltMethods in org.apache.storm.bolt with parameters of type TupleModifier and TypeMethodDescriptionprotected ObjectJoinBolt.lookupField(JoinBolt.FieldSelector fieldSelector, Tuple tuple) Method parameters in org.apache.storm.bolt with type arguments of type TupleModifier and TypeMethodDescriptionprotected JoinBolt.JoinAccumulatorJoinBolt.doInnerJoin(JoinBolt.JoinAccumulator probe, Map<Object, ArrayList<Tuple>> buildInput, JoinBolt.JoinInfo joinInfo, boolean finalJoin) protected JoinBolt.JoinAccumulatorJoinBolt.doJoin(JoinBolt.JoinAccumulator probe, HashMap<Object, ArrayList<Tuple>> buildInput, JoinBolt.JoinInfo joinInfo, boolean finalJoin) protected JoinBolt.JoinAccumulatorJoinBolt.doLeftJoin(JoinBolt.JoinAccumulator probe, Map<Object, ArrayList<Tuple>> buildInput, JoinBolt.JoinInfo joinInfo, boolean finalJoin) JoinBolt.doProjection(ArrayList<Tuple> tuples, JoinBolt.FieldSelector[] projectionFields) protected JoinBolt.JoinAccumulatorConstructors 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.clojureClasses 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.coordinationMethods in org.apache.storm.coordination with parameters of type TupleModifier and TypeMethodDescriptionvoidvoidvoidvoidvoidvoidvoidvoidCoordinatedBolt.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) voidCoordinatedBolt.CoordinatedOutputCollector.emitDirect(int task, String stream, Collection<Tuple> anchors, List<Object> tuple) 
- 
Uses of Tuple in org.apache.storm.daemonMethods 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.drpcMethods in org.apache.storm.drpc with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.executor.boltMethods in org.apache.storm.executor.bolt with parameters of type TupleModifier and TypeMethodDescriptionvoidvoidvoidBoltOutputCollectorImpl.resetTimeout(Tuple input) Method parameters in org.apache.storm.executor.bolt with type arguments of type TupleModifier and TypeMethodDescriptionvoidBoltOutputCollectorImpl.emitDirect(int taskId, String streamId, Collection<Tuple> anchors, List<Object> tuple) 
- 
Uses of Tuple in org.apache.storm.flux.examplesMethods in org.apache.storm.flux.examples with parameters of type TupleModifier and TypeMethodDescriptionvoidvoidTestPrintBolt.execute(Tuple tuple, BasicOutputCollector collector) voidWordCounter.execute(Tuple input, BasicOutputCollector collector) 
- 
Uses of Tuple in org.apache.storm.flux.wrappers.boltsMethods in org.apache.storm.flux.wrappers.bolts with parameters of type TupleModifier and TypeMethodDescriptionvoidLogInfoBolt.execute(Tuple tuple, BasicOutputCollector basicOutputCollector) 
- 
Uses of Tuple in org.apache.storm.hdfs.boltMethods in org.apache.storm.hdfs.bolt with parameters of type TupleModifier and TypeMethodDescriptionfinal voidvoidvoidprotected org.apache.hadoop.fs.PathAbstractHdfsBolt.getBasePathForNextFile(Tuple tuple) protected abstract StringAbstractHdfsBolt.getWriterKey(Tuple tuple) protected StringAvroGenericRecordBolt.getWriterKey(Tuple tuple) AvroGenericRecordBolt must override this method because messages with different schemas cannot be written to the same file.protected StringHdfsBolt.getWriterKey(Tuple tuple) protected StringSequenceFileBolt.getWriterKey(Tuple tuple) protected abstract WriterAbstractHdfsBolt.makeNewWriter(org.apache.hadoop.fs.Path path, Tuple tuple) protected AbstractHDFSWriterAvroGenericRecordBolt.makeNewWriter(org.apache.hadoop.fs.Path path, Tuple tuple) protected AbstractHDFSWriterHdfsBolt.makeNewWriter(org.apache.hadoop.fs.Path path, Tuple tuple) protected AbstractHDFSWriterSequenceFileBolt.makeNewWriter(org.apache.hadoop.fs.Path path, Tuple tuple) long
- 
Uses of Tuple in org.apache.storm.hdfs.bolt.formatMethods in org.apache.storm.hdfs.bolt.format with parameters of type TupleModifier and TypeMethodDescriptionbyte[]byte[]org.apache.hadoop.io.WritableGiven a tuple, return the key that should be written to the sequence file.org.apache.hadoop.io.WritableGiven a tuple, return the value that should be written to the sequence file.
- 
Uses of Tuple in org.apache.storm.hdfs.bolt.rotationMethods in org.apache.storm.hdfs.bolt.rotation with parameters of type TupleModifier and TypeMethodDescriptionbooleanCalled for every tuple the HdfsBolt executes.booleanbooleanbooleanCalled for every tuple the HdfsBolt executes.
- 
Uses of Tuple in org.apache.storm.hdfs.bolt.syncMethods in org.apache.storm.hdfs.bolt.sync with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.hdfs.commonMethods in org.apache.storm.hdfs.common with parameters of type TupleModifier and TypeMethodDescriptionprotected abstract voidprotected voidprotected voidprotected voidNullPartitioner.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.spoutMethods in org.apache.storm.hdfs.spout with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.hooks.infoFields 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.boltMethods in org.apache.storm.jdbc.bolt with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.jms.boltMethods in org.apache.storm.jms.bolt with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.jms.exampleMethods in org.apache.storm.jms.example with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.kafka.boltMethods in org.apache.storm.kafka.bolt with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.kafka.bolt.mapperMethods 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.selectorMethods in org.apache.storm.kafka.bolt.selector with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.kafka.spoutMethods in org.apache.storm.kafka.spout with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.lambdaMethods in org.apache.storm.lambda with parameters of type TupleModifier and TypeMethodDescriptionvoidLambdaBiConsumerBolt.execute(Tuple input, BasicOutputCollector collector) voidLambdaConsumerBolt.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.loadgenMethods in org.apache.storm.loadgen with parameters of type TupleModifier and TypeMethodDescriptionvoidvoidThroughputVsLatency.SplitSentence.execute(Tuple tuple, BasicOutputCollector collector) voidThroughputVsLatency.WordCount.execute(Tuple tuple, BasicOutputCollector collector) 
- 
Uses of Tuple in org.apache.storm.metricMethods in org.apache.storm.metric with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.perfMethods in org.apache.storm.perf with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.perf.boltMethods in org.apache.storm.perf.bolt with parameters of type TupleModifier and TypeMethodDescriptionvoidCountBolt.execute(Tuple tuple, BasicOutputCollector collector) voidvoidvoidSplitSentenceBolt.execute(Tuple input, BasicOutputCollector collector) 
- 
Uses of Tuple in org.apache.storm.perf.utilsMethods in org.apache.storm.perf.utils with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.redis.boltMethods in org.apache.storm.redis.bolt with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.redis.topologyMethods in org.apache.storm.redis.topology with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.serializationMethods 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.spoutMethods in org.apache.storm.spout with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.sql.runtime.datasource.socket.boltMethods in org.apache.storm.sql.runtime.datasource.socket.bolt with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.sql.runtime.streams.functionsMethods in org.apache.storm.sql.runtime.streams.functions with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.st.topology.window.dataMethods in org.apache.storm.st.topology.window.data with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.starterMethods in org.apache.storm.starter with parameters of type TupleModifier and TypeMethodDescriptionvoidAnchoredWordCount.SplitSentence.execute(Tuple tuple, BasicOutputCollector collector) voidAnchoredWordCount.WordCount.execute(Tuple tuple, BasicOutputCollector collector) voidBasicDRPCTopology.ExclaimBolt.execute(Tuple tuple, BasicOutputCollector collector) voidBlobStoreAPIWordCountTopology.FilterWords.execute(Tuple tuple, BasicOutputCollector collector) voidvoidFastWordCountTopology.SplitSentence.execute(Tuple tuple, BasicOutputCollector collector) voidFastWordCountTopology.WordCount.execute(Tuple tuple, BasicOutputCollector collector) voidInOrderDeliveryTest.Check.execute(Tuple tuple, BasicOutputCollector collector) voidManualDRPC.ExclamationBolt.execute(Tuple tuple, BasicOutputCollector collector) voidvoidvoidvoidReachTopology.GetFollowers.execute(Tuple tuple, BasicOutputCollector collector) voidReachTopology.GetTweeters.execute(Tuple tuple, BasicOutputCollector collector) voidvoidvoidStatefulTopology.PrinterBolt.execute(Tuple tuple, BasicOutputCollector collector) voidWordCountTopologyNode.WordCount.execute(Tuple tuple, BasicOutputCollector collector) 
- 
Uses of Tuple in org.apache.storm.starter.boltMethods in org.apache.storm.starter.bolt with parameters of type TupleModifier and TypeMethodDescriptionfinal voidAbstractRankerBolt.execute(Tuple tuple, BasicOutputCollector collector) This method functions as a template method (design pattern).voidPrinterBolt.execute(Tuple tuple, BasicOutputCollector collector) voidvoidvoidvoidWordCountBolt.execute(Tuple tuple, BasicOutputCollector collector) 
- 
Uses of Tuple in org.apache.storm.starter.toolsMethods in org.apache.storm.starter.tools with parameters of type TupleModifier and TypeMethodDescriptionstatic RankableObjectWithFieldsConstruct a new instance based on the providedTuple.
- 
Uses of Tuple in org.apache.storm.stateMethods in org.apache.storm.state with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.streamsMethods 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 newStreamof tuples from the givenIRichSpout.StreamBuilder.newStream(IRichSpout spout, int parallelism) Creates a newStreamof tuples from the givenIRichSpoutwith the given parallelism.
- 
Uses of Tuple in org.apache.storm.streams.operations.mappersMethods in org.apache.storm.streams.operations.mappers with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.taskMethods in org.apache.storm.task with parameters of type TupleModifier and TypeMethodDescriptionvoidvoidEmits a new tuple to a specific stream with a single anchor.Emits a new tuple to the default stream anchored on a single tuple.voidOutputCollector.emitDirect(int taskId, String streamId, Tuple anchor, List<Object> tuple) Emits a tuple directly to the specified task id on the specified stream.voidOutputCollector.emitDirect(int taskId, Tuple anchor, List<Object> tuple) Emits a tuple directly to the specified task id on the default stream.voidProcess a single tuple of input.voidvoidvoidvoidIOutputCollector.resetTimeout(Tuple input) voidOutputCollector.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.voidIOutputCollector.emitDirect(int taskId, String streamId, Collection<Tuple> anchors, List<Object> tuple) voidOutputCollector.emitDirect(int taskId, String streamId, Collection<Tuple> anchors, List<Object> tuple) voidOutputCollector.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.testingMethods in org.apache.storm.testing with parameters of type TupleModifier and TypeMethodDescriptionvoidIdentityBolt.execute(Tuple input, BasicOutputCollector collector) voidvoidPrepareBatchBolt.execute(Tuple input, BasicOutputCollector collector) voidvoidTestConfBolt.execute(Tuple input, BasicOutputCollector collector) voidvoidvoidvoidTestWordCounter.execute(Tuple input, BasicOutputCollector collector) voidprotected StringTestWordBytesCounter.getTupleValue(Tuple t, int idx) protected StringTestWordCounter.getTupleValue(Tuple t, int idx) 
- 
Uses of Tuple in org.apache.storm.topologyMethods 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 TypeMethodDescriptionvoidvoidvoidIBasicBolt.execute(Tuple input, BasicOutputCollector collector) Process the input tuple and optionally emit new tuples based on the input tuple.voidAnalogue to bolt function.voidvoidvoidlongTupleFieldTimestampExtractor.extractTimestamp(Tuple tuple) protected abstract voidBaseStatefulBoltExecutor.handleCheckpoint(Tuple checkpointTuple, CheckPointState.Action action, long txid) Sub-classes can implement the logic for handling checkpoint tuple.protected voidCheckpointTupleForwarder.handleCheckpoint(Tuple checkpointTuple, CheckPointState.Action action, long txid) Forwards the checkpoint tuple downstream.protected voidStatefulBoltExecutor.handleCheckpoint(Tuple checkpointTuple, CheckPointState.Action action, long txid) protected abstract voidBaseStatefulBoltExecutor.handleTuple(Tuple input) Sub-classes can implement the logic for handling the tuple.protected voidCheckpointTupleForwarder.handleTuple(Tuple input) Hands off tuple to the wrapped bolt to execute.protected voidStatefulBoltExecutor.handleTuple(Tuple input) voidBasicOutputCollector.resetTimeout(Tuple tuple) Resets the message timeout for any tuple trees to which the given tuple belongs.voidIBasicOutputCollector.resetTimeout(Tuple tuple) voidBasicOutputCollector.setContext(Tuple inputTuple) Method parameters in org.apache.storm.topology with type arguments of type TupleModifier and TypeMethodDescriptionprotected voidWindowedBoltExecutor.boltExecute(Supplier<Iterator<Tuple>> tuples, Supplier<Iterator<Tuple>> newTuples, Supplier<Iterator<Tuple>> expiredTuples, Long timestamp) protected voidWindowedBoltExecutor.boltExecute(List<Tuple> tuples, List<Tuple> newTuples, List<Tuple> expiredTuples, Long timestamp) protected voidWindowedBoltExecutor.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.baseMethods in org.apache.storm.topology.base with parameters of type TupleModifier and TypeMethodDescriptionvoidProcess a single tuple of input.protected voidBaseTickTupleAwareRichBolt.onTickTuple(Tuple tuple) Process a single tick tuple of input.protected abstract voidProcess a single non-tick tuple of input.
- 
Uses of Tuple in org.apache.storm.trident.plannerMethods in org.apache.storm.trident.planner with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.trident.spoutMethods in org.apache.storm.trident.spout with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.trident.topologyMethods in org.apache.storm.trident.topology with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.trident.tupleMethods in org.apache.storm.trident.tuple with parameters of type Tuple
- 
Uses of Tuple in org.apache.storm.tupleClasses 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.utilsMethods 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.windowingMethods 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 TypeMethodDescriptionlongTimestampExtractor.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)