All Classes Interface Summary Class Summary Enum Summary Exception Summary
Class |
Description |
AbstractBaseTriggerPolicy<T extends Serializable,S> |
|
AllStreamGrouping |
This is the stream grouping strategy that all tuples are transmitted to all instances of a bolt.
|
AlreadyAliveException |
|
AssignableMetric<T> |
|
BaseBasicBolt |
|
BaseComponent |
|
BaseComponentDeclarer<T extends ComponentConfigurationDeclarer<?>> |
|
BaseConfigurationDeclarer<T extends ComponentConfigurationDeclarer<?>> |
|
BaseRichBolt |
|
BaseRichSpout |
|
BaseStatefulWindowedBolt<K extends Serializable,V extends Serializable> |
|
BaseTaskHook |
|
BaseWindowedBolt |
|
BaseWindowedBolt.Count |
Holds a count value for count based windows and sliding intervals.
|
BasicBoltExecutor |
|
BasicOutputCollector |
|
BoltAckInfo |
|
BoltDeclarer |
|
BoltExecuteInfo |
|
BoltFailInfo |
|
Builder |
Builder is used to register all sources.
|
BuilderImpl |
BuilderImpl implements the Builder interface.
|
CombinedMetric<T> |
|
ComplexSink<R> |
ConsumerSink is a very simple Sink that basically invokes a user supplied
consume function for every tuple.
|
ComplexSource<R> |
SupplierSource is a way to wrap a supplier function inside a Heron Spout.
|
ComponentConfigurationDeclarer<T extends ComponentConfigurationDeclarer<?>> |
|
ConcurrentCountMetric |
|
Config |
Topology configs are specified as a plain old map.
|
Config |
Config is the way users configure the execution of the topology.
|
Config.Builder |
|
Config.DeliverySemantics |
An enum encapsulating the delivery semantics that can be applied to Heron topologies.
|
Config.Serializer |
An enum encapsulating the serializers that can be used for data in the topology.
|
Config.TopologyReliabilityMode |
What is the reliability mode under which we are running this topology
Topology writers must set TOPOLOGY_RELIABILITY_MODE to one
one of the following modes
|
Constants |
|
ConsumerSink<R> |
ConsumerSink is a very simple Sink that basically invokes a user supplied
consume function for every tuple.
|
ConsumerStreamlet<R> |
ConsumerStreamlet represents an empty Streamlet that is made up of elements from the parent
streamlet after consuming every element.
|
Context |
Context is the information available at runtime for operators like transform.
|
ContextImpl |
Context is the information available at runtime for operators like transform.
|
CountByKeyAndWindowStreamlet<R,K> |
CountByKeyAndWindowStreamlet represents a KVStreamlet that is the result of
counting all elements within each window defined by a user supplied Window Config.
|
CountByKeyStreamlet<R,K> |
ReduceByKeyAndWindowStreamlet represents a KVStreamlet that is the result of
applying user supplied reduceFn on all elements within each window defined by a
user supplied Window Config.
|
CountEvictionPolicy<T extends Serializable> |
An eviction policy that tracks event counts and can
evict based on a threshold count.
|
CountMetric |
|
CountStatAndMetric |
Acts as a Count Metric, but also keeps track of approximate counts
for the last 10 mins, 3 hours, 1 day, and all time.
|
CountTriggerPolicy<T extends Serializable> |
|
CountWindowConfig |
CountWindowConfig implements a count based WindowConfig.
|
CumulativeCountMetric |
This is a different kind of counter that value is not
reset after fetched.
|
CustomStreamGrouping |
This is the interface for user defined stream grouping strategies.
|
CustomStreamlet<R,T> |
CustomStreamlet represents a Streamlet that is made up of applying the user
supplied custom operator to each element of the parent streamlet.
|
CustomWindowConfig |
CustomWindowConfig implements a trigger/eviction based WindowConfig.
|
DefaultEvictionContext |
|
DefaultKryoFactory |
|
DefaultKryoFactory.KryoSerializableDefault |
|
DefaultMaxSpoutPendingTuner |
This is a class that helps to auto tune the max spout pending value
|
DirectStreamGrouping |
This is the stream grouping strategy that tuples are sent to the instance of choice.
|
EmitInfo |
|
Event<T extends Serializable> |
An event is a wrapper object that gets stored in the window.
|
EventImpl<T extends Serializable> |
|
EvictionContext |
Context information that can be used by the eviction policy
|
EvictionPolicy<T extends Serializable,S> |
Eviction policy tracks events and decides whether
an event should be evicted from the window or not.
|
EvictionPolicy.Action |
|
FailedException |
|
Fields |
|
FieldsStreamGrouping |
This is the stream grouping strategy that tuples are sent to the particular instance of
the downstream bolt based on the values of a specified fields.
|
FilterOperator<R> |
FilterOperator implements the functionality of the filter operation
It takes in a filterFunction predicate as the input.
|
FilterStreamlet<R> |
FilterStreamlet represents a Streamlet that is made up of elements from
the parent Streamlet after applying a user supplied filter function.
|
FlatMapOperator<R,T> |
FlatMapOperator is the class that implements the flatMap functionality.
|
FlatMapStreamlet<R,T> |
FlatMapStreamlet represents a Streamlet that is made up of applying the user
supplied flatMap function to each element of the parent streamlet and flattening
out the result.
|
GeneralReduceByKeyAndWindowOperator<R,K,T> |
ReduceByKeyAndWindowOperator is the class that implements reduceByKeyAndWindow functionality.
|
GeneralReduceByKeyAndWindowStreamlet<R,K,T> |
ReduceByKeyAndWindowStreamlet represents a KVStreamlet that is the result of
applying user supplied reduceFn on all elements within each window defined by a
user supplied Window Config.
|
GeneralReduceByKeyOperator<R,K,T> |
ReduceByKeyOperator is the class that implements the reduce functionality.
|
GeneralReduceByKeyStreamlet<R,K,T> |
GeneralReduceByKeyStreamlet represents a KVStreamlet that is the result of
applying user supplied reduceFn on all elements.
|
GeneralTopologyContext |
|
GlobalMetrics |
Singleton class which exposes a simple globally available counter for heron jobs.
|
GlobalStreamGrouping |
This is the stream grouping strategy that all tuples are transmitted to a single instance
of a bolt with the lowest task id.
|
HashMapState<K extends Serializable,V extends Serializable> |
A State backed up by HashMap
|
HeronSubmitter |
Use this class to submit topologies to run on the Heron cluster.
|
HeronTopology |
|
IBasicBolt |
|
IBasicOutputCollector |
|
IBolt |
An IBolt represents a component that takes tuples as input and produces tuples
as output.
|
ICombiner<T> |
Interface for classes that are able to combine multiple objects into one result.
|
IComponent |
Common methods for all possible components in a topology.
|
IErrorReporter |
|
IKryoDecorator |
|
IKryoFactory |
An interface that controls the Kryo instance used by Storm for serialization.
|
IMetric<T> |
Interface for a metric that can be tracked
|
IMetricsRegister |
|
IMultiSchemableSpout |
|
InvalidTopologyException |
|
IOutputCollector |
|
IPluggableSerializer |
|
IReducer<T,U,V> |
Apply an update to an accumulator for which a result can be extracted.
|
IRichBolt |
When writing topologies using Java, IRichBolt and
IRichSpout are the main interfaces
to use to implement components of the topology.
|
IRichSpout |
When writing topologies using Java, IRichBolt and
IRichSpout are the main interfaces
to use to implement components of the topology.
|
ISchemableSpout |
|
ISpout |
ISpout is the core interface for implementing spouts.
|
ISpoutOutputCollector |
|
IStatefulComponent<K extends Serializable,V extends Serializable> |
Defines a component that saves its internal state in the State interface
|
IStatefulWindowedBolt<K extends Serializable,V extends Serializable> |
|
IStreamletBasicOperator<R,T> |
The interface for streamlet operators.
|
IStreamletOperator<R,T> |
The base interface for all Streamlet operator interfaces.
|
IStreamletRichOperator<R,T> |
The interface for custom operators: it can be used to create
operators based on existing Bolts (subclasses of IRichBolt).
|
IStreamletWindowOperator<R,T> |
The interface for streamlet operators.
|
ITaskHook |
|
ITwoPhaseStatefulComponent<K extends Serializable,V extends Serializable> |
Defines a stateful component that is aware of Heron topology's "two-phase commit".
|
IUpdatable |
Bolt or spout instances should implement this method if they wish to be informed of changed to
the topology context during the lifecycle of the instance.
|
IWindowedBolt |
A bolt abstraction for supporting time and count based sliding & tumbling windows.
|
JavaSerializer |
|
JoinCustomGrouping<R,K> |
JoinCustomGrouping is the class that routes the incoming tuples into the
JoinOperator.
|
JoinOperator<K,V1,V2,VR> |
JoinOperator is the bolt that implements the join/leftJoin/innerJoin functionality.
|
JoinStreamlet<K,R,S,T> |
JoinStreamlet represents a KVStreamlet that is the result of joining two KVStreamlets left
and right using a WindowConfig.
|
JoinType |
|
KeyByOperator<R,K,V> |
KeyByOperator is the class that implements keyBy functionality.
|
KeyByStreamlet<R,K,V> |
KeyByStreamlet represents a KVStreamlet that is the result of applying key and value extractors
on all elements.
|
KeyedWindow<T> |
Transformation depending on Windowing pass on the window/key information
using this class
|
KeyValue<K,V> |
Certain operations in the Streamlet API, like join/reduce, necessitate
the concept of key value pairs.
|
KryoSerializer |
KryoSerializer is a wrapper around Heron's IPluggableSerializer.
|
KryoSerializer |
KryoSerializer has been moved to heron.api.serializer package so that it can be used
by Heron topologies written in low level API.
|
KVStreamlet<K,V> |
A KVStreamlet is a Streamlet with KeyValue data.
|
KVStreamletShadow<K,V> |
KVStreamletShadow is a decorator for StreamletImpl> objects.
|
LatencyStatAndMetric |
Acts as a Latency Metric, but also keeps track of approximate latency
for the last 10 mins, 3 hours, 1 day, and all time.
|
LogSink<R> |
LogSink is a very simple Bolt that implements the log functionality.
|
LogStreamlet<R> |
LogStreamlet represents en empty Streamlet that is made up of elements from the parent
streamlet after logging each element.
|
MapOperator<R,T> |
MapOperator is the class that implements the map functionality.
|
MapStreamlet<R,T> |
MapStreamlet represents a Streamlet that is made up of applying the user
supplied map function to each element of the parent streamlet.
|
MeanReducer |
|
MeanReducerState |
|
MultiAssignableMetric<T extends Number> |
|
MultiCountMetric |
|
MultiReducedMetric<T,U,V> |
|
MultiScheme |
|
NoneStreamGrouping |
This is the stream grouping strategy that is the same as shuffle grouping.
|
OutputCollector |
This output collector exposes the API for emitting tuples from an IRichBolt.
|
OutputFieldsDeclarer |
|
OutputFieldsGetter |
|
Pair<T1,T2> |
A pair of values.
|
RawMultiScheme |
|
RawScheme |
|
ReduceByKeyAndWindowCustomGrouping<R,K> |
ReduceByKeyAndWindowCustomGrouping is the class that routes the incoming tuples
into the ReduceByKeyAndWindowOperator.
|
ReduceByKeyAndWindowOperator<R,K,T> |
ReduceByKeyAndWindowOperator is the class that implements reduceByKeyAndWindow functionality.
|
ReduceByKeyAndWindowStreamlet<R,K,T> |
ReduceByKeyAndWindowStreamlet represents a KVStreamlet that is the result of
applying user supplied reduceFn on all elements within each window defined by a
user supplied Window Config.
|
ReduceByKeyOperator<R,K,T> |
ReduceByKeyOperator is the class that implements the reduce functionality.
|
ReduceByKeyStreamlet<R,K,T> |
ReduceByKeyStreamlet represents a KVStreamlet that is the result of
applying user supplied reduceFn on all elements.
|
ReducedMetric<T,U,V> |
Apply an update to an metric using an IReducer for which a result can be extracted.
|
RemapCustomGrouping<R> |
RemapCustomGrouping is the class that routes the incoming tuples
into the ReMapBolt.
|
RemapStreamlet<R> |
RemapStreamlet represents a Streamlet that is the result of
applying user supplied remapFn on all elements of its parent Streamlet.
|
ReportedFailedException |
|
Runner |
Runner is used to run a topology that is built by the builder.
|
Scheme |
|
SchemeAsMultiScheme |
|
SerializableBiFunction<A,B,C> |
All user supplied transformation functions have to be serializable.
|
SerializableBinaryOperator<T> |
All user supplied transformation functions have to be serializable.
|
SerializableConsumer<T> |
All user supplied transformation functions have to be serializable.
|
SerializableFunction<A,B> |
All user supplied transformation functions have to be serializable.
|
SerializablePredicate<T> |
All user supplied transformation functions have to be serializable.
|
SerializableSerializer |
|
SerializableSupplier<T> |
All user supplied transformation functions have to be serializable.
|
SerializableTransformer<I,O> |
All user supplied transformation functions have to be serializable.
|
ShuffleStreamGrouping |
This is the stream grouping strategy that tuples are randomly distributed to instances of
the bolt.
|
Sink<T> |
Sink is how Streamlet's end.
|
SinkStreamlet<R> |
SinkStreamlet represents en empty Streamlet that is made up of elements from the parent
streamlet after consuming every element.
|
Slf4jUtils |
|
Source<T> |
Source is how Streamlet's originate.
|
SourceStreamlet<R> |
SourceStreamlet is a very quick and flexible way of creating a Streamlet
from a user supplied Generator Function.
|
SplitOperator<R> |
SplitOperator is the class that implements the split functionality.
|
SplitStreamlet<R> |
SplitStreamlet represents a Streamlet that splits an incoming
stream into multiple streams using a split function.
|
SpoutAckInfo |
|
SpoutDeclarer |
|
SpoutFailInfo |
|
SpoutOutputCollector |
This output collector exposes the API for emitting tuples from an
IRichSpout .
|
SpoutStreamlet<R> |
SpoutStreamlet is a quick way of creating a Streamlet
from an user supplied Spout object.
|
State<K extends Serializable,V extends Serializable> |
State represents the state interface as seen by stateful bolts and spouts.
|
StatefulWindowedBoltExecutor<K extends Serializable,V extends Serializable> |
|
StreamGrouping |
This is the interface of stream grouping at runtime the tasks in the target bolt.
|
Streamlet<R> |
A Streamlet is a (potentially unbounded) ordered collection of tuples.
|
StreamletBase<R> |
A Streamlet is a (potentially unbounded) ordered collection of tuples.
|
StreamletBaseImpl<R> |
A Streamlet is a (potentially unbounded) ordered collection of tuples.
|
StreamletBaseImpl.StreamletNamePrefix |
|
StreamletImpl<R> |
A Streamlet is a (potentially unbounded) ordered collection of tuples.
|
StreamletOperator<R,T> |
The Bolt interface that other operators of the streamlet packages extend.
|
StreamletReducers |
This class contains a few standard reduces that can be used with
Streamlet reduce functions such as reduceByKeyAndWindow.
|
StreamletShadow<R> |
StreamletShadow is a special kind of StreamletImpl object:
- It is still an StreamletImpl therefore it supports all Streamlet functions like filter()
and map(), and can be the parent object of other StreamletImpl objects.
|
StreamletSource |
StreamletSource is the base class for all streamlet sources.
|
StreamletUtils |
|
StreamletWindowOperator<R,T> |
The Bolt interface that other windowed operators of the streamlet packages extend.
|
SupplierSource<R> |
SupplierSource is a way to wrap a supplier function inside a Heron Spout.
|
SupplierStreamlet<R> |
SupplierStreamlet is a very quick and flexible way of creating a Streamlet
from an user supplied Supplier Function.
|
TimeEvictionPolicy<T extends Serializable> |
Eviction policy that evicts events based on time duration.
|
TimestampExtractor |
Interface to be implemented for extracting timestamp from a tuple.
|
TimeTriggerPolicy<T extends Serializable> |
|
TimeWindowConfig |
TimeWindowConfig implements a time based WindowConfig.
|
TopologyBuilder |
TopologyBuilder exposes the Java API for specifying a topology for Heron
to execute.
|
TopologyContext |
A TopologyContext is given to bolts and spouts in their "prepare" and "open"
methods, respectively.
|
TopologySubmissionException |
Thrown to indicate that the application has attempted to submit an invalid topology.
|
TopologyUtils |
Utility to process TopologyAPI.Topology proto
|
TransformOperator<R,T> |
TransformOperator is the class that implements the transform functionality.
|
TransformStreamlet<R,T> |
TransformStreamlet represents a Streamlet that is made up of applying the user
supplied transform function to each element of the parent streamlet.
|
TriggerHandler |
The callback fired by TriggerPolicy when the trigger
condition is satisfied.
|
TriggerPolicy<T extends Serializable,S> |
Triggers the window calculations based on the policy.
|
Tuple |
The tuple is the main data structure in Heron.
|
TupleFieldTimestampExtractor |
|
TupleUtils |
|
TupleWindow |
|
TupleWindowImpl |
Holds the expired, new and current tuples in a window.
|
UnionOperator<I> |
UnionOperator is the class that implements the union functionality.
|
UnionStreamlet<I> |
UnionStreamlet is a Streamlet composed of all the elements of two
parent streamlets.
|
Utils |
|
Values |
A convenience class for making tuple values using new Values("field1", 2, 3)
syntax.
|
WatermarkCountEvictionPolicy<T extends Serializable> |
An eviction policy that tracks count based on watermark ts and
evicts events up to the watermark based on a threshold count.
|
WatermarkCountTriggerPolicy<T extends Serializable> |
A trigger policy that tracks event counts and sets the context for
eviction policy to evict based on latest watermark time.
|
WaterMarkEvent<T extends Serializable> |
Watermark event used for tracking progress of time when
processing event based ts.
|
WaterMarkEventGenerator<T extends Serializable> |
Tracks tuples across input streams and periodically emits watermark events.
|
WatermarkTimeEvictionPolicy<T extends Serializable> |
An eviction policy that evicts events based on time duration taking
watermark time and event lag into account.
|
WatermarkTimeTriggerPolicy<T extends Serializable> |
Handles watermark events and triggers TriggerHandler.onTrigger() for each window
interval that has events to be processed up to the watermark ts.
|
Window<T> |
A view of events in a sliding window.
|
Window |
Window is a container containing information about a particular window.
|
WindowConfig |
WindowConfig allows Streamlet API users to program window configuration for operations
that rely on windowing.
|
WindowedBoltExecutor |
|
WindowingConfigs |
|
WindowLifecycleListener<T> |
A callback for expiry, activation of events tracked by the WindowManager
|
WindowManager<T extends Serializable> |
|