A B C D E F G H I J K L M N O P R S T U V W 
All Classes All Packages

A

ack(Object) - Method in interface org.apache.storm.spout.ISpout
Storm has determined that the tuple emitted by this spout with the msgId identifier has been fully processed.
ack(Object) - Method in class org.apache.storm.testing.TestWordSpout
 
ack(Object) - Method in class org.apache.storm.topology.base.BaseRichSpout
 
ack(Object) - Method in class org.apache.storm.topology.IRichSpoutDelegate
 
ack(Tuple) - Method in interface org.apache.storm.task.IOutputCollector
 
ack(Tuple) - Method in class org.apache.storm.task.OutputCollector
 
ack(Tuple) - Method in class org.apache.storm.task.OutputCollectorImpl
 
ackingTaskId - Variable in class org.apache.storm.hooks.info.BoltAckInfo
 
activate() - Method in interface org.apache.storm.spout.ISpout
Called when a spout has been activated out of a deactivated mode.
activate() - Method in class org.apache.storm.topology.base.BaseRichSpout
 
activate() - Method in class org.apache.storm.topology.IRichSpoutDelegate
 
activate(String) - Method in interface org.apache.storm.ILocalCluster
 
activate(String) - Method in class org.apache.storm.LocalCluster
 
add(int, Object) - Method in class org.apache.storm.utils.ListDelegate
 
add(Object) - Method in class org.apache.storm.utils.ListDelegate
 
addAll(int, Collection<? extends Object>) - Method in class org.apache.storm.utils.ListDelegate
 
addAll(Collection<? extends Object>) - Method in class org.apache.storm.utils.ListDelegate
 
addConfiguration(String, Object) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
addConfiguration(String, Object) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
 
addConfiguration(String, Object) - Method in class org.apache.storm.topology.SpoutDeclarerImpl
 
addConfigurations(Map) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
addConfigurations(Map) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
 
addConfigurations(Map) - Method in class org.apache.storm.topology.SpoutDeclarerImpl
 
addHook(ITaskHook) - Method in class org.apache.storm.hooks.ITaskHookDelegate
 
addTaskHook(ITaskHook) - Method in class org.apache.storm.task.TopologyContext
 
advanceTime(long) - Static method in class org.apache.storm.utils.Time
 
advanceTimeNanos(long) - Static method in class org.apache.storm.utils.Time
 
advanceTimeSecs(long) - Static method in class org.apache.storm.utils.Time
 
allGrouping(String) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
allGrouping(String) - Method in interface org.apache.storm.topology.InputDeclarer
 
allGrouping(String, String) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
allGrouping(String, String) - Method in interface org.apache.storm.topology.InputDeclarer
 
AlreadyAliveException - Exception in org.apache.storm.generated
 
AlreadyAliveException() - Constructor for exception org.apache.storm.generated.AlreadyAliveException
 
AssignableMetric - Class in org.apache.storm.metric.api
 
AssignableMetric(Object) - Constructor for class org.apache.storm.metric.api.AssignableMetric
 
Atom - Class in org.apache.storm.clojure.lang
 
Atom() - Constructor for class org.apache.storm.clojure.lang.Atom
 
autoTune(Long) - Method in class org.apache.storm.utils.DefaultMaxSpoutPendingTuner
 

B

BaseBasicBolt - Class in org.apache.storm.topology.base
 
BaseBasicBolt() - Constructor for class org.apache.storm.topology.base.BaseBasicBolt
 
BaseComponent - Class in org.apache.storm.topology.base
 
BaseComponent() - Constructor for class org.apache.storm.topology.base.BaseComponent
 
BaseRichBolt - Class in org.apache.storm.topology.base
 
BaseRichBolt() - Constructor for class org.apache.storm.topology.base.BaseRichBolt
 
BaseRichSpout - Class in org.apache.storm.topology.base
 
BaseRichSpout() - Constructor for class org.apache.storm.topology.base.BaseRichSpout
 
BaseTaskHook - Class in org.apache.storm.hooks
 
BaseTaskHook() - Constructor for class org.apache.storm.hooks.BaseTaskHook
 
BaseTickTupleAwareRichBolt - Class in org.apache.storm.topology.base
This class is based on BaseRichBolt, but is aware of tick tuple.
BaseTickTupleAwareRichBolt() - Constructor for class org.apache.storm.topology.base.BaseTickTupleAwareRichBolt
 
BaseWindowedBolt - Class in org.apache.storm.topology.base
 
BaseWindowedBolt() - Constructor for class org.apache.storm.topology.base.BaseWindowedBolt
 
BaseWindowedBolt.Count - Class in org.apache.storm.topology.base
Holds a count value for count based windows and sliding intervals.
BaseWindowedBolt.Duration - Class in org.apache.storm.topology.base
Holds a Time duration for time based windows and sliding intervals.
BasicBoltExecutor - Class in org.apache.storm.topology
 
BasicBoltExecutor(IBasicBolt) - Constructor for class org.apache.storm.topology.BasicBoltExecutor
 
BasicOutputCollector - Class in org.apache.storm.topology
 
BasicOutputCollector(OutputCollector) - Constructor for class org.apache.storm.topology.BasicOutputCollector
 
Bolt - Class in org.apache.storm.generated
 
Bolt(TopologyAPI.Bolt) - Constructor for class org.apache.storm.generated.Bolt
 
boltAck(BoltAckInfo) - Method in class org.apache.storm.hooks.ITaskHookDelegate
 
