| Modifier and Type | Method and Description | 
|---|---|
| static Tuple | Testing. testTuple(List<Object> values)Create a  Tuplefor use with testing. | 
| static Tuple | Testing. testTuple(List<Object> values,
         MkTupleParam param)Create a  Tuplefor use with testing. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ExclamationTopology.ExclamationBolt. execute(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Object | JoinBolt. lookupField(JoinBolt.FieldSelector fieldSelector,
           Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected 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) | 
| protected ArrayList<Object> | JoinBolt. doProjection(ArrayList<Tuple> tuples,
            JoinBolt.FieldSelector[] projectionFields) | 
| protected JoinBolt.JoinAccumulator | JoinBolt. hashJoin(List<Tuple> tuples) | 
| Constructor and Description | 
|---|
| ResultRecord(JoinBolt.ResultRecord lhs,
            Tuple rhs,
            boolean generateOutputFields) | 
| ResultRecord(Tuple tuple,
            boolean generateOutputFields) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | BaseExecutionResultHandler. onDriverException(com.datastax.driver.core.exceptions.DriverException e,
                 OutputCollector collector,
                 Tuple tuple)This method is called when an one of the methods of the  BaseExecutionResultHandleris not overridden. | 
| void | BaseExecutionResultHandler. onQuerySuccess(OutputCollector collector,
              Tuple tuple)Invoked when a query is executed with success. | 
| void | ExecutionResultHandler. onQuerySuccess(OutputCollector collector,
              Tuple tuple)Invoked when a query is executed with success. | 
| void | BaseExecutionResultHandler. onQueryValidationException(com.datastax.driver.core.exceptions.QueryValidationException e,
                          OutputCollector collector,
                          Tuple tuple)Invoked when a  QueryValidationExceptionis thrown. | 
| void | ExecutionResultHandler. onQueryValidationException(com.datastax.driver.core.exceptions.QueryValidationException e,
                          OutputCollector collector,
                          Tuple tuple)Invoked when a  QueryValidationExceptionis thrown. | 
| void | BaseExecutionResultHandler. onReadTimeoutException(com.datastax.driver.core.exceptions.ReadTimeoutException e,
                      OutputCollector collector,
                      Tuple tuple)Invoked when a  ReadTimeoutExceptionis thrown. | 
| void | ExecutionResultHandler. onReadTimeoutException(com.datastax.driver.core.exceptions.ReadTimeoutException e,
                      OutputCollector collector,
                      Tuple tuple)Invoked when a  ReadTimeoutExceptionis thrown. | 
| void | AbstractExecutionResultHandler. onThrowable(Throwable t,
           OutputCollector collector,
           Tuple i) | 
| void | ExecutionResultHandler. onThrowable(Throwable t,
           OutputCollector collector,
           Tuple i)Default method used to handle any type of exception. | 
| void | BaseExecutionResultHandler. onUnavailableException(com.datastax.driver.core.exceptions.UnavailableException e,
                      OutputCollector collector,
                      Tuple tuple)Invoked when a  UnavailableExceptionis thrown. | 
| void | ExecutionResultHandler. onUnavailableException(com.datastax.driver.core.exceptions.UnavailableException e,
                      OutputCollector collector,
                      Tuple tuple)Invoked when a  UnavailableExceptionis thrown. | 
| void | BaseExecutionResultHandler. onWriteTimeoutException(com.datastax.driver.core.exceptions.WriteTimeoutException e,
                       OutputCollector collector,
                       Tuple tuple)Invoked when a  WriteTimeoutExceptionis thrown. | 
| void | ExecutionResultHandler. onWriteTimeoutException(com.datastax.driver.core.exceptions.WriteTimeoutException e,
                       OutputCollector collector,
                       Tuple tuple)Invoked when a  WriteTimeoutExceptionis thrown. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AbstractExecutionResultHandler. onThrowable(Throwable t,
           OutputCollector collector,
           List<Tuple> tl) | 
| void | ExecutionResultHandler. onThrowable(Throwable t,
           OutputCollector collector,
           List<Tuple> tl)Default method used to handle any type of exception. | 
| Modifier and Type | Method and Description | 
|---|---|
| Tuple | PairStatementTuple. getTuple() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected AsyncResultHandler<Tuple> | CassandraWriterBolt. getAsyncHandler() | 
| protected AsyncResultHandler<List<Tuple>> | BatchCassandraWriterBolt. getAsyncHandler() | 
| List<Tuple> | PairBatchStatementTuples. getInputs() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BaseCassandraBolt. execute(Tuple input)Process a single tuple of input. | 
| protected void | BatchCassandraWriterBolt. onTickTuple(Tuple tuple)Process a single tick tuple of input. | 
| protected void | CassandraWriterBolt. process(Tuple input)Process a single non-tick tuple of input. | 
| protected void | BatchCassandraWriterBolt. process(Tuple input)Process a single non-tick tuple of input. | 
| Constructor and Description | 
|---|
| PairStatementTuple(Tuple tuple,
                  com.datastax.driver.core.Statement statement)Creates a new  PairStatementTupleinstance. | 
| Constructor and Description | 
|---|
| PairBatchStatementTuples(List<Tuple> inputs,
                        com.datastax.driver.core.BatchStatement statement)Creates a new  PairBatchStatementTuplesinstance. | 
| Constructor and Description | 
|---|
| FailedCollector(Tuple input,
               Throwable cause)Creates a new  ExecutionResultCollector.FailedCollectorinstance. | 
| SucceedCollector(Tuple input)Creates a new  ExecutionResultCollectorinstance. | 
| Constructor and Description | 
|---|
| FailedCollector(List<Tuple> inputs,
               Throwable cause)Creates a new  ExecutionResultCollector.FailedCollectorinstance. | 
| SucceedCollector(List<Tuple> inputs)Creates a new  ExecutionResultCollectorinstance. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SingleAsyncResultHandler. failure(Throwable t,
       Tuple input)This method is responsible for failing specified inputs. | 
| void | SingleAsyncResultHandler. success(Tuple input)This method is responsible for acknowledging specified inputs. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BatchAsyncResultHandler. failure(Throwable t,
       List<Tuple> input)This method is responsible for failing specified inputs. | 
| void | BatchAsyncResultHandler. success(List<Tuple> input)This method is responsible for acknowledging specified inputs. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClojureTuple | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ClojureBolt. execute(Tuple input) | 
| Constructor and Description | 
|---|
| ClojureTuple(Tuple t) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CoordinatedBolt.CoordinatedOutputCollector. ack(Tuple tuple) | 
| void | BatchOutputCollectorImpl. ack(Tuple tup) | 
| void | CoordinatedBolt. execute(Tuple tuple) | 
| void | IBatchBolt. execute(Tuple tuple) | 
| void | BatchBoltExecutor. execute(Tuple input) | 
| void | CoordinatedBolt.CoordinatedOutputCollector. fail(Tuple tuple) | 
| void | BatchOutputCollectorImpl. fail(Tuple tup) | 
| void | CoordinatedBolt.CoordinatedOutputCollector. resetTimeout(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Integer> | CoordinatedBolt.CoordinatedOutputCollector. emit(String stream,
    Collection<Tuple> anchors,
    List<Object> tuple) | 
| void | CoordinatedBolt.CoordinatedOutputCollector. emitDirect(int task,
          String stream,
          Collection<Tuple> anchors,
          List<Object> tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| Tuple | Task. getTuple(String stream,
        List values) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | Acker. execute(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | KeyedFairBolt. execute(Tuple input) | 
| void | ReturnResults. execute(Tuple input) | 
| void | JoinResult. execute(Tuple tuple) | 
| void | PrepareRequest. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | EsLookupBolt. process(Tuple tuple) | 
| void | EsIndexBolt. process(Tuple tuple)Process a single non-tick tuple of input. | 
| void | EsPercolateBolt. process(Tuple tuple)Process a single non-tick tuple of input. | 
| Modifier and Type | Method and Description | 
|---|---|
| static Tuple | EsTestUtil. generateTestTuple(String source,
                 String index,
                 String type,
                 String id)Generates a test tuple. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | EventHubBolt. execute(Tuple tuple) | 
| byte[] | DefaultEventDataFormat. serialize(Tuple tuple) | 
| byte[] | IEventDataFormat. serialize(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BoltOutputCollectorImpl. ack(Tuple input) | 
| void | BoltOutputCollectorImpl. fail(Tuple input) | 
| void | BoltOutputCollectorImpl. resetTimeout(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Integer> | BoltOutputCollectorImpl. emit(String streamId,
    Collection<Tuple> anchors,
    List<Object> tuple) | 
| void | BoltOutputCollectorImpl. emitDirect(int taskId,
          String streamId,
          Collection<Tuple> anchors,
          List<Object> tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | StatefulWordCounter. execute(Tuple tuple) | 
| void | WordCounter. execute(Tuple input,
       BasicOutputCollector collector) | 
| void | TestPrintBolt. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | LogInfoBolt. execute(Tuple tuple,
       BasicOutputCollector basicOutputCollector) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | HBaseBolt. execute(Tuple tuple) | 
| void | HBaseLookupBolt. execute(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| ColumnList | HBaseMapper. columns(Tuple tuple)Given a tuple, return a list of HBase columns to insert. | 
| ColumnList | SimpleHBaseMapper. columns(Tuple tuple) | 
| byte[] | HBaseMapper. rowKey(Tuple tuple)Given a tuple, return the HBase rowkey. | 
| byte[] | SimpleHBaseMapper. rowKey(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | WordCounter. execute(Tuple input,
       BasicOutputCollector collector) | 
| void | TotalWordCounter. execute(Tuple input,
       BasicOutputCollector collector) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SequenceFileTopology.MyBolt. execute(Tuple tuple) | 
| void | HdfsFileTopology.MyBolt. execute(Tuple tuple) | 
| void | AbstractHdfsBolt. execute(Tuple tuple) | 
| protected org.apache.hadoop.fs.Path | AbstractHdfsBolt. getBasePathForNextFile(Tuple tuple) | 
| protected String | HdfsBolt. getWriterKey(Tuple tuple) | 
| protected String | SequenceFileBolt. 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 abstract String | AbstractHdfsBolt. getWriterKey(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) | 
| protected AbstractHDFSWriter | AvroGenericRecordBolt. makeNewWriter(org.apache.hadoop.fs.Path path,
             Tuple tuple) | 
| protected abstract Writer | AbstractHdfsBolt. makeNewWriter(org.apache.hadoop.fs.Path path,
             Tuple tuple) | 
| long | Writer. write(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| byte[] | DelimitedRecordFormat. format(Tuple tuple) | 
| byte[] | RecordFormat. format(Tuple tuple) | 
| org.apache.hadoop.io.Writable | DefaultSequenceFormat. key(Tuple tuple) | 
| Object | SequenceFormat. key(Tuple tuple)Given a tuple, return the key that should be written to the sequence file. | 
| org.apache.hadoop.io.Writable | DefaultSequenceFormat. value(Tuple tuple) | 
| Object | SequenceFormat. value(Tuple tuple)Given a tuple, return the value that should be written to the sequence file. | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | TimedRotationPolicy. mark(Tuple tuple,
    long offset)Called for every tuple the HdfsBolt executes. | 
| boolean | NoRotationPolicy. mark(Tuple tuple,
    long offset) | 
| boolean | FileRotationPolicy. mark(Tuple tuple,
    long offset)Called for every tuple the HdfsBolt executes. | 
| boolean | FileSizeRotationPolicy. mark(Tuple tuple,
    long offset) | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | CountSyncPolicy. mark(Tuple tuple,
    long offset) | 
| boolean | SyncPolicy. mark(Tuple tuple,
    long offset)Called for every tuple the HdfsBolt executes. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | AvroGenericRecordHDFSWriter. doWrite(Tuple tuple) | 
| protected abstract void | AbstractHDFSWriter. doWrite(Tuple tuple) | 
| protected void | SequenceFileWriter. doWrite(Tuple tuple) | 
| protected void | HDFSWriter. doWrite(Tuple tuple) | 
| String | NullPartitioner. getPartitionPath(Tuple tuple) | 
| String | Partitioner. getPartitionPath(Tuple tuple)Return a relative path that the tuple should be written to. | 
| long | AbstractHDFSWriter. write(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | HdfsSpoutTopology.ConstBolt. execute(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | HiveBolt. execute(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<String> | HiveMapper. mapPartitions(Tuple tuple)Given a tuple, return a hive partition values list. | 
| List<String> | DelimitedRecordHiveMapper. mapPartitions(Tuple tuple) | 
| List<String> | JsonRecordHiveMapper. mapPartitions(Tuple tuple) | 
| byte[] | HiveMapper. mapRecord(Tuple tuple)Given a tuple, maps to a HiveRecord based on columnFields. | 
| byte[] | DelimitedRecordHiveMapper. mapRecord(Tuple tuple) | 
| byte[] | JsonRecordHiveMapper. mapRecord(Tuple tuple) | 
| void | HiveMapper. write(org.apache.hive.hcatalog.streaming.TransactionBatch txnBatch,
     Tuple tuple) | 
| void | DelimitedRecordHiveMapper. write(org.apache.hive.hcatalog.streaming.TransactionBatch txnBatch,
     Tuple tuple) | 
| void | JsonRecordHiveMapper. write(org.apache.hive.hcatalog.streaming.TransactionBatch txnBatch,
     Tuple tuple) | 
| Modifier and Type | Field and Description | 
|---|---|
| Tuple | BoltAckInfo. tuple | 
| Tuple | BoltExecuteInfo. tuple | 
| Tuple | BoltFailInfo. tuple | 
| Constructor and Description | 
|---|
| BoltAckInfo(Tuple tuple,
           int ackingTaskId,
           Long processLatencyMs) | 
| BoltExecuteInfo(Tuple tuple,
               int executingTaskId,
               Long executeLatencyMs) | 
| BoltFailInfo(Tuple tuple,
            int failingTaskId,
            Long failLatencyMs) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | JdbcLookupBolt. process(Tuple tuple) | 
| protected void | JdbcInsertBolt. process(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | JmsBolt. process(Tuple input)Consumes a tuple and sends a JMS message. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | GenericBolt. execute(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | KafkaBolt. process(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| K | FieldNameBasedTupleToKafkaMapper. getKeyFromTuple(Tuple tuple) | 
| K | TupleToKafkaMapper. getKeyFromTuple(Tuple tuple) | 
| V | FieldNameBasedTupleToKafkaMapper. getMessageFromTuple(Tuple tuple) | 
| V | TupleToKafkaMapper. getMessageFromTuple(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| String | KafkaTopicSelector. getTopic(Tuple tuple) | 
| String | FieldNameTopicSelector. getTopic(Tuple tuple) | 
| String | FieldIndexTopicSelector. getTopic(Tuple tuple) | 
| String | DefaultTopicSelector. getTopic(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | KafkaSpoutTestBolt. execute(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | LambdaBiConsumerBolt. execute(Tuple input,
       BasicOutputCollector collector) | 
| void | LambdaConsumerBolt. execute(Tuple input,
       BasicOutputCollector collector) | 
| Constructor and Description | 
|---|
| LambdaBiConsumerBolt(SerializableBiConsumer<Tuple,BasicOutputCollector> biConsumer,
                    String[] fields) | 
| LambdaConsumerBolt(SerializableConsumer<Tuple> consumer) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | LoadBolt. execute(Tuple input) | 
| void | ThroughputVsLatency.SplitSentence. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | ThroughputVsLatency.WordCount. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MetricsConsumerBolt. execute(Tuple input) | 
| void | SystemBolt. execute(Tuple input) | 
| void | EventLoggerBolt. execute(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MongoLookupBolt. execute(Tuple tuple) | 
| void | MongoInsertBolt. execute(Tuple tuple) | 
| void | MongoUpdateBolt. execute(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | WordCounter. execute(Tuple input,
       BasicOutputCollector collector) | 
| void | TotalWordCounter. execute(Tuple input,
       BasicOutputCollector collector) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | MqttBolt. process(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | OpenTsdbBolt. execute(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| byte[] | StrGenSpoutHdfsBoltTopo.LineWriter. format(Tuple tuple) | 
| byte[] | KafkaClientHdfsTopo.LineWriter. format(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | IdBolt. execute(Tuple tuple) | 
| void | DevNullBolt. execute(Tuple tuple) | 
| void | CountBolt. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | SplitSentenceBolt. execute(Tuple input,
       BasicOutputCollector collector) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | IdentityBolt. execute(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | PMMLPredictorBolt. process(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<String,List<Object>> | ModelRunner. scoredTuplePerStream(Tuple input)Creates and returns a map with the predicted scores that are to be emitted on each stream. | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<org.dmg.pmml.FieldName,Object> | JPmmlModelRunner. extractRawInputs(Tuple tuple)Extract raw inputs. | 
| Map<String,List<Object>> | JPmmlModelRunner. scoredTuplePerStream(Tuple input)Retrieve scores. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RedisFilterBolt. process(Tuple input)Process a single non-tick tuple of input. | 
| void | RedisLookupBolt. process(Tuple input)Process a single non-tick tuple of input. | 
| void | RedisStoreBolt. process(Tuple input)Process a single non-tick tuple of input. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | WhitelistWordCount.PrintWordTotalCountBolt. execute(Tuple input) | 
| void | LookupWordCount.PrintWordTotalCountBolt. execute(Tuple input) | 
| void | WordCounter. execute(Tuple input,
       BasicOutputCollector collector) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RocketMqBolt. execute(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | WordCounter. execute(Tuple input,
       BasicOutputCollector collector) | 
| Modifier and Type | Method and Description | 
|---|---|
| Tuple | ITupleDeserializer. deserialize(byte[] ser) | 
| Modifier and Type | Method and Description | 
|---|---|
| byte[] | ITupleSerializer. serialize(Tuple tuple) | 
| byte[] | KryoTupleSerializer. serialize(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | SolrUpdateBolt. process(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| static boolean | CheckpointSpout. isCheckpoint(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SocketBolt. execute(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| Values | StreamsScanTupleValueMapper. apply(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| static TimeData | TimeData. fromTuple(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ResourceAwareExampleTopology.ExclamationBolt. execute(Tuple tuple) | 
| void | MultiThreadWordCountTopology.MultiThreadedSplitSentence. execute(Tuple input) | 
| void | MultipleLoggerTopology.ExclamationLoggingBolt. execute(Tuple tuple) | 
| void | ReachTopology.PartialUniquer. execute(Tuple tuple) | 
| void | ReachTopology.CountAggregator. execute(Tuple tuple) | 
| void | ExclamationTopology.ExclamationBolt. execute(Tuple tuple) | 
| void | ManualDRPC.ExclamationBolt. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | AnchoredWordCount.SplitSentence. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | AnchoredWordCount.WordCount. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | StatefulTopology.PrinterBolt. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | FastWordCountTopology.SplitSentence. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | FastWordCountTopology.WordCount. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | BasicDRPCTopology.ExclaimBolt. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | WordCountTopologyNode.WordCount. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | InOrderDeliveryTest.Check. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | ReachTopology.GetTweeters. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | ReachTopology.GetFollowers. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | BlobStoreAPIWordCountTopology.FilterWords. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RollingCountAggBolt. execute(Tuple tuple) | 
| void | RollingCountBolt. execute(Tuple tuple) | 
| void | SingleJoinBolt. execute(Tuple tuple) | 
| void | PrinterBolt. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | WordCountBolt. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| void | AbstractRankerBolt. execute(Tuple tuple,
       BasicOutputCollector collector)This method functions as a template method (design pattern). | 
| Modifier and Type | Method and Description | 
|---|---|
| static RankableObjectWithFields | RankableObjectWithFields. from(Tuple tuple)Construct a new instance based on the provided  Tuple. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ISubscribedState. set(Object id,
   Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| Tuple | RefCountedTuple. tuple() | 
| Modifier and Type | Method and Description | 
|---|---|
| Stream<Tuple> | StreamBuilder. newStream(IRichSpout spout)Creates a new  Streamof tuples from the givenIRichSpout. | 
| Stream<Tuple> | StreamBuilder. newStream(IRichSpout spout,
         int parallelism)Creates a new  Streamof tuples from the givenIRichSpoutwith the given parallelism. | 
| Modifier and Type | Method and Description | 
|---|---|
| Values | ValuesMapper. apply(Tuple input) | 
| Pair<K,V> | PairValueMapper. apply(Tuple input) | 
| T | ValueMapper. apply(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | OutputCollector. ack(Tuple input) | 
| void | IOutputCollector. ack(Tuple input) | 
| List<Integer> | OutputCollector. emit(String streamId,
    Tuple anchor,
    List<Object> tuple)Emits a new tuple to a specific stream with a single anchor. | 
| List<Integer> | OutputCollector. emit(Tuple anchor,
    List<Object> tuple)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 | ShellBolt. execute(Tuple input) | 
| void | IBolt. execute(Tuple input)Process a single tuple of input. | 
| void | OutputCollector. fail(Tuple input) | 
| void | IOutputCollector. fail(Tuple input) | 
| void | OutputCollector. resetTimeout(Tuple input)Resets the message timeout for any tuple trees to which the given tuple belongs. | 
| void | IOutputCollector. resetTimeout(Tuple input) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Integer> | OutputCollector. emit(Collection<Tuple> anchors,
    List<Object> tuple)Emits a new tuple to the default stream anchored on a group of input tuples. | 
| List<Integer> | OutputCollector. emit(String streamId,
    Collection<Tuple> anchors,
    List<Object> tuple) | 
| List<Integer> | IOutputCollector. emit(String streamId,
    Collection<Tuple> anchors,
    List<Object> tuple)Returns the task ids that received the tuples. | 
| void | OutputCollector. emitDirect(int taskId,
          Collection<Tuple> anchors,
          List<Object> tuple)Emits a tuple directly to the specified task id on the default stream. | 
| void | OutputCollector. emitDirect(int taskId,
          String streamId,
          Collection<Tuple> anchors,
          List<Object> tuple) | 
| void | IOutputCollector. emitDirect(int taskId,
          String streamId,
          Collection<Tuple> anchors,
          List<Object> tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | TupleCaptureBolt. execute(Tuple input) | 
| void | NonRichBoltTracker. execute(Tuple input) | 
| void | TestPlannerBolt. execute(Tuple input) | 
| void | TestAggregatesCounter. execute(Tuple input) | 
| void | TestGlobalCount. execute(Tuple input) | 
| void | TestEventOrderCheckBolt. execute(Tuple input) | 
| void | TestConfBolt. execute(Tuple input,
       BasicOutputCollector collector) | 
| void | PrepareBatchBolt. execute(Tuple input,
       BasicOutputCollector collector) | 
| void | IdentityBolt. execute(Tuple input,
       BasicOutputCollector collector) | 
| void | TestWordCounter. execute(Tuple input,
       BasicOutputCollector collector) | 
| protected String | TestWordBytesCounter. getTupleValue(Tuple t,
             int idx) | 
| protected String | TestWordCounter. getTupleValue(Tuple t,
             int idx) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected WindowLifecycleListener<Tuple> | StatefulWindowedBoltExecutor. newWindowLifecycleListener() | 
| protected WindowLifecycleListener<Tuple> | PersistentWindowedBoltExecutor. newWindowLifecycleListener() | 
| protected WindowLifecycleListener<Tuple> | WindowedBoltExecutor. newWindowLifecycleListener() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BaseStatefulBoltExecutor. execute(Tuple input) | 
| void | StatefulWindowedBoltExecutor. execute(Tuple input) | 
| void | IStatefulBolt. execute(Tuple input)Analogue to bolt function. | 
| void | PersistentWindowedBoltExecutor. execute(Tuple input) | 
| void | BasicBoltExecutor. execute(Tuple input) | 
| void | WindowedBoltExecutor. execute(Tuple input) | 
| void | IBasicBolt. execute(Tuple input,
       BasicOutputCollector collector)Process the input tuple and optionally emit new tuples based on the input tuple. | 
| long | TupleFieldTimestampExtractor. extractTimestamp(Tuple tuple) | 
| protected void | StatefulBoltExecutor. handleCheckpoint(Tuple checkpointTuple,
                CheckPointState.Action action,
                long txid) | 
| 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. handleTuple(Tuple input) | 
| 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. | 
| void | IBasicOutputCollector. resetTimeout(Tuple tuple) | 
| void | BasicOutputCollector. resetTimeout(Tuple tuple)Resets the message timeout for any tuple trees to which the given tuple belongs. | 
| void | BasicOutputCollector. setContext(Tuple inputTuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | WindowedBoltExecutor. boltExecute(List<Tuple> tuples,
           List<Tuple> newTuples,
           List<Tuple> expiredTuples,
           Long timestamp) | 
| protected void | WindowedBoltExecutor. boltExecute(List<Tuple> tuples,
           List<Tuple> newTuples,
           List<Tuple> expiredTuples,
           Long timestamp) | 
| protected void | WindowedBoltExecutor. boltExecute(List<Tuple> tuples,
           List<Tuple> newTuples,
           List<Tuple> expiredTuples,
           Long timestamp) | 
| protected void | WindowedBoltExecutor. boltExecute(Supplier<Iterator<Tuple>> tuples,
           Supplier<Iterator<Tuple>> newTuples,
           Supplier<Iterator<Tuple>> expiredTuples,
           Long timestamp) | 
| protected void | WindowedBoltExecutor. boltExecute(Supplier<Iterator<Tuple>> tuples,
           Supplier<Iterator<Tuple>> newTuples,
           Supplier<Iterator<Tuple>> expiredTuples,
           Long timestamp) | 
| protected void | WindowedBoltExecutor. boltExecute(Supplier<Iterator<Tuple>> tuples,
           Supplier<Iterator<Tuple>> newTuples,
           Supplier<Iterator<Tuple>> expiredTuples,
           Long timestamp) | 
| protected void | WindowedBoltExecutor. doPrepare(Map<String,Object> topoConf,
         TopologyContext context,
         OutputCollector collector,
         Collection<Event<Tuple>> queue,
         boolean stateful) | 
| BoltDeclarer | TopologyBuilder. setBolt(String id,
       SerializableBiConsumer<Tuple,BasicOutputCollector> biConsumer,
       Number parallelismHint,
       String... fields)Define a new bolt in this topology. | 
| BoltDeclarer | TopologyBuilder. setBolt(String id,
       SerializableBiConsumer<Tuple,BasicOutputCollector> biConsumer,
       String... fields)Define a new bolt in this topology. | 
| BoltDeclarer | TopologyBuilder. setBolt(String id,
       SerializableConsumer<Tuple> consumer)Define a new bolt in this topology. | 
| BoltDeclarer | TopologyBuilder. setBolt(String id,
       SerializableConsumer<Tuple> consumer,
       Number parallelismHint)Define a new bolt in this topology. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BaseTickTupleAwareRichBolt. execute(Tuple tuple)Process a single tuple of input. | 
| protected void | BaseTickTupleAwareRichBolt. onTickTuple(Tuple tuple)Process a single tick tuple of input. | 
| protected abstract void | BaseTickTupleAwareRichBolt. process(Tuple tuple)Process a single non-tick tuple of input. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SubtopologyBolt. execute(BatchInfo batchInfo,
       Tuple tuple) | 
| void | SubtopologyBolt.InitialReceiver. receive(ProcessorContext context,
       Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | TridentSpoutExecutor. execute(BatchInfo info,
       Tuple input) | 
| void | TridentSpoutCoordinator. execute(Tuple tuple,
       BasicOutputCollector collector) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ITridentBatchBolt. execute(BatchInfo batchInfo,
       Tuple tuple) | 
| void | TridentBoltExecutor. execute(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| TridentTuple | TridentTupleView.RootFactory. create(Tuple parent) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | TupleImpl | 
| Modifier and Type | Field and Description | 
|---|---|
| Tuple | AddressedTuple. tuple | 
| Modifier and Type | Method and Description | 
|---|---|
| Tuple | AddressedTuple. getTuple() | 
| Constructor and Description | 
|---|
| AddressedTuple(int dest,
              Tuple tuple) | 
| TupleImpl(Tuple t) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Tuple> | BatchHelper. getBatchTuples() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BatchHelper. addBatch(Tuple tuple) | 
| static boolean | TupleUtils. isTick(Tuple tuple) | 
| boolean | BatchHelper. shouldHandle(Tuple tuple) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Tuple> | TupleWindowImpl. get() | 
| List<Tuple> | TupleWindowIterImpl. get() | 
| List<Tuple> | TupleWindowImpl. getExpired() | 
| List<Tuple> | TupleWindowIterImpl. getExpired() | 
| Iterator<Tuple> | TupleWindowIterImpl. getIter() | 
| List<Tuple> | TupleWindowImpl. getNew() | 
| List<Tuple> | TupleWindowIterImpl. getNew() | 
| Modifier and Type | Method and Description | 
|---|---|
| long | TimestampExtractor. extractTimestamp(Tuple tuple)Return the tuple timestamp indicating the time when the event happened. | 
| Constructor and Description | 
|---|
| TupleWindowImpl(List<Tuple> tuples,
               List<Tuple> newTuples,
               List<Tuple> expiredTuples) | 
| TupleWindowImpl(List<Tuple> tuples,
               List<Tuple> newTuples,
               List<Tuple> expiredTuples) | 
| TupleWindowImpl(List<Tuple> tuples,
               List<Tuple> newTuples,
               List<Tuple> expiredTuples) | 
| TupleWindowImpl(List<Tuple> tuples,
               List<Tuple> newTuples,
               List<Tuple> expiredTuples,
               Long startTimestamp,
               Long endTimestamp) | 
| TupleWindowImpl(List<Tuple> tuples,
               List<Tuple> newTuples,
               List<Tuple> expiredTuples,
               Long startTimestamp,
               Long endTimestamp) | 
| TupleWindowImpl(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) | 
| TupleWindowIterImpl(Supplier<Iterator<Tuple>> tuplesIt,
                   Supplier<Iterator<Tuple>> newTuplesIt,
                   Supplier<Iterator<Tuple>> expiredTuplesIt,
                   Long startTimestamp,
                   Long endTimestamp) | 
| TupleWindowIterImpl(Supplier<Iterator<Tuple>> tuplesIt,
                   Supplier<Iterator<Tuple>> newTuplesIt,
                   Supplier<Iterator<Tuple>> expiredTuplesIt,
                   Long startTimestamp,
                   Long endTimestamp) | 
Copyright © 2022 The Apache Software Foundation. All rights reserved.