Modifier and Type | Class and Description |
---|---|
static class |
ExclamationTopology.ExclamationBolt |
Modifier and Type | Class and Description |
---|---|
class |
BaseCassandraBolt<T>
A base cassandra bolt.
|
class |
BatchCassandraWriterBolt |
class |
CassandraWriterBolt |
Modifier and Type | Class and Description |
---|---|
class |
ClojureBolt |
class |
RichShellBolt |
Modifier and Type | Class and Description |
---|---|
class |
BatchBoltExecutor |
class |
CoordinatedBolt
Coordination requires the request ids to be globally unique for awhile.
|
Constructor and Description |
---|
CoordinatedBolt(IRichBolt delegate) |
CoordinatedBolt(IRichBolt delegate,
Map<String,CoordinatedBolt.SourceArgs> sourceArgs,
CoordinatedBolt.IdStreamSpec idStreamSpec) |
CoordinatedBolt(IRichBolt delegate,
String sourceComponent,
CoordinatedBolt.SourceArgs sourceArgs,
CoordinatedBolt.IdStreamSpec idStreamSpec) |
Modifier and Type | Class and Description |
---|---|
class |
JoinResult |
class |
KeyedFairBolt |
class |
ReturnResults |
Modifier and Type | Method and Description |
---|---|
LinearDRPCInputDeclarer |
LinearDRPCTopologyBuilder.addBolt(IRichBolt bolt)
Deprecated.
|
LinearDRPCInputDeclarer |
LinearDRPCTopologyBuilder.addBolt(IRichBolt bolt,
Number parallelism)
Deprecated.
|
Constructor and Description |
---|
KeyedFairBolt(IRichBolt delegate) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractEsBolt |
class |
EsIndexBolt
Basic bolt for storing tuple to ES document.
|
class |
EsLookupBolt
Basic bolt for looking up document in ES.
|
class |
EsPercolateBolt
Basic bolt for retrieve matched percolate queries.
|
Modifier and Type | Class and Description |
---|---|
class |
EventHubBolt
A bolt that writes event message to EventHub.
|
Modifier and Type | Class and Description |
---|---|
class |
FluxShellBolt
A generic
ShellBolt implementation that allows you specify output fields and even streams without having to subclass ShellBolt to do so. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractHBaseBolt |
class |
HBaseBolt
Basic bolt for writing to HBase.
|
class |
HBaseLookupBolt
Basic bolt for querying from HBase.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractHdfsBolt |
class |
AvroGenericRecordBolt |
class |
HdfsBolt |
static class |
HdfsFileTopology.MyBolt |
class |
SequenceFileBolt |
static class |
SequenceFileTopology.MyBolt |
Modifier and Type | Class and Description |
---|---|
static class |
HdfsSpoutTopology.ConstBolt |
Modifier and Type | Class and Description |
---|---|
class |
HiveBolt |
Modifier and Type | Class and Description |
---|---|
class |
AbstractJdbcBolt |
class |
JdbcInsertBolt
Basic bolt for writing to any Database table.
|
class |
JdbcLookupBolt
Basic bolt for querying from any database.
|
Modifier and Type | Class and Description |
---|---|
class |
JmsBolt
A JmsBolt receives
org.apache.storm.tuple.Tuple objects from a Storm topology and publishes JMS Messages to a destination (topic or queue). |
Modifier and Type | Class and Description |
---|---|
class |
GenericBolt
A generic
org.apache.storm.topology.IRichBolt implementation for testing/debugging the Storm JMS Spout and example topologies. |
Modifier and Type | Class and Description |
---|---|
class |
KafkaBolt<K,V>
Bolt implementation that can send Tuple data to Kafka.
|
Modifier and Type | Class and Description |
---|---|
class |
KafkaSpoutTestBolt |
Modifier and Type | Class and Description |
---|---|
class |
LoadBolt
A bolt that simulates a real world bolt based off of statistics about it.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractMongoBolt |
class |
MongoInsertBolt
Basic bolt for writing to MongoDB.
|
class |
MongoLookupBolt
Basic bolt for querying from MongoDB.
|
class |
MongoUpdateBolt
Basic bolt for updating from MongoDB.
|
Modifier and Type | Class and Description |
---|---|
class |
MqttBolt |
Modifier and Type | Class and Description |
---|---|
class |
OpenTsdbBolt
Basic bolt implementation for storing timeseries datapoints to OpenTSDB.
|
Modifier and Type | Class and Description |
---|---|
class |
DevNullBolt |
class |
IdBolt |
Modifier and Type | Class and Description |
---|---|
class |
IdentityBolt |
Modifier and Type | Class and Description |
---|---|
class |
PMMLPredictorBolt |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRedisBolt
AbstractRedisBolt class is for users to implement custom bolts which makes interaction with Redis.
|
class |
RedisFilterBolt
Basic bolt for querying from Redis and filters out if key/field doesn’t exist.
|
class |
RedisLookupBolt
Basic bolt for querying from Redis and emits response as tuple.
|
class |
RedisStoreBolt
Basic bolt for writing to Redis.
|
Modifier and Type | Class and Description |
---|---|
static class |
LookupWordCount.PrintWordTotalCountBolt |
static class |
WhitelistWordCount.PrintWordTotalCountBolt |
Modifier and Type | Class and Description |
---|---|
class |
RocketMqBolt |
Modifier and Type | Class and Description |
---|---|
class |
SolrUpdateBolt |
Modifier and Type | Method and Description |
---|---|
IRichBolt |
ISqlStreamsDataSource.getConsumer()
Provides instance of IRichBolt which can be used as consumer in topology.
|
Modifier and Type | Class and Description |
---|---|
class |
SocketBolt
The Bolt implementation for Socket.
|
Modifier and Type | Class and Description |
---|---|
static class |
BlobStoreAPIWordCountTopology.SplitSentence |
static class |
MultipleLoggerTopology.ExclamationLoggingBolt |
static class |
MultiThreadWordCountTopology.MultiThreadedSplitSentence |
static class |
ResourceAwareExampleTopology.ExclamationBolt |
static class |
WordCountTopology.SplitSentence |
static class |
WordCountTopologyNode.SplitSentence |
Modifier and Type | Class and Description |
---|---|
class |
RollingCountAggBolt
This bolt aggregates counts from multiple upstream bolts.
|
class |
RollingCountBolt
This bolt performs rolling counts of incoming objects, i.e.
|
class |
SingleJoinBolt
Example of a simple custom bolt for joining two streams.
|
Modifier and Type | Method and Description |
---|---|
void |
Stream.to(IRichBolt bolt)
Sends the elements of this stream to a bolt.
|
void |
Stream.to(IRichBolt bolt,
int parallelism)
Sends the elements of this stream to a bolt.
|
Modifier and Type | Class and Description |
---|---|
class |
BoltTracker |
class |
PythonShellMetricsBolt |
class |
TestAggregatesCounter |
class |
TestEventOrderCheckBolt |
class |
TestGlobalCount |
class |
TestPlannerBolt |
class |
TupleCaptureBolt |
Constructor and Description |
---|
BoltTracker(IRichBolt delegate,
String id) |
Modifier and Type | Class and Description |
---|---|
class |
BaseStatefulBoltExecutor
Base class that abstracts the common logic for executing bolts in a stateful topology.
|
class |
BasicBoltExecutor |
class |
CheckpointTupleForwarder
Wraps
IRichBolt and forwards checkpoint tuples in a stateful topology. |
class |
PersistentWindowedBoltExecutor<T extends State>
Wraps a
IStatefulWindowedBolt and handles the execution. |
class |
StatefulBoltExecutor<T extends State>
Wraps a
IStatefulBolt and manages the state of the bolt. |
class |
StatefulWindowedBoltExecutor<T extends State>
Wraps a
IStatefulWindowedBolt and handles the execution. |
class |
WindowedBoltExecutor
An
IWindowedBolt wrapper that does the windowing of tuples. |
Modifier and Type | Method and Description |
---|---|
BoltDeclarer |
TopologyBuilder.setBolt(String id,
IRichBolt bolt)
Define a new bolt in this topology with parallelism of just one thread.
|
BoltDeclarer |
TopologyBuilder.setBolt(String id,
IRichBolt bolt,
Number parallelismHint)
Define a new bolt in this topology with the specified amount of parallelism.
|
Constructor and Description |
---|
CheckpointTupleForwarder(IRichBolt bolt) |
Modifier and Type | Class and Description |
---|---|
class |
BaseRichBolt |
class |
BaseTickTupleAwareRichBolt
This class is based on BaseRichBolt, but is aware of tick tuple.
|
Modifier and Type | Class and Description |
---|---|
class |
TridentBoltExecutor |
Copyright © 2022 The Apache Software Foundation. All rights reserved.