Modifier and Type | Class and Description |
---|---|
class |
JoinBolt |
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 |
ClojureSpout |
class |
RichShellBolt |
class |
RichShellSpout |
Modifier and Type | Interface and Description |
---|---|
interface |
IBatchBolt<T> |
Modifier and Type | Class and Description |
---|---|
class |
BatchBoltExecutor |
class |
CoordinatedBolt
Coordination requires the request ids to be globally unique for awhile.
|
Modifier and Type | Class and Description |
---|---|
class |
DRPCSpout |
class |
JoinResult |
class |
KeyedFairBolt |
class |
PrepareRequest |
class |
ReturnResults |
Modifier and Type | Class and Description |
---|---|
class |
DruidBeamBolt<E>
Deprecated.
the preferred way to ingest streaming events to druid is through Kafka, as such storm-druid is deprecated and will be removed in 2.x releases of storm.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractEsBolt |
class |
EsIndexBolt
Basic bolt for storing tuple to ES document.
|
static class |
EsIndexTopology.UserDataSpout |
class |
EsLookupBolt |
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 |
GlobalCountBolt
Globally count number of messages
|
class |
PartialCountBolt
Partially count number of messages from EventHubs
|
Modifier and Type | Class and Description |
---|---|
class |
EventHubSpout |
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. |
class |
LogInfoBolt
Simple bolt that does nothing other than LOG.info() every tuple recieveed.
|
Modifier and Type | Class and Description |
---|---|
class |
FluxShellSpout
A generic
ShellSpout implementation that allows you specify output fields and even streams without having to subclass ShellSpout 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 |
TotalWordCounter |
Modifier and Type | Class and Description |
---|---|
class |
AbstractHdfsBolt |
class |
AvroGenericRecordBolt |
class |
HdfsBolt |
static class |
HdfsFileTopology.MyBolt |
static class |
HdfsFileTopology.SentenceSpout |
class |
SequenceFileBolt |
static class |
SequenceFileTopology.MyBolt |
static class |
SequenceFileTopology.SentenceSpout |
Modifier and Type | Class and Description |
---|---|
class |
HdfsSpout |
static class |
HdfsSpoutTopology.ConstBolt |
Modifier and Type | Class and Description |
---|---|
static class |
BucketTestHiveTopology.UserDataSpout |
class |
HiveBolt |
static class |
HiveTopology.UserDataSpout |
static class |
HiveTopologyPartitioned.UserDataSpout |
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 |
UserSpout |
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 |
JmsSpout
A Storm
Spout implementation that listens to a JMS topic or queue and outputs tuples based on the messages it receives. |
Modifier and Type | Class and Description |
---|---|
class |
KafkaSpout
Deprecated.
storm-kafka has been deprecated and will be removed in a future Storm release. Please upgrade to storm-kafka-client. If you need to migrate the committed offsets to the new spout, consider using the storm-kafka-migration tool.
|
Modifier and Type | Class and Description |
---|---|
class |
KafkaBolt<K,V>
Deprecated.
Please use the KafkaBolt in storm-kafka-client
|
Modifier and Type | Class and Description |
---|---|
class |
KinesisSpout |
Modifier and Type | Class and Description |
---|---|
class |
AbstractMongoBolt |
class |
MongoInsertBolt
Basic bolt for writing to MongoDB.
|
class |
MongoUpdateBolt
Basic bolt for updating from MongoDB.
|
Modifier and Type | Class and Description |
---|---|
class |
WordCounter |
class |
WordSpout |
Modifier and Type | Class and Description |
---|---|
class |
MqttBolt |
Modifier and Type | Class and Description |
---|---|
class |
MqttSpout |
Modifier and Type | Class and Description |
---|---|
class |
MetricGenSpout
Spout to generate tuples containing metric data.
|
Modifier and Type | Class and Description |
---|---|
class |
OpenTsdbBolt
Basic bolt implementation for storing timeseries datapoints to OpenTSDB.
|
Modifier and Type | Class and Description |
---|---|
class |
CountBolt |
class |
DevNullBolt |
class |
IdBolt |
class |
SplitSentenceBolt |
Modifier and Type | Class and Description |
---|---|
class |
ConstSpout |
class |
FileReadSpout |
class |
StringGenSpout
Spout pre-computes a list with 30k fixed length random strings.
|
Modifier and Type | Class and Description |
---|---|
class |
PMMLPredictorBolt |
class |
RawInputFromCSVSpout |
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 Various data types are supported: STRING, LIST, HASH, SET, SORTED_SET, HYPER_LOG_LOG, GEO
|
Modifier and Type | Class and Description |
---|---|
static class |
LookupWordCount.PrintWordTotalCountBolt |
static class |
WhitelistWordCount.PrintWordTotalCountBolt |
Modifier and Type | Class and Description |
---|---|
class |
SolrUpdateBolt |
Modifier and Type | Class and Description |
---|---|
class |
SolrFieldsSpout |
class |
SolrJsonSpout |
Modifier and Type | Class and Description |
---|---|
class |
CheckpointSpout
Emits checkpoint tuples which is used to save the state of the
IStatefulComponent across the topology. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRankerBolt
This abstract bolt provides the basic behavior of bolts that rank objects according to their count.
|
class |
IntermediateRankingsBolt
This bolt ranks incoming objects by their count.
|
class |
PrinterBolt |
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 NOTE: Prefer to use the built-in JoinBolt wherever applicable
|
class |
SlidingWindowSumBolt
Computes sliding window sum
|
class |
TotalRankingsBolt
This bolt merges incoming
Rankings . |
Modifier and Type | Class and Description |
---|---|
class |
RandomIntegerSpout
Emits a random integer and a timestamp value (offset by one day), every 100 ms.
|
class |
RandomSentenceSpout |
static class |
RandomSentenceSpout.TimeStamped |
Modifier and Type | Class and Description |
---|---|
class |
BatchNumberList |
class |
BatchProcessWord |
class |
BatchRepeatA |
class |
BoltTracker |
class |
CountingBatchBolt |
class |
CountingCommitBolt |
class |
FeederSpout |
class |
FixedTupleSpout |
class |
IdentityBolt |
class |
KeyedCountingBatchBolt |
class |
KeyedCountingCommitterBolt |
class |
KeyedSummingBatchBolt |
class |
MemoryTransactionalSpout |
class |
OpaqueMemoryTransactionalSpout
This spout only works in local mode.
|
class |
PrepareBatchBolt |
class |
PythonShellMetricsBolt |
class |
PythonShellMetricsSpout |
class |
SpoutTracker |
class |
TestAggregatesCounter |
class |
TestConfBolt |
class |
TestEventLogSpout |
class |
TestEventOrderCheckBolt |
class |
TestGlobalCount |
class |
TestPlannerBolt |
class |
TestPlannerSpout |
class |
TestWordBytesCounter |
class |
TestWordCounter |
class |
TestWordSpout |
class |
TupleCaptureBolt |
Modifier and Type | Interface and Description |
---|---|
interface |
IBasicBolt |
interface |
IRichBolt
When writing topologies using Java,
IRichBolt and IRichSpout are the main interfaces to use to implement components of the topology. |
interface |
IRichSpout
When writing topologies using Java,
IRichBolt and IRichSpout are the main interfaces to use to implement components of the topology. |
interface |
IRichStateSpout |
interface |
IStatefulBolt<T extends State>
A bolt abstraction for supporting stateful computation.
|
interface |
IStatefulComponent<T extends State>
Common methods for stateful components in the topology.
|
interface |
IStatefulWindowedBolt<T extends State>
A windowed bolt abstraction for supporting windowing operation with state
|
interface |
IWindowedBolt
A bolt abstraction for supporting time and count based sliding & tumbling windows.
|
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 |
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 | Class and Description |
---|---|
class |
BaseBasicBolt |
class |
BaseBatchBolt<T> |
class |
BaseComponent |
class |
BaseOpaquePartitionedTransactionalSpout<T> |
class |
BasePartitionedTransactionalSpout<T> |
class |
BaseRichBolt |
class |
BaseRichSpout |
class |
BaseStatefulBolt<T extends State> |
class |
BaseStatefulWindowedBolt<T extends State> |
class |
BaseTickTupleAwareRichBolt
This class is based on BaseRichBolt, but is aware of tick tuple.
|
class |
BaseTransactionalBolt |
class |
BaseTransactionalSpout<T> |
class |
BaseWindowedBolt |
Modifier and Type | Interface and Description |
---|---|
interface |
ICommitterTransactionalSpout<X> |
interface |
ITransactionalSpout<T> |
Modifier and Type | Class and Description |
---|---|
class |
TransactionalSpoutBatchExecutor |
class |
TransactionalSpoutCoordinator |
Modifier and Type | Interface and Description |
---|---|
interface |
IOpaquePartitionedTransactionalSpout<T>
This defines a transactional spout which does not necessarily replay the same batch every time it emits a batch for a transaction id.
|
interface |
IPartitionedTransactionalSpout<T>
This interface defines a transactional spout that reads its tuples from a partitioned set of brokers.
|
Modifier and Type | Class and Description |
---|---|
class |
OpaquePartitionedTransactionalSpoutExecutor |
class |
PartitionedTransactionalSpoutExecutor |
Modifier and Type | Class and Description |
---|---|
class |
SubtopologyBolt |
Modifier and Type | Class and Description |
---|---|
class |
RichSpoutBatchTriggerer |
class |
TridentSpoutCoordinator |
class |
TridentSpoutExecutor |
Modifier and Type | Interface and Description |
---|---|
interface |
ITridentBatchBolt |
Modifier and Type | Class and Description |
---|---|
class |
MasterBatchCoordinator |
class |
TridentBoltExecutor |
Modifier and Type | Method and Description |
---|---|
static Fields |
TridentUtils.getSingleOutputStreamFields(IComponent component) |
Modifier and Type | Class and Description |
---|---|
static class |
StatefulTopology.PrinterBolt |
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.