boltAck(BoltAckInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
 
boltAck(BoltAckInfo) - Method in interface org.apache.storm.hooks.ITaskHook
 
BoltAckInfo - Class in org.apache.storm.hooks.info
 
BoltAckInfo(BoltAckInfo) - Constructor for class org.apache.storm.hooks.info.BoltAckInfo
 
BoltAckInfo(Tuple, int, Long) - Constructor for class org.apache.storm.hooks.info.BoltAckInfo
 
BoltDeclarer - Interface in org.apache.storm.topology
 
BoltDeclarerImpl - Class in org.apache.storm.topology
 
BoltDeclarerImpl(BoltDeclarer) - Constructor for class org.apache.storm.topology.BoltDeclarerImpl
 
boltExecute(BoltExecuteInfo) - Method in class org.apache.storm.hooks.ITaskHookDelegate
 
boltExecute(BoltExecuteInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
 
boltExecute(BoltExecuteInfo) - Method in interface org.apache.storm.hooks.ITaskHook
 
BoltExecuteInfo - Class in org.apache.storm.hooks.info
 
BoltExecuteInfo(BoltExecuteInfo) - Constructor for class org.apache.storm.hooks.info.BoltExecuteInfo
 
BoltExecuteInfo(Tuple, int, Long) - Constructor for class org.apache.storm.hooks.info.BoltExecuteInfo
 
boltFail(BoltFailInfo) - Method in class org.apache.storm.hooks.ITaskHookDelegate
 
boltFail(BoltFailInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
 
boltFail(BoltFailInfo) - Method in interface org.apache.storm.hooks.ITaskHook
 
BoltFailInfo - Class in org.apache.storm.hooks.info
 
BoltFailInfo(BoltFailInfo) - Constructor for class org.apache.storm.hooks.info.BoltFailInfo
 
BoltFailInfo(Tuple, int, Long) - Constructor for class org.apache.storm.hooks.info.BoltFailInfo
 
BoltTopologyContext - Class in org.apache.storm.task
A TopologyContext that is given to a bolt is actually an instance of BoltTopologyContext.
BoltTopologyContext(TopologyContext) - Constructor for class org.apache.storm.task.BoltTopologyContext
 

C

chooseTasks(int, List<Object>) - Method in interface org.apache.storm.grouping.CustomStreamGrouping
This function implements a custom stream grouping.
chooseTasks(List<Object>) - Method in class org.apache.storm.grouping.CustomStreamGroupingDelegate
 
cleanup() - Method in class org.apache.storm.hooks.BaseTaskHook
 
cleanup() - Method in interface org.apache.storm.hooks.ITaskHook
 
cleanup() - Method in class org.apache.storm.hooks.ITaskHookDelegate
 
cleanup() - Method in interface org.apache.storm.metric.api.IMetricsConsumer
 
cleanup() - Method in interface org.apache.storm.task.IBolt
Called when an IBolt is going to be shutdown.
cleanup() - Method in interface org.apache.storm.testing.CompletableSpout
 
cleanup() - Method in class org.apache.storm.topology.base.BaseBasicBolt
 
cleanup() - Method in class org.apache.storm.topology.base.BaseRichBolt
 
cleanup() - Method in class org.apache.storm.topology.base.BaseWindowedBolt
 
cleanup() - Method in class org.apache.storm.topology.BasicBoltExecutor
 
cleanup() - Method in interface org.apache.storm.topology.IBasicBolt
 
cleanup() - Method in class org.apache.storm.topology.IRichBoltDelegate
 
cleanup() - Method in interface org.apache.storm.topology.IWindowedBolt
 
cleanup() - Method in class org.apache.storm.topology.IWindowedBoltDelegate
 
clear() - Method in class org.apache.storm.generated.GlobalStreamId
 
clear() - Method in class org.apache.storm.utils.ListDelegate
 
close() - Method in class org.apache.storm.metric.internal.CountStatAndMetric
 
close() - Method in class org.apache.storm.metric.internal.LatencyStatAndMetric
 
close() - Method in interface org.apache.storm.spout.ISpout
Called when an ISpout is going to be shutdown.
close() - Method in class org.apache.storm.testing.TestWordSpout
 
close() - Method in class org.apache.storm.topology.base.BaseRichSpout
 
close() - Method in class org.apache.storm.topology.IRichSpoutDelegate
 
close() - Method in class org.apache.storm.utils.Time.SimulatedTime
 
combine(T, T) - Method in interface org.apache.storm.metric.api.ICombiner
 
CombinedMetric - Class in org.apache.storm.metric.api
 
CombinedMetric(ICombiner) - Constructor for class org.apache.storm.metric.api.CombinedMetric
 
CompletableSpout - Interface in org.apache.storm.testing
 
completeLatencyMs - Variable in class org.apache.storm.hooks.info.SpoutAckInfo
 
ComponentConfigurationDeclarer<T extends ComponentConfigurationDeclarer> - Interface in org.apache.storm.topology
 
Config - Class in org.apache.storm
Topology configs are specified as a plain old map.
Config() - Constructor for class org.apache.storm.Config
 
ConfigUtils - Class in org.apache.storm.utils
 
Constants - Class in org.apache.storm
 
contains(Object) - Method in class org.apache.storm.utils.ListDelegate
 
contains(String) - Method in class org.apache.storm.tuple.Fields
Returns true if this contains the specified name of the field.
contains(String) - Method in interface org.apache.storm.tuple.Tuple
Returns true if this tuple contains the specified name of the field.
contains(String) - Method in class org.apache.storm.tuple.TupleImpl
Returns true if this tuple contains the specified name of the field.
containsAll(Collection<?>) - Method in class org.apache.storm.utils.ListDelegate
 
Count(int) - Constructor for class org.apache.storm.topology.base.BaseWindowedBolt.Count
 
CountMetric - Class in org.apache.storm.metric.api
 
CountMetric() - Constructor for class org.apache.storm.metric.api.CountMetric
 
CountStatAndMetric - Class in org.apache.storm.metric.internal
 
CountStatAndMetric(int) - Constructor for class org.apache.storm.metric.internal.CountStatAndMetric
 
createTopology() - Method in class org.apache.storm.topology.TopologyBuilder
 
currentTimeMillis() - Static method in class org.apache.storm.utils.Time
 
currentTimeSecs() - Static method in class org.apache.storm.utils.Time
 
customGrouping(String, String, CustomStreamGrouping) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
customGrouping(String, String, CustomStreamGrouping) - Method in interface org.apache.storm.topology.InputDeclarer
 
customGrouping(String, CustomStreamGrouping) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
customGrouping(String, CustomStreamGrouping) - Method in interface org.apache.storm.topology.InputDeclarer
 
CustomStreamGrouping - Interface in org.apache.storm.grouping
 
CustomStreamGroupingDelegate - Class in org.apache.storm.grouping
 
CustomStreamGroupingDelegate(CustomStreamGrouping) - Constructor for class org.apache.storm.grouping.CustomStreamGroupingDelegate
 

D

DataPoint() - Constructor for class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
 
DataPoint(String, Object) - Constructor for class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
 
days(int) - Static method in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
Returns a BaseWindowedBolt.Duration corresponding to the the given value in days.
deactivate() - Method in interface org.apache.storm.spout.ISpout
Called when a spout has been deactivated.
deactivate() - Method in class org.apache.storm.topology.base.BaseRichSpout
 
deactivate() - Method in class org.apache.storm.topology.IRichSpoutDelegate
 
deactivate(String) - Method in interface org.apache.storm.ILocalCluster
 
deactivate(String) - Method in class org.apache.storm.LocalCluster
 
declare(boolean, Fields) - Method in interface org.apache.storm.topology.OutputFieldsDeclarer
 
declare(boolean, Fields) - Method in class org.apache.storm.topology.OutputFieldsGetter
 
declare(Fields) - Method in interface org.apache.storm.topology.OutputFieldsDeclarer
Uses default stream id.
declare(Fields) - Method in class org.apache.storm.topology.OutputFieldsGetter
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.topology.IRichBoltDelegate
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.topology.IRichSpoutDelegate
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.topology.IWindowedBoltDelegate
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.testing.TestWordSpout
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.storm.topology.BasicBoltExecutor
 
declareOutputFields(OutputFieldsDeclarer) - Method in interface org.apache.storm.topology.IComponent
Declare the output schema for all the streams of this topology.
declareStream(String, boolean, Fields) - Method in interface org.apache.storm.topology.OutputFieldsDeclarer
 
declareStream(String, boolean, Fields) - Method in class org.apache.storm.topology.OutputFieldsGetter
 
declareStream(String, Fields) - Method in interface org.apache.storm.topology.OutputFieldsDeclarer
 
declareStream(String, Fields) - Method in class org.apache.storm.topology.OutputFieldsGetter
 
decorate(Kryo) - Method in interface org.apache.storm.serialization.IKryoDecorator
 
DEFAULT_STREAM_ID - Static variable in class org.apache.storm.utils.Utils
 
DefaultKryoFactory - Class in org.apache.storm.serialization
 
DefaultKryoFactory() - Constructor for class org.apache.storm.serialization.DefaultKryoFactory
 
DefaultKryoFactory.KryoSerializableDefault - Class in org.apache.storm.serialization
 
DefaultMaxSpoutPendingTuner - Class in org.apache.storm.utils
This is a class that helps to auto tune the max spout pending value
DefaultMaxSpoutPendingTuner(float, double) - Constructor for class org.apache.storm.utils.DefaultMaxSpoutPendingTuner
Conv constructor when initing from a non-set initial value
DefaultMaxSpoutPendingTuner(Long, float, double) - Constructor for class org.apache.storm.utils.DefaultMaxSpoutPendingTuner
 
deltaMs(long) - Static method in class org.apache.storm.utils.Time
 
deltaSecs(int) - Static method in class org.apache.storm.utils.Time
 
deserialize(byte[]) - Method in class org.apache.storm.serialization.HeronPluggableSerializerDelegate
 
deserialize(byte[]) - Method in interface org.apache.storm.trident.state.Serializer
 
deserialize(byte[]) - Static method in class org.apache.storm.utils.Utils
 
deserialize(ByteBuffer) - Method in interface org.apache.storm.spout.MultiScheme
 
deserialize(ByteBuffer) - Method in class org.apache.storm.spout.RawMultiScheme
 
deserialize(ByteBuffer) - Method in class org.apache.storm.spout.RawScheme
 
deserialize(ByteBuffer) - Method in interface org.apache.storm.spout.Scheme
 
deserialize(ByteBuffer) - Method in class org.apache.storm.spout.SchemeAsMultiScheme
 
directGrouping(String) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
directGrouping(String) - Method in interface org.apache.storm.topology.InputDeclarer
 
directGrouping(String, String) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
directGrouping(String, String) - Method in interface org.apache.storm.topology.InputDeclarer
 
Duration(int, TimeUnit) - Constructor for class org.apache.storm.topology.base.BaseWindowedBolt.Duration
 

E

emit(String, Collection<Tuple>, List<Object>) - Method in interface org.apache.storm.task.IOutputCollector
Returns the task ids that received the tuples.
emit(String, Collection<Tuple>, List<Object>) - Method in class org.apache.storm.task.OutputCollector
 
emit(String, Collection<Tuple>, List<Object>) - Method in class org.apache.storm.task.OutputCollectorImpl
 
emit(String, List<Object>) - Method in class org.apache.storm.spout.SpoutOutputCollector
Emits a tuple to the specified output stream with a null message id.
emit(String, List<Object>) - Method in class org.apache.storm.spout.SpoutOutputCollectorImpl
 
emit(String, List<Object>) - Method in class org.apache.storm.task.OutputCollector
Emits a new unanchored tuple to the specified stream.
emit(String, List<Object>) - Method in class org.apache.storm.topology.BasicOutputCollector
 
emit(String, List<Object>) - Method in interface org.apache.storm.topology.IBasicOutputCollector
 
emit(String, List<Object>, Object) - Method in interface org.apache.storm.spout.ISpoutOutputCollector
Returns the task ids that received the tuples.
emit(String, List<Object>, Object) - Method in class org.apache.storm.spout.SpoutOutputCollector
Emits a new tuple to the specified output stream with the given message ID.
emit(String, List<Object>, Object) - Method in class org.apache.storm.spout.SpoutOutputCollectorImpl
 
emit(String, Tuple, List<Object>) - Method in class org.apache.storm.task.OutputCollector
Emits a new tuple to a specific stream with a single anchor.
emit(Collection<Tuple>, List<Object>) - Method in class org.apache.storm.task.OutputCollector
Emits a new tuple to the default stream anchored on a group of input tuples.
emit(List<Object>) - Method in class org.apache.storm.spout.SpoutOutputCollector
Emits a tuple to the default output stream with a null message id.
emit(List<Object>) - Method in class org.apache.storm.spout.SpoutOutputCollectorImpl
 
emit(List<Object>) - Method in class org.apache.storm.task.OutputCollector
Emits a new unanchored tuple to the default stream.
emit(List<Object>) - Method in class org.apache.storm.topology.BasicOutputCollector
 
emit(List<Object>, Object) - Method in class org.apache.storm.spout.SpoutOutputCollector
Emits a new tuple to the default output stream with the given message ID.
emit(List<Object>, Object) - Method in class org.apache.storm.spout.SpoutOutputCollectorImpl
 
emit(EmitInfo) - Method in class org.apache.storm.hooks.ITaskHookDelegate
 
emit(EmitInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
 
emit(EmitInfo) - Method in interface org.apache.storm.hooks.ITaskHook
 
emit(Tuple, List<Object>) - Method in class org.apache.storm.task.OutputCollector
Emits a new tuple to the default stream anchored on a single tuple.
emitDirect(int, String, Collection<Tuple>, List<Object>) - Method in interface org.apache.storm.task.IOutputCollector
 
emitDirect(int, String, Collection<Tuple>, List<Object>) - Method in class org.apache.storm.task.OutputCollector
 
emitDirect(int, String, Collection<Tuple>, List<Object>) - Method in class org.apache.storm.task.OutputCollectorImpl
 
emitDirect(int, String, List<Object>) - Method in class org.apache.storm.spout.SpoutOutputCollector
Emits a tuple to the specified task on the specified output stream.
emitDirect(int, String, List<Object>) - Method in class org.apache.storm.spout.SpoutOutputCollectorImpl
 
emitDirect(int, String, List<Object>) - Method in class org.apache.storm.task.OutputCollector
Emits a tuple directly to the specified task id on the specified stream.
emitDirect(int, String, List<Object>) - Method in class org.apache.storm.topology.BasicOutputCollector
 
emitDirect(int, String, List<Object>) - Method in interface org.apache.storm.topology.IBasicOutputCollector
 
emitDirect(int, String, List<Object>, Object) - Method in interface org.apache.storm.spout.ISpoutOutputCollector
 
emitDirect(int, String, List<Object>, Object) - Method in class org.apache.storm.spout.SpoutOutputCollector
Emits a tuple to the specified task on the specified output stream.
emitDirect(int, String, List<Object>, Object) - Method in class org.apache.storm.spout.SpoutOutputCollectorImpl
 
emitDirect(int, String, Tuple, List<Object>) - Method in class org.apache.storm.task.OutputCollector
Emits a tuple directly to the specified task id on the specified stream.
emitDirect(int, Collection<Tuple>, List<Object>) - Method in class org.apache.storm.task.OutputCollector
Emits a tuple directly to the specified task id on the default stream.
emitDirect(int, List<Object>) - Method in class org.apache.storm.spout.SpoutOutputCollector
Emits a tuple to the specified task on the default output stream.
emitDirect(int, List<Object>) - Method in class org.apache.storm.spout.SpoutOutputCollectorImpl
 
emitDirect(int, List<Object>) - Method in class org.apache.storm.task.OutputCollector
Emits a tuple directly to the specified task id on the default stream.
emitDirect(int, List<Object>) - Method in class org.apache.storm.topology.BasicOutputCollector
 
emitDirect(int, List<Object>, Object) - Method in class org.apache.storm.spout.SpoutOutputCollector
Emits a tuple to the specified task on the default output stream.
emitDirect(int, List<Object>, Object) - Method in class org.apache.storm.spout.SpoutOutputCollectorImpl
 
emitDirect(int, Tuple, List<Object>) - Method in class org.apache.storm.task.OutputCollector
Emits a tuple directly to the specified task id on the default stream.
EmitInfo - Class in org.apache.storm.hooks.info
 
EmitInfo(List<Object>, String, int, Collection<Integer>) - Constructor for class org.apache.storm.hooks.info.EmitInfo
 
EmitInfo(EmitInfo) - Constructor for class org.apache.storm.hooks.info.EmitInfo
 
emptyEmit(long) - Method in interface org.apache.storm.spout.ISpoutWaitStrategy
 
emptyEmit(long) - Method in class org.apache.storm.spout.NothingEmptyEmitStrategy
 
emptyEmit(long) - Method in class org.apache.storm.spout.SleepSpoutWaitStrategy
 
equals(Object) - Method in class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
 
equals(Object) - Method in class org.apache.storm.topology.base.BaseWindowedBolt.Count
 
equals(Object) - Method in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
 
equals(Object) - Method in class org.apache.storm.tuple.TupleImpl
 
execute(Tuple) - Method in class org.apache.storm.topology.IRichBoltDelegate
 
execute(TupleWindow) - Method in class org.apache.storm.topology.IWindowedBoltDelegate
 
execute(Tuple) - Method in interface org.apache.storm.task.IBolt
Process a single tuple of input.
execute(Tuple) - Method in class org.apache.storm.topology.base.BaseTickTupleAwareRichBolt
Process a single tuple of input.
execute(Tuple) - Method in class org.apache.storm.topology.BasicBoltExecutor
 
execute(Tuple, BasicOutputCollector) - Method in interface org.apache.storm.topology.IBasicBolt
Process the input tuple and optionally emit new tuples based on the input tuple.
execute(TupleWindow) - Method in interface org.apache.storm.topology.IWindowedBolt
Process the tuple window and optionally emit new tuples based on the tuples in the input window.
executeLatencyMs - Variable in class org.apache.storm.hooks.info.BoltExecuteInfo
 
executingTaskId - Variable in class org.apache.storm.hooks.info.BoltExecuteInfo
 
exhausted_QMARK_() - Method in interface org.apache.storm.testing.CompletableSpout
 
extractResult(MeanReducerState) - Method in class org.apache.storm.metric.api.MeanReducer
 
extractResult(T) - Method in interface org.apache.storm.metric.api.IReducer
 
extractTimestamp(Tuple) - Method in class org.apache.storm.topology.TupleFieldTimestampExtractor
 
extractTimestamp(Tuple) - Method in interface org.apache.storm.windowing.TimestampExtractor
Return the tuple timestamp indicating the time when the event happened.

F

fail(Object) - Method in interface org.apache.storm.spout.ISpout
The tuple emitted by this spout with the msgId identifier has failed to be fully processed.
fail(Object) - Method in class org.apache.storm.testing.TestWordSpout
 
fail(Object) - Method in class org.apache.storm.topology.base.BaseRichSpout
 
fail(Object) - Method in class org.apache.storm.topology.IRichSpoutDelegate
 
fail(Tuple) - Method in interface org.apache.storm.task.IOutputCollector
 
fail(Tuple) - Method in class org.apache.storm.task.OutputCollector
 
fail(Tuple) - Method in class org.apache.storm.task.OutputCollectorImpl
 
FailedException - Exception in org.apache.storm.topology
 
FailedException() - Constructor for exception org.apache.storm.topology.FailedException
 
FailedException(String) - Constructor for exception org.apache.storm.topology.FailedException
 
FailedException(String, Throwable) - Constructor for exception org.apache.storm.topology.FailedException
 
FailedException(Throwable) - Constructor for exception org.apache.storm.topology.FailedException
 
failingTaskId - Variable in class org.apache.storm.hooks.info.BoltFailInfo
 
failLatencyMs - Variable in class org.apache.storm.hooks.info.BoltFailInfo
 
failLatencyMs - Variable in class org.apache.storm.hooks.info.SpoutFailInfo
 
fieldIndex(String) - Method in class org.apache.storm.tuple.Fields
Returns the position of the specified field.
fieldIndex(String) - Method in interface org.apache.storm.tuple.Tuple
Returns the position of the specified field in this tuple.
fieldIndex(String) - Method in class org.apache.storm.tuple.TupleImpl
Returns the position of the specified field in this tuple.
Fields - Class in org.apache.storm.tuple
 
Fields(String...) - Constructor for class org.apache.storm.tuple.Fields
 
Fields(List<String>) - Constructor for class org.apache.storm.tuple.Fields
 
Fields(Fields) - Constructor for class org.apache.storm.tuple.Fields
 
fieldsGrouping(String, String, Fields) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
fieldsGrouping(String, String, Fields) - Method in interface org.apache.storm.topology.InputDeclarer
 
fieldsGrouping(String, Fields) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
fieldsGrouping(String, Fields) - Method in interface org.apache.storm.topology.InputDeclarer
 
FixedTuple - Class in org.apache.storm.testing
 
FixedTuple(String, List<Object>) - Constructor for class org.apache.storm.testing.FixedTuple
 
FixedTuple(List<Object>) - Constructor for class org.apache.storm.testing.FixedTuple
 

G

GeneralTopologyContext - Class in org.apache.storm.task
 
GeneralTopologyContext(GeneralTopologyContext) - Constructor for class org.apache.storm.task.GeneralTopologyContext
 
GeneralTopologyContext(StormTopology, Map, Map<Integer, String>, Map<String, List<Integer>>, Map<String, Map<String, Fields>>, String) - Constructor for class org.apache.storm.task.GeneralTopologyContext
 
get() - Method in class org.apache.storm.utils.DefaultMaxSpoutPendingTuner
 
get() - Method in class org.apache.storm.windowing.TupleWindowImpl
 
get() - Method in interface org.apache.storm.windowing.Window
Gets the list of events in the window.
get(int) - Method in class org.apache.storm.tuple.Fields
 
get(int) - Method in class org.apache.storm.utils.ListDelegate
 
get(Map<S, T>, S, T) - Static method in class org.apache.storm.utils.Utils
 
get_bolts() - Method in class org.apache.storm.generated.StormTopology
 
get_bolts_size() - Method in class org.apache.storm.generated.StormTopology
 
get_componentId() - Method in class org.apache.storm.generated.GlobalStreamId
 
get_spouts() - Method in class org.apache.storm.generated.StormTopology
 
get_spouts_size() - Method in class org.apache.storm.generated.StormTopology
 
get_streamId() - Method in class org.apache.storm.generated.GlobalStreamId
 
getBinary(int) - Method in interface org.apache.storm.tuple.Tuple
Returns the byte array at position i in the tuple.
getBinary(int) - Method in class org.apache.storm.tuple.TupleImpl
Returns the byte array at position i in the tuple.
getBinaryByField(String) - Method in interface org.apache.storm.tuple.Tuple
Gets the Byte array field with a specific name.
getBinaryByField(String) - Method in class org.apache.storm.tuple.TupleImpl
 
getBoolean(int) - Method in interface org.apache.storm.tuple.Tuple
Returns the Boolean at position i in the tuple.
getBoolean(int) - Method in class org.apache.storm.tuple.TupleImpl
Returns the Boolean at position i in the tuple.
getBoolean(Object, boolean) - Static method in class org.apache.storm.utils.Utils
 
getBooleanByField(String) - Method in interface org.apache.storm.tuple.Tuple
Gets the Boolean field with a specific name.
getBooleanByField(String) - Method in class org.apache.storm.tuple.TupleImpl
 
getByte(int) - Method in interface org.apache.storm.tuple.Tuple
Returns the Byte at position i in the tuple.
getByte(int) - Method in class org.apache.storm.tuple.TupleImpl
Returns the Byte at position i in the tuple.
getByteByField(String) - Method in interface org.apache.storm.tuple.Tuple
Gets the Byte field with a specific name.
getByteByField(String) - Method in class org.apache.storm.tuple.TupleImpl
 
getCodeDir() - Method in class org.apache.storm.task.WorkerTopologyContext
Gets the location of the external resources for this worker on the local filesystem.
getComponentConfiguration() - Method in class org.apache.storm.topology.base.BaseComponent
 
getComponentConfiguration() - Method in class org.apache.storm.topology.base.BaseWindowedBolt
 
getComponentConfiguration() - Method in class org.apache.storm.topology.BasicBoltExecutor
 
getComponentConfiguration() - Method in interface org.apache.storm.topology.IComponent
Declare configuration specific to this component.
getComponentConfiguration() - Method in class org.apache.storm.topology.IRichBoltDelegate
 
getComponentConfiguration() - Method in class org.apache.storm.topology.IRichSpoutDelegate
 
getComponentConfiguration() - Method in class org.apache.storm.topology.IWindowedBoltDelegate
 
getComponentId(int) - Method in class org.apache.storm.task.GeneralTopologyContext
Gets the component id for the specified task id.
getComponentIds() - Method in class org.apache.storm.task.GeneralTopologyContext
Gets a list of all component ids in this topology
getComponentOutputFields(String, String) - Method in class org.apache.storm.task.GeneralTopologyContext
Gets the declared output fields for the specified component/stream.
getComponentStreams(String) - Method in class org.apache.storm.task.GeneralTopologyContext
Gets the set of streams declared for the specified component.
getComponentTasks(String) - Method in class org.apache.storm.task.GeneralTopologyContext
Gets the task ids allocated for the given component id.
getConf() - Method in class org.apache.storm.hooks.ITaskHookDelegate
 
getDefaultSerializer(Class) - Method in class org.apache.storm.serialization.DefaultKryoFactory.KryoSerializableDefault
 
getDelegate() - Method in class org.apache.storm.tuple.Fields
 
getDelegate() - Method in class org.apache.storm.tuple.TupleImpl
 
getDouble(int) - Method in interface org.apache.storm.tuple.Tuple
Returns the Double at position i in the tuple.
getDouble(int) - Method in class org.apache.storm.tuple.TupleImpl
Returns the Double at position i in the tuple.
getDoubleByField(String) - Method in interface org.apache.storm.tuple.Tuple
Gets the Double field with a specific name.
getDoubleByField(String) - Method in class org.apache.storm.tuple.TupleImpl
 
getEndTimestamp() - Method in class org.apache.storm.windowing.TupleWindowImpl
 
getEndTimestamp() - Method in interface org.apache.storm.windowing.Window
If processing based on event time, returns the window end time based on watermark otherwise returns the window end time based on processing time.
getExpired() - Method in class org.apache.storm.windowing.TupleWindowImpl
 
getExpired() - Method in interface org.apache.storm.windowing.Window
Get the list of events expired from the window since the last time the window was generated.
getFields() - Method in interface org.apache.storm.tuple.Tuple
Gets the names of the fields in this tuple.
getFields() - Method in class org.apache.storm.tuple.TupleImpl
Gets the names of the fields in this tuple.
getFloat(int) - Method in interface org.apache.storm.tuple.Tuple
Returns the Float at position i in the tuple.
getFloat(int) - Method in class org.apache.storm.tuple.TupleImpl
Returns the Float at position i in the tuple.
getFloatByField(String) - Method in interface org.apache.storm.tuple.Tuple
Gets the Float field with a specific name.
getFloatByField(String) - Method in class org.apache.storm.tuple.TupleImpl
 
getHooks() - Method in class org.apache.storm.hooks.ITaskHookDelegate
 
getHooks() - Method in class org.apache.storm.task.TopologyContext
 
getId() - Method in interface org.apache.storm.trident.spout.ISpoutPartition
 
getInt(Object) - Static method in class org.apache.storm.utils.Utils
 
getInteger(int) - Method in interface org.apache.storm.tuple.Tuple
Returns the Integer at position i in the tuple.
getInteger(int) - Method in class org.apache.storm.tuple.TupleImpl
Returns the Integer at position i in the tuple.
getIntegerByField(String) - Method in interface org.apache.storm.tuple.Tuple
Gets the Integer field with a specific name.
getIntegerByField(String) - Method in class org.apache.storm.tuple.TupleImpl
 
getIter() - Method in interface org.apache.storm.windowing.Window
Returns an iterator over the events in the window.
getKryo(Map) - Method in class org.apache.storm.serialization.DefaultKryoFactory
 
getKryo(Map) - Method in interface org.apache.storm.serialization.IKryoFactory
 
getKryo(Map) - Static method in class org.apache.storm.serialization.SerializationFactory
Get kryo based on conf
getLong(int) - Method in interface org.apache.storm.tuple.Tuple
Returns the Long at position i in the tuple.
getLong(int) - Method in class org.apache.storm.tuple.TupleImpl
Returns the Long at position i in the tuple.
getLongByField(String) - Method in interface org.apache.storm.tuple.Tuple
Gets the Long field with a specific name.
getLongByField(String) - Method in class org.apache.storm.tuple.TupleImpl
 
getMaxSpoutPending() - Method in class org.apache.storm.task.SpoutTopologyContext
Gets the Maximum Spout Pending value for this instance of spout.
getNew() - Method in class org.apache.storm.windowing.TupleWindowImpl
 
getNew() - Method in interface org.apache.storm.windowing.Window
Get the list of newly added events in the window since the last time the window was generated.
getOutputFields() - Method in interface org.apache.storm.spout.MultiScheme
 
getOutputFields() - Method in class org.apache.storm.spout.RawMultiScheme
 
getOutputFields() - Method in class org.apache.storm.spout.RawScheme
 
getOutputFields() - Method in interface org.apache.storm.spout.Scheme
 
getOutputFields() - Method in class org.apache.storm.spout.SchemeAsMultiScheme
 
getOutputter() - Method in class org.apache.storm.topology.BasicOutputCollector
 
getPIDDir() - Method in class org.apache.storm.task.WorkerTopologyContext
If this task spawns any subprocesses, those subprocesses must immediately write their PID to this directory on the local filesystem to ensure that Storm properly destroys that process when the worker is shutdown.
getRawTopology() - Method in class org.apache.storm.task.GeneralTopologyContext
Gets the Thrift object representing the topology.
getResource(String) - Method in class org.apache.storm.task.WorkerTopologyContext
 
getScheme() - Method in interface org.apache.storm.spout.IMultiSchemableSpout
 
getScheme() - Method in interface org.apache.storm.topology.ISchemableSpout
 
getSharedExecutor() - Method in class org.apache.storm.task.WorkerTopologyContext
 
getShort(int) - Method in interface org.apache.storm.tuple.Tuple
Returns the Short at position i in the tuple.
getShort(int) - Method in class org.apache.storm.tuple.TupleImpl
Returns the Short at position i in the tuple.
getShortByField(String) - Method in interface org.apache.storm.tuple.Tuple
Gets the Short field with a specific name.
getShortByField(String) - Method in class org.apache.storm.tuple.TupleImpl
 
getSourceComponent() - Method in interface org.apache.storm.tuple.Tuple
Gets the id of the component that created this tuple.
getSourceComponent() - Method in class org.apache.storm.tuple.TupleImpl
Gets the id of the component that created this tuple.
getSourceStreamId() - Method in interface org.apache.storm.tuple.Tuple
Gets the id of the stream that this tuple was emitted to.
getSourceStreamId() - Method in class org.apache.storm.tuple.TupleImpl
Gets the id of the stream that this tuple was emitted to.
getSourceTask() - Method in interface org.apache.storm.tuple.Tuple
Gets the id of the task that created this tuple.
getSourceTask() - Method in class org.apache.storm.tuple.TupleImpl
Gets the id of the task that created this tuple.
getStartTimestamp() - Method in class org.apache.storm.windowing.TupleWindowImpl
 
getStartTimestamp() - Method in interface org.apache.storm.windowing.Window
Returns the window start timestamp.
getState() - Method in interface org.apache.storm.ILocalCluster
 
getState() - Method in class org.apache.storm.LocalCluster
 
getStormId() - Method in class org.apache.storm.task.GeneralTopologyContext
Gets the unique id assigned to this topology.
getStormTopology() - Method in class org.apache.storm.generated.StormTopology
 
getString(int) - Method in interface org.apache.storm.tuple.Tuple
Returns the String at position i in the tuple.
getString(int) - Method in class org.apache.storm.tuple.TupleImpl
Returns the String at position i in the tuple.
getStringByField(String) - Method in interface org.apache.storm.tuple.Tuple
Gets the String field with a specific name.
getStringByField(String) - Method in class org.apache.storm.tuple.TupleImpl
 
getTaskData(String) - Method in class org.apache.storm.task.TopologyContext
 
getTaskToComponent() - Method in class org.apache.storm.task.GeneralTopologyContext
Gets a map from task id to component id.
getThisComponentId() - Method in class org.apache.storm.task.TopologyContext
Gets the component id for this task.
getThisOutputFields(String) - Method in class org.apache.storm.task.TopologyContext
Gets the declared output fields for the specified stream id for the component this task is a part of.
getThisStreams() - Method in class org.apache.storm.task.TopologyContext
Gets the set of streams declared for the component of this task.
getThisTaskId() - Method in class org.apache.storm.task.TopologyContext
Gets the task id of this task.
getThisTaskIndex() - Method in class org.apache.storm.task.TopologyContext
Gets the index of this task id in getComponentTasks(getThisComponentId()).
getThisWorkerPort() - Method in class org.apache.storm.task.WorkerTopologyContext
Return the port that the worker is running on.
getThisWorkerTasks() - Method in class org.apache.storm.task.WorkerTopologyContext
Gets all the task ids that are running in this worker process (including the task for this task).
getTimeCounts() - Method in class org.apache.storm.metric.internal.CountStatAndMetric
 
getTimeLatAvg() - Method in class org.apache.storm.metric.internal.LatencyStatAndMetric
 
getTimestampExtractor() - Method in class org.apache.storm.topology.base.BaseWindowedBolt
 
getTimestampExtractor() - Method in interface org.apache.storm.topology.IWindowedBolt
Return a TimestampExtractor for extracting timestamps from a tuple for event time based processing, or null for processing time.
getTimestampExtractor() - Method in class org.apache.storm.topology.IWindowedBoltDelegate
 
getTopology(String) - Method in interface org.apache.storm.ILocalCluster
 
getTopology(String) - Method in class org.apache.storm.LocalCluster
 
getTopologyConf(String) - Method in interface org.apache.storm.ILocalCluster
 
getTopologyConf(String) - Method in class org.apache.storm.LocalCluster
 
getValue(int) - Method in interface org.apache.storm.tuple.Tuple
Gets the field at position i in the tuple.
getValue(int) - Method in class org.apache.storm.tuple.TupleImpl
Gets the field at position i in the tuple.
getValueAndReset() - Method in class org.apache.storm.metric.api.AssignableMetric
 
getValueAndReset() - Method in class org.apache.storm.metric.api.CombinedMetric
 
getValueAndReset() - Method in class org.apache.storm.metric.api.CountMetric
 
getValueAndReset() - Method in interface org.apache.storm.metric.api.IMetric
 
getValueAndReset() - Method in class org.apache.storm.metric.api.MetricDelegate
 
getValueAndReset() - Method in class org.apache.storm.metric.api.MultiCountMetric
 
getValueAndReset() - Method in class org.apache.storm.metric.api.MultiReducedMetric
 
getValueAndReset() - Method in class org.apache.storm.metric.api.ReducedMetric
 
getValueAndReset() - Method in class org.apache.storm.metric.internal.CountStatAndMetric
 
getValueAndReset() - Method in class org.apache.storm.metric.internal.LatencyStatAndMetric
 
getValueByField(String) - Method in interface org.apache.storm.tuple.Tuple
Gets the field with a specific name.
getValueByField(String) - Method in class org.apache.storm.tuple.TupleImpl
 
getValues() - Method in interface org.apache.storm.tuple.Tuple
Gets all the values in this tuple.
getValues() - Method in class org.apache.storm.tuple.TupleImpl
Gets all the values in this tuple.
globalGrouping(String) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
globalGrouping(String) - Method in interface org.apache.storm.topology.InputDeclarer
 
globalGrouping(String, String) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
globalGrouping(String, String) - Method in interface org.apache.storm.topology.InputDeclarer
 
GlobalMetrics - Class in org.apache.storm.metric.api
 
GlobalStreamId - Class in org.apache.storm.generated
 
GlobalStreamId() - Constructor for class org.apache.storm.generated.GlobalStreamId
 
GlobalStreamId(String, String) - Constructor for class org.apache.storm.generated.GlobalStreamId
 

H

handleDataPoints(IMetricsConsumer.TaskInfo, Collection<IMetricsConsumer.DataPoint>) - Method in interface org.apache.storm.metric.api.IMetricsConsumer
 
hashCode() - Method in class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
 
hashCode() - Method in class org.apache.storm.topology.base.BaseWindowedBolt.Count
 
hashCode() - Method in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
 
hashCode() - Method in class org.apache.storm.tuple.TupleImpl
 
HeronPluggableSerializerDelegate - Class in org.apache.storm.serialization
 
HeronPluggableSerializerDelegate() - Constructor for class org.apache.storm.serialization.HeronPluggableSerializerDelegate
 
hours(int) - Static method in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
Returns a BaseWindowedBolt.Duration corresponding to the the given value in hours.

I

IBasicBolt - Interface in org.apache.storm.topology
 
IBasicOutputCollector - Interface in org.apache.storm.topology
 
IBolt - Interface in org.apache.storm.task
An IBolt represents a component that takes tuples as input and produces tuples as output.
ICombiner<T> - Interface in org.apache.storm.metric.api
 
IComponent - Interface in org.apache.storm.topology
Common methods for all possible components in a topology.
identity() - Method in interface org.apache.storm.metric.api.ICombiner
 
IErrorReporter - Interface in org.apache.storm.task
 
IKryoDecorator - Interface in org.apache.storm.serialization
 
IKryoFactory - Interface in org.apache.storm.serialization
An interface that controls the Kryo instance used by Storm for serialization.
ILocalCluster - Interface in org.apache.storm
 
IMetric - Interface in org.apache.storm.metric.api
 
IMetricsConsumer - Interface in org.apache.storm.metric.api
 
IMetricsConsumer.DataPoint - Class in org.apache.storm.metric.api
 
IMetricsConsumer.TaskInfo - Class in org.apache.storm.metric.api
 
IMetricsContext - Interface in org.apache.storm.task
 
IMultiSchemableSpout - Interface in org.apache.storm.spout
 
incBy(long) - Method in class org.apache.storm.metric.internal.CountStatAndMetric
 
incr() - Method in class org.apache.storm.metric.api.CountMetric
 
incr(String) - Static method in class org.apache.storm.metric.api.GlobalMetrics
Not thread safe increment of counterName.
incrBy(long) - Method in class org.apache.storm.metric.api.CountMetric
 
incrBy(String, int) - Static method in class org.apache.storm.metric.api.GlobalMetrics
Not thread safe 'incrementing by' of counterName.
indexOf(Object) - Method in class org.apache.storm.utils.ListDelegate
 
init() - Method in interface org.apache.storm.metric.api.IReducer
 
init() - Method in class org.apache.storm.metric.api.MeanReducer
 
initialize(Map) - Method in class org.apache.storm.serialization.HeronPluggableSerializerDelegate
 
InputDeclarer<T extends InputDeclarer> - Interface in org.apache.storm.topology
 
InvalidTopologyException - Exception in org.apache.storm.generated
 
InvalidTopologyException() - Constructor for exception org.apache.storm.generated.InvalidTopologyException
 
IOutputCollector - Interface in org.apache.storm.task
 
IReducer<T> - Interface in org.apache.storm.metric.api
 
IRichBolt - Interface in org.apache.storm.topology
When writing topologies using Java, IRichBolt and IRichSpout are the main interfaces to use to implement components of the topology.
IRichBoltDelegate - Class in org.apache.storm.topology
When writing topologies using Java, IRichBolt and IRichSpout are the main interfaces to use to implement components of the topology.
IRichBoltDelegate(IRichBolt) - Constructor for class org.apache.storm.topology.IRichBoltDelegate
 
IRichSpout - Interface in org.apache.storm.topology
When writing topologies using Java, IRichBolt and IRichSpout are the main interfaces to use to implement components of the topology.
IRichSpoutDelegate - Class in org.apache.storm.topology
When writing topologies using Java, IRichBolt and IRichSpout are the main interfaces to use to implement components of the topology.
IRichSpoutDelegate(IRichSpout) - Constructor for class org.apache.storm.topology.IRichSpoutDelegate
 
ISchemableSpout - Interface in org.apache.storm.topology
 
isEmpty() - Method in class org.apache.storm.utils.ListDelegate
 
ISpout - Interface in org.apache.storm.spout
ISpout is the core interface for implementing spouts.
ISpoutOutputCollector - Interface in org.apache.storm.spout
 
ISpoutPartition - Interface in org.apache.storm.trident.spout
 
ISpoutWaitStrategy - Interface in org.apache.storm.spout
The strategy a spout needs to use when its waiting.
isSimulating() - Static method in class org.apache.storm.utils.Time
 
isThreadWaiting(Thread) - Static method in class org.apache.storm.utils.Time
 
isTick(Tuple) - Static method in class org.apache.storm.utils.TupleUtils
 
ITaskHook - Interface in org.apache.storm.hooks
 
ITaskHookDelegate - Class in org.apache.storm.hooks
There would be types of task hooks inside ITaskHookDelegate: 1.
ITaskHookDelegate() - Constructor for class org.apache.storm.hooks.ITaskHookDelegate
 
iterator() - Method in class org.apache.storm.tuple.Fields
 
iterator() - Method in class org.apache.storm.utils.ListDelegate
 
IWindowedBolt - Interface in org.apache.storm.topology
A bolt abstraction for supporting time and count based sliding & tumbling windows.
IWindowedBoltDelegate - Class in org.apache.storm.topology
 
IWindowedBoltDelegate(IWindowedBolt) - Constructor for class org.apache.storm.topology.IWindowedBoltDelegate
 

J

java.backtype.storm - package java.backtype.storm
 
java.backtype.storm.generated - package java.backtype.storm.generated
 
java.backtype.storm.grouping - package java.backtype.storm.grouping
 
java.backtype.storm.hooks - package java.backtype.storm.hooks
 
java.backtype.storm.hooks.info - package java.backtype.storm.hooks.info
 
java.backtype.storm.metric.api - package java.backtype.storm.metric.api
 
java.backtype.storm.serialization - package java.backtype.storm.serialization
 
java.backtype.storm.spout - package java.backtype.storm.spout
 
java.backtype.storm.task - package java.backtype.storm.task
 
java.backtype.storm.testing - package java.backtype.storm.testing
 
java.backtype.storm.topology - package java.backtype.storm.topology
 
java.backtype.storm.topology.base - package java.backtype.storm.topology.base
 
java.backtype.storm.tuple - package java.backtype.storm.tuple
 
java.backtype.storm.utils - package java.backtype.storm.utils
 
java.clojure.lang - package java.clojure.lang
 
java.storm.trident.spout - package java.storm.trident.spout
 
java.storm.trident.state - package java.storm.trident.state
 

K

killTopology(String) - Method in interface org.apache.storm.ILocalCluster
 
killTopology(String) - Method in class org.apache.storm.LocalCluster
 
KryoSerializableDefault() - Constructor for class org.apache.storm.serialization.DefaultKryoFactory.KryoSerializableDefault
 

L

lastIndexOf(Object) - Method in class org.apache.storm.utils.ListDelegate
 
LatencyStatAndMetric - Class in org.apache.storm.metric.internal
 
LatencyStatAndMetric(int) - Constructor for class org.apache.storm.metric.internal.LatencyStatAndMetric
 
ListDelegate - Class in org.apache.storm.utils
 
ListDelegate() - Constructor for class org.apache.storm.utils.ListDelegate
 
listHashCode(List<T>) - Static method in class org.apache.storm.utils.TupleUtils
 
listIterator() - Method in class org.apache.storm.utils.ListDelegate
 
listIterator(int) - Method in class org.apache.storm.utils.ListDelegate
 
LocalCluster - Class in org.apache.storm
 
LocalCluster() - Constructor for class org.apache.storm.LocalCluster
 
localOrShuffleGrouping(String) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
localOrShuffleGrouping(String) - Method in interface org.apache.storm.topology.InputDeclarer
 
localOrShuffleGrouping(String, String) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
localOrShuffleGrouping(String, String) - Method in interface org.apache.storm.topology.InputDeclarer
 
LOG - Static variable in class org.apache.storm.serialization.SerializationFactory
 

M

MeanReducer - Class in org.apache.storm.metric.api
 
MeanReducer() - Constructor for class org.apache.storm.metric.api.MeanReducer
 
messageId - Variable in class org.apache.storm.hooks.info.SpoutAckInfo
 
messageId - Variable in class org.apache.storm.hooks.info.SpoutFailInfo
 
MetricDelegate - Class in org.apache.storm.metric.api
 
MetricDelegate(IMetric) - Constructor for class org.apache.storm.metric.api.MetricDelegate
 
millisToNanos(long) - Static method in class org.apache.storm.utils.Time
 
minutes(int) - Static method in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
Returns a BaseWindowedBolt.Duration corresponding to the the given value in minutes.
MultiCountMetric - Class in org.apache.storm.metric.api
 
MultiCountMetric() - Constructor for class org.apache.storm.metric.api.MultiCountMetric
 
MultiReducedMetric - Class in org.apache.storm.metric.api
 
MultiReducedMetric(IReducer) - Constructor for class org.apache.storm.metric.api.MultiReducedMetric
 
MultiScheme - Interface in org.apache.storm.spout
 

N

name - Variable in class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
 
nanosToMillis(long) - Static method in class org.apache.storm.utils.Time
 
nanoTime() - Static method in class org.apache.storm.utils.Time
 
newInstance(String) - Static method in class org.apache.storm.utils.Utils
 
nextTuple() - Method in interface org.apache.storm.spout.ISpout
When this method is called, Storm is requesting that the Spout emit tuples to the output collector.
nextTuple() - Method in class org.apache.storm.testing.TestWordSpout
 
nextTuple() - Method in class org.apache.storm.topology.IRichSpoutDelegate
 
noneGrouping(String) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
noneGrouping(String) - Method in interface org.apache.storm.topology.InputDeclarer
 
noneGrouping(String, String) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
noneGrouping(String, String) - Method in interface org.apache.storm.topology.InputDeclarer
 
NotAliveException - Exception in org.apache.storm.generated
 
NotAliveException() - Constructor for exception org.apache.storm.generated.NotAliveException
 
NothingEmptyEmitStrategy - Class in org.apache.storm.spout
 
NothingEmptyEmitStrategy() - Constructor for class org.apache.storm.spout.NothingEmptyEmitStrategy
 

O

of(int) - Static method in class org.apache.storm.topology.base.BaseWindowedBolt.Count
Returns a BaseWindowedBolt.Count of given value.
of(int) - Static method in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
Returns a BaseWindowedBolt.Duration corresponding to the the given value in milli seconds.
of(String) - Static method in class org.apache.storm.topology.TupleFieldTimestampExtractor
 
onTickTuple(Tuple) - Method in class org.apache.storm.topology.base.BaseTickTupleAwareRichBolt
Process a single tick tuple of input.
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.apache.storm.topology.IRichSpoutDelegate
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in interface org.apache.storm.spout.ISpout
Called when a task for this component is initialized within a worker on the cluster.
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.apache.storm.testing.TestWordSpout
 
org.apache.storm - package org.apache.storm
 
org.apache.storm.clojure.lang - package org.apache.storm.clojure.lang
 
org.apache.storm.generated - package org.apache.storm.generated
 
org.apache.storm.grouping - package org.apache.storm.grouping
 
org.apache.storm.hooks - package org.apache.storm.hooks
 
org.apache.storm.hooks.info - package org.apache.storm.hooks.info
 
org.apache.storm.metric.api - package org.apache.storm.metric.api
 
org.apache.storm.metric.internal - package org.apache.storm.metric.internal
 
org.apache.storm.serialization - package org.apache.storm.serialization
 
org.apache.storm.spout - package org.apache.storm.spout
 
org.apache.storm.task - package org.apache.storm.task
 
org.apache.storm.testing - package org.apache.storm.testing
 
org.apache.storm.topology - package org.apache.storm.topology
 
org.apache.storm.topology.base - package org.apache.storm.topology.base
 
org.apache.storm.trident.spout - package org.apache.storm.trident.spout
 
org.apache.storm.trident.state - package org.apache.storm.trident.state
 
org.apache.storm.tuple - package org.apache.storm.tuple
 
org.apache.storm.utils - package org.apache.storm.utils
 
org.apache.storm.windowing - package org.apache.storm.windowing
 
OutputCollector - Class in org.apache.storm.task
This output collector exposes the API for emitting tuples from an IRichBolt.
OutputCollector(IOutputCollector) - Constructor for class org.apache.storm.task.OutputCollector
 
OutputCollectorImpl - Class in org.apache.storm.task
This output collector exposes the API for emitting tuples from an IRichBolt.
OutputCollectorImpl(OutputCollector) - Constructor for class org.apache.storm.task.OutputCollectorImpl
 
OutputFieldsDeclarer - Interface in org.apache.storm.topology
 
OutputFieldsGetter - Class in org.apache.storm.topology
 
OutputFieldsGetter(OutputFieldsDeclarer) - Constructor for class org.apache.storm.topology.OutputFieldsGetter
 
outTasks - Variable in class org.apache.storm.hooks.info.EmitInfo
 
overrideDefault(boolean) - Method in class org.apache.storm.serialization.DefaultKryoFactory.KryoSerializableDefault
 

P

parkNanos(long) - Static method in class org.apache.storm.utils.Time
 
postDecorate(Kryo, Map) - Method in class org.apache.storm.serialization.DefaultKryoFactory
 
postDecorate(Kryo, Map) - Method in interface org.apache.storm.serialization.IKryoFactory
 
postRegister(Kryo, Map) - Method in class org.apache.storm.serialization.DefaultKryoFactory
 
postRegister(Kryo, Map) - Method in interface org.apache.storm.serialization.IKryoFactory
 
prepare(Map) - Method in interface org.apache.storm.spout.ISpoutWaitStrategy
 
prepare(Map) - Method in class org.apache.storm.spout.NothingEmptyEmitStrategy
 
prepare(Map) - Method in class org.apache.storm.spout.SleepSpoutWaitStrategy
 
prepare(Map<String, Object>, TopologyContext) - Method in class org.apache.storm.hooks.ITaskHookDelegate
 
prepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.storm.topology.IRichBoltDelegate
 
prepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.storm.topology.IWindowedBoltDelegate
 
prepare(Map, Object, TopologyContext, IErrorReporter) - Method in interface org.apache.storm.metric.api.IMetricsConsumer
 
prepare(Map, TopologyContext) - Method in class org.apache.storm.hooks.BaseTaskHook
 
prepare(Map, TopologyContext) - Method in interface org.apache.storm.hooks.ITaskHook
 
prepare(Map, TopologyContext) - Method in class org.apache.storm.topology.base.BaseBasicBolt
 
prepare(Map, TopologyContext) - Method in interface org.apache.storm.topology.IBasicBolt
 
prepare(Map, TopologyContext, OutputCollector) - Method in interface org.apache.storm.task.IBolt
Called when a task for this component is initialized within a worker on the cluster.
prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.storm.topology.BasicBoltExecutor
 
prepare(Map, TopologyContext, OutputCollector) - Method in interface org.apache.storm.topology.IWindowedBolt
This is similar to the IBolt.prepare(Map, TopologyContext, OutputCollector) except that while emitting, the tuples are automatically anchored to the tuples in the inputWindow.
prepare(TopologyContext, String, String, List<Integer>) - Method in class org.apache.storm.grouping.CustomStreamGroupingDelegate
 
prepare(WorkerTopologyContext, GlobalStreamId, List<Integer>) - Method in interface org.apache.storm.grouping.CustomStreamGrouping
Tells the stream grouping at runtime the tasks in the target bolt.
preRegister(Kryo, Map) - Method in class org.apache.storm.serialization.DefaultKryoFactory
 
preRegister(Kryo, Map) - Method in interface org.apache.storm.serialization.IKryoFactory
 
process(Tuple) - Method in class org.apache.storm.topology.base.BaseTickTupleAwareRichBolt
Process a single non-tick tuple of input.
processLatencyMs - Variable in class org.apache.storm.hooks.info.BoltAckInfo
 
putTickFrequencyIntoComponentConfig(Map<String, Object>, int) - Static method in class org.apache.storm.utils.TupleUtils
 

R

RawMultiScheme - Class in org.apache.storm.spout
 
RawMultiScheme() - Constructor for class org.apache.storm.spout.RawMultiScheme
 
RawScheme - Class in org.apache.storm.spout
 
RawScheme() - Constructor for class org.apache.storm.spout.RawScheme
 
read(Kryo, Input, Class) - Method in class org.apache.storm.serialization.SerializableSerializer
 
readCommandLineOpts() - Static method in class org.apache.storm.utils.Utils
 
record(long) - Method in class org.apache.storm.metric.internal.LatencyStatAndMetric
 
reduce(MeanReducerState, Object) - Method in class org.apache.storm.metric.api.MeanReducer
 
reduce(T, Object) - Method in interface org.apache.storm.metric.api.IReducer
 
ReducedMetric - Class in org.apache.storm.metric.api
 
ReducedMetric(IReducer) - Constructor for class org.apache.storm.metric.api.ReducedMetric
 
registerDecorator(Class<? extends IKryoDecorator>) - Method in class org.apache.storm.Config
 
registerDecorator(Map, Class<? extends IKryoDecorator>) - Static method in class org.apache.storm.Config
 
registerMetric(String, ICombiner, int) - Method in interface org.apache.storm.task.IMetricsContext
 
registerMetric(String, ICombiner, int) - Method in class org.apache.storm.task.TopologyContext
 
registerMetric(String, IReducer, int) - Method in interface org.apache.storm.task.IMetricsContext
 
registerMetric(String, IReducer, int) - Method in class org.apache.storm.task.TopologyContext
 
registerMetric(String, T, int) - Method in interface org.apache.storm.task.IMetricsContext
 
registerMetric(String, T, int) - Method in class org.apache.storm.task.TopologyContext
 
registerMetricsConsumer(Class) - Method in class org.apache.storm.Config
 
registerMetricsConsumer(Class, long) - Method in class org.apache.storm.Config
 
registerMetricsConsumer(Class, Object, long) - Method in class org.apache.storm.Config
 
registerSerialization(Class) - Method in class org.apache.storm.Config
 
registerSerialization(Class, Class<? extends Serializer>) - Method in class org.apache.storm.Config
 
registerSerialization(Map, Class) - Static method in class org.apache.storm.Config
 
registerSerialization(Map, Class, Class<? extends Serializer>) - Static method in class org.apache.storm.Config
 
remove(int) - Method in class org.apache.storm.utils.ListDelegate
 
remove(Object) - Method in class org.apache.storm.utils.ListDelegate
 
removeAll(Collection<?>) - Method in class org.apache.storm.utils.ListDelegate
 
ReportedFailedException - Exception in org.apache.storm.topology
 
ReportedFailedException() - Constructor for exception org.apache.storm.topology.ReportedFailedException
 
ReportedFailedException(String) - Constructor for exception org.apache.storm.topology.ReportedFailedException
 
ReportedFailedException(String, Throwable) - Constructor for exception org.apache.storm.topology.ReportedFailedException
 
ReportedFailedException(Throwable) - Constructor for exception org.apache.storm.topology.ReportedFailedException
 
reportError(Throwable) - Method in interface org.apache.storm.spout.ISpoutOutputCollector
 
reportError(Throwable) - Method in class org.apache.storm.spout.SpoutOutputCollector
 
reportError(Throwable) - Method in class org.apache.storm.spout.SpoutOutputCollectorImpl
 
reportError(Throwable) - Method in interface org.apache.storm.task.IErrorReporter
 
reportError(Throwable) - Method in class org.apache.storm.task.OutputCollector
 
reportError(Throwable) - Method in class org.apache.storm.task.OutputCollectorImpl
 
reportError(Throwable) - Method in class org.apache.storm.topology.BasicOutputCollector
 
reportError(Throwable) - Method in interface org.apache.storm.topology.IBasicOutputCollector
 
resetValues() - Method in interface org.apache.storm.tuple.Tuple
Resets the tuple values to null TODO:- Is this needed
resetValues() - Method in class org.apache.storm.tuple.TupleImpl
Resets the tuple values to null TODO:- Is this needed
retainAll(Collection<?>) - Method in class org.apache.storm.utils.ListDelegate
 

S

safeIncr(String) - Static method in class org.apache.storm.metric.api.GlobalMetrics
Thread safe created increment of counterName.
safeIncrBy(String, int) - Static method in class org.apache.storm.metric.api.GlobalMetrics
Thread safe created increment of counterName.
scheme - Variable in class org.apache.storm.spout.SchemeAsMultiScheme
 
Scheme - Interface in org.apache.storm.spout
 
SchemeAsMultiScheme - Class in org.apache.storm.spout
 
SchemeAsMultiScheme(Scheme) - Constructor for class org.apache.storm.spout.SchemeAsMultiScheme
 
scope(String) - Method in class org.apache.storm.metric.api.MultiCountMetric
 
scope(String) - Method in class org.apache.storm.metric.api.MultiReducedMetric
 
seconds(int) - Static method in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
Returns a BaseWindowedBolt.Duration corresponding to the the given value in seconds.
secsToMillis(int) - Static method in class org.apache.storm.utils.Time
 
secsToMillisLong(double) - Static method in class org.apache.storm.utils.Time
 
select(Fields) - Method in interface org.apache.storm.tuple.Tuple
Returns a subset of the tuple based on the fields selector.
select(Fields) - Method in class org.apache.storm.tuple.TupleImpl
Returns a subset of the tuple based on the fields selector.
select(Fields, List<Object>) - Method in class org.apache.storm.tuple.Fields
 
SerializableSerializer - Class in org.apache.storm.serialization
 
SerializableSerializer() - Constructor for class org.apache.storm.serialization.SerializableSerializer
 
SerializationFactory - Class in org.apache.storm.serialization
 
serialize(Object) - Method in class org.apache.storm.serialization.HeronPluggableSerializerDelegate
 
serialize(Object) - Static method in class org.apache.storm.utils.Utils
 
serialize(T) - Method in interface org.apache.storm.trident.state.Serializer
 
Serializer<T> - Interface in org.apache.storm.trident.state
 
set(int, Object) - Method in class org.apache.storm.utils.ListDelegate
 
set_bolts(Map<String, Bolt>) - Method in class org.apache.storm.generated.StormTopology
 
set_componentId(String) - Method in class org.apache.storm.generated.GlobalStreamId
 
set_spouts(Map<String, SpoutSpec>) - Method in class org.apache.storm.generated.StormTopology
 
set_streamId(String) - Method in class org.apache.storm.generated.GlobalStreamId
 
setBolt(String, IBasicBolt) - Method in class org.apache.storm.topology.TopologyBuilder
 
setBolt(String, IBasicBolt, Number) - Method in class org.apache.storm.topology.TopologyBuilder
 
setBolt(String, IRichBolt) - Method in class org.apache.storm.topology.TopologyBuilder
 
setBolt(String, IRichBolt, Number) - Method in class org.apache.storm.topology.TopologyBuilder
 
setBolt(String, IWindowedBolt) - Method in class org.apache.storm.topology.TopologyBuilder
 
setBolt(String, IWindowedBolt, Number) - Method in class org.apache.storm.topology.TopologyBuilder
 
setContext(Tuple) - Method in class org.apache.storm.topology.BasicOutputCollector
 
setDebug(boolean) - Method in class org.apache.storm.Config
 
setDebug(boolean) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
setDebug(boolean) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
 
setDebug(boolean) - Method in class org.apache.storm.topology.SpoutDeclarerImpl
 
setDebug(Map, boolean) - Static method in class org.apache.storm.Config
 
setDelegate(List<Object>) - Method in class org.apache.storm.utils.ListDelegate
 
setEnvironment(Map<String, Object>, Map) - Static method in class org.apache.storm.Config
 
setFallBackOnJavaSerialization(boolean) - Method in class org.apache.storm.Config
 
setFallBackOnJavaSerialization(Map, boolean) - Static method in class org.apache.storm.Config
 
setKryoFactory(Class<? extends IKryoFactory>) - Method in class org.apache.storm.Config
 
setKryoFactory(Map, Class<? extends IKryoFactory>) - Static method in class org.apache.storm.Config
 
setMaxSpoutPending(int) - Method in class org.apache.storm.Config
 
setMaxSpoutPending(Long) - Method in class org.apache.storm.task.SpoutTopologyContext
Sets the Maximum Spout Pending value for this instance of spout
setMaxSpoutPending(Number) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
setMaxSpoutPending(Number) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
 
setMaxSpoutPending(Number) - Method in class org.apache.storm.topology.SpoutDeclarerImpl
 
setMaxSpoutPending(Map, int) - Static method in class org.apache.storm.Config
 
setMaxTaskParallelism(int) - Method in class org.apache.storm.Config
 
setMaxTaskParallelism(Number) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
setMaxTaskParallelism(Number) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
 
setMaxTaskParallelism(Number) - Method in class org.apache.storm.topology.SpoutDeclarerImpl
 
setMaxTaskParallelism(Map, int) - Static method in class org.apache.storm.Config
 
setMessageTimeoutSecs(int) - Method in class org.apache.storm.Config
 
setMessageTimeoutSecs(Map, int) - Static method in class org.apache.storm.Config
 
setNumAckers(int) - Method in class org.apache.storm.Config
 
setNumAckers(Map, int) - Static method in class org.apache.storm.Config
 
setNumTasks(Number) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
setNumTasks(Number) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
 
setNumTasks(Number) - Method in class org.apache.storm.topology.SpoutDeclarerImpl
 
setNumWorkers(int) - Method in class org.apache.storm.Config
 
setNumWorkers(Map, int) - Static method in class org.apache.storm.Config
 
setOptimize(boolean) - Method in class org.apache.storm.Config
Deprecated.
we don't have optimization
setScheme(MultiScheme) - Method in interface org.apache.storm.spout.IMultiSchemableSpout
 
setScheme(Scheme) - Method in interface org.apache.storm.topology.ISchemableSpout
 
setSkipMissingKryoRegistrations(boolean) - Method in class org.apache.storm.Config
 
setSkipMissingKryoRegistrations(Map, boolean) - Static method in class org.apache.storm.Config
 
setSpout(String, IRichSpout) - Method in class org.apache.storm.topology.TopologyBuilder
 
setSpout(String, IRichSpout, Number) - Method in class org.apache.storm.topology.TopologyBuilder
 
setStatsSampleRate(double) - Method in class org.apache.storm.Config
 
setStatsSampleRate(Map, double) - Static method in class org.apache.storm.Config
 
setTaskData(String, Object) - Method in class org.apache.storm.task.TopologyContext
 
setTeamEmail(String) - Method in class org.apache.storm.Config
 
setTeamEmail(Map, String) - Static method in class org.apache.storm.Config
 
setTeamName(String) - Method in class org.apache.storm.Config
 
setTeamName(Map, String) - Static method in class org.apache.storm.Config
 
setTopologyCapTicket(String) - Method in class org.apache.storm.Config
 
setTopologyCapTicket(Map, String) - Static method in class org.apache.storm.Config
 
setTopologyProjectName(String) - Method in class org.apache.storm.Config
 
setTopologyProjectName(Map, String) - Static method in class org.apache.storm.Config
 
setValue(Object) - Method in class org.apache.storm.metric.api.AssignableMetric
 
shuffleGrouping(String) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
shuffleGrouping(String) - Method in interface org.apache.storm.topology.InputDeclarer
 
shuffleGrouping(String, String) - Method in class org.apache.storm.topology.BoltDeclarerImpl
 
shuffleGrouping(String, String) - Method in interface org.apache.storm.topology.InputDeclarer
 
shutdown() - Method in interface org.apache.storm.ILocalCluster
 
shutdown() - Method in class org.apache.storm.LocalCluster
 
SimulatedTime() - Constructor for class org.apache.storm.utils.Time.SimulatedTime
 
SimulatedTime(Number) - Constructor for class org.apache.storm.utils.Time.SimulatedTime
 
size() - Method in class org.apache.storm.tuple.Fields
 
size() - Method in interface org.apache.storm.tuple.Tuple
Returns the number of fields in this tuple.
size() - Method in class org.apache.storm.tuple.TupleImpl
Returns the number of fields in this tuple.
size() - Method in class org.apache.storm.utils.ListDelegate
 
sleep(long) - Static method in class org.apache.storm.utils.Time
 
sleep(long) - Static method in class org.apache.storm.utils.Utils
 
sleepSecs(long) - Static method in class org.apache.storm.utils.Time
 
SleepSpoutWaitStrategy - Class in org.apache.storm.spout
 
SleepSpoutWaitStrategy() - Constructor for class org.apache.storm.spout.SleepSpoutWaitStrategy
 
sleepUntil(long) - Static method in class org.apache.storm.utils.Time
 
sleepUntilNanos(long) - Static method in class org.apache.storm.utils.Time
 
spoutAck(SpoutAckInfo) - Method in class org.apache.storm.hooks.ITaskHookDelegate
 
spoutAck(SpoutAckInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
 
spoutAck(SpoutAckInfo) - Method in interface org.apache.storm.hooks.ITaskHook
 
SpoutAckInfo - Class in org.apache.storm.hooks.info
 
SpoutAckInfo(Object, int, Long) - Constructor for class org.apache.storm.hooks.info.SpoutAckInfo
 
SpoutAckInfo(SpoutAckInfo) - Constructor for class org.apache.storm.hooks.info.SpoutAckInfo
 
SpoutDeclarer - Interface in org.apache.storm.topology
 
SpoutDeclarerImpl - Class in org.apache.storm.topology
 
SpoutDeclarerImpl(SpoutDeclarer) - Constructor for class org.apache.storm.topology.SpoutDeclarerImpl
 
spoutFail(SpoutFailInfo) - Method in class org.apache.storm.hooks.ITaskHookDelegate
 
spoutFail(SpoutFailInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
 
spoutFail(SpoutFailInfo) - Method in interface org.apache.storm.hooks.ITaskHook
 
SpoutFailInfo - Class in org.apache.storm.hooks.info
 
SpoutFailInfo(Object, int, Long) - Constructor for class org.apache.storm.hooks.info.SpoutFailInfo
 
SpoutFailInfo(SpoutFailInfo) - Constructor for class org.apache.storm.hooks.info.SpoutFailInfo
 
SpoutOutputCollector - Class in org.apache.storm.spout
This output collector exposes the API for emitting tuples from an IRichSpout.
SpoutOutputCollector(ISpoutOutputCollector) - Constructor for class org.apache.storm.spout.SpoutOutputCollector
 
SpoutOutputCollectorImpl - Class in org.apache.storm.spout
This output collector exposes the API for emitting tuples from an IRichSpout.
SpoutOutputCollectorImpl(SpoutOutputCollector) - Constructor for class org.apache.storm.spout.SpoutOutputCollectorImpl
 
SpoutSpec - Class in org.apache.storm.generated
 
SpoutSpec(TopologyAPI.Spout) - Constructor for class org.apache.storm.generated.SpoutSpec
 
spoutTaskId - Variable in class org.apache.storm.hooks.info.SpoutAckInfo
 
spoutTaskId - Variable in class org.apache.storm.hooks.info.SpoutFailInfo
 
SpoutTopologyContext - Class in org.apache.storm.task
A TopologyContext that is given to a spout is actually an instance of SpoutTopologyContext.
SpoutTopologyContext(TopologyContext) - Constructor for class org.apache.storm.task.SpoutTopologyContext
 
srcComponentId - Variable in class org.apache.storm.metric.api.IMetricsConsumer.TaskInfo
 
srcTaskId - Variable in class org.apache.storm.metric.api.IMetricsConsumer.TaskInfo
 
srcWorkerHost - Variable in class org.apache.storm.metric.api.IMetricsConsumer.TaskInfo
 
srcWorkerPort - Variable in class org.apache.storm.metric.api.IMetricsConsumer.TaskInfo
 
startup() - Method in interface org.apache.storm.testing.CompletableSpout
 
STORM_ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class org.apache.storm.Config
The connection timeout for clients to ZooKeeper.
STORM_ZOOKEEPER_PORT - Static variable in class org.apache.storm.Config
The port Storm will use to connect to each of the ZooKeeper servers.
STORM_ZOOKEEPER_RETRY_INTERVAL - Static variable in class org.apache.storm.Config
The interval between retries of a Zookeeper operation.
STORM_ZOOKEEPER_RETRY_TIMES - Static variable in class org.apache.storm.Config
The number of times to retry a Zookeeper operation.
STORM_ZOOKEEPER_SERVERS - Static variable in class org.apache.storm.Config
A list of hosts of ZooKeeper servers used to manage the cluster.
STORM_ZOOKEEPER_SESSION_TIMEOUT - Static variable in class org.apache.storm.Config
The session timeout for clients to ZooKeeper.
STORMCOMPAT_TOPOLOGY_AUTO_TASK_HOOKS - Static variable in class org.apache.storm.Config
---- DO NOT USE ----- This variable is used to rewrite the TOPOLOGY_AUTO_TASK_HOOKS variable.
StormSubmitter - Class in org.apache.storm
Use this class to submit topologies to run on the Storm cluster.
StormTopology - Class in org.apache.storm.generated
 
StormTopology() - Constructor for class org.apache.storm.generated.StormTopology
 
StormTopology(HeronTopology) - Constructor for class org.apache.storm.generated.StormTopology
 
stream - Variable in class org.apache.storm.hooks.info.EmitInfo
 
stream - Variable in class org.apache.storm.testing.FixedTuple
 
subList(int, int) - Method in class org.apache.storm.utils.ListDelegate
 
submitTopology(String, Map, StormTopology) - Method in interface org.apache.storm.ILocalCluster
 
submitTopology(String, Map, StormTopology) - Method in class org.apache.storm.LocalCluster
 
submitTopology(String, Map, StormTopology) - Static method in class org.apache.storm.StormSubmitter
Submits a topology to run on the cluster.
SYSTEM_COMPONENT_ID - Static variable in class org.apache.storm.Constants
 
SYSTEM_TICK_STREAM_ID - Static variable in class org.apache.storm.Constants
 

T

taskId - Variable in class org.apache.storm.hooks.info.EmitInfo
 
TaskInfo() - Constructor for class org.apache.storm.metric.api.IMetricsConsumer.TaskInfo
 
TaskInfo(String, int, String, int, long, int) - Constructor for class org.apache.storm.metric.api.IMetricsConsumer.TaskInfo
 
TestWordSpout - Class in org.apache.storm.testing
 
TestWordSpout() - Constructor for class org.apache.storm.testing.TestWordSpout
 
Time - Class in org.apache.storm.utils
This class implements time simulation support.
Time.SimulatedTime - Class in org.apache.storm.utils
 
timestamp - Variable in class org.apache.storm.metric.api.IMetricsConsumer.TaskInfo
 
timestampExtractor - Variable in class org.apache.storm.topology.base.BaseWindowedBolt
 
TimestampExtractor - Interface in org.apache.storm.windowing
Interface to be implemented for extracting timestamp from a tuple.
toArray() - Method in class org.apache.storm.utils.ListDelegate
 
toArray(T[]) - Method in class org.apache.storm.utils.ListDelegate
 
toByteArray(ByteBuffer) - Static method in class org.apache.storm.utils.Utils
 
toJSONString() - Method in class org.apache.storm.task.GeneralTopologyContext
Gets information about who is consuming the outputs of the specified component, and how.
toList() - Method in class org.apache.storm.tuple.Fields
 
TOPOLOGY_ACKER_EXECUTORS - Static variable in class org.apache.storm.Config
How many executors to spawn for ackers.
TOPOLOGY_AUTO_TASK_HOOKS - Static variable in class org.apache.storm.Config
A list of task hooks that are automatically added to every spout and bolt in the topology.
TOPOLOGY_BOLTS_LATE_TUPLE_STREAM - Static variable in class org.apache.storm.Config
Bolt-specific configuration for windowed bolts to specify the name of the stream on which late tuples are going to be emitted.
TOPOLOGY_BOLTS_SLIDING_INTERVAL_COUNT - Static variable in class org.apache.storm.Config
 
TOPOLOGY_BOLTS_SLIDING_INTERVAL_DURATION_MS - Static variable in class org.apache.storm.Config
 
TOPOLOGY_BOLTS_TUPLE_TIMESTAMP_MAX_LAG_MS - Static variable in class org.apache.storm.Config
Bolt-specific configuration for windowed bolts to specify the maximum time lag of the tuple timestamp in milliseconds.
TOPOLOGY_BOLTS_WATERMARK_EVENT_INTERVAL_MS - Static variable in class org.apache.storm.Config
 
TOPOLOGY_BOLTS_WINDOW_LENGTH_COUNT - Static variable in class org.apache.storm.Config
 
TOPOLOGY_BOLTS_WINDOW_LENGTH_DURATION_MS - Static variable in class org.apache.storm.Config
 
TOPOLOGY_CAP_TICKET - Static variable in class org.apache.storm.Config
Cap ticket (if filed) for the topology.
TOPOLOGY_DEBUG - Static variable in class org.apache.storm.Config
When set to true, Storm will log every message that's emitted.
TOPOLOGY_ENABLE_MESSAGE_TIMEOUTS - Static variable in class org.apache.storm.Config
True if Storm should timeout messages or not.
TOPOLOGY_ENVIRONMENT - Static variable in class org.apache.storm.Config
Topology-specific environment variables for the worker child process.
TOPOLOGY_ERROR_THROTTLE_INTERVAL_SECS - Static variable in class org.apache.storm.Config
The interval in seconds to use for determining whether to throttle error reported to Zookeeper.
TOPOLOGY_FALL_BACK_ON_JAVA_SERIALIZATION - Static variable in class org.apache.storm.Config
Whether or not to use Java serialization in a topology.
TOPOLOGY_KRYO_DECORATORS - Static variable in class org.apache.storm.Config
A list of classes that customize storm's kryo instance during start-up.
TOPOLOGY_KRYO_FACTORY - Static variable in class org.apache.storm.Config
Class that specifies how to create a Kryo instance for serialization.
TOPOLOGY_KRYO_REGISTER - Static variable in class org.apache.storm.Config
A list of serialization registrations for Kryo ( http://code.google.com/p/kryo/ ), the underlying serialization framework for Storm.
TOPOLOGY_MAX_ERROR_REPORT_PER_INTERVAL - Static variable in class org.apache.storm.Config
See doc for TOPOLOGY_ERROR_THROTTLE_INTERVAL_SECS.
TOPOLOGY_MAX_SPOUT_PENDING - Static variable in class org.apache.storm.Config
The maximum number of tuples that can be pending on a spout task at any given time.
TOPOLOGY_MAX_TASK_PARALLELISM - Static variable in class org.apache.storm.Config
The maximum parallelism allowed for a component in this topology.
TOPOLOGY_MESSAGE_TIMEOUT_SECS - Static variable in class org.apache.storm.Config
The maximum amount of time given to the topology to fully process a message emitted by a spout.
TOPOLOGY_METRICS_CONSUMER_REGISTER - Static variable in class org.apache.storm.Config
 
TOPOLOGY_NAME - Static variable in class org.apache.storm.Config
Name of the topology.
TOPOLOGY_OPTIMIZE - Static variable in class org.apache.storm.Config
Whether or not the master should optimize topologies by running multiple tasks in a single thread where appropriate.
TOPOLOGY_PROJECT_NAME - Static variable in class org.apache.storm.Config
Project name of the topology, to help us with tagging which topologies are part of which project.
TOPOLOGY_SKIP_MISSING_KRYO_REGISTRATIONS - Static variable in class org.apache.storm.Config
Whether or not Storm should skip the loading of kryo registrations for which it does not know the class or have the serializer implementation.
TOPOLOGY_SLEEP_SPOUT_WAIT_STRATEGY_TIME_MS - Static variable in class org.apache.storm.Config
The amount of milliseconds the SleepEmptyEmitStrategy should sleep for.
TOPOLOGY_SPOUT_WAIT_STRATEGY - Static variable in class org.apache.storm.Config
A class that implements a strategy for what to do when a spout needs to wait.
TOPOLOGY_STATE_SYNCHRONIZATION_TIMEOUT_SECS - Static variable in class org.apache.storm.Config
The maximum amount of time a component gives a source of state to synchronize before it requests synchronization again.
TOPOLOGY_STATS_SAMPLE_RATE - Static variable in class org.apache.storm.Config
The percentage of tuples to sample to produce stats for a task.
TOPOLOGY_TASKS - Static variable in class org.apache.storm.Config
How many instances to create for a spout/bolt.
TOPOLOGY_TEAM_EMAIL - Static variable in class org.apache.storm.Config
Email of the team which owns this topology.
TOPOLOGY_TEAM_NAME - Static variable in class org.apache.storm.Config
Name of the team which owns this topology.
TOPOLOGY_TICK_TUPLE_FREQ_SECS - Static variable in class org.apache.storm.Config
How often a tick tuple from the "__system" component and "__tick" stream should be sent to tasks.
TOPOLOGY_TRANSACTIONAL_ID - Static variable in class org.apache.storm.Config
This config is available for TransactionalSpouts, and contains the id ( a String) for the transactional topology.
TOPOLOGY_WORKER_CHILDOPTS - Static variable in class org.apache.storm.Config
Topology-specific options for the worker child process.
TOPOLOGY_WORKERS - Static variable in class org.apache.storm.Config
This currently gets translated to TOPOLOGY_STMGRS.
TopologyBuilder - Class in org.apache.storm.topology
 
TopologyBuilder() - Constructor for class org.apache.storm.topology.TopologyBuilder
 
TopologyContext - Class in org.apache.storm.task
A TopologyContext is given to bolts and spouts in their "prepare" and "open" methods, respectively.
TopologyContext(TopologyContext) - Constructor for class org.apache.storm.task.TopologyContext
 
TopologyContext(StormTopology, Map, Map<Integer, String>, Map<String, List<Integer>>, Map<String, Map<String, Fields>>, String, String, String, Integer, Integer, List<Integer>, Map<String, Object>, Map<String, Object>, Map<String, Object>, Map<String, Object>, Atom) - Constructor for class org.apache.storm.task.TopologyContext
 
toString() - Method in class org.apache.storm.generated.StormTopology
 
toString() - Method in class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
 
toString() - Method in class org.apache.storm.testing.FixedTuple
 
toString() - Method in class org.apache.storm.topology.base.BaseWindowedBolt.Count
 
toString() - Method in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
 
toString() - Method in class org.apache.storm.topology.TupleFieldTimestampExtractor
 
toString() - Method in class org.apache.storm.tuple.Fields
 
toString() - Method in class org.apache.storm.tuple.TupleImpl
 
TRANSACTIONAL_ZOOKEEPER_PORT - Static variable in class org.apache.storm.Config
The port to use to connect to the transactional zookeeper servers.
TRANSACTIONAL_ZOOKEEPER_ROOT - Static variable in class org.apache.storm.Config
The root directory in ZooKeeper for metadata about TransactionalSpouts.
TRANSACTIONAL_ZOOKEEPER_SERVERS - Static variable in class org.apache.storm.Config
The list of zookeeper servers in which to keep the transactional state.
translateComponentConfig(Map) - Static method in class org.apache.storm.utils.ConfigUtils
Translate storm config to heron config for components
translateConfig(Map) - Static method in class org.apache.storm.utils.ConfigUtils
Translate storm config to heron config for topology
tuple - Variable in class org.apache.storm.hooks.info.BoltAckInfo
 
tuple - Variable in class org.apache.storm.hooks.info.BoltExecuteInfo
 
tuple - Variable in class org.apache.storm.hooks.info.BoltFailInfo
 
tuple(Object...) - Static method in class org.apache.storm.utils.Utils
 
Tuple - Interface in org.apache.storm.tuple
The tuple is the main data structure in Storm.
TupleFieldTimestampExtractor - Class in org.apache.storm.topology
A TimestampExtractor that extracts timestamp from a specific field in the tuple.
TupleImpl - Class in org.apache.storm.tuple
The tuple is the main data structure in Storm.
TupleImpl(Tuple) - Constructor for class org.apache.storm.tuple.TupleImpl
 
TupleUtils - Class in org.apache.storm.utils
 
TupleWindow - Interface in org.apache.storm.windowing
A Window that contains Tuple objects.
TupleWindowImpl - Class in org.apache.storm.windowing
 
TupleWindowImpl(TupleWindow) - Constructor for class org.apache.storm.windowing.TupleWindowImpl
 

U

unset_componentId() - Method in class org.apache.storm.generated.GlobalStreamId
 
unset_streamId() - Method in class org.apache.storm.generated.GlobalStreamId
 
update(Object) - Method in class org.apache.storm.metric.api.CombinedMetric
 
update(Object) - Method in class org.apache.storm.metric.api.ReducedMetric
 
update(TopologyContext) - Method in class org.apache.storm.topology.BasicBoltExecutor
 
update(TopologyContext) - Method in class org.apache.storm.topology.IRichBoltDelegate
 
update(TopologyContext) - Method in class org.apache.storm.topology.IRichSpoutDelegate
 
updateIntervalSecs - Variable in class org.apache.storm.metric.api.IMetricsConsumer.TaskInfo
 
Utils - Class in org.apache.storm.utils
 

V

value - Variable in class org.apache.storm.metric.api.IMetricsConsumer.DataPoint
 
value - Variable in class org.apache.storm.topology.base.BaseWindowedBolt.Count
 
value - Variable in class org.apache.storm.topology.base.BaseWindowedBolt.Duration
 
values - Variable in class org.apache.storm.hooks.info.EmitInfo
 
values - Variable in class org.apache.storm.testing.FixedTuple
 
Values - Class in org.apache.storm.tuple
A convenience class for making tuple values using new Values("field1", 2, 3) syntax.
Values() - Constructor for class org.apache.storm.tuple.Values
 
Values(Object...) - Constructor for class org.apache.storm.tuple.Values
 

W

Window<T> - Interface in org.apache.storm.windowing
A view of events in a sliding window.
windowConfiguration - Variable in class org.apache.storm.topology.base.BaseWindowedBolt
 
withLag(BaseWindowedBolt.Duration) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
Specify the maximum time lag of the tuple timestamp in milliseconds.
withLateTupleStream(String) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
Specify a stream id on which late tuples are going to be emitted.
withTimestampExtractor(TimestampExtractor) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
Specify the timestamp extractor implementation.
withTimestampField(String) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
Specify a field in the tuple that represents the timestamp as a long value.
withTumblingWindow(BaseWindowedBolt.Count) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
A count based tumbling window.
withTumblingWindow(BaseWindowedBolt.Duration) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
A time duration based tumbling window.
withWatermarkInterval(BaseWindowedBolt.Duration) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
Specify the watermark event generation interval.
withWindow(BaseWindowedBolt.Count) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
A tuple count based window that slides with every incoming tuple.
withWindow(BaseWindowedBolt.Count, BaseWindowedBolt.Count) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
Tuple count based sliding window configuration.
withWindow(BaseWindowedBolt.Count, BaseWindowedBolt.Duration) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
Tuple count and time duration based sliding window configuration.
withWindow(BaseWindowedBolt.Duration) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
A time duration based window that slides with every incoming tuple.
withWindow(BaseWindowedBolt.Duration, BaseWindowedBolt.Count) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
Time duration and count based sliding window configuration.
withWindow(BaseWindowedBolt.Duration, BaseWindowedBolt.Duration) - Method in class org.apache.storm.topology.base.BaseWindowedBolt
Time duration based sliding window configuration.
WorkerTopologyContext - Class in org.apache.storm.task
 
WorkerTopologyContext(TopologyContext) - Constructor for class org.apache.storm.task.WorkerTopologyContext
 
WorkerTopologyContext(StormTopology, Map, Map<Integer, String>, Map<String, List<Integer>>, Map<String, Map<String, Fields>>, String, String, String, Integer, List<Integer>, Map<String, Object>, Map<String, Object>) - Constructor for class org.apache.storm.task.WorkerTopologyContext
 
write(Kryo, Output, Object) - Method in class org.apache.storm.serialization.SerializableSerializer
 
A B C D E F G H I J K L M N O P R S T U V W 
All Classes All Packages