A B C D E F G H I J K L M N O P Q R S T U V W Z
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- AbstractBaseTriggerPolicy<T extends Serializable,S> - Class in org.apache.heron.api.windowing.triggers
- AbstractBaseTriggerPolicy() - Constructor for class org.apache.heron.api.windowing.triggers.AbstractBaseTriggerPolicy
-
Set the requirements in the constructor
- ack(Object) - Method in class org.apache.heron.api.spout.BaseRichSpout
- ack(Object) - Method in interface org.apache.heron.api.spout.ISpout
-
Heron has determined that the tuple emitted by this spout with the msgId identifier has been fully processed.
- ack(Tuple) - Method in interface org.apache.heron.api.bolt.IOutputCollector
- ack(Tuple) - Method in class org.apache.heron.api.bolt.OutputCollector
- activate() - Method in class org.apache.heron.api.spout.BaseRichSpout
- activate() - Method in interface org.apache.heron.api.spout.ISpout
-
Called when a spout has been activated out of a deactivated mode.
- add(Event<T>) - Method in class org.apache.heron.api.windowing.WindowManager
-
Tracks a window event
- add(T) - Method in class org.apache.heron.api.windowing.WindowManager
-
Add an event into the window, with
System.currentTimeMillis()
as the tracking ts. - add(T, long) - Method in class org.apache.heron.api.windowing.WindowManager
-
Add an event into the window, with the given ts as the tracking ts.
- addChild(StreamletBaseImpl<T>) - Method in class org.apache.heron.streamlet.impl.StreamletBaseImpl
- addChild(StreamletBaseImpl<T>) - Method in class org.apache.heron.streamlet.impl.streamlets.StreamletShadow
- addClasspath(Map<String, Object>, String) - Method in class org.apache.heron.api.Config
- addConfiguration(String, Object) - Method in class org.apache.heron.api.topology.BaseConfigurationDeclarer
- addConfiguration(String, Object) - Method in interface org.apache.heron.api.topology.ComponentConfigurationDeclarer
- addConfigurations(Map<String, Object>) - Method in class org.apache.heron.api.topology.BaseComponentDeclarer
- addConfigurations(Map<String, Object>) - Method in interface org.apache.heron.api.topology.ComponentConfigurationDeclarer
- addTaskHook(ITaskHook) - Method in interface org.apache.heron.api.topology.TopologyContext
-
Add a Task Hook for this instance
- allGrouping(String) - Method in class org.apache.heron.api.topology.BoltDeclarer
- allGrouping(String, String) - Method in class org.apache.heron.api.topology.BoltDeclarer
- AllStreamGrouping - Class in org.apache.heron.api.grouping
-
This is the stream grouping strategy that all tuples are transmitted to all instances of a bolt.
- AllStreamGrouping() - Constructor for class org.apache.heron.api.grouping.AllStreamGrouping
- AlreadyAliveException - Exception in org.apache.heron.api.exception
- AlreadyAliveException() - Constructor for exception org.apache.heron.api.exception.AlreadyAliveException
- applyOperator(IStreamletOperator<R, T>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Returns a new Streamlet by applying the operator on each element of this streamlet.
- applyOperator(IStreamletOperator<R, T>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Returns a new Streamlet by applying the operator on each element of this streamlet.
- applyOperator(IStreamletOperator<R, T>, StreamGrouping) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Returns a new Streamlet by applying the operator on each element of this streamlet.
- applyOperator(IStreamletOperator<R, T>, StreamGrouping) - Method in interface org.apache.heron.streamlet.Streamlet
-
Returns a new Streamlet by applying the operator on each element of this streamlet.
- applyTo(BaseWindowedBolt) - Method in class org.apache.heron.streamlet.impl.windowings.CountWindowConfig
-
Apply this WindowConfig object to a bolt object
- applyTo(BaseWindowedBolt) - Method in class org.apache.heron.streamlet.impl.windowings.CustomWindowConfig
-
Apply this WindowConfig object to a bolt object
- applyTo(BaseWindowedBolt) - Method in class org.apache.heron.streamlet.impl.windowings.TimeWindowConfig
-
Apply this WindowConfig object to a bolt object
- applyTo(BaseWindowedBolt) - Method in interface org.apache.heron.streamlet.WindowConfig
-
Apply this WindowConfig object to a bolt object
- AssignableMetric<T> - Class in org.apache.heron.api.metric
- AssignableMetric(T) - Constructor for class org.apache.heron.api.metric.AssignableMetric
- assignKeyToTask(int, List<Integer>) - Static method in class org.apache.heron.api.utils.Utils
- ATLEAST_ONCE - org.apache.heron.api.Config.TopologyReliabilityMode
-
Heron guarantees that each emitted tuple is seen by the downstream components atleast once.
- ATLEAST_ONCE - org.apache.heron.streamlet.Config.DeliverySemantics
- ATMOST_ONCE - org.apache.heron.api.Config.TopologyReliabilityMode
-
Heron provides no guarantees wrt tuple delivery.
- ATMOST_ONCE - org.apache.heron.streamlet.Config.DeliverySemantics
- autoTune(Long) - Method in class org.apache.heron.api.utils.DefaultMaxSpoutPendingTuner
-
Tune max default max spout pending based on progress
B
- BaseBasicBolt - Class in org.apache.heron.api.bolt
- BaseBasicBolt() - Constructor for class org.apache.heron.api.bolt.BaseBasicBolt
- BaseComponent - Class in org.apache.heron.api.topology
- BaseComponent() - Constructor for class org.apache.heron.api.topology.BaseComponent
- BaseComponentDeclarer<T extends ComponentConfigurationDeclarer<?>> - Class in org.apache.heron.api.topology
- BaseComponentDeclarer(String, IComponent, Number) - Constructor for class org.apache.heron.api.topology.BaseComponentDeclarer
- BaseConfigurationDeclarer<T extends ComponentConfigurationDeclarer<?>> - Class in org.apache.heron.api.topology
- BaseConfigurationDeclarer() - Constructor for class org.apache.heron.api.topology.BaseConfigurationDeclarer
- BaseRichBolt - Class in org.apache.heron.api.bolt
- BaseRichBolt() - Constructor for class org.apache.heron.api.bolt.BaseRichBolt
- BaseRichSpout - Class in org.apache.heron.api.spout
- BaseRichSpout() - Constructor for class org.apache.heron.api.spout.BaseRichSpout
- BaseStatefulWindowedBolt<K extends Serializable,V extends Serializable> - Class in org.apache.heron.api.bolt
- BaseStatefulWindowedBolt() - Constructor for class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
- BaseTaskHook - Class in org.apache.heron.api.hooks
- BaseTaskHook() - Constructor for class org.apache.heron.api.hooks.BaseTaskHook
- BaseWindowedBolt - Class in org.apache.heron.api.bolt
- BaseWindowedBolt() - Constructor for class org.apache.heron.api.bolt.BaseWindowedBolt
- BaseWindowedBolt.Count - Class in org.apache.heron.api.bolt
-
Holds a count value for count based windows and sliding intervals.
- BasicBoltExecutor - Class in org.apache.heron.api.bolt
- BasicBoltExecutor(IBasicBolt) - Constructor for class org.apache.heron.api.bolt.BasicBoltExecutor
- BasicOutputCollector - Class in org.apache.heron.api.bolt
- BasicOutputCollector(OutputCollector) - Constructor for class org.apache.heron.api.bolt.BasicOutputCollector
- boltAck(BoltAckInfo) - Method in class org.apache.heron.api.hooks.BaseTaskHook
- boltAck(BoltAckInfo) - Method in interface org.apache.heron.api.hooks.ITaskHook
-
Called in bolt everytime a tuple gets acked
- BoltAckInfo - Class in org.apache.heron.api.hooks.info
- BoltAckInfo(Tuple, int, Duration) - Constructor for class org.apache.heron.api.hooks.info.BoltAckInfo
- BoltDeclarer - Class in org.apache.heron.api.topology
- BoltDeclarer(String, IRichBolt, Number) - Constructor for class org.apache.heron.api.topology.BoltDeclarer
- boltExecute(List<Tuple>, List<Tuple>, List<Tuple>, Long) - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- boltExecute(BoltExecuteInfo) - Method in class org.apache.heron.api.hooks.BaseTaskHook
- boltExecute(BoltExecuteInfo) - Method in interface org.apache.heron.api.hooks.ITaskHook
-
Called in bolt everytime a tuple gets executed
- BoltExecuteInfo - Class in org.apache.heron.api.hooks.info
- BoltExecuteInfo(Tuple, int, Duration) - Constructor for class org.apache.heron.api.hooks.info.BoltExecuteInfo
- boltFail(BoltFailInfo) - Method in class org.apache.heron.api.hooks.BaseTaskHook
- boltFail(BoltFailInfo) - Method in interface org.apache.heron.api.hooks.ITaskHook
-
Called in bolt everytime a tuple gets failed
- BoltFailInfo - Class in org.apache.heron.api.hooks.info
- BoltFailInfo(Tuple, int, Duration) - Constructor for class org.apache.heron.api.hooks.info.BoltFailInfo
- build() - Method in class org.apache.heron.streamlet.Config.Builder
- build() - Method in class org.apache.heron.streamlet.impl.BuilderImpl
-
We start traversing from all sources and build each node.
- build(TopologyBuilder) - Method in class org.apache.heron.streamlet.impl.BuilderImpl
- build(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.StreamletBaseImpl
- build(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.StreamletShadow
- Builder - Interface in org.apache.heron.streamlet
-
Builder is used to register all sources.
- BuilderImpl - Class in org.apache.heron.streamlet.impl
-
BuilderImpl implements the Builder interface.
- BuilderImpl() - Constructor for class org.apache.heron.streamlet.impl.BuilderImpl
- buildStream(String, String) - Method in class org.apache.heron.api.grouping.AllStreamGrouping
- buildStream(String, String) - Method in interface org.apache.heron.api.grouping.CustomStreamGrouping
-
Build InputStream for CustomStreamGrouping implementations.
- buildStream(String, String) - Method in class org.apache.heron.api.grouping.DirectStreamGrouping
- buildStream(String, String) - Method in class org.apache.heron.api.grouping.FieldsStreamGrouping
- buildStream(String, String) - Method in class org.apache.heron.api.grouping.GlobalStreamGrouping
- buildStream(String, String) - Method in class org.apache.heron.api.grouping.NoneStreamGrouping
- buildStream(String, String) - Method in class org.apache.heron.api.grouping.ShuffleStreamGrouping
- buildStream(String, String) - Method in interface org.apache.heron.api.grouping.StreamGrouping
-
Create an InputStream Builder object with the corresponding grouping logic.
C
- checkNotBlank(String, String) - Static method in class org.apache.heron.streamlet.impl.utils.StreamletUtils
-
Verifies not blank text as the utility function.
- checkNotNull(T, String) - Static method in class org.apache.heron.streamlet.impl.utils.StreamletUtils
-
Verifies not null reference as the utility function.
- chooseTasks(List<Object>) - Method in interface org.apache.heron.api.grouping.CustomStreamGrouping
-
This function implements a custom stream grouping.
- chooseTasks(List<Object>) - Method in class org.apache.heron.streamlet.impl.groupings.JoinCustomGrouping
- chooseTasks(List<Object>) - Method in class org.apache.heron.streamlet.impl.groupings.ReduceByKeyAndWindowCustomGrouping
- chooseTasks(List<Object>) - Method in class org.apache.heron.streamlet.impl.groupings.RemapCustomGrouping
- cleanup() - Method in class org.apache.heron.api.bolt.BaseBasicBolt
- cleanup() - Method in class org.apache.heron.api.bolt.BaseRichBolt
- cleanup() - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
- cleanup() - Method in class org.apache.heron.api.bolt.BasicBoltExecutor
- cleanup() - Method in interface org.apache.heron.api.bolt.IBasicBolt
- cleanup() - Method in interface org.apache.heron.api.bolt.IBolt
-
Called when an IBolt is going to be shutdown.
- cleanup() - Method in interface org.apache.heron.api.bolt.IWindowedBolt
- cleanup() - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- cleanup() - Method in class org.apache.heron.api.hooks.BaseTaskHook
- cleanup() - Method in interface org.apache.heron.api.hooks.ITaskHook
-
Called just before the spout/bolt's cleanup method is called.
- cleanup() - Method in class org.apache.heron.streamlet.impl.operators.TransformOperator
- cleanup() - Method in interface org.apache.heron.streamlet.SerializableTransformer
- cleanup() - Method in interface org.apache.heron.streamlet.Sink
- cleanup() - Method in interface org.apache.heron.streamlet.Source
- clone(int) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Clones the current Streamlet.
- clone(int) - Method in interface org.apache.heron.streamlet.Streamlet
-
Clones the current Streamlet.
- close() - Method in class org.apache.heron.api.metric.CountStatAndMetric
- close() - Method in class org.apache.heron.api.metric.LatencyStatAndMetric
- close() - Method in class org.apache.heron.api.spout.BaseRichSpout
- close() - Method in interface org.apache.heron.api.spout.ISpout
-
Called when an ISpout is going to be shutdown.
- collector - Variable in class org.apache.heron.streamlet.impl.operators.StreamletOperator
- collector - Variable in class org.apache.heron.streamlet.impl.operators.StreamletWindowOperator
- collector - Variable in class org.apache.heron.streamlet.impl.sources.StreamletSource
- combine(T, T) - Method in interface org.apache.heron.api.metric.ICombiner
- CombinedMetric<T> - Class in org.apache.heron.api.metric
- CombinedMetric(ICombiner<T>) - Constructor for class org.apache.heron.api.metric.CombinedMetric
- compactWindow() - Method in class org.apache.heron.api.windowing.WindowManager
-
expires events that fall out of the window every EXPIRE_EVENTS_THRESHOLD so that the window does not grow too big.
- ComplexSink<R> - Class in org.apache.heron.streamlet.impl.sinks
-
ConsumerSink is a very simple Sink that basically invokes a user supplied consume function for every tuple.
- ComplexSink(Sink<R>) - Constructor for class org.apache.heron.streamlet.impl.sinks.ComplexSink
- ComplexSource<R> - Class in org.apache.heron.streamlet.impl.sources
-
SupplierSource is a way to wrap a supplier function inside a Heron Spout.
- ComplexSource(Source<R>) - Constructor for class org.apache.heron.streamlet.impl.sources.ComplexSource
- ComponentConfigurationDeclarer<T extends ComponentConfigurationDeclarer<?>> - Interface in org.apache.heron.api.topology
- ConcurrentCountMetric - Class in org.apache.heron.api.metric
- ConcurrentCountMetric() - Constructor for class org.apache.heron.api.metric.ConcurrentCountMetric
- Config - Class in org.apache.heron.api
-
Topology configs are specified as a plain old map.
- Config - Class in org.apache.heron.streamlet
-
Config is the way users configure the execution of the topology.
- Config() - Constructor for class org.apache.heron.api.Config
- Config(Map<String, Object>) - Constructor for class org.apache.heron.api.Config
- Config.Builder - Class in org.apache.heron.streamlet
- Config.DeliverySemantics - Enum in org.apache.heron.streamlet
-
An enum encapsulating the delivery semantics that can be applied to Heron topologies.
- Config.Serializer - Enum in org.apache.heron.streamlet
-
An enum encapsulating the serializers that can be used for data in the topology.
- Config.TopologyReliabilityMode - Enum in org.apache.heron.api
-
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 - Class in org.apache.heron.api
- consume(SerializableConsumer<R>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Applies the consumer function for every element of this streamlet
- consume(SerializableConsumer<R>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Applies the consumer function to every element of the stream This function does not return anything.
- CONSUMER - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- ConsumerSink<R> - Class in org.apache.heron.streamlet.impl.sinks
-
ConsumerSink is a very simple Sink that basically invokes a user supplied consume function for every tuple.
- ConsumerSink(SerializableConsumer<R>) - Constructor for class org.apache.heron.streamlet.impl.sinks.ConsumerSink
- ConsumerStreamlet<R> - Class in org.apache.heron.streamlet.impl.streamlets
-
ConsumerStreamlet represents an empty Streamlet that is made up of elements from the parent streamlet after consuming every element.
- ConsumerStreamlet(StreamletImpl<R>, SerializableConsumer<R>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.ConsumerStreamlet
- contains(String) - Method in class org.apache.heron.api.tuple.Fields
-
Returns true if this contains the specified name of the field.
- contains(String) - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns true if this tuple contains the specified name of the field.
- Context - Interface in org.apache.heron.streamlet
-
Context is the information available at runtime for operators like transform.
- ContextImpl - Class in org.apache.heron.streamlet.impl
-
Context is the information available at runtime for operators like transform.
- ContextImpl(TopologyContext, Map<String, Object>, State<Serializable, Serializable>) - Constructor for class org.apache.heron.streamlet.impl.ContextImpl
- count - Variable in class org.apache.heron.api.metric.MeanReducerState
- Count(int) - Constructor for class org.apache.heron.api.bolt.BaseWindowedBolt.Count
- COUNT - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- countByKey(SerializableFunction<R, K>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Returns a new stream of
by counting tuples in this stream on each key. - countByKey(SerializableFunction<R, K>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Returns a new stream of
by counting tuples in this stream on each key. - countByKeyAndWindow(SerializableFunction<R, K>, WindowConfig) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Returns a new stream of
by counting tuples over a window in this stream on each key. - countByKeyAndWindow(SerializableFunction<R, K>, WindowConfig) - Method in interface org.apache.heron.streamlet.Streamlet
-
Returns a new stream of
by counting tuples over a window in this stream on each key. - CountByKeyAndWindowStreamlet<R,K> - Class in org.apache.heron.streamlet.impl.streamlets
-
CountByKeyAndWindowStreamlet represents a KVStreamlet that is the result of counting all elements within each window defined by a user supplied Window Config.
- CountByKeyAndWindowStreamlet(StreamletImpl<R>, SerializableFunction<R, K>, WindowConfig) - Constructor for class org.apache.heron.streamlet.impl.streamlets.CountByKeyAndWindowStreamlet
- CountByKeyStreamlet<R,K> - Class in org.apache.heron.streamlet.impl.streamlets
-
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.
- CountByKeyStreamlet(StreamletImpl<R>, SerializableFunction<R, K>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.CountByKeyStreamlet
- CountEvictionPolicy<T extends Serializable> - Class in org.apache.heron.api.windowing.evictors
-
An eviction policy that tracks event counts and can evict based on a threshold count.
- CountEvictionPolicy(int) - Constructor for class org.apache.heron.api.windowing.evictors.CountEvictionPolicy
- CountMetric - Class in org.apache.heron.api.metric
- CountMetric() - Constructor for class org.apache.heron.api.metric.CountMetric
- CountStatAndMetric - Class in org.apache.heron.api.metric
-
Acts as a Count Metric, but also keeps track of approximate counts for the last 10 mins, 3 hours, 1 day, and all time.
- CountStatAndMetric(int) - Constructor for class org.apache.heron.api.metric.CountStatAndMetric
-
Constructor
- CountTriggerPolicy<T extends Serializable> - Class in org.apache.heron.api.windowing.triggers
-
A trigger that tracks event counts and calls back
TriggerHandler.onTrigger()
when the count threshold is hit. - CountTriggerPolicy(int) - Constructor for class org.apache.heron.api.windowing.triggers.CountTriggerPolicy
- CountWindowConfig - Class in org.apache.heron.streamlet.impl.windowings
-
CountWindowConfig implements a count based WindowConfig.
- CountWindowConfig(int, int) - Constructor for class org.apache.heron.streamlet.impl.windowings.CountWindowConfig
- create(R, T) - Static method in class org.apache.heron.streamlet.KeyValue
- createJoinStreamlet(StreamletImpl<B>, StreamletImpl<C>, SerializableFunction<B, A>, SerializableFunction<C, A>, WindowConfig, JoinType, SerializableBiFunction<B, C, ? extends D>) - Static method in class org.apache.heron.streamlet.impl.streamlets.JoinStreamlet
- createTopology() - Method in class org.apache.heron.api.topology.TopologyBuilder
- CumulativeCountMetric - Class in org.apache.heron.api.metric
-
This is a different kind of counter that value is not reset after fetched.
- CumulativeCountMetric() - Constructor for class org.apache.heron.api.metric.CumulativeCountMetric
- currentCount - Variable in class org.apache.heron.api.windowing.evictors.CountEvictionPolicy
- currentCount - Variable in class org.apache.heron.api.windowing.evictors.WatermarkCountEvictionPolicy
- CUSTOM - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- CUSTOM_BASIC - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- CUSTOM_WINDOW - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- customGrouping(String, String, CustomStreamGrouping) - Method in class org.apache.heron.api.topology.BoltDeclarer
- customGrouping(String, CustomStreamGrouping) - Method in class org.apache.heron.api.topology.BoltDeclarer
- CustomStreamGrouping - Interface in org.apache.heron.api.grouping
-
This is the interface for user defined stream grouping strategies.
- CustomStreamlet<R,T> - Class in org.apache.heron.streamlet.impl.streamlets
-
CustomStreamlet represents a Streamlet that is made up of applying the user supplied custom operator to each element of the parent streamlet.
- CustomStreamlet(StreamletImpl<R>, IStreamletOperator<R, T>, StreamGrouping) - Constructor for class org.apache.heron.streamlet.impl.streamlets.CustomStreamlet
-
Create a custom streamlet from user defined CustomOperator object.
- CustomWindow(TriggerPolicy<Tuple, ?>, EvictionPolicy<Tuple, ?>) - Static method in interface org.apache.heron.streamlet.WindowConfig
-
Creates a window based on the provided custom trigger and eviction policies
- CustomWindowConfig - Class in org.apache.heron.streamlet.impl.windowings
-
CustomWindowConfig implements a trigger/eviction based WindowConfig.
- CustomWindowConfig(TriggerPolicy<Tuple, ?>, EvictionPolicy<Tuple, ?>) - Constructor for class org.apache.heron.streamlet.impl.windowings.CustomWindowConfig
D
- deactivate() - Method in class org.apache.heron.api.spout.BaseRichSpout
- deactivate() - Method in interface org.apache.heron.api.spout.ISpout
-
Called when a spout has been deactivated.
- declare(boolean, Fields) - Method in interface org.apache.heron.api.topology.OutputFieldsDeclarer
- declare(boolean, Fields) - Method in class org.apache.heron.api.topology.OutputFieldsGetter
- declare(Fields) - Method in interface org.apache.heron.api.topology.OutputFieldsDeclarer
-
Uses default stream id.
- declare(Fields) - Method in class org.apache.heron.api.topology.OutputFieldsGetter
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.heron.api.bolt.BasicBoltExecutor
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- declareOutputFields(OutputFieldsDeclarer) - Method in interface org.apache.heron.api.topology.IComponent
-
Declare the output schema for all the streams of this topology.
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.heron.streamlet.impl.operators.SplitOperator
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.heron.streamlet.impl.operators.StreamletOperator
-
The operators implementing streamlet functionality have some properties.
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.heron.streamlet.impl.operators.StreamletWindowOperator
-
The operators implementing streamlet functionality have some properties.
- declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.heron.streamlet.impl.sources.StreamletSource
-
The sources implementing streamlet functionality have some properties.
- declareStream(String, boolean, Fields) - Method in interface org.apache.heron.api.topology.OutputFieldsDeclarer
- declareStream(String, boolean, Fields) - Method in class org.apache.heron.api.topology.OutputFieldsGetter
- declareStream(String, Fields) - Method in interface org.apache.heron.api.topology.OutputFieldsDeclarer
- declareStream(String, Fields) - Method in class org.apache.heron.api.topology.OutputFieldsGetter
- decorate(Kryo) - Method in interface org.apache.heron.api.serializer.IKryoDecorator
- DEFAULT_STREAM_ID - Static variable in class org.apache.heron.api.utils.Utils
- defaultConfig() - Static method in class org.apache.heron.streamlet.Config
-
Sets the topology to use the default configuration: 100 megabytes of RAM per container, 1.0 CPUs per container, at-most-once delivery semantics, and the Kryo serializer.
- DefaultEvictionContext - Class in org.apache.heron.api.windowing
- DefaultEvictionContext(Long) - Constructor for class org.apache.heron.api.windowing.DefaultEvictionContext
- DefaultEvictionContext(Long, Long) - Constructor for class org.apache.heron.api.windowing.DefaultEvictionContext
- DefaultEvictionContext(Long, Long, Long) - Constructor for class org.apache.heron.api.windowing.DefaultEvictionContext
- DefaultEvictionContext(Long, Long, Long, Long) - Constructor for class org.apache.heron.api.windowing.DefaultEvictionContext
- DefaultKryoFactory - Class in org.apache.heron.api.serializer
- DefaultKryoFactory() - Constructor for class org.apache.heron.api.serializer.DefaultKryoFactory
- DefaultKryoFactory.KryoSerializableDefault - Class in org.apache.heron.api.serializer
- DefaultMaxSpoutPendingTuner - Class in org.apache.heron.api.utils
-
This is a class that helps to auto tune the max spout pending value
- DefaultMaxSpoutPendingTuner(float, double) - Constructor for class org.apache.heron.api.utils.DefaultMaxSpoutPendingTuner
-
Conv constructor when initing from a non-set initial value
- DefaultMaxSpoutPendingTuner(Long, float, double) - Constructor for class org.apache.heron.api.utils.DefaultMaxSpoutPendingTuner
- deserialize(byte[]) - Method in interface org.apache.heron.api.serializer.IPluggableSerializer
- deserialize(byte[]) - Method in class org.apache.heron.api.serializer.JavaSerializer
- deserialize(byte[]) - Method in class org.apache.heron.api.serializer.KryoSerializer
- deserialize(byte[]) - Method in interface org.apache.heron.api.spout.MultiScheme
- deserialize(byte[]) - Method in class org.apache.heron.api.spout.RawMultiScheme
- deserialize(byte[]) - Method in class org.apache.heron.api.spout.RawScheme
- deserialize(byte[]) - Method in interface org.apache.heron.api.spout.Scheme
- deserialize(byte[]) - Method in class org.apache.heron.api.spout.SchemeAsMultiScheme
- deserialize(byte[]) - Static method in class org.apache.heron.api.utils.Utils
- directGrouping(String) - Method in class org.apache.heron.api.topology.BoltDeclarer
- directGrouping(String, String) - Method in class org.apache.heron.api.topology.BoltDeclarer
- DirectStreamGrouping - Class in org.apache.heron.api.grouping
-
This is the stream grouping strategy that tuples are sent to the instance of choice.
- DirectStreamGrouping() - Constructor for class org.apache.heron.api.grouping.DirectStreamGrouping
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.StreamletBaseImpl
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.ConsumerStreamlet
-
Connect this streamlet to TopologyBuilder.
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.CountByKeyAndWindowStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.CountByKeyStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.CustomStreamlet
-
Connect this streamlet to TopologyBuilder.
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.FilterStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.FlatMapStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.GeneralReduceByKeyAndWindowStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.GeneralReduceByKeyStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.JoinStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.KeyByStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.LogStreamlet
-
Connect this streamlet to TopologyBuilder.
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.MapStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.ReduceByKeyAndWindowStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.ReduceByKeyStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.RemapStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.SinkStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.SourceStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.SplitStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.SpoutStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.StreamletShadow
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.SupplierStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.TransformStreamlet
- doBuild(TopologyBuilder, Set<String>) - Method in class org.apache.heron.streamlet.impl.streamlets.UnionStreamlet
- doPrepare(Map<String, Object>, TopologyContext, OutputCollector, Collection<Event<Tuple>>) - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- Dummy() - Method in class org.apache.heron.streamlet.impl.windowings.CountWindowConfig
- Dummy() - Method in class org.apache.heron.streamlet.impl.windowings.CustomWindowConfig
- Dummy() - Method in class org.apache.heron.streamlet.impl.windowings.TimeWindowConfig
- Dummy() - Method in interface org.apache.heron.streamlet.WindowConfig
-
This is just a dummy function to avoid WindowConfig objects to be matched with Java functional interface and cause ambiguous reference compiling error.
- dump(TopologyAPI.Component.Builder) - Method in class org.apache.heron.api.topology.BaseComponentDeclarer
- dump(TopologyAPI.Topology.Builder) - Method in class org.apache.heron.api.topology.BoltDeclarer
- dump(TopologyAPI.Topology.Builder) - Method in class org.apache.heron.api.topology.SpoutDeclarer
E
- EFFECTIVELY_ONCE - org.apache.heron.api.Config.TopologyReliabilityMode
-
Heron guarantees that each emitted tuple is seen by the downstream components effectively once.
- EFFECTIVELY_ONCE - org.apache.heron.streamlet.Config.DeliverySemantics
- emit(String, Collection<Tuple>, List<Object>) - Method in interface org.apache.heron.api.bolt.IOutputCollector
-
Returns the task ids that received the tuples.
- emit(String, Collection<Tuple>, List<Object>) - Method in class org.apache.heron.api.bolt.OutputCollector
- emit(String, List<Object>) - Method in class org.apache.heron.api.bolt.BasicOutputCollector
- emit(String, List<Object>) - Method in interface org.apache.heron.api.bolt.IBasicOutputCollector
- emit(String, List<Object>) - Method in class org.apache.heron.api.bolt.OutputCollector
-
Emits a new unanchored tuple to the specified stream.
- emit(String, List<Object>) - Method in class org.apache.heron.api.spout.SpoutOutputCollector
-
Emits a tuple to the specified output stream with a null message id.
- emit(String, List<Object>, Object) - Method in interface org.apache.heron.api.spout.ISpoutOutputCollector
-
Returns the task ids that received the tuples.
- emit(String, List<Object>, Object) - Method in class org.apache.heron.api.spout.SpoutOutputCollector
-
Emits a new tuple to the specified output stream with the given message ID.
- emit(String, Tuple, List<Object>) - Method in class org.apache.heron.api.bolt.OutputCollector
-
Emits a new tuple to a specific stream with a single anchor.
- emit(Collection<Tuple>, List<Object>) - Method in class org.apache.heron.api.bolt.OutputCollector
-
Emits a new tuple to the default stream anchored on a group of input tuples.
- emit(List<Object>) - Method in class org.apache.heron.api.bolt.BasicOutputCollector
- emit(List<Object>) - Method in class org.apache.heron.api.bolt.OutputCollector
-
Emits a new unanchored tuple to the default stream.
- emit(List<Object>) - Method in class org.apache.heron.api.spout.SpoutOutputCollector
-
Emits a tuple to the default output stream with a null message id.
- emit(List<Object>, Object) - Method in class org.apache.heron.api.spout.SpoutOutputCollector
-
Emits a new tuple to the default output stream with the given message ID.
- emit(EmitInfo) - Method in class org.apache.heron.api.hooks.BaseTaskHook
- emit(EmitInfo) - Method in interface org.apache.heron.api.hooks.ITaskHook
-
Called everytime a tuple is emitted in spout/bolt
- emit(Tuple, List<Object>) - Method in class org.apache.heron.api.bolt.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.heron.api.bolt.IOutputCollector
- emitDirect(int, String, Collection<Tuple>, List<Object>) - Method in class org.apache.heron.api.bolt.OutputCollector
- emitDirect(int, String, List<Object>) - Method in class org.apache.heron.api.bolt.BasicOutputCollector
- emitDirect(int, String, List<Object>) - Method in interface org.apache.heron.api.bolt.IBasicOutputCollector
- emitDirect(int, String, List<Object>) - Method in class org.apache.heron.api.bolt.OutputCollector
-
Emits a tuple directly to the specified task id on the specified stream.
- emitDirect(int, String, List<Object>) - Method in class org.apache.heron.api.spout.SpoutOutputCollector
-
Emits a tuple to the specified task on the specified output stream.
- emitDirect(int, String, List<Object>, Object) - Method in interface org.apache.heron.api.spout.ISpoutOutputCollector
- emitDirect(int, String, List<Object>, Object) - Method in class org.apache.heron.api.spout.SpoutOutputCollector
-
Emits a tuple to the specified task on the specified output stream.
- emitDirect(int, String, Tuple, List<Object>) - Method in class org.apache.heron.api.bolt.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.heron.api.bolt.OutputCollector
-
Emits a tuple directly to the specified task id on the default stream.
- emitDirect(int, List<Object>) - Method in class org.apache.heron.api.bolt.BasicOutputCollector
- emitDirect(int, List<Object>) - Method in class org.apache.heron.api.bolt.OutputCollector
-
Emits a tuple directly to the specified task id on the default stream.
- emitDirect(int, List<Object>) - Method in class org.apache.heron.api.spout.SpoutOutputCollector
-
Emits a tuple to the specified task on the default output stream.
- emitDirect(int, List<Object>, Object) - Method in class org.apache.heron.api.spout.SpoutOutputCollector
-
Emits a tuple to the specified task on the default output stream.
- emitDirect(int, Tuple, List<Object>) - Method in class org.apache.heron.api.bolt.OutputCollector
-
Emits a tuple directly to the specified task id on the default stream.
- EmitInfo - Class in org.apache.heron.api.hooks.info
- EmitInfo(List<Object>, String, int, Collection<Integer>) - Constructor for class org.apache.heron.api.hooks.info.EmitInfo
- equals(Object) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt.Count
- equals(Object) - Method in class org.apache.heron.api.Pair
- equals(Object) - Method in class org.apache.heron.api.windowing.TupleWindowImpl
- Event<T extends Serializable> - Interface in org.apache.heron.api.windowing
-
An event is a wrapper object that gets stored in the window.
- EventImpl<T extends Serializable> - Class in org.apache.heron.api.windowing
- evict(Event<T>) - Method in interface org.apache.heron.api.windowing.EvictionPolicy
-
Decides if an event should be expired from the window, processed in the current window or kept for later processing.
- evict(Event<T>) - Method in class org.apache.heron.api.windowing.evictors.CountEvictionPolicy
- evict(Event<T>) - Method in class org.apache.heron.api.windowing.evictors.TimeEvictionPolicy
-
Decides if an event should be expired from the window, processed in the current window or kept for later processing.
- evict(Event<T>) - Method in class org.apache.heron.api.windowing.evictors.WatermarkCountEvictionPolicy
- evict(Event<T>) - Method in class org.apache.heron.api.windowing.evictors.WatermarkTimeEvictionPolicy
-
Decides if an event should be expired from the window, processed in the current window or kept for later processing.
- evictionContext - Variable in class org.apache.heron.api.windowing.evictors.TimeEvictionPolicy
- EvictionContext - Interface in org.apache.heron.api.windowing
-
Context information that can be used by the eviction policy
- evictionPolicy - Variable in class org.apache.heron.api.windowing.triggers.AbstractBaseTriggerPolicy
- evictionPolicy - Variable in class org.apache.heron.api.windowing.WindowManager
- EvictionPolicy<T extends Serializable,S> - Interface in org.apache.heron.api.windowing
-
Eviction policy tracks events and decides whether an event should be evicted from the window or not.
- EvictionPolicy.Action - Enum in org.apache.heron.api.windowing
-
The action to be taken when
EvictionPolicy.evict(Event)
is invoked. - execute(Tuple) - Method in class org.apache.heron.api.bolt.BasicBoltExecutor
- execute(Tuple) - Method in interface org.apache.heron.api.bolt.IBolt
-
Process a single tuple of input.
- execute(Tuple) - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- execute(Tuple) - Method in class org.apache.heron.streamlet.impl.operators.FilterOperator
- execute(Tuple) - Method in class org.apache.heron.streamlet.impl.operators.FlatMapOperator
- execute(Tuple) - Method in class org.apache.heron.streamlet.impl.operators.GeneralReduceByKeyOperator
- execute(Tuple) - Method in class org.apache.heron.streamlet.impl.operators.KeyByOperator
- execute(Tuple) - Method in class org.apache.heron.streamlet.impl.operators.MapOperator
- execute(Tuple) - Method in class org.apache.heron.streamlet.impl.operators.ReduceByKeyOperator
- execute(Tuple) - Method in class org.apache.heron.streamlet.impl.operators.SplitOperator
- execute(Tuple) - Method in class org.apache.heron.streamlet.impl.operators.TransformOperator
- execute(Tuple) - Method in class org.apache.heron.streamlet.impl.operators.UnionOperator
- execute(Tuple) - Method in class org.apache.heron.streamlet.impl.sinks.ComplexSink
- execute(Tuple) - Method in class org.apache.heron.streamlet.impl.sinks.ConsumerSink
- execute(Tuple) - Method in class org.apache.heron.streamlet.impl.sinks.LogSink
- execute(Tuple, BasicOutputCollector) - Method in interface org.apache.heron.api.bolt.IBasicBolt
-
Process the input tuple and optionally emit new tuples based on the input tuple.
- execute(TupleWindow) - Method in interface org.apache.heron.api.bolt.IWindowedBolt
-
Process the tuple window and optionally emit new tuples based on the tuples in the input window.
- execute(TupleWindow) - Method in class org.apache.heron.streamlet.impl.operators.GeneralReduceByKeyAndWindowOperator
- execute(TupleWindow) - Method in class org.apache.heron.streamlet.impl.operators.JoinOperator
- execute(TupleWindow) - Method in class org.apache.heron.streamlet.impl.operators.ReduceByKeyAndWindowOperator
- EXPIRE - org.apache.heron.api.windowing.EvictionPolicy.Action
-
expire the event and remove it from the queue.
- EXPIRE_EVENTS_THRESHOLD - Static variable in class org.apache.heron.api.windowing.WindowManager
-
Expire old events every EXPIRE_EVENTS_THRESHOLD to keep the window size in check.
- extractResult(MeanReducerState) - Method in class org.apache.heron.api.metric.MeanReducer
- extractResult(T) - Method in interface org.apache.heron.api.metric.IReducer
- extractTimestamp(Tuple) - Method in interface org.apache.heron.api.windowing.TimestampExtractor
-
Return the tuple timestamp indicating the time when the event happened.
- extractTimestamp(Tuple) - Method in class org.apache.heron.api.windowing.TupleFieldTimestampExtractor
F
- fail(Object) - Method in class org.apache.heron.api.spout.BaseRichSpout
- fail(Object) - Method in interface org.apache.heron.api.spout.ISpout
-
The tuple emitted by this spout with the msgId identifier has failed to be fully processed.
- fail(Tuple) - Method in interface org.apache.heron.api.bolt.IOutputCollector
- fail(Tuple) - Method in class org.apache.heron.api.bolt.OutputCollector
- FailedException - Exception in org.apache.heron.api.exception
- FailedException() - Constructor for exception org.apache.heron.api.exception.FailedException
- FailedException(String) - Constructor for exception org.apache.heron.api.exception.FailedException
- FailedException(String, Throwable) - Constructor for exception org.apache.heron.api.exception.FailedException
- FailedException(Throwable) - Constructor for exception org.apache.heron.api.exception.FailedException
- fieldIndex(String) - Method in class org.apache.heron.api.tuple.Fields
-
Returns the position of the specified field.
- fieldIndex(String) - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns the position of the specified field in this tuple.
- Fields - Class in org.apache.heron.api.tuple
- Fields(String...) - Constructor for class org.apache.heron.api.tuple.Fields
- Fields(List<String>) - Constructor for class org.apache.heron.api.tuple.Fields
- fieldsGrouping(String, String, Fields) - Method in class org.apache.heron.api.topology.BoltDeclarer
- fieldsGrouping(String, Fields) - Method in class org.apache.heron.api.topology.BoltDeclarer
- FieldsStreamGrouping - Class in org.apache.heron.api.grouping
-
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.
- FieldsStreamGrouping(Fields) - Constructor for class org.apache.heron.api.grouping.FieldsStreamGrouping
- filter(SerializablePredicate<R>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Return a new Streamlet by applying the filterFn on each element of this streamlet and including only those elements that satisfy the filterFn
- filter(SerializablePredicate<R>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Return a new Streamlet by applying the filterFn on each element of this streamlet and including only those elements that satisfy the filterFn
- FILTER - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- FilterOperator<R> - Class in org.apache.heron.streamlet.impl.operators
-
FilterOperator implements the functionality of the filter operation It takes in a filterFunction predicate as the input.
- FilterOperator(SerializablePredicate<? super R>) - Constructor for class org.apache.heron.streamlet.impl.operators.FilterOperator
- FilterStreamlet<R> - Class in org.apache.heron.streamlet.impl.streamlets
-
FilterStreamlet represents a Streamlet that is made up of elements from the parent Streamlet after applying a user supplied filter function.
- FilterStreamlet(StreamletImpl<R>, SerializablePredicate<? super R>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.FilterStreamlet
- flatMap(SerializableFunction<R, ? extends Iterable<? extends T>>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Return a new Streamlet by applying flatMapFn to each element of this Streamlet and flattening the result
- flatMap(SerializableFunction<R, ? extends Iterable<? extends T>>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Return a new Streamlet by applying flatMapFn to each element of this Streamlet and flattening the result
- FLATMAP - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- FlatMapOperator<R,T> - Class in org.apache.heron.streamlet.impl.operators
-
FlatMapOperator is the class that implements the flatMap functionality.
- FlatMapOperator(SerializableFunction<? super R, ? extends Iterable<? extends T>>) - Constructor for class org.apache.heron.streamlet.impl.operators.FlatMapOperator
- FlatMapStreamlet<R,T> - Class in org.apache.heron.streamlet.impl.streamlets
-
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.
- FlatMapStreamlet(StreamletImpl<R>, SerializableFunction<? super R, ? extends Iterable<? extends T>>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.FlatMapStreamlet
G
- GeneralReduceByKeyAndWindowOperator<R,K,T> - Class in org.apache.heron.streamlet.impl.operators
-
ReduceByKeyAndWindowOperator is the class that implements reduceByKeyAndWindow functionality.
- GeneralReduceByKeyAndWindowOperator(SerializableFunction<R, K>, T, SerializableBiFunction<T, R, ? extends T>) - Constructor for class org.apache.heron.streamlet.impl.operators.GeneralReduceByKeyAndWindowOperator
- GeneralReduceByKeyAndWindowStreamlet<R,K,T> - Class in org.apache.heron.streamlet.impl.streamlets
-
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.
- GeneralReduceByKeyAndWindowStreamlet(StreamletImpl<R>, SerializableFunction<R, K>, WindowConfig, T, SerializableBiFunction<T, R, ? extends T>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.GeneralReduceByKeyAndWindowStreamlet
- GeneralReduceByKeyOperator<R,K,T> - Class in org.apache.heron.streamlet.impl.operators
-
ReduceByKeyOperator is the class that implements the reduce functionality.
- GeneralReduceByKeyOperator(SerializableFunction<R, K>, T, SerializableBiFunction<T, R, ? extends T>) - Constructor for class org.apache.heron.streamlet.impl.operators.GeneralReduceByKeyOperator
- GeneralReduceByKeyStreamlet<R,K,T> - Class in org.apache.heron.streamlet.impl.streamlets
-
GeneralReduceByKeyStreamlet represents a KVStreamlet that is the result of applying user supplied reduceFn on all elements.
- GeneralReduceByKeyStreamlet(StreamletImpl<R>, SerializableFunction<R, K>, T, SerializableBiFunction<T, R, ? extends T>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.GeneralReduceByKeyStreamlet
- GeneralTopologyContext - Interface in org.apache.heron.api.topology
- get() - Method in class org.apache.heron.api.utils.DefaultMaxSpoutPendingTuner
- get() - Method in interface org.apache.heron.api.windowing.Event
-
Returns the wrapped object, E.g.
- get() - Method in class org.apache.heron.api.windowing.EventImpl
- get() - Method in class org.apache.heron.api.windowing.TupleWindowImpl
- get() - Method in interface org.apache.heron.api.windowing.Window
-
Gets the list of events in the window.
- get() - Method in interface org.apache.heron.streamlet.Source
- get(int) - Method in class org.apache.heron.api.tuple.Fields
- get(Map<S, T>, S, T) - Static method in class org.apache.heron.api.utils.Utils
- getAckingTaskId() - Method in class org.apache.heron.api.hooks.info.BoltAckInfo
- getAdditionalClassPath(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getApiVars() - Method in class org.apache.heron.api.Config
- getAutoTaskHooks() - Method in class org.apache.heron.api.Config
- getAutoTaskHooks(Map<String, Object>) - Static method in class org.apache.heron.api.Config
- getAvailableStreamIds() - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Get the available stream ids in the Streamlet.
- getAvailableStreamIds() - Method in class org.apache.heron.streamlet.impl.streamlets.SplitStreamlet
-
Get the available stream ids in the Streamlet.
- getBinary(int) - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns the byte array at position i in the tuple.
- getBinaryByField(String) - Method in interface org.apache.heron.api.tuple.Tuple
- getBoolean(int) - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns the Boolean at position i in the tuple.
- getBooleanByField(String) - Method in interface org.apache.heron.api.tuple.Tuple
- getByte(int) - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns the Byte at position i in the tuple.
- getByteByField(String) - Method in interface org.apache.heron.api.tuple.Tuple
- getCheckpointManagerRam(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getChildren() - Method in class org.apache.heron.streamlet.impl.StreamletBaseImpl
-
Gets all the children of this streamlet.
- getChildren() - Method in class org.apache.heron.streamlet.impl.streamlets.StreamletShadow
-
Gets all the children of this streamlet.
- getCompleteLatency() - Method in class org.apache.heron.api.hooks.info.SpoutAckInfo
- getComponentConfigMap(TopologyAPI.Topology, String) - Static method in class org.apache.heron.api.utils.TopologyUtils
-
This is a util function to parse cpumap, rammap and diskmap.
- getComponentConfiguration() - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
- getComponentConfiguration() - Method in class org.apache.heron.api.bolt.BasicBoltExecutor
- getComponentConfiguration() - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- getComponentConfiguration() - Method in class org.apache.heron.api.topology.BaseComponent
- getComponentConfiguration() - Method in interface org.apache.heron.api.topology.IComponent
-
Declare configuration specific to this component.
- getComponentConfiguration() - Method in class org.apache.heron.streamlet.impl.operators.JoinOperator
- getComponentCpuMapConfig(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
-
Parses the value in Config.TOPOLOGY_COMPONENT_CPUMAP, and returns a map containing only component specified.
- getComponentDiskMapConfig(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
-
Parses the value in Config.TOPOLOGY_COMPONENT_DISKMAP, and returns a map containing only component specified.
- getComponentId(int) - Method in interface org.apache.heron.api.topology.GeneralTopologyContext
-
Gets the component id for the specified task id.
- getComponentIds() - Method in interface org.apache.heron.api.topology.GeneralTopologyContext
-
Gets a list of all component ids in this topology
- getComponentJvmOptions(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getComponentOutputFields(String, String) - Method in interface org.apache.heron.api.topology.GeneralTopologyContext
-
Gets the declared output fields for the specified component/stream.
- getComponentParallelism(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getComponentRamMapConfig(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
-
Parses the value in Config.TOPOLOGY_COMPONENT_RAMMAP, and returns a map containing only component specified.
- getComponentStreams(String) - Method in interface org.apache.heron.api.topology.GeneralTopologyContext
-
Gets the set of streams declared for the specified component.
- getComponentTasks(String) - Method in interface org.apache.heron.api.topology.GeneralTopologyContext
-
Gets the task ids allocated for the given component id.
- getConfig() - Method in interface org.apache.heron.streamlet.Context
-
Fetches the config of the computation
- getConfig() - Method in class org.apache.heron.streamlet.impl.ContextImpl
- getConfigBuilder(Config) - Static method in class org.apache.heron.api.utils.Utils
-
Converts a Heron Config object into a TopologyAPI.Config.Builder.
- getConfigWithDefault(List<TopologyAPI.Config.KeyValue>, String, boolean) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getConfigWithDefault(List<TopologyAPI.Config.KeyValue>, String, Double) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getConfigWithDefault(List<TopologyAPI.Config.KeyValue>, String, Integer) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getConfigWithDefault(List<TopologyAPI.Config.KeyValue>, String, Long) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getConfigWithDefault(List<TopologyAPI.Config.KeyValue>, String, String) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getConfigWithDefault(List<TopologyAPI.Config.KeyValue>, String, ByteAmount) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getConfigWithException(List<TopologyAPI.Config.KeyValue>, String) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getContext() - Method in interface org.apache.heron.api.windowing.EvictionPolicy
-
Returns the current context that is part of this eviction policy.
- getContext() - Method in class org.apache.heron.api.windowing.evictors.CountEvictionPolicy
- getContext() - Method in class org.apache.heron.api.windowing.evictors.TimeEvictionPolicy
- getContext() - Method in class org.apache.heron.api.windowing.evictors.WatermarkCountEvictionPolicy
- getCount() - Method in class org.apache.heron.streamlet.Window
- getCurrentCount() - Method in class org.apache.heron.api.windowing.DefaultEvictionContext
- getCurrentCount() - Method in interface org.apache.heron.api.windowing.EvictionContext
-
Returns the current count of events in the queue up to the reference time based on which count based evictions can be performed.
- getDefaultSerializer(Class) - Method in class org.apache.heron.api.serializer.DefaultKryoFactory.KryoSerializableDefault
- getDeliverySemantics() - Method in class org.apache.heron.streamlet.Config
-
Gets the delivery semantics applied to the topology
- getDouble(int) - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns the Double at position i in the tuple.
- getDoubleByField(String) - Method in interface org.apache.heron.api.tuple.Tuple
- getEarliestEventTs(long, long) - Method in class org.apache.heron.api.windowing.WindowManager
-
Scans the event queue and returns the next earliest event ts between the startTs and endTs
- getEndTime() - Method in class org.apache.heron.streamlet.Window
- getEndTimestamp() - Method in class org.apache.heron.api.windowing.TupleWindowImpl
- getEndTimestamp() - Method in interface org.apache.heron.api.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.
- getEventCount(long) - Method in class org.apache.heron.api.windowing.WindowManager
-
Scans the event queue and returns number of events having timestamp less than or equal to the reference time.
- getExecuteLatency() - Method in class org.apache.heron.api.hooks.info.BoltExecuteInfo
- getExecutingTaskId() - Method in class org.apache.heron.api.hooks.info.BoltExecuteInfo
- getExpired() - Method in class org.apache.heron.api.windowing.TupleWindowImpl
- getExpired() - Method in interface org.apache.heron.api.windowing.Window
-
Get the list of events expired from the window since the last time the window was generated.
- getFailingTaskId() - Method in class org.apache.heron.api.hooks.info.BoltFailInfo
- getFailLatency() - Method in class org.apache.heron.api.hooks.info.BoltFailInfo
- getFailLatency() - Method in class org.apache.heron.api.hooks.info.SpoutFailInfo
- getFields() - Method in interface org.apache.heron.api.tuple.Tuple
-
Gets the names of the fields in this tuple.
- getFieldsDeclaration() - Method in class org.apache.heron.api.topology.OutputFieldsGetter
- getFirst() - Method in class org.apache.heron.api.Pair
-
Returns the first value in a pair.
- getFloat(int) - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns the Float at position i in the tuple.
- getFloatByField(String) - Method in interface org.apache.heron.api.tuple.Tuple
- getHeronConfig() - Method in class org.apache.heron.streamlet.Config
- getHooks() - Method in interface org.apache.heron.api.topology.TopologyContext
-
Get the list of all task hooks
- getInstanceJvmOptions(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getInteger(int) - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns the Integer at position i in the tuple.
- getIntegerByField(String) - Method in interface org.apache.heron.api.tuple.Tuple
- getJoinType() - Method in class org.apache.heron.streamlet.impl.streamlets.JoinStreamlet
- getKey() - Method in class org.apache.heron.streamlet.KeyedWindow
- getKey() - Method in class org.apache.heron.streamlet.KeyValue
- getKryo(Map) - Method in class org.apache.heron.api.serializer.DefaultKryoFactory
- getKryo(Map) - Method in interface org.apache.heron.api.serializer.IKryoFactory
- getLong(int) - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns the Long at position i in the tuple.
- getLongByField(String) - Method in interface org.apache.heron.api.tuple.Tuple
- getMessageId() - Method in class org.apache.heron.api.hooks.info.SpoutAckInfo
- getMessageId() - Method in class org.apache.heron.api.hooks.info.SpoutFailInfo
- getName() - Method in class org.apache.heron.api.topology.BaseComponentDeclarer
- getName() - Method in class org.apache.heron.streamlet.impl.StreamletBaseImpl
-
Gets the name of the Streamlet.
- getName() - Method in class org.apache.heron.streamlet.impl.streamlets.StreamletShadow
- getName() - Method in interface org.apache.heron.streamlet.Streamlet
-
Gets the name of the Streamlet.
- getName() - Method in interface org.apache.heron.streamlet.StreamletBase
-
Gets the name of the Streamlet.
- getNew() - Method in class org.apache.heron.api.windowing.TupleWindowImpl
- getNew() - Method in interface org.apache.heron.api.windowing.Window
-
Get the list of newly added events in the window since the last time the window was generated.
- getNumContainers(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getNumPartitions() - Method in class org.apache.heron.streamlet.impl.StreamletBaseImpl
-
Gets the number of partitions of this Streamlet.
- getNumPartitions() - Method in class org.apache.heron.streamlet.impl.streamlets.StreamletShadow
- getNumPartitions() - Method in interface org.apache.heron.streamlet.Streamlet
-
Gets the number of partitions of this Streamlet.
- getNumPartitions() - Method in interface org.apache.heron.streamlet.StreamletBase
-
Gets the number of partitions of this Streamlet.
- getOutputFields() - Method in interface org.apache.heron.api.spout.MultiScheme
- getOutputFields() - Method in class org.apache.heron.api.spout.RawMultiScheme
- getOutputFields() - Method in class org.apache.heron.api.spout.RawScheme
- getOutputFields() - Method in interface org.apache.heron.api.spout.Scheme
- getOutputFields() - Method in class org.apache.heron.api.spout.SchemeAsMultiScheme
- getOutputter() - Method in class org.apache.heron.api.bolt.BasicOutputCollector
- getOutTasks() - Method in class org.apache.heron.api.hooks.info.EmitInfo
- getParent() - Method in class org.apache.heron.streamlet.impl.streamlets.MapStreamlet
- getPerContainerCpu() - Method in class org.apache.heron.streamlet.Config
-
Gets the CPU used per topology container
- getPerContainerRam() - Method in class org.apache.heron.streamlet.Config
-
Gets the RAM used per topology container as a number of bytes
- getPerContainerRamAsBytes() - Method in class org.apache.heron.streamlet.Config
-
Gets the RAM used per topology container as a number of bytes
- getPerContainerRamAsGigabytes() - Method in class org.apache.heron.streamlet.Config
-
Gets the RAM used per topology container as a number of gigabytes
- getPerContainerRamAsMegabytes() - Method in class org.apache.heron.streamlet.Config
-
Gets the RAM used per topology container as a number of megabytes
- getProcessLatency() - Method in class org.apache.heron.api.hooks.info.BoltAckInfo
- getRawTopology() - Method in interface org.apache.heron.api.topology.GeneralTopologyContext
-
Deprecated.for backwards compatibility purposes
- getReal() - Method in class org.apache.heron.streamlet.impl.streamlets.StreamletShadow
- getReferenceTime() - Method in class org.apache.heron.api.windowing.DefaultEvictionContext
- getReferenceTime() - Method in interface org.apache.heron.api.windowing.EvictionContext
-
Returns the reference time that the eviction policy could use to evict the events.
- getScheme() - Method in interface org.apache.heron.api.spout.IMultiSchemableSpout
- getScheme() - Method in interface org.apache.heron.api.spout.ISchemableSpout
- getSecond() - Method in class org.apache.heron.api.Pair
-
Returns the second value in a pair.
- getSerializer() - Method in class org.apache.heron.streamlet.Config
-
Gets the serializer used by the topology
- getShort(int) - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns the Short at position i in the tuple.
- getShortByField(String) - Method in interface org.apache.heron.api.tuple.Tuple
- getSlidingCount() - Method in class org.apache.heron.api.windowing.DefaultEvictionContext
- getSlidingCount() - Method in interface org.apache.heron.api.windowing.EvictionContext
-
Returns the sliding count for count based windows
- getSlidingCountTimestamps(long, long, int) - Method in class org.apache.heron.api.windowing.WindowManager
-
Scans the event queue and returns the list of event ts falling between startTs (exclusive) and endTs (inclusive) at each sliding interval counts.
- getSlidingInterval() - Method in class org.apache.heron.api.windowing.DefaultEvictionContext
- getSlidingInterval() - Method in interface org.apache.heron.api.windowing.EvictionContext
-
Returns the sliding interval for time based windows
- getSourceComponent() - Method in interface org.apache.heron.api.tuple.Tuple
-
Gets the id of the component that created this tuple.
- getSourceGlobalStreamId() - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns the global stream id (component + stream) of this tuple.
- getSources(String) - Method in interface org.apache.heron.api.topology.GeneralTopologyContext
-
Gets the declared inputs to the specified component.
- getSourceStreamId() - Method in interface org.apache.heron.api.tuple.Tuple
-
Gets the id of the stream that this tuple was emitted to.
- getSourceTask() - Method in interface org.apache.heron.api.tuple.Tuple
-
Gets the id of the task that created this tuple.
- getSpoutTaskId() - Method in class org.apache.heron.api.hooks.info.SpoutAckInfo
- getSpoutTaskId() - Method in class org.apache.heron.api.hooks.info.SpoutFailInfo
- getStartTime() - Method in class org.apache.heron.streamlet.Window
- getStartTimestamp() - Method in class org.apache.heron.api.windowing.TupleWindowImpl
- getStartTimestamp() - Method in interface org.apache.heron.api.windowing.Window
-
Returns the window start timestamp.
- getState() - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- getState() - Method in interface org.apache.heron.api.windowing.EvictionPolicy
-
Return runtime state to be checkpointed by the framework for restoring the eviction policy in case of failures.
- getState() - Method in class org.apache.heron.api.windowing.evictors.CountEvictionPolicy
- getState() - Method in class org.apache.heron.api.windowing.evictors.TimeEvictionPolicy
- getState() - Method in class org.apache.heron.api.windowing.evictors.WatermarkCountEvictionPolicy
- getState() - Method in interface org.apache.heron.api.windowing.TriggerPolicy
-
Return runtime state to be checkpointed by the framework for restoring the trigger policy in case of failures.
- getState() - Method in class org.apache.heron.api.windowing.triggers.CountTriggerPolicy
- getState() - Method in class org.apache.heron.api.windowing.triggers.TimeTriggerPolicy
- getState() - Method in class org.apache.heron.api.windowing.triggers.WatermarkCountTriggerPolicy
- getState() - Method in class org.apache.heron.api.windowing.triggers.WatermarkTimeTriggerPolicy
- getState() - Method in class org.apache.heron.api.windowing.WindowManager
-
Get the state of the window manager
- getState() - Method in interface org.apache.heron.streamlet.Context
-
The state where components can store any of their local state
- getState() - Method in class org.apache.heron.streamlet.impl.ContextImpl
- getStream() - Method in class org.apache.heron.api.hooks.info.EmitInfo
- getStreamId() - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Gets the stream id of this Streamlet.
- getStreamId() - Method in class org.apache.heron.streamlet.impl.streamlets.StreamletShadow
-
Gets the stream id of this Streamlet.
- getStreamId() - Method in interface org.apache.heron.streamlet.Streamlet
-
Gets the stream id of this Streamlet.
- getStreamName() - Method in interface org.apache.heron.streamlet.Context
-
The stream name that we are operating on
- getStreamName() - Method in class org.apache.heron.streamlet.impl.ContextImpl
- getStreamPartition() - Method in interface org.apache.heron.streamlet.Context
-
The partition number that we are operating on
- getStreamPartition() - Method in class org.apache.heron.streamlet.impl.ContextImpl
- getString(int) - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns the String at position i in the tuple.
- getStringByField(String) - Method in interface org.apache.heron.api.tuple.Tuple
- getTargets(String) - Method in interface org.apache.heron.api.topology.GeneralTopologyContext
-
Gets information about who is consuming the outputs of the specified component, and how.
- getTaskData(String) - Method in interface org.apache.heron.api.topology.TopologyContext
- getTaskId() - Method in class org.apache.heron.api.hooks.info.EmitInfo
- getTaskId() - Method in interface org.apache.heron.streamlet.Context
-
Fetches the task id of the current instance of the operator
- getTaskId() - Method in class org.apache.heron.streamlet.impl.ContextImpl
- getTaskToComponent() - Method in interface org.apache.heron.api.topology.GeneralTopologyContext
-
Gets a map from task id to component id.
- getThisComponentId() - Method in interface org.apache.heron.api.topology.TopologyContext
-
Gets the component id for this task.
- getThisOutputFields(String) - Method in interface org.apache.heron.api.topology.TopologyContext
-
Gets the declared output fields for the specified stream id for the component this task is a part of.
- getThisSources() - Method in interface org.apache.heron.api.topology.TopologyContext
-
Gets the declared inputs to this component.
- getThisStreams() - Method in interface org.apache.heron.api.topology.TopologyContext
-
Gets the set of streams declared for the component of this task.
- getThisTargets() - Method in interface org.apache.heron.api.topology.TopologyContext
-
Gets information about who is consuming the outputs of this component, and how.
- getThisTaskId() - Method in interface org.apache.heron.api.topology.TopologyContext
-
Gets the task id of this task.
- getThisTaskIndex() - Method in interface org.apache.heron.api.topology.TopologyContext
-
Gets the index of this task id in getComponentTasks(getThisComponentId()).
- getTimeCounts() - Method in class org.apache.heron.api.metric.CountStatAndMetric
-
Get current time counts
- getTimeLatAvg() - Method in class org.apache.heron.api.metric.LatencyStatAndMetric
-
Get time latency average
- getTimestamp() - Method in interface org.apache.heron.api.windowing.Event
-
The event timestamp in millis.
- getTimestamp() - Method in class org.apache.heron.api.windowing.EventImpl
- getTimestampExtractor() - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
- getTimestampExtractor() - Method in interface org.apache.heron.api.bolt.IWindowedBolt
-
Return a
TimestampExtractor
for extracting timestamps from a tuple for event time based processing, or null for processing time. - getTopology() - Method in class org.apache.heron.api.HeronTopology
- getTopology(String) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getTopologyId() - Method in interface org.apache.heron.api.topology.GeneralTopologyContext
-
Gets the unique id assigned to this topology.
- getTopologyRemoteDebuggingEnabled(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getTopologyTimeoutMillis(Map<String, Object>) - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- getTotalInstance(Map<String, Integer>) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getTotalInstance(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
- getTuple() - Method in class org.apache.heron.api.hooks.info.BoltAckInfo
- getTuple() - Method in class org.apache.heron.api.hooks.info.BoltExecuteInfo
- getTuple() - Method in class org.apache.heron.api.hooks.info.BoltFailInfo
- getUnderlyingCounter() - Static method in enum org.apache.heron.api.metric.GlobalMetrics
-
test-only
- getValue() - Method in class org.apache.heron.api.metric.CountMetric
- getValue() - Method in class org.apache.heron.streamlet.KeyValue
- getValue(int) - Method in interface org.apache.heron.api.tuple.Tuple
-
Gets the field at position i in the tuple.
- getValueAndReset() - Method in class org.apache.heron.api.metric.AssignableMetric
- getValueAndReset() - Method in class org.apache.heron.api.metric.CombinedMetric
- getValueAndReset() - Method in class org.apache.heron.api.metric.ConcurrentCountMetric
- getValueAndReset() - Method in class org.apache.heron.api.metric.CountMetric
- getValueAndReset() - Method in class org.apache.heron.api.metric.CountStatAndMetric
- getValueAndReset() - Method in class org.apache.heron.api.metric.CumulativeCountMetric
- getValueAndReset() - Method in interface org.apache.heron.api.metric.IMetric
- getValueAndReset() - Method in class org.apache.heron.api.metric.LatencyStatAndMetric
- getValueAndReset() - Method in class org.apache.heron.api.metric.MultiAssignableMetric
- getValueAndReset() - Method in class org.apache.heron.api.metric.MultiCountMetric
- getValueAndReset() - Method in class org.apache.heron.api.metric.MultiReducedMetric
- getValueAndReset() - Method in class org.apache.heron.api.metric.ReducedMetric
- getValueByField(String) - Method in interface org.apache.heron.api.tuple.Tuple
- getValues() - Method in class org.apache.heron.api.hooks.info.EmitInfo
- getValues() - Method in interface org.apache.heron.api.tuple.Tuple
-
Gets all the values in this tuple.
- getWindow() - Method in class org.apache.heron.streamlet.KeyedWindow
- globalGrouping(String) - Method in class org.apache.heron.api.topology.BoltDeclarer
- globalGrouping(String, String) - Method in class org.apache.heron.api.topology.BoltDeclarer
- GlobalMetrics - Enum in org.apache.heron.api.metric
-
Singleton class which exposes a simple globally available counter for heron jobs.
- GlobalStreamGrouping - Class in org.apache.heron.api.grouping
-
This is the stream grouping strategy that all tuples are transmitted to a single instance of a bolt with the lowest task id.
- GlobalStreamGrouping() - Constructor for class org.apache.heron.api.grouping.GlobalStreamGrouping
- grouping(String, String, StreamGrouping) - Method in class org.apache.heron.api.topology.BoltDeclarer
- grouping(String, StreamGrouping) - Method in class org.apache.heron.api.topology.BoltDeclarer
H
- handler - Variable in class org.apache.heron.api.windowing.triggers.AbstractBaseTriggerPolicy
- hashCode() - Method in class org.apache.heron.api.bolt.BaseWindowedBolt.Count
- hashCode() - Method in class org.apache.heron.api.Pair
- hashCode() - Method in class org.apache.heron.api.windowing.TupleWindowImpl
- HashMapState<K extends Serializable,V extends Serializable> - Class in org.apache.heron.api.state
-
A State backed up by HashMap
- HashMapState() - Constructor for class org.apache.heron.api.state.HashMapState
- HERON_JAVA_SERIALIZER_CLASS_NAME - Static variable in class org.apache.heron.api.Config
-
The serializers available for TOPOLOGY_SERIALIZER_CLASSNAME.
- HERON_KRYO_SERIALIZER_CLASS_NAME - Static variable in class org.apache.heron.api.Config
- HeronSubmitter - Class in org.apache.heron.api
-
Use this class to submit topologies to run on the Heron cluster.
- HeronTopology - Class in org.apache.heron.api
- HeronTopology(TopologyAPI.Topology.Builder) - Constructor for class org.apache.heron.api.HeronTopology
I
- IBasicBolt - Interface in org.apache.heron.api.bolt
- IBasicOutputCollector - Interface in org.apache.heron.api.bolt
- IBolt - Interface in org.apache.heron.api.bolt
-
An IBolt represents a component that takes tuples as input and produces tuples as output.
- ICombiner<T> - Interface in org.apache.heron.api.metric
-
Interface for classes that are able to combine multiple objects into one result.
- IComponent - Interface in org.apache.heron.api.topology
-
Common methods for all possible components in a topology.
- identity() - Method in interface org.apache.heron.api.metric.ICombiner
- IErrorReporter - Interface in org.apache.heron.api.bolt
- IKryoDecorator - Interface in org.apache.heron.api.serializer
- IKryoFactory - Interface in org.apache.heron.api.serializer
-
An interface that controls the Kryo instance used by Storm for serialization.
- IMetric<T> - Interface in org.apache.heron.api.metric
-
Interface for a metric that can be tracked
- IMetricsRegister - Interface in org.apache.heron.api.metric
- IMultiSchemableSpout - Interface in org.apache.heron.api.spout
- incBy(long) - Method in class org.apache.heron.api.metric.CountStatAndMetric
-
Increase the count by the given value.
- incr() - Method in class org.apache.heron.api.metric.ConcurrentCountMetric
- incr() - Method in class org.apache.heron.api.metric.CountMetric
- incr(String) - Static method in enum org.apache.heron.api.metric.GlobalMetrics
-
Not thread safe increment of counterName.
- incrBy(long) - Method in class org.apache.heron.api.metric.ConcurrentCountMetric
- incrBy(long) - Method in class org.apache.heron.api.metric.CountMetric
- incrBy(String, int) - Static method in enum org.apache.heron.api.metric.GlobalMetrics
-
Not thread safe 'incrementing by' of counterName.
- init() - Method in interface org.apache.heron.api.metric.IReducer
- init() - Method in class org.apache.heron.api.metric.MeanReducer
- init(IMetricsRegister, Duration) - Static method in enum org.apache.heron.api.metric.GlobalMetrics
-
Initialize the counter by registering the metricContainer.
- initialize(Map<String, Object>) - Method in interface org.apache.heron.api.serializer.IPluggableSerializer
- initialize(Map<String, Object>) - Method in class org.apache.heron.api.serializer.JavaSerializer
- initialize(Map<String, Object>) - Method in class org.apache.heron.api.serializer.KryoSerializer
- initState(State) - Method in class org.apache.heron.api.bolt.StatefulWindowedBoltExecutor
-
initalize state that is partitioned by window internal and user defined
- initState(State<Serializable, Serializable>) - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- initState(State<Serializable, Serializable>) - Method in class org.apache.heron.streamlet.impl.operators.TransformOperator
- initState(State<Serializable, Serializable>) - Method in class org.apache.heron.streamlet.impl.sinks.ComplexSink
- initState(State<Serializable, Serializable>) - Method in class org.apache.heron.streamlet.impl.sources.ComplexSource
- initState(State<Serializable, Serializable>) - Method in class org.apache.heron.streamlet.impl.sources.StreamletSource
- initState(State<K, V>) - Method in interface org.apache.heron.api.topology.IStatefulComponent
-
Initializes the state of the function or operator to that of a previous checkpoint.
- INNER - org.apache.heron.streamlet.JoinType
-
Return a new KVStreamlet by inner joining 'this streamlet with ‘other’ streamlet.
- installSLF4JBridge() - Static method in class org.apache.heron.api.utils.Slf4jUtils
- INSTANCE - org.apache.heron.api.metric.GlobalMetrics
- InvalidTopologyException - Exception in org.apache.heron.api.exception
- InvalidTopologyException() - Constructor for exception org.apache.heron.api.exception.InvalidTopologyException
- InvalidTopologyException(String) - Constructor for exception org.apache.heron.api.exception.InvalidTopologyException
- IOutputCollector - Interface in org.apache.heron.api.bolt
- IPluggableSerializer - Interface in org.apache.heron.api.serializer
- IReducer<T,U,V> - Interface in org.apache.heron.api.metric
-
Apply an update to an accumulator for which a result can be extracted.
- IRichBolt - Interface in org.apache.heron.api.bolt
-
When writing topologies using Java,
IRichBolt
andIRichSpout
are the main interfaces to use to implement components of the topology. - IRichSpout - Interface in org.apache.heron.api.spout
-
When writing topologies using Java,
IRichBolt
andIRichSpout
are the main interfaces to use to implement components of the topology. - isBuilt() - Method in class org.apache.heron.streamlet.impl.StreamletBaseImpl
- ISchemableSpout - Interface in org.apache.heron.api.spout
- isFullyBuilt() - Method in class org.apache.heron.streamlet.impl.StreamletBaseImpl
- ISpout - Interface in org.apache.heron.api.spout
-
ISpout is the core interface for implementing spouts.
- ISpoutOutputCollector - Interface in org.apache.heron.api.spout
- IStatefulComponent<K extends Serializable,V extends Serializable> - Interface in org.apache.heron.api.topology
-
Defines a component that saves its internal state in the State interface
- IStatefulWindowedBolt<K extends Serializable,V extends Serializable> - Interface in org.apache.heron.api.bolt
- isTick(Tuple) - Static method in class org.apache.heron.api.utils.TupleUtils
- IStreamletBasicOperator<R,T> - Interface in org.apache.heron.streamlet
-
The interface for streamlet operators.
- IStreamletOperator<R,T> - Interface in org.apache.heron.streamlet
-
The base interface for all Streamlet operator interfaces.
- IStreamletRichOperator<R,T> - Interface in org.apache.heron.streamlet
-
The interface for custom operators: it can be used to create operators based on existing Bolts (subclasses of IRichBolt).
- IStreamletWindowOperator<R,T> - Interface in org.apache.heron.streamlet
-
The interface for streamlet operators.
- isWatermark() - Method in interface org.apache.heron.api.windowing.Event
-
If this is a watermark event or not.
- isWatermark() - Method in class org.apache.heron.api.windowing.EventImpl
- isWatermark() - Method in class org.apache.heron.api.windowing.WaterMarkEvent
- ITaskHook - Interface in org.apache.heron.api.hooks
- iterator() - Method in class org.apache.heron.api.tuple.Fields
- ITwoPhaseStatefulComponent<K extends Serializable,V extends Serializable> - Interface in org.apache.heron.api.topology
-
Defines a stateful component that is aware of Heron topology's "two-phase commit".
- IUpdatable - Interface in org.apache.heron.api.topology
-
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 - Interface in org.apache.heron.api.bolt
-
A bolt abstraction for supporting time and count based sliding & tumbling windows.
J
- JAVA - org.apache.heron.streamlet.Config.Serializer
- JavaSerializer - Class in org.apache.heron.api.serializer
- JavaSerializer() - Constructor for class org.apache.heron.api.serializer.JavaSerializer
- join(Streamlet<S>, SerializableFunction<R, K>, SerializableFunction<S, K>, WindowConfig, JoinType, SerializableBiFunction<R, S, ? extends T>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Return a new KVStreamlet by joining 'this streamlet with ‘other’ streamlet.
- join(Streamlet<S>, SerializableFunction<R, K>, SerializableFunction<S, K>, WindowConfig, JoinType, SerializableBiFunction<R, S, ? extends T>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Return a new KVStreamlet by joining 'this streamlet with ‘other’ streamlet.
- join(Streamlet<S>, SerializableFunction<R, K>, SerializableFunction<S, K>, WindowConfig, SerializableBiFunction<R, S, ? extends T>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Return a new Streamlet by inner joining 'this streamlet with ‘other’ streamlet.
- join(Streamlet<S>, SerializableFunction<R, K>, SerializableFunction<S, K>, WindowConfig, SerializableBiFunction<R, S, ? extends T>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Return a new Streamlet by inner joining 'this streamlet with ‘other’ streamlet.
- JOIN - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- JoinCustomGrouping<R,K> - Class in org.apache.heron.streamlet.impl.groupings
-
JoinCustomGrouping is the class that routes the incoming tuples into the JoinOperator.
- JoinCustomGrouping(SerializableFunction<R, K>) - Constructor for class org.apache.heron.streamlet.impl.groupings.JoinCustomGrouping
- JoinOperator<K,V1,V2,VR> - Class in org.apache.heron.streamlet.impl.operators
-
JoinOperator is the bolt that implements the join/leftJoin/innerJoin functionality.
- JoinOperator(JoinType, String, String, SerializableFunction<V1, K>, SerializableFunction<V2, K>, SerializableBiFunction<V1, V2, ? extends VR>) - Constructor for class org.apache.heron.streamlet.impl.operators.JoinOperator
- JoinStreamlet<K,R,S,T> - Class in org.apache.heron.streamlet.impl.streamlets
-
JoinStreamlet represents a KVStreamlet that is the result of joining two KVStreamlets left and right using a WindowConfig.
- JoinType - Enum in org.apache.heron.streamlet
K
- KEEP - org.apache.heron.api.windowing.EvictionPolicy.Action
-
don't include in the current window but keep the event in the queue for evaluating as a part of future windows.
- keyBy(SerializableFunction<R, K>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Return a new KVStreamlet
by applying key extractor to each element of this Streamlet - keyBy(SerializableFunction<R, K>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Return a new KVStreamlet
by applying key extractor to each element of this Streamlet - keyBy(SerializableFunction<R, K>, SerializableFunction<R, V>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Return a new KVStreamlet
by applying key and value extractor to each element of this Streamlet - keyBy(SerializableFunction<R, K>, SerializableFunction<R, V>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Return a new KVStreamlet
by applying key and value extractor to each element of this Streamlet - KEYBY - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- KeyByOperator<R,K,V> - Class in org.apache.heron.streamlet.impl.operators
-
KeyByOperator is the class that implements keyBy functionality.
- KeyByOperator(SerializableFunction<R, K>, SerializableFunction<R, V>) - Constructor for class org.apache.heron.streamlet.impl.operators.KeyByOperator
- KeyByStreamlet<R,K,V> - Class in org.apache.heron.streamlet.impl.streamlets
-
KeyByStreamlet represents a KVStreamlet that is the result of applying key and value extractors on all elements.
- KeyByStreamlet(StreamletImpl<R>, SerializableFunction<R, K>, SerializableFunction<R, V>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.KeyByStreamlet
- KeyedWindow<T> - Class in org.apache.heron.streamlet
-
Transformation depending on Windowing pass on the window/key information using this class
- KeyedWindow(T, Window) - Constructor for class org.apache.heron.streamlet.KeyedWindow
- KeyValue<K,V> - Class in org.apache.heron.streamlet
-
Certain operations in the Streamlet API, like join/reduce, necessitate the concept of key value pairs.
- KeyValue(K, V) - Constructor for class org.apache.heron.streamlet.KeyValue
- KRYO - org.apache.heron.streamlet.Config.Serializer
- KryoSerializableDefault() - Constructor for class org.apache.heron.api.serializer.DefaultKryoFactory.KryoSerializableDefault
- KryoSerializer - Class in org.apache.heron.api.serializer
-
KryoSerializer is a wrapper around Heron's IPluggableSerializer.
- KryoSerializer - Class in org.apache.heron.streamlet.impl
-
KryoSerializer has been moved to heron.api.serializer package so that it can be used by Heron topologies written in low level API.
- KryoSerializer() - Constructor for class org.apache.heron.api.serializer.KryoSerializer
- KryoSerializer() - Constructor for class org.apache.heron.streamlet.impl.KryoSerializer
- KVStreamlet<K,V> - Interface in org.apache.heron.streamlet
-
A KVStreamlet is a Streamlet with KeyValue data.
- KVStreamletShadow<K,V> - Class in org.apache.heron.streamlet.impl.streamlets
-
KVStreamletShadow is a decorator for StreamletImpl
> objects. - KVStreamletShadow(StreamletImpl<KeyValue<K, V>>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.KVStreamletShadow
L
- LATE_TUPLE_FIELD - Static variable in class org.apache.heron.api.bolt.WindowedBoltExecutor
- LatencyStatAndMetric - Class in org.apache.heron.api.metric
-
Acts as a Latency Metric, but also keeps track of approximate latency for the last 10 mins, 3 hours, 1 day, and all time.
- LatencyStatAndMetric(int) - Constructor for class org.apache.heron.api.metric.LatencyStatAndMetric
-
Constructor
- lessThanNum(Long, Long, double) - Static method in class org.apache.heron.api.utils.DefaultMaxSpoutPendingTuner
- localOrShuffleGrouping(String) - Method in class org.apache.heron.api.topology.BoltDeclarer
- localOrShuffleGrouping(String, String) - Method in class org.apache.heron.api.topology.BoltDeclarer
- log() - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Logs every element of the streamlet using String.valueOf function Note that LogStreamlet is an empty streamlet.
- log() - Method in interface org.apache.heron.streamlet.Streamlet
-
Logs every element of the streamlet using String.valueOf function This is one of the sink functions in the sense that this operation returns void
- LOGGER - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- LogSink<R> - Class in org.apache.heron.streamlet.impl.sinks
-
LogSink is a very simple Bolt that implements the log functionality.
- LogSink() - Constructor for class org.apache.heron.streamlet.impl.sinks.LogSink
- LogStreamlet<R> - Class in org.apache.heron.streamlet.impl.streamlets
-
LogStreamlet represents en empty Streamlet that is made up of elements from the parent streamlet after logging each element.
- LogStreamlet(StreamletImpl<R>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.LogStreamlet
- lookUpTopologyDefnFile(String, String) - Static method in class org.apache.heron.api.utils.TopologyUtils
M
- makeClassPath(TopologyAPI.Topology, String) - Static method in class org.apache.heron.api.utils.TopologyUtils
- map(SerializableFunction<R, ? extends T>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Return a new Streamlet by applying mapFn to each element of this Streamlet
- map(SerializableFunction<R, ? extends T>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Return a new Streamlet by applying mapFn to each element of this Streamlet
- MAP - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- MapOperator<R,T> - Class in org.apache.heron.streamlet.impl.operators
-
MapOperator is the class that implements the map functionality.
- MapOperator(SerializableFunction<? super R, ? extends T>) - Constructor for class org.apache.heron.streamlet.impl.operators.MapOperator
- MapStreamlet<R,T> - Class in org.apache.heron.streamlet.impl.streamlets
-
MapStreamlet represents a Streamlet that is made up of applying the user supplied map function to each element of the parent streamlet.
- MapStreamlet(StreamletImpl<R>, SerializableFunction<? super R, ? extends T>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.MapStreamlet
- max(Double, Double) - Static method in class org.apache.heron.streamlet.StreamletReducers
- max(Float, Float) - Static method in class org.apache.heron.streamlet.StreamletReducers
- max(Integer, Integer) - Static method in class org.apache.heron.streamlet.StreamletReducers
- max(Long, Long) - Static method in class org.apache.heron.streamlet.StreamletReducers
- maxTopologyMessageTimeout() - Method in interface org.apache.heron.api.topology.GeneralTopologyContext
- MeanReducer - Class in org.apache.heron.api.metric
- MeanReducer() - Constructor for class org.apache.heron.api.metric.MeanReducer
- MeanReducerState - Class in org.apache.heron.api.metric
- MeanReducerState() - Constructor for class org.apache.heron.api.metric.MeanReducerState
- min(Double, Double) - Static method in class org.apache.heron.streamlet.StreamletReducers
- min(Float, Float) - Static method in class org.apache.heron.streamlet.StreamletReducers
- min(Integer, Integer) - Static method in class org.apache.heron.streamlet.StreamletReducers
- min(Long, Long) - Static method in class org.apache.heron.streamlet.StreamletReducers
- moreThanNum(Long, Long, double) - Static method in class org.apache.heron.api.utils.DefaultMaxSpoutPendingTuner
- MultiAssignableMetric<T extends Number> - Class in org.apache.heron.api.metric
- MultiAssignableMetric(T) - Constructor for class org.apache.heron.api.metric.MultiAssignableMetric
- MultiCountMetric - Class in org.apache.heron.api.metric
- MultiCountMetric() - Constructor for class org.apache.heron.api.metric.MultiCountMetric
- MultiReducedMetric<T,U,V> - Class in org.apache.heron.api.metric
- MultiReducedMetric(IReducer<T, U, V>) - Constructor for class org.apache.heron.api.metric.MultiReducedMetric
- MultiScheme - Interface in org.apache.heron.api.spout
N
- name - Variable in class org.apache.heron.streamlet.impl.StreamletBaseImpl
- newBuilder() - Static method in interface org.apache.heron.streamlet.Builder
- newBuilder() - Static method in class org.apache.heron.streamlet.Config
-
Returns a new
Config.Builder
that can be used to create a configuration object for Streamlet API topologies - newInstance(String) - Static method in class org.apache.heron.api.utils.Utils
- newSource(IRichSpout) - Method in interface org.apache.heron.streamlet.Builder
-
Creates a new Streamlet using the provided spout
- newSource(IRichSpout) - Method in class org.apache.heron.streamlet.impl.BuilderImpl
- newSource(SerializableSupplier<R>) - Method in interface org.apache.heron.streamlet.Builder
-
All sources of the computation should register using addSource.
- newSource(SerializableSupplier<R>) - Method in class org.apache.heron.streamlet.impl.BuilderImpl
- newSource(Source<R>) - Method in interface org.apache.heron.streamlet.Builder
-
Creates a new Streamlet using the underlying generator
- newSource(Source<R>) - Method in class org.apache.heron.streamlet.impl.BuilderImpl
- newWindowLifecycleListener() - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- nextTuple() - Method in interface org.apache.heron.api.spout.ISpout
-
When this method is called, Heron is requesting that the Spout emit tuples to the output collector.
- nextTuple() - Method in class org.apache.heron.streamlet.impl.sources.ComplexSource
- nextTuple() - Method in class org.apache.heron.streamlet.impl.sources.SupplierSource
- noneGrouping(String) - Method in class org.apache.heron.api.topology.BoltDeclarer
- noneGrouping(String, String) - Method in class org.apache.heron.api.topology.BoltDeclarer
- NoneStreamGrouping - Class in org.apache.heron.api.grouping
-
This is the stream grouping strategy that is the same as shuffle grouping.
- NoneStreamGrouping() - Constructor for class org.apache.heron.api.grouping.NoneStreamGrouping
- nPartitions - Variable in class org.apache.heron.streamlet.impl.StreamletBaseImpl
O
- of(int) - Static method in class org.apache.heron.api.bolt.BaseWindowedBolt.Count
-
Returns a
BaseWindowedBolt.Count
of given value. - of(String) - Static method in class org.apache.heron.api.windowing.TupleFieldTimestampExtractor
- of(T1, T2) - Static method in class org.apache.heron.api.Pair
-
Constructs a new pair of values.
- onActivation(List<T>, List<T>, List<T>, Long) - Method in interface org.apache.heron.api.windowing.WindowLifecycleListener
-
Called on activation of the window due to the
TriggerPolicy
- onExpiry(List<T>) - Method in interface org.apache.heron.api.windowing.WindowLifecycleListener
-
Called on expiry of events from the window due to
EvictionPolicy
- onTrigger() - Method in interface org.apache.heron.api.windowing.TriggerHandler
-
The code to execute when the
TriggerPolicy
condition is satisfied. - onTrigger() - Method in class org.apache.heron.api.windowing.WindowManager
-
The callback invoked by the trigger policy.
- open(Map<String, Object>, TopologyContext, SpoutOutputCollector) - Method in interface org.apache.heron.api.spout.ISpout
-
Called when a task for this component is initialized within a worker on the cluster.
- open(Map<String, Object>, TopologyContext, SpoutOutputCollector) - Method in class org.apache.heron.streamlet.impl.sources.ComplexSource
- open(Map<String, Object>, TopologyContext, SpoutOutputCollector) - Method in class org.apache.heron.streamlet.impl.sources.StreamletSource
- org.apache.heron.api - package org.apache.heron.api
- org.apache.heron.api.bolt - package org.apache.heron.api.bolt
- org.apache.heron.api.exception - package org.apache.heron.api.exception
- org.apache.heron.api.grouping - package org.apache.heron.api.grouping
- org.apache.heron.api.hooks - package org.apache.heron.api.hooks
- org.apache.heron.api.hooks.info - package org.apache.heron.api.hooks.info
- org.apache.heron.api.metric - package org.apache.heron.api.metric
- org.apache.heron.api.serializer - package org.apache.heron.api.serializer
- org.apache.heron.api.spout - package org.apache.heron.api.spout
- org.apache.heron.api.state - package org.apache.heron.api.state
- org.apache.heron.api.topology - package org.apache.heron.api.topology
- org.apache.heron.api.tuple - package org.apache.heron.api.tuple
- org.apache.heron.api.utils - package org.apache.heron.api.utils
- org.apache.heron.api.windowing - package org.apache.heron.api.windowing
- org.apache.heron.api.windowing.evictors - package org.apache.heron.api.windowing.evictors
- org.apache.heron.api.windowing.triggers - package org.apache.heron.api.windowing.triggers
- org.apache.heron.streamlet - package org.apache.heron.streamlet
- org.apache.heron.streamlet.impl - package org.apache.heron.streamlet.impl
- org.apache.heron.streamlet.impl.groupings - package org.apache.heron.streamlet.impl.groupings
- org.apache.heron.streamlet.impl.operators - package org.apache.heron.streamlet.impl.operators
- org.apache.heron.streamlet.impl.sinks - package org.apache.heron.streamlet.impl.sinks
- org.apache.heron.streamlet.impl.sources - package org.apache.heron.streamlet.impl.sources
- org.apache.heron.streamlet.impl.streamlets - package org.apache.heron.streamlet.impl.streamlets
- org.apache.heron.streamlet.impl.utils - package org.apache.heron.streamlet.impl.utils
- org.apache.heron.streamlet.impl.windowings - package org.apache.heron.streamlet.impl.windowings
- OUTER - org.apache.heron.streamlet.JoinType
-
Return a new KVStreamlet by outer joining ‘this’ streamlet with ‘other’ streamlet.
- OUTER_LEFT - org.apache.heron.streamlet.JoinType
-
Return a new KVStreamlet by left joining ‘this’ streamlet with ‘other’ streamlet.
- OUTER_RIGHT - org.apache.heron.streamlet.JoinType
-
Return a new KVStreamlet by right joining ‘this’ streamlet with ‘other’ streamlet.
- OUTPUT_FIELD_NAME - Static variable in class org.apache.heron.streamlet.impl.operators.StreamletOperator
- OutputCollector - Class in org.apache.heron.api.bolt
-
This output collector exposes the API for emitting tuples from an IRichBolt.
- OutputCollector(IOutputCollector) - Constructor for class org.apache.heron.api.bolt.OutputCollector
- OutputFieldsDeclarer - Interface in org.apache.heron.api.topology
- OutputFieldsGetter - Class in org.apache.heron.api.topology
- OutputFieldsGetter() - Constructor for class org.apache.heron.api.topology.OutputFieldsGetter
- overrideDefault(boolean) - Method in class org.apache.heron.api.serializer.DefaultKryoFactory.KryoSerializableDefault
P
- Pair<T1,T2> - Class in org.apache.heron.api
-
A pair of values.
- postDecorate(Kryo, Map) - Method in class org.apache.heron.api.serializer.DefaultKryoFactory
- postDecorate(Kryo, Map) - Method in interface org.apache.heron.api.serializer.IKryoFactory
- postRegister(Kryo, Map) - Method in class org.apache.heron.api.serializer.DefaultKryoFactory
- postRegister(Kryo, Map) - Method in interface org.apache.heron.api.serializer.IKryoFactory
- postSave(String) - Method in interface org.apache.heron.api.topology.ITwoPhaseStatefulComponent
-
This is a hook for the component to perform some actions after a checkpoint is persisted successfully for all components in the topology.
- prepare(Map<String, Object>, TopologyContext) - Method in class org.apache.heron.api.bolt.BaseBasicBolt
- prepare(Map<String, Object>, TopologyContext) - Method in interface org.apache.heron.api.bolt.IBasicBolt
- prepare(Map<String, Object>, TopologyContext) - Method in class org.apache.heron.api.hooks.BaseTaskHook
- prepare(Map<String, Object>, TopologyContext) - Method in interface org.apache.heron.api.hooks.ITaskHook
-
Called after the spout/bolt's open/prepare method is called conf is the Config thats passed to the topology
- prepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
- prepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.heron.api.bolt.BasicBoltExecutor
- prepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in interface org.apache.heron.api.bolt.IBolt
-
Called when a task for this component is initialized within a worker on the cluster.
- prepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in interface org.apache.heron.api.bolt.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(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- prepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.heron.streamlet.impl.operators.StreamletOperator
- prepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.heron.streamlet.impl.operators.StreamletWindowOperator
- prepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.heron.streamlet.impl.operators.TransformOperator
- prepare(Map<String, Object>, TopologyContext, OutputCollector) - Method in class org.apache.heron.streamlet.impl.sinks.ComplexSink
- prepare(TopologyContext, String, String, List<Integer>) - Method in interface org.apache.heron.api.grouping.CustomStreamGrouping
-
Tells the stream grouping at runtime the tasks in the target bolt.
- prepare(TopologyContext, String, String, List<Integer>) - Method in class org.apache.heron.streamlet.impl.groupings.JoinCustomGrouping
- prepare(TopologyContext, String, String, List<Integer>) - Method in class org.apache.heron.streamlet.impl.groupings.ReduceByKeyAndWindowCustomGrouping
- prepare(TopologyContext, String, String, List<Integer>) - Method in class org.apache.heron.streamlet.impl.groupings.RemapCustomGrouping
- preRegister(Kryo, Map) - Method in class org.apache.heron.api.serializer.DefaultKryoFactory
- preRegister(Kryo, Map) - Method in interface org.apache.heron.api.serializer.IKryoFactory
- preRestore(String) - Method in interface org.apache.heron.api.topology.ITwoPhaseStatefulComponent
-
This is a hook for the component to perform some actions (eg.
- preSave(String) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
- preSave(String) - Method in class org.apache.heron.api.bolt.StatefulWindowedBoltExecutor
- preSave(String) - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- preSave(String) - Method in interface org.apache.heron.api.topology.IStatefulComponent
-
This is a hook for the component to perform some actions just before the framework saves its state.
- preSave(String) - Method in class org.apache.heron.streamlet.impl.operators.TransformOperator
- preSave(String) - Method in class org.apache.heron.streamlet.impl.sinks.ComplexSink
- preSave(String) - Method in class org.apache.heron.streamlet.impl.sources.StreamletSource
- PROCESS - org.apache.heron.api.windowing.EvictionPolicy.Action
-
process the event in the current window of events.
- put(T) - Method in interface org.apache.heron.streamlet.Sink
Q
- queue - Variable in class org.apache.heron.api.windowing.WindowManager
R
- RawMultiScheme - Class in org.apache.heron.api.spout
- RawMultiScheme() - Constructor for class org.apache.heron.api.spout.RawMultiScheme
- RawScheme - Class in org.apache.heron.api.spout
- RawScheme() - Constructor for class org.apache.heron.api.spout.RawScheme
- read(Kryo, Input, Class) - Method in class org.apache.heron.api.serializer.SerializableSerializer
- readCommandLineOpts() - Static method in class org.apache.heron.api.utils.Utils
- readResolve() - Method in enum org.apache.heron.api.metric.GlobalMetrics
-
During serialization don't create a copy of this class.
- record(long) - Method in class org.apache.heron.api.metric.LatencyStatAndMetric
-
Record a specific latency
- reduce(MeanReducerState, Number) - Method in class org.apache.heron.api.metric.MeanReducer
- reduce(T, U) - Method in interface org.apache.heron.api.metric.IReducer
- REDUCE - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- reduceByKey(SerializableFunction<R, K>, SerializableFunction<R, T>, SerializableBinaryOperator<T>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Return a new Streamlet accumulating tuples of this streamlet and applying reduceFn on those tuples.
- reduceByKey(SerializableFunction<R, K>, SerializableFunction<R, T>, SerializableBinaryOperator<T>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Return a new Streamlet accumulating tuples of this streamlet and applying reduceFn on those tuples.
- reduceByKey(SerializableFunction<R, K>, T, SerializableBiFunction<T, R, ? extends T>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Return a new Streamlet accumulating tuples of this streamlet and applying reduceFn on those tuples.
- reduceByKey(SerializableFunction<R, K>, T, SerializableBiFunction<T, R, ? extends T>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Return a new Streamlet accumulating tuples of this streamlet and applying reduceFn on those tuples.
- reduceByKeyAndWindow(SerializableFunction<R, K>, SerializableFunction<R, T>, WindowConfig, SerializableBinaryOperator<T>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Return a new Streamlet accumulating tuples of this streamlet over a Window defined by windowCfg and applying reduceFn on those tuples.
- reduceByKeyAndWindow(SerializableFunction<R, K>, SerializableFunction<R, V>, WindowConfig, SerializableBinaryOperator<V>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Return a new Streamlet accumulating tuples of this streamlet over a Window defined by windowCfg and applying reduceFn on those tuples.
- reduceByKeyAndWindow(SerializableFunction<R, K>, WindowConfig, T, SerializableBiFunction<T, R, ? extends T>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Return a new Streamlet accumulating tuples of this streamlet over a Window defined by windowCfg and applying reduceFn on those tuples.
- reduceByKeyAndWindow(SerializableFunction<R, K>, WindowConfig, T, SerializableBiFunction<T, R, ? extends T>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Return a new Streamlet accumulating tuples of this streamlet over a Window defined by windowCfg and applying reduceFn on those tuples.
- ReduceByKeyAndWindowCustomGrouping<R,K> - Class in org.apache.heron.streamlet.impl.groupings
-
ReduceByKeyAndWindowCustomGrouping is the class that routes the incoming tuples into the ReduceByKeyAndWindowOperator.
- ReduceByKeyAndWindowCustomGrouping(SerializableFunction<R, K>) - Constructor for class org.apache.heron.streamlet.impl.groupings.ReduceByKeyAndWindowCustomGrouping
- ReduceByKeyAndWindowOperator<R,K,T> - Class in org.apache.heron.streamlet.impl.operators
-
ReduceByKeyAndWindowOperator is the class that implements reduceByKeyAndWindow functionality.
- ReduceByKeyAndWindowOperator(SerializableFunction<R, K>, SerializableFunction<R, T>, SerializableBinaryOperator<T>) - Constructor for class org.apache.heron.streamlet.impl.operators.ReduceByKeyAndWindowOperator
- ReduceByKeyAndWindowStreamlet<R,K,T> - Class in org.apache.heron.streamlet.impl.streamlets
-
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.
- ReduceByKeyAndWindowStreamlet(StreamletImpl<R>, SerializableFunction<R, K>, SerializableFunction<R, T>, WindowConfig, SerializableBinaryOperator<T>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.ReduceByKeyAndWindowStreamlet
- ReduceByKeyOperator<R,K,T> - Class in org.apache.heron.streamlet.impl.operators
-
ReduceByKeyOperator is the class that implements the reduce functionality.
- ReduceByKeyOperator(SerializableFunction<R, K>, SerializableFunction<R, T>, SerializableBinaryOperator<T>) - Constructor for class org.apache.heron.streamlet.impl.operators.ReduceByKeyOperator
- ReduceByKeyStreamlet<R,K,T> - Class in org.apache.heron.streamlet.impl.streamlets
-
ReduceByKeyStreamlet represents a KVStreamlet that is the result of applying user supplied reduceFn on all elements.
- ReduceByKeyStreamlet(StreamletImpl<R>, SerializableFunction<R, K>, SerializableFunction<R, T>, SerializableBinaryOperator<T>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.ReduceByKeyStreamlet
- ReducedMetric<T,U,V> - Class in org.apache.heron.api.metric
-
Apply an update to an metric using an IReducer for which a result can be extracted.
- ReducedMetric(IReducer<T, U, V>) - Constructor for class org.apache.heron.api.metric.ReducedMetric
- registerDecorator(Class<? extends IKryoDecorator>) - Method in class org.apache.heron.api.Config
- registerDecorator(Map, Class<? extends IKryoDecorator>) - Static method in class org.apache.heron.api.Config
- registerKryoSerialization(Class) - Method in class org.apache.heron.api.Config
- registerKryoSerialization(Class, Class<? extends Serializer>) - Method in class org.apache.heron.api.Config
- registerKryoSerialization(Map<String, Object>, Class) - Static method in class org.apache.heron.api.Config
- registerKryoSerialization(Map<String, Object>, Class, Class<? extends Serializer>) - Static method in class org.apache.heron.api.Config
- registerMetric(String, int, Supplier<T>) - Method in interface org.apache.heron.streamlet.Context
-
Register a metric function.
- registerMetric(String, int, Supplier<T>) - Method in class org.apache.heron.streamlet.impl.ContextImpl
- registerMetric(String, ICombiner<T>, int) - Method in interface org.apache.heron.api.topology.TopologyContext
- registerMetric(String, IReducer<T, U, V>, int) - Method in interface org.apache.heron.api.topology.TopologyContext
- registerMetric(String, T, int) - Method in interface org.apache.heron.api.metric.IMetricsRegister
-
Register an IMetric instance.
- registerTopologyTimerEvents(String, Duration, Runnable) - Method in class org.apache.heron.api.Config
- registerTopologyTimerEvents(Map<String, Object>, String, Duration, Runnable) - Static method in class org.apache.heron.api.Config
-
Registers a timer event that executes periodically
- REMAP - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- RemapCustomGrouping<R> - Class in org.apache.heron.streamlet.impl.groupings
-
RemapCustomGrouping is the class that routes the incoming tuples into the ReMapBolt.
- RemapCustomGrouping(SerializableBiFunction<? super R, Integer, List<Integer>>) - Constructor for class org.apache.heron.streamlet.impl.groupings.RemapCustomGrouping
- RemapStreamlet<R> - Class in org.apache.heron.streamlet.impl.streamlets
-
RemapStreamlet represents a Streamlet that is the result of applying user supplied remapFn on all elements of its parent Streamlet.
- RemapStreamlet(StreamletImpl<R>, SerializableBiFunction<? super R, Integer, List<Integer>>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.RemapStreamlet
- repartition(int) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Same as filter(Identity).setNumPartitions(nPartitions)
- repartition(int) - Method in interface org.apache.heron.streamlet.Streamlet
-
Same as filter(filterFn).setNumPartitions(nPartitions) where filterFn is identity
- repartition(int, SerializableBiFunction<R, Integer, List<Integer>>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
A more generalized version of repartition where a user can determine which partitions any particular tuple should go to
- repartition(int, SerializableBiFunction<R, Integer, List<Integer>>) - Method in interface org.apache.heron.streamlet.Streamlet
-
A more generalized version of repartition where a user can determine which partitions any particular tuple should go to.
- ReportedFailedException - Exception in org.apache.heron.api.exception
- ReportedFailedException() - Constructor for exception org.apache.heron.api.exception.ReportedFailedException
- ReportedFailedException(String) - Constructor for exception org.apache.heron.api.exception.ReportedFailedException
- ReportedFailedException(String, Throwable) - Constructor for exception org.apache.heron.api.exception.ReportedFailedException
- ReportedFailedException(Throwable) - Constructor for exception org.apache.heron.api.exception.ReportedFailedException
- reportError(Throwable) - Method in class org.apache.heron.api.bolt.BasicOutputCollector
- reportError(Throwable) - Method in interface org.apache.heron.api.bolt.IBasicOutputCollector
- reportError(Throwable) - Method in interface org.apache.heron.api.bolt.IErrorReporter
- reportError(Throwable) - Method in class org.apache.heron.api.bolt.OutputCollector
- reportError(Throwable) - Method in interface org.apache.heron.api.spout.ISpoutOutputCollector
- reportError(Throwable) - Method in class org.apache.heron.api.spout.SpoutOutputCollector
- require(Boolean, String) - Static method in class org.apache.heron.streamlet.impl.utils.StreamletUtils
-
Verifies the requirement as the utility function.
- reset() - Method in interface org.apache.heron.api.windowing.EvictionPolicy
-
Resets the eviction policy.
- reset() - Method in class org.apache.heron.api.windowing.evictors.CountEvictionPolicy
- reset() - Method in class org.apache.heron.api.windowing.evictors.TimeEvictionPolicy
- reset() - Method in class org.apache.heron.api.windowing.evictors.WatermarkCountEvictionPolicy
- reset() - Method in interface org.apache.heron.api.windowing.TriggerPolicy
-
resets the trigger policy.
- reset() - Method in class org.apache.heron.api.windowing.triggers.CountTriggerPolicy
- reset() - Method in class org.apache.heron.api.windowing.triggers.TimeTriggerPolicy
- reset() - Method in class org.apache.heron.api.windowing.triggers.WatermarkCountTriggerPolicy
- reset() - Method in class org.apache.heron.api.windowing.triggers.WatermarkTimeTriggerPolicy
- resetValues() - Method in interface org.apache.heron.api.tuple.Tuple
-
Resets the tuple values to null TODO:- Is this needed
- restoreState(Integer) - Method in class org.apache.heron.api.windowing.triggers.CountTriggerPolicy
- restoreState(Long) - Method in class org.apache.heron.api.windowing.evictors.CountEvictionPolicy
- restoreState(Long) - Method in class org.apache.heron.api.windowing.triggers.WatermarkCountTriggerPolicy
- restoreState(Long) - Method in class org.apache.heron.api.windowing.triggers.WatermarkTimeTriggerPolicy
- restoreState(Void) - Method in class org.apache.heron.api.windowing.triggers.TimeTriggerPolicy
- restoreState(Map<String, Serializable>) - Method in class org.apache.heron.api.windowing.WindowManager
-
Restore state associated with the window manager
- restoreState(Pair<Long, Long>) - Method in class org.apache.heron.api.windowing.evictors.WatermarkCountEvictionPolicy
- restoreState(EvictionContext) - Method in class org.apache.heron.api.windowing.evictors.TimeEvictionPolicy
- restoreState(S) - Method in interface org.apache.heron.api.windowing.EvictionPolicy
-
Restore the eviction policy from the state that was earlier checkpointed by the framework.
- restoreState(S) - Method in interface org.apache.heron.api.windowing.TriggerPolicy
-
Restore the trigger policy from the state that was earlier checkpointed by the framework.
- returnThis() - Method in class org.apache.heron.api.topology.BaseComponentDeclarer
- returnThis() - Method in class org.apache.heron.api.topology.BoltDeclarer
- returnThis() - Method in class org.apache.heron.api.topology.SpoutDeclarer
- ROOT_NAME - Static variable in enum org.apache.heron.api.metric.GlobalMetrics
- run() - Method in class org.apache.heron.api.windowing.WaterMarkEventGenerator
- run(String, Config, Builder) - Method in class org.apache.heron.streamlet.Runner
-
Runs the computation
- Runner - Class in org.apache.heron.streamlet
-
Runner is used to run a topology that is built by the builder.
- Runner() - Constructor for class org.apache.heron.streamlet.Runner
S
- safeIncr(String) - Static method in enum org.apache.heron.api.metric.GlobalMetrics
-
Thread safe created increment of counterName.
- safeIncrBy(String, int) - Static method in enum org.apache.heron.api.metric.GlobalMetrics
-
Thread safe created increment of counterName.
- safeScope(String) - Method in class org.apache.heron.api.metric.MultiAssignableMetric
- scheme - Variable in class org.apache.heron.api.spout.SchemeAsMultiScheme
- Scheme - Interface in org.apache.heron.api.spout
- SchemeAsMultiScheme - Class in org.apache.heron.api.spout
- SchemeAsMultiScheme(Scheme) - Constructor for class org.apache.heron.api.spout.SchemeAsMultiScheme
- scope(String) - Method in class org.apache.heron.api.metric.MultiAssignableMetric
- scope(String) - Method in class org.apache.heron.api.metric.MultiCountMetric
- scope(String) - Method in class org.apache.heron.api.metric.MultiReducedMetric
- select(Fields) - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns a subset of the tuple based on the fields selector.
- select(Fields, List<Object>) - Method in class org.apache.heron.api.tuple.Fields
- SerializableBiFunction<A,B,C> - Interface in org.apache.heron.streamlet
-
All user supplied transformation functions have to be serializable.
- SerializableBinaryOperator<T> - Interface in org.apache.heron.streamlet
-
All user supplied transformation functions have to be serializable.
- SerializableConsumer<T> - Interface in org.apache.heron.streamlet
-
All user supplied transformation functions have to be serializable.
- SerializableFunction<A,B> - Interface in org.apache.heron.streamlet
-
All user supplied transformation functions have to be serializable.
- SerializablePredicate<T> - Interface in org.apache.heron.streamlet
-
All user supplied transformation functions have to be serializable.
- SerializableSerializer - Class in org.apache.heron.api.serializer
- SerializableSerializer() - Constructor for class org.apache.heron.api.serializer.SerializableSerializer
- SerializableSupplier<T> - Interface in org.apache.heron.streamlet
-
All user supplied transformation functions have to be serializable.
- SerializableTransformer<I,O> - Interface in org.apache.heron.streamlet
-
All user supplied transformation functions have to be serializable.
- serialize(Object) - Method in interface org.apache.heron.api.serializer.IPluggableSerializer
- serialize(Object) - Method in class org.apache.heron.api.serializer.JavaSerializer
- serialize(Object) - Method in class org.apache.heron.api.serializer.KryoSerializer
- serialize(Object) - Static method in class org.apache.heron.api.utils.Utils
- setAutoTaskHooks(List<String>) - Method in class org.apache.heron.api.Config
- setAutoTaskHooks(Map<String, Object>, List<String>) - Static method in class org.apache.heron.api.Config
- setBolt(String, IBasicBolt) - Method in class org.apache.heron.api.topology.TopologyBuilder
-
Define a new bolt in this topology.
- setBolt(String, IBasicBolt, Number) - Method in class org.apache.heron.api.topology.TopologyBuilder
-
Define a new bolt in this topology.
- setBolt(String, IRichBolt) - Method in class org.apache.heron.api.topology.TopologyBuilder
-
Define a new bolt in this topology with parallelism of just one thread.
- setBolt(String, IRichBolt, Number) - Method in class org.apache.heron.api.topology.TopologyBuilder
-
Define a new bolt in this topology with the specified amount of parallelism.
- setBolt(String, IStatefulWindowedBolt<K, V>) - Method in class org.apache.heron.api.topology.TopologyBuilder
-
Define a new bolt in this topology.
- setBolt(String, IStatefulWindowedBolt<K, V>, Number) - Method in class org.apache.heron.api.topology.TopologyBuilder
-
Define a new bolt in this topology.
- setBolt(String, IWindowedBolt) - Method in class org.apache.heron.api.topology.TopologyBuilder
-
Define a new bolt in this topology.
- setBolt(String, IWindowedBolt, Number) - Method in class org.apache.heron.api.topology.TopologyBuilder
-
Define a new bolt in this topology.
- setCheckpointManagerRam(Map<String, Object>, ByteAmount) - Static method in class org.apache.heron.api.Config
- setCheckpointManagerRam(ByteAmount) - Method in class org.apache.heron.api.Config
- setComponentCpu(String, double) - Method in class org.apache.heron.api.Config
- setComponentCpu(Map<String, Object>, String, double) - Static method in class org.apache.heron.api.Config
- setComponentCpuMap(String) - Method in class org.apache.heron.api.Config
- setComponentCpuMap(Map<String, Object>, String) - Static method in class org.apache.heron.api.Config
- setComponentDisk(String, ByteAmount) - Method in class org.apache.heron.api.Config
- setComponentDisk(Map<String, Object>, String, ByteAmount) - Static method in class org.apache.heron.api.Config
- setComponentDiskMap(String) - Method in class org.apache.heron.api.Config
- setComponentDiskMap(Map<String, Object>, String) - Static method in class org.apache.heron.api.Config
- setComponentJvmOptions(String, String) - Method in class org.apache.heron.api.Config
- setComponentJvmOptions(Map<String, Object>, String, String) - Static method in class org.apache.heron.api.Config
- setComponentParallelism(int) - Method in class org.apache.heron.api.Config
- setComponentParallelism(Map<String, Object>, int) - Static method in class org.apache.heron.api.Config
- setComponentRam(String, ByteAmount) - Method in class org.apache.heron.api.Config
- setComponentRam(Map<String, Object>, String, long) - Static method in class org.apache.heron.api.Config
-
Deprecated.use setComponentRam(Map<String, Object> conf, String component, ByteAmount ramInBytes)
- setComponentRam(Map<String, Object>, String, ByteAmount) - Static method in class org.apache.heron.api.Config
- setComponentRamMap(String) - Method in class org.apache.heron.api.Config
- setComponentRamMap(Map<String, Object>, String) - Static method in class org.apache.heron.api.Config
- setConfig(Config) - Method in class org.apache.heron.api.HeronTopology
- setContainerCpuPadding(double) - Method in class org.apache.heron.api.Config
- setContainerCpuPadding(Map<String, Object>, double) - Static method in class org.apache.heron.api.Config
- setContainerCpuRequested(double) - Method in class org.apache.heron.api.Config
- setContainerCpuRequested(Map<String, Object>, double) - Static method in class org.apache.heron.api.Config
- setContainerDiskRequested(Map<String, Object>, long) - Static method in class org.apache.heron.api.Config
-
Deprecated.use setContainerDiskRequested(Map<String, Object> conf, ByteAmount nbytes)
- setContainerDiskRequested(Map<String, Object>, ByteAmount) - Static method in class org.apache.heron.api.Config
- setContainerDiskRequested(ByteAmount) - Method in class org.apache.heron.api.Config
- setContainerMaxCpuHint(double) - Method in class org.apache.heron.api.Config
- setContainerMaxCpuHint(Map<String, Object>, double) - Static method in class org.apache.heron.api.Config
- setContainerMaxDiskHint(Map<String, Object>, ByteAmount) - Static method in class org.apache.heron.api.Config
- setContainerMaxDiskHint(ByteAmount) - Method in class org.apache.heron.api.Config
- setContainerMaxRamHint(Map<String, Object>, ByteAmount) - Static method in class org.apache.heron.api.Config
- setContainerMaxRamHint(ByteAmount) - Method in class org.apache.heron.api.Config
- setContainerPaddingPercentage(int) - Method in class org.apache.heron.api.Config
- setContainerPaddingPercentage(Map<String, Object>, int) - Static method in class org.apache.heron.api.Config
- setContainerRamPadding(Map<String, Object>, ByteAmount) - Static method in class org.apache.heron.api.Config
- setContainerRamPadding(ByteAmount) - Method in class org.apache.heron.api.Config
- setContainerRamRequested(Map<String, Object>, long) - Static method in class org.apache.heron.api.Config
-
Deprecated.use setContainerRamRequested(Map<String, Object> conf, ByteAmount nbytes)
- setContainerRamRequested(Map<String, Object>, ByteAmount) - Static method in class org.apache.heron.api.Config
- setContainerRamRequested(ByteAmount) - Method in class org.apache.heron.api.Config
- setContext(Tuple) - Method in class org.apache.heron.api.bolt.BasicOutputCollector
- setContext(EvictionContext) - Method in interface org.apache.heron.api.windowing.EvictionPolicy
-
Sets a context in the eviction policy that can be used while evicting the events.
- setContext(EvictionContext) - Method in class org.apache.heron.api.windowing.evictors.CountEvictionPolicy
- setContext(EvictionContext) - Method in class org.apache.heron.api.windowing.evictors.TimeEvictionPolicy
- setContext(EvictionContext) - Method in class org.apache.heron.api.windowing.evictors.WatermarkCountEvictionPolicy
- setDebug(boolean) - Method in class org.apache.heron.api.Config
- setDebug(boolean) - Method in class org.apache.heron.api.topology.BaseConfigurationDeclarer
- setDebug(boolean) - Method in interface org.apache.heron.api.topology.ComponentConfigurationDeclarer
- setDebug(Map<String, Object>, boolean) - Static method in class org.apache.heron.api.Config
- setDefaultNameIfNone(StreamletBaseImpl.StreamletNamePrefix, Set<String>) - Method in class org.apache.heron.streamlet.impl.StreamletBaseImpl
-
Sets a default unique name to the Streamlet by type if it is not set.
- setDeliverySemantics(Config.DeliverySemantics) - Method in class org.apache.heron.streamlet.Config.Builder
-
Sets the delivery semantics of the topology
- setEnableAcking(boolean) - Method in class org.apache.heron.api.Config
-
Deprecated.
- setEnableAcking(Map<String, Object>, boolean) - Static method in class org.apache.heron.api.Config
-
Deprecated.
- setEnvironment(Map<String, Object>, Map) - Static method in class org.apache.heron.api.Config
- setEvictionPolicy(EvictionPolicy<T, ?>) - Method in interface org.apache.heron.api.windowing.TriggerPolicy
-
Set the eviction policy to whatever eviction policy to use this with
- setEvictionPolicy(EvictionPolicy<T, ?>) - Method in class org.apache.heron.api.windowing.triggers.AbstractBaseTriggerPolicy
-
Set the eviction policy to whatever eviction policy to use this with
- setEvictionPolicy(EvictionPolicy<T, ?>) - Method in class org.apache.heron.api.windowing.WindowManager
- setFallBackOnJavaSerialization(boolean) - Method in class org.apache.heron.api.Config
- setFallBackOnJavaSerialization(Map, boolean) - Static method in class org.apache.heron.api.Config
- setFFDSortingStrategy(String) - Method in class org.apache.heron.api.Config
- setFFDSortingStrategy(Map<String, Object>, String) - Static method in class org.apache.heron.api.Config
- setKey(K) - Method in class org.apache.heron.streamlet.KeyValue
- setKryoFactory(Class<? extends IKryoFactory>) - Method in class org.apache.heron.api.Config
- setKryoFactory(Map, Class<? extends IKryoFactory>) - Static method in class org.apache.heron.api.Config
- setMaxNumInstancesPerContainer(Map<String, Object>, int) - Static method in class org.apache.heron.api.Config
- setMaxSpoutPending(int) - Method in class org.apache.heron.api.Config
- setMaxSpoutPending(Number) - Method in class org.apache.heron.api.topology.BaseConfigurationDeclarer
- setMaxSpoutPending(Number) - Method in interface org.apache.heron.api.topology.ComponentConfigurationDeclarer
- setMaxSpoutPending(Map<String, Object>, int) - Static method in class org.apache.heron.api.Config
- setMessageTimeoutSecs(int) - Method in class org.apache.heron.api.Config
- setMessageTimeoutSecs(Map<String, Object>, int) - Static method in class org.apache.heron.api.Config
- setMetricsmgrRam(Map<String, Object>, ByteAmount) - Static method in class org.apache.heron.api.Config
- setMetricsmgrRam(ByteAmount) - Method in class org.apache.heron.api.Config
- setName(String) - Method in class org.apache.heron.api.HeronTopology
- setName(String) - Method in class org.apache.heron.streamlet.impl.StreamletBaseImpl
-
Sets the name of the Streamlet.
- setName(String) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Sets the name of the Streamlet.
- setName(String) - Method in class org.apache.heron.streamlet.impl.streamlets.KVStreamletShadow
- setName(String) - Method in class org.apache.heron.streamlet.impl.streamlets.StreamletShadow
- setName(String) - Method in interface org.apache.heron.streamlet.Streamlet
-
Sets the name of the BaseStreamlet.
- setName(String) - Method in interface org.apache.heron.streamlet.StreamletBase
-
Sets the name of the BaseStreamlet.
- setNumContainers(int) - Method in class org.apache.heron.streamlet.Config.Builder
-
Sets the number of containers to run this topology
- setNumPartitions(int) - Method in class org.apache.heron.streamlet.impl.StreamletBaseImpl
-
Sets the number of partitions of the streamlet
- setNumPartitions(int) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Sets the number of partitions of the streamlet
- setNumPartitions(int) - Method in class org.apache.heron.streamlet.impl.streamlets.KVStreamletShadow
- setNumPartitions(int) - Method in class org.apache.heron.streamlet.impl.streamlets.StreamletShadow
- setNumPartitions(int) - Method in interface org.apache.heron.streamlet.Streamlet
-
Sets the number of partitions of the streamlet
- setNumPartitions(int) - Method in interface org.apache.heron.streamlet.StreamletBase
-
Sets the number of partitions of the streamlet
- setNumStmgrs(int) - Method in class org.apache.heron.api.Config
- setNumStmgrs(Map<String, Object>, int) - Static method in class org.apache.heron.api.Config
- setPerContainerCpu(double) - Method in class org.apache.heron.streamlet.Config.Builder
-
Sets the per-container (per-instance) CPU to be used by this topology
- setPerContainerRam(long) - Method in class org.apache.heron.streamlet.Config.Builder
-
Sets the per-container (per-instance) RAM to be used by this topology
- setPerContainerRamInBytes(long) - Method in class org.apache.heron.streamlet.Config.Builder
-
Sets the per-container (per-instance) RAM to be used by this topology as a number of bytes
- setPerContainerRamInGigabytes(long) - Method in class org.apache.heron.streamlet.Config.Builder
-
Sets the per-container (per-instance) RAM to be used by this topology in gigabytes
- setPerContainerRamInMegabytes(long) - Method in class org.apache.heron.streamlet.Config.Builder
-
Sets the per-container (per-instance) RAM to be used by this topology in megabytes
- setScheme(MultiScheme) - Method in interface org.apache.heron.api.spout.IMultiSchemableSpout
- setScheme(Scheme) - Method in interface org.apache.heron.api.spout.ISchemableSpout
- setSerializationClassName(String) - Method in class org.apache.heron.api.Config
- setSerializationClassName(Map<String, Object>, String) - Static method in class org.apache.heron.api.Config
- setSerializer(Config.Serializer) - Method in class org.apache.heron.streamlet.Config.Builder
-
Sets the
Config.Serializer
to be used by the topology (current options areKryoSerializer
and the native Java serializer. - setSkipMissingKryoRegistrations(boolean) - Method in class org.apache.heron.api.Config
- setSkipMissingKryoRegistrations(Map, boolean) - Static method in class org.apache.heron.api.Config
- setSpout(String, IRichSpout) - Method in class org.apache.heron.api.topology.TopologyBuilder
-
Define a new spout in this topology.
- setSpout(String, IRichSpout, Number) - Method in class org.apache.heron.api.topology.TopologyBuilder
-
Define a new spout in this topology with the specified parallelism.
- setState(TopologyAPI.TopologyState) - Method in class org.apache.heron.api.HeronTopology
- setStreamManagerRam(Map<String, Object>, ByteAmount) - Static method in class org.apache.heron.api.Config
- setStreamManagerRam(ByteAmount) - Method in class org.apache.heron.api.Config
- setTaskData(String, Object) - Method in interface org.apache.heron.api.topology.TopologyContext
- setTeamEmail(String) - Method in class org.apache.heron.api.Config
- setTeamEmail(Map<String, Object>, String) - Static method in class org.apache.heron.api.Config
- setTeamName(String) - Method in class org.apache.heron.api.Config
- setTeamName(Map<String, Object>, String) - Static method in class org.apache.heron.api.Config
- setTickTupleFrequency(int) - Method in class org.apache.heron.api.Config
- setTickTupleFrequency(Map<String, Object>, int) - Static method in class org.apache.heron.api.Config
- setTickTupleFrequencyMs(Map<String, Object>, long) - Static method in class org.apache.heron.api.Config
- setTopologyBoltsLateTupleStream(String) - Method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsLateTupleStream(Map<String, Object>, String) - Static method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsSlidingIntervalCount(long) - Method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsSlidingIntervalCount(Map<String, Object>, long) - Static method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsSlidingIntervalDurationMs(long) - Method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsSlidingIntervalDurationMs(Map<String, Object>, long) - Static method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsTupleTimestampMaxLagMs(long) - Method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsTupleTimestampMaxLagMs(Map<String, Object>, long) - Static method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsWatermarkEventIntervalMs(long) - Method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsWatermarkEventIntervalMs(Map<String, Object>, long) - Static method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsWindowCustomEvictor(Map<String, Object>, EvictionPolicy<Tuple, ?>) - Static method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsWindowCustomEvictor(EvictionPolicy<Tuple, ?>) - Method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsWindowCustomTrigger(Map<String, Object>, TriggerPolicy<Tuple, ?>) - Static method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsWindowCustomTrigger(TriggerPolicy<Tuple, ?>) - Method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsWindowLengthCount(long) - Method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsWindowLengthCount(Map<String, Object>, long) - Static method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsWindowLengthDurationMs(long) - Method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyBoltsWindowLengthDurationMs(Map<String, Object>, long) - Static method in class org.apache.heron.api.windowing.WindowingConfigs
- setTopologyCapTicket(String) - Method in class org.apache.heron.api.Config
- setTopologyCapTicket(Map<String, Object>, String) - Static method in class org.apache.heron.api.Config
- setTopologyComponentOutputBPS(long) - Method in class org.apache.heron.api.Config
-
Deprecated.use the TOPOLOGY_COMPONENT_OUTPUT_BPS config with ComponentConfigurationDeclarer's addConfiguration() instead. Example: builder.setSpout(...).addConfiguration(Config.TOPOLOGY_COMPONENT_OUTPUT_BPS, 1000);
- setTopologyComponentOutputBPS(Map<String, Object>, long) - Static method in class org.apache.heron.api.Config
-
Deprecated.use the TOPOLOGY_COMPONENT_OUTPUT_BPS config with ComponentConfigurationDeclarer's addConfiguration() instead. Example: builder.setSpout(...).addConfiguration(Config.TOPOLOGY_COMPONENT_OUTPUT_BPS, 1000);
- setTopologyConfig(Map<String, Object>) - Method in interface org.apache.heron.api.windowing.TriggerPolicy
-
Sets the Config used for this topology
- setTopologyConfig(Map<String, Object>) - Method in class org.apache.heron.api.windowing.triggers.AbstractBaseTriggerPolicy
-
Sets the Config used for this topology
- setTopologyContainerMaxNumInstances(int) - Method in class org.apache.heron.api.Config
- setTopologyDropTuplesUponBackpressure(boolean) - Method in class org.apache.heron.api.Config
- setTopologyProjectName(String) - Method in class org.apache.heron.api.Config
- setTopologyProjectName(Map<String, Object>, String) - Static method in class org.apache.heron.api.Config
- setTopologyReliabilityMode(Map<String, Object>, Config.TopologyReliabilityMode) - Static method in class org.apache.heron.api.Config
- setTopologyReliabilityMode(Config.TopologyReliabilityMode) - Method in class org.apache.heron.api.Config
- setTopologyRemoteDebugging(boolean) - Method in class org.apache.heron.api.Config
- setTopologyStatefulCheckpointIntervalSecs(int) - Method in class org.apache.heron.api.Config
- setTopologyStatefulCheckpointIntervalSecs(Map<String, Object>, int) - Static method in class org.apache.heron.api.Config
- setTopologyStatefulSpillState(String) - Method in class org.apache.heron.api.Config
- setTopologyStatefulSpillState(Map<String, Object>, String) - Static method in class org.apache.heron.api.Config
- setTopologyStatefulSpillStateLocation(String) - Method in class org.apache.heron.api.Config
- setTopologyStatefulSpillStateLocation(Map<String, Object>, String) - Static method in class org.apache.heron.api.Config
- setTopologyStatefulStartClean(boolean) - Method in class org.apache.heron.api.Config
- setTopologyStatefulStartClean(Map<String, Object>, boolean) - Static method in class org.apache.heron.api.Config
- setTriggerHandler(TriggerHandler) - Method in interface org.apache.heron.api.windowing.TriggerPolicy
-
Set the trigger handler for this trigger policy to trigger
- setTriggerHandler(TriggerHandler) - Method in class org.apache.heron.api.windowing.triggers.AbstractBaseTriggerPolicy
-
Set the trigger handler for this trigger policy to trigger
- setTriggerPolicy(TriggerPolicy<T, ?>) - Method in class org.apache.heron.api.windowing.WindowManager
- setup(Context) - Method in interface org.apache.heron.streamlet.SerializableTransformer
- setup(Context) - Method in interface org.apache.heron.streamlet.Sink
- setup(Context) - Method in interface org.apache.heron.streamlet.Source
- setUpdateDeactivateWaitDuration(int) - Method in class org.apache.heron.api.Config
- setUpdateReactivateWaitDuration(int) - Method in class org.apache.heron.api.Config
- setUserConfig(String, Object) - Method in class org.apache.heron.streamlet.Config.Builder
-
Sets some user-defined key/value mapping
- setValue(T) - Method in class org.apache.heron.api.metric.AssignableMetric
- setValue(V) - Method in class org.apache.heron.streamlet.KeyValue
- setWindowManager(WindowManager<T>) - Method in interface org.apache.heron.api.windowing.TriggerPolicy
-
Sets the window manager that uses this trigger policy
- setWindowManager(WindowManager<T>) - Method in class org.apache.heron.api.windowing.triggers.AbstractBaseTriggerPolicy
-
Sets the window manager that uses this trigger policy
- shouldStartCkptMgr(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
- shuffleGrouping(String) - Method in class org.apache.heron.api.topology.BoltDeclarer
- shuffleGrouping(String, String) - Method in class org.apache.heron.api.topology.BoltDeclarer
- ShuffleStreamGrouping - Class in org.apache.heron.api.grouping
-
This is the stream grouping strategy that tuples are randomly distributed to instances of the bolt.
- ShuffleStreamGrouping() - Constructor for class org.apache.heron.api.grouping.ShuffleStreamGrouping
- shutdown() - Method in interface org.apache.heron.api.windowing.TriggerPolicy
-
Any clean up could be handled here.
- shutdown() - Method in class org.apache.heron.api.windowing.triggers.CountTriggerPolicy
- shutdown() - Method in class org.apache.heron.api.windowing.triggers.TimeTriggerPolicy
- shutdown() - Method in class org.apache.heron.api.windowing.triggers.WatermarkCountTriggerPolicy
- shutdown() - Method in class org.apache.heron.api.windowing.triggers.WatermarkTimeTriggerPolicy
- shutdown() - Method in class org.apache.heron.api.windowing.WindowManager
- similarToNum(Long, Long, double) - Static method in class org.apache.heron.api.utils.DefaultMaxSpoutPendingTuner
- Sink<T> - Interface in org.apache.heron.streamlet
-
Sink is how Streamlet's end.
- SINK - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- SinkStreamlet<R> - Class in org.apache.heron.streamlet.impl.streamlets
-
SinkStreamlet represents en empty Streamlet that is made up of elements from the parent streamlet after consuming every element.
- SinkStreamlet(StreamletImpl<R>, Sink<R>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.SinkStreamlet
- size() - Method in class org.apache.heron.api.tuple.Fields
- size() - Method in interface org.apache.heron.api.tuple.Tuple
-
Returns the number of fields in this tuple.
- sleep(long) - Static method in class org.apache.heron.api.utils.Utils
- Slf4jUtils - Class in org.apache.heron.api.utils
- SlidingCountWindow(int, int) - Static method in interface org.apache.heron.streamlet.WindowConfig
-
Creates a count based sliding window with windowSize as the window countsize and slideSize as slide size
- SlidingTimeWindow(Duration, Duration) - Static method in interface org.apache.heron.streamlet.WindowConfig
-
Creates a time based sliding window with windowDuration as the window duration and slideInterval as slideInterval
- Source<T> - Interface in org.apache.heron.streamlet
-
Source is how Streamlet's originate.
- SOURCE - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- SourceStreamlet<R> - Class in org.apache.heron.streamlet.impl.streamlets
-
SourceStreamlet is a very quick and flexible way of creating a Streamlet from a user supplied Generator Function.
- SourceStreamlet(Source<R>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.SourceStreamlet
- split(Map<String, SerializablePredicate<R>>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Returns multiple streams by splitting incoming stream.
- split(Map<String, SerializablePredicate<R>>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Returns multiple streams by splitting incoming stream.
- SPLIT - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- SplitOperator<R> - Class in org.apache.heron.streamlet.impl.operators
-
SplitOperator is the class that implements the split functionality.
- SplitOperator(Map<String, SerializablePredicate<R>>) - Constructor for class org.apache.heron.streamlet.impl.operators.SplitOperator
- SplitStreamlet<R> - Class in org.apache.heron.streamlet.impl.streamlets
-
SplitStreamlet represents a Streamlet that splits an incoming stream into multiple streams using a split function.
- SplitStreamlet(StreamletImpl<R>, Map<String, SerializablePredicate<R>>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.SplitStreamlet
- SPOUT - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- spoutAck(SpoutAckInfo) - Method in class org.apache.heron.api.hooks.BaseTaskHook
- spoutAck(SpoutAckInfo) - Method in interface org.apache.heron.api.hooks.ITaskHook
-
Called in spout everytime a tuple gets acked
- SpoutAckInfo - Class in org.apache.heron.api.hooks.info
- SpoutAckInfo(Object, int, Duration) - Constructor for class org.apache.heron.api.hooks.info.SpoutAckInfo
- SpoutDeclarer - Class in org.apache.heron.api.topology
- SpoutDeclarer(String, IRichSpout, Number) - Constructor for class org.apache.heron.api.topology.SpoutDeclarer
- spoutFail(SpoutFailInfo) - Method in class org.apache.heron.api.hooks.BaseTaskHook
- spoutFail(SpoutFailInfo) - Method in interface org.apache.heron.api.hooks.ITaskHook
-
Called in spout everytime a tuple gets failed
- SpoutFailInfo - Class in org.apache.heron.api.hooks.info
- SpoutFailInfo(Object, int, Duration) - Constructor for class org.apache.heron.api.hooks.info.SpoutFailInfo
- SpoutOutputCollector - Class in org.apache.heron.api.spout
-
This output collector exposes the API for emitting tuples from an
IRichSpout
. - SpoutOutputCollector(ISpoutOutputCollector) - Constructor for class org.apache.heron.api.spout.SpoutOutputCollector
- SpoutStreamlet<R> - Class in org.apache.heron.streamlet.impl.streamlets
-
SpoutStreamlet is a quick way of creating a Streamlet from an user supplied Spout object.
- SpoutStreamlet(IRichSpout) - Constructor for class org.apache.heron.streamlet.impl.streamlets.SpoutStreamlet
- start() - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
-
Start the trigger policy and waterMarkEventGenerator if set
- start() - Method in interface org.apache.heron.api.windowing.TriggerPolicy
-
Starts the trigger policy.
- start() - Method in class org.apache.heron.api.windowing.triggers.AbstractBaseTriggerPolicy
-
Starts the trigger policy.
- start() - Method in class org.apache.heron.api.windowing.triggers.TimeTriggerPolicy
- start() - Method in class org.apache.heron.api.windowing.WaterMarkEventGenerator
- started - Variable in class org.apache.heron.api.windowing.triggers.AbstractBaseTriggerPolicy
- State<K extends Serializable,V extends Serializable> - Interface in org.apache.heron.api.state
-
State represents the state interface as seen by stateful bolts and spouts.
- StatefulWindowedBoltExecutor<K extends Serializable,V extends Serializable> - Class in org.apache.heron.api.bolt
- StatefulWindowedBoltExecutor(IStatefulWindowedBolt) - Constructor for class org.apache.heron.api.bolt.StatefulWindowedBoltExecutor
- STOP - org.apache.heron.api.windowing.EvictionPolicy.Action
-
stop processing the queue, there cannot be anymore events satisfying the eviction policy.
- StreamGrouping - Interface in org.apache.heron.api.grouping
-
This is the interface of stream grouping at runtime the tasks in the target bolt.
- Streamlet<R> - Interface in org.apache.heron.streamlet
-
A Streamlet is a (potentially unbounded) ordered collection of tuples.
- StreamletBase<R> - Interface in org.apache.heron.streamlet
-
A Streamlet is a (potentially unbounded) ordered collection of tuples.
- StreamletBaseImpl<R> - Class in org.apache.heron.streamlet.impl
-
A Streamlet is a (potentially unbounded) ordered collection of tuples.
- StreamletBaseImpl() - Constructor for class org.apache.heron.streamlet.impl.StreamletBaseImpl
-
Only used by the implementors
- StreamletBaseImpl.StreamletNamePrefix - Enum in org.apache.heron.streamlet.impl
- StreamletImpl<R> - Class in org.apache.heron.streamlet.impl
-
A Streamlet is a (potentially unbounded) ordered collection of tuples.
- StreamletImpl() - Constructor for class org.apache.heron.streamlet.impl.StreamletImpl
-
Only used by the implementors
- StreamletOperator<R,T> - Class in org.apache.heron.streamlet.impl.operators
-
The Bolt interface that other operators of the streamlet packages extend.
- StreamletOperator() - Constructor for class org.apache.heron.streamlet.impl.operators.StreamletOperator
- StreamletReducers - Class in org.apache.heron.streamlet
-
This class contains a few standard reduces that can be used with Streamlet reduce functions such as reduceByKeyAndWindow.
- StreamletShadow<R> - Class in org.apache.heron.streamlet.impl.streamlets
-
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.
- StreamletShadow(StreamletImpl<R>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.StreamletShadow
- StreamletSource - Class in org.apache.heron.streamlet.impl.sources
-
StreamletSource is the base class for all streamlet sources.
- StreamletSource() - Constructor for class org.apache.heron.streamlet.impl.sources.StreamletSource
- StreamletUtils - Class in org.apache.heron.streamlet.impl.utils
- StreamletWindowOperator<R,T> - Class in org.apache.heron.streamlet.impl.operators
-
The Bolt interface that other windowed operators of the streamlet packages extend.
- StreamletWindowOperator() - Constructor for class org.apache.heron.streamlet.impl.operators.StreamletWindowOperator
- submitJar(Config, String) - Static method in class org.apache.heron.api.HeronSubmitter
-
Submits a topology to run on the cluster.
- submitTopology(String, Config, HeronTopology) - Static method in class org.apache.heron.api.HeronSubmitter
-
Submits a topology to run on the cluster.
- sum - Variable in class org.apache.heron.api.metric.MeanReducerState
- sum(Double, Double) - Static method in class org.apache.heron.streamlet.StreamletReducers
- sum(Float, Float) - Static method in class org.apache.heron.streamlet.StreamletReducers
- sum(Integer, Integer) - Static method in class org.apache.heron.streamlet.StreamletReducers
- sum(Long, Long) - Static method in class org.apache.heron.streamlet.StreamletReducers
- SUPPLIER - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- SupplierSource<R> - Class in org.apache.heron.streamlet.impl.sources
-
SupplierSource is a way to wrap a supplier function inside a Heron Spout.
- SupplierSource(SerializableSupplier<R>) - Constructor for class org.apache.heron.streamlet.impl.sources.SupplierSource
- SupplierStreamlet<R> - Class in org.apache.heron.streamlet.impl.streamlets
-
SupplierStreamlet is a very quick and flexible way of creating a Streamlet from an user supplied Supplier Function.
- SupplierStreamlet(SerializableSupplier<R>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.SupplierStreamlet
- SYSTEM_COMPONENT_ID - Static variable in class org.apache.heron.api.Constants
- SYSTEM_TICK_STREAM_ID - Static variable in class org.apache.heron.api.Constants
T
- threshold - Variable in class org.apache.heron.api.windowing.evictors.CountEvictionPolicy
- threshold - Variable in class org.apache.heron.api.windowing.evictors.WatermarkCountEvictionPolicy
- TimeEvictionPolicy<T extends Serializable> - Class in org.apache.heron.api.windowing.evictors
-
Eviction policy that evicts events based on time duration.
- TimeEvictionPolicy(long) - Constructor for class org.apache.heron.api.windowing.evictors.TimeEvictionPolicy
-
Constructs a TimeEvictionPolicy that evicts events older than the given window length in millis
- timestampExtractor - Variable in class org.apache.heron.api.bolt.BaseWindowedBolt
- TimestampExtractor - Interface in org.apache.heron.api.windowing
-
Interface to be implemented for extracting timestamp from a tuple.
- TimeTriggerPolicy<T extends Serializable> - Class in org.apache.heron.api.windowing.triggers
-
Invokes
TriggerHandler.onTrigger()
after the duration. - TimeTriggerPolicy(long) - Constructor for class org.apache.heron.api.windowing.triggers.TimeTriggerPolicy
- TimeWindowConfig - Class in org.apache.heron.streamlet.impl.windowings
-
TimeWindowConfig implements a time based WindowConfig.
- TimeWindowConfig(Duration, Duration) - Constructor for class org.apache.heron.streamlet.impl.windowings.TimeWindowConfig
- toByteArray(ByteBuffer) - Static method in class org.apache.heron.api.utils.Utils
- toList() - Method in class org.apache.heron.api.tuple.Fields
- topoConf - Variable in class org.apache.heron.api.windowing.triggers.AbstractBaseTriggerPolicy
- TOPOLOGY_ADDITIONAL_CLASSPATH - Static variable in class org.apache.heron.api.Config
-
Any user defined classpath that needs to be passed to instances should be set in to config through this key.
- TOPOLOGY_AUTO_TASK_HOOKS - Static variable in class org.apache.heron.api.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.heron.api.windowing.WindowingConfigs
-
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.heron.api.windowing.WindowingConfigs
- TOPOLOGY_BOLTS_SLIDING_INTERVAL_DURATION_MS - Static variable in class org.apache.heron.api.windowing.WindowingConfigs
- TOPOLOGY_BOLTS_TUPLE_TIMESTAMP_MAX_LAG_MS - Static variable in class org.apache.heron.api.windowing.WindowingConfigs
-
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.heron.api.windowing.WindowingConfigs
- TOPOLOGY_BOLTS_WINDOW_CUSTOM_EVICTOR - Static variable in class org.apache.heron.api.windowing.WindowingConfigs
- TOPOLOGY_BOLTS_WINDOW_CUSTOM_TRIGGER - Static variable in class org.apache.heron.api.windowing.WindowingConfigs
- TOPOLOGY_BOLTS_WINDOW_LENGTH_COUNT - Static variable in class org.apache.heron.api.windowing.WindowingConfigs
- TOPOLOGY_BOLTS_WINDOW_LENGTH_DURATION_MS - Static variable in class org.apache.heron.api.windowing.WindowingConfigs
- TOPOLOGY_CAP_TICKET - Static variable in class org.apache.heron.api.Config
-
Cap ticket (if filed) for the topology.
- TOPOLOGY_COMPONENT_CPUMAP - Static variable in class org.apache.heron.api.Config
-
Per component RAM requirement.
- TOPOLOGY_COMPONENT_DISKMAP - Static variable in class org.apache.heron.api.Config
-
Per component RAM requirement.
- TOPOLOGY_COMPONENT_JVMOPTS - Static variable in class org.apache.heron.api.Config
-
Per component JVM options.
- TOPOLOGY_COMPONENT_OUTPUT_BPS - Static variable in class org.apache.heron.api.Config
-
The per component output bytes per second (rate limit) in this topology.
- TOPOLOGY_COMPONENT_PARALLELISM - Static variable in class org.apache.heron.api.Config
-
The per component parallelism for a component in this topology.
- TOPOLOGY_COMPONENT_RAMMAP - Static variable in class org.apache.heron.api.Config
-
Per component RAM requirement.
- TOPOLOGY_CONTAINER_CPU_PADDING - Static variable in class org.apache.heron.api.Config
-
Amount of CPU to pad each container.
- TOPOLOGY_CONTAINER_CPU_REQUESTED - Static variable in class org.apache.heron.api.Config
-
Number of CPU cores per container to be reserved for this topology
- TOPOLOGY_CONTAINER_DISK_REQUESTED - Static variable in class org.apache.heron.api.Config
-
Amount of disk per container to be reserved for this topology.
- TOPOLOGY_CONTAINER_MAX_CPU_HINT - Static variable in class org.apache.heron.api.Config
-
Hint for max number of CPU cores per container to be reserved for this topology
- TOPOLOGY_CONTAINER_MAX_DISK_HINT - Static variable in class org.apache.heron.api.Config
-
Hint for max amount of disk per container to be reserved for this topology.
- TOPOLOGY_CONTAINER_MAX_NUM_INSTANCES - Static variable in class org.apache.heron.api.Config
-
Max number of instances per container for this topology.
- TOPOLOGY_CONTAINER_MAX_RAM_HINT - Static variable in class org.apache.heron.api.Config
-
Hint for max amount of RAM per container to be reserved for this topology.
- TOPOLOGY_CONTAINER_PADDING_PERCENTAGE - Static variable in class org.apache.heron.api.Config
-
Percent of resource to pad each container.
- TOPOLOGY_CONTAINER_RAM_PADDING - Static variable in class org.apache.heron.api.Config
-
Amount of RAM to pad each container.
- TOPOLOGY_CONTAINER_RAM_REQUESTED - Static variable in class org.apache.heron.api.Config
-
Amount of RAM per container to be reserved for this topology.
- TOPOLOGY_DEBUG - Static variable in class org.apache.heron.api.Config
-
When set to true, Heron will log every message that's emitted.
- TOPOLOGY_DROPTUPLES_UPON_BACKPRESSURE - Static variable in class org.apache.heron.api.Config
-
Do we want to drop tuples instead of initiating Spout BackPressure
- TOPOLOGY_ENABLE_ACKING - Static variable in class org.apache.heron.api.Config
-
Deprecated.use
Config.TOPOLOGY_RELIABILITY_MODE
instead. - TOPOLOGY_ENABLE_MESSAGE_TIMEOUTS - Static variable in class org.apache.heron.api.Config
-
True if Heron should timeout messages or not.
- TOPOLOGY_ENVIRONMENT - Static variable in class org.apache.heron.api.Config
-
Topology-specific environment properties to be added to an Heron instance.
- TOPOLOGY_FALL_BACK_ON_JAVA_SERIALIZATION - Static variable in class org.apache.heron.api.Config
-
Whether or not to fallback to Java serialization in a topology.
- TOPOLOGY_KRYO_DECORATORS - Static variable in class org.apache.heron.api.Config
-
A list of classes that customize storm's kryo instance during start-up.
- TOPOLOGY_KRYO_FACTORY - Static variable in class org.apache.heron.api.Config
-
Class that specifies how to create a Kryo instance for serialization.
- TOPOLOGY_KRYO_REGISTER - Static variable in class org.apache.heron.api.Config
-
A list of serialization registrations if KryoSerializor is used.
- TOPOLOGY_MAX_SPOUT_PENDING - Static variable in class org.apache.heron.api.Config
-
The maximum number of tuples that can be pending on a spout task at any given time.
- TOPOLOGY_MESSAGE_TIMEOUT_SECS - Static variable in class org.apache.heron.api.Config
-
The maximum amount of time given to the topology to fully process a message emitted by a spout.
- TOPOLOGY_METRICSMGR_RAM - Static variable in class org.apache.heron.api.Config
-
Metrics Manager RAM requirement
- TOPOLOGY_NAME - Static variable in class org.apache.heron.api.Config
-
Name of the topology.
- TOPOLOGY_PACKING_FFD_SORTING_STRATEGY - Static variable in class org.apache.heron.api.Config
-
Sorting strategy for FirstFitDecreasingPacking algorithm.
- TOPOLOGY_PROJECT_NAME - Static variable in class org.apache.heron.api.Config
-
Project name of the topology, to help us with tagging which topologies are part of which project.
- TOPOLOGY_RELIABILITY_MODE - Static variable in class org.apache.heron.api.Config
-
A Heron topology can be run in any one of the TopologyReliabilityMode mode.
- TOPOLOGY_REMOTE_DEBUGGING_ENABLE - Static variable in class org.apache.heron.api.Config
-
Enable Remote debugging for java heron instances
- TOPOLOGY_SERIALIZER_CLASSNAME - Static variable in class org.apache.heron.api.Config
-
The serialization class that is used to serialize/deserialize tuples
- TOPOLOGY_SKIP_MISSING_KRYO_REGISTRATIONS - Static variable in class org.apache.heron.api.Config
-
Whether or not Heron should skip the loading of kryo registrations for which it does not know the class or have the serializer implementation.
- TOPOLOGY_STATEFUL_CHECKPOINT_INTERVAL_SECONDS - Static variable in class org.apache.heron.api.Config
-
What's the checkpoint interval for stateful topologies in seconds
- TOPOLOGY_STATEFUL_CKPTMGR_RAM - Static variable in class org.apache.heron.api.Config
-
Checkpoint Manager RAM requirement.
- TOPOLOGY_STATEFUL_SPILL_STATE - Static variable in class org.apache.heron.api.Config
-
Whether spill the state to disk for transferring
- TOPOLOGY_STATEFUL_SPILL_STATE_LOCATION - Static variable in class org.apache.heron.api.Config
-
The local disk location where the state is spilled
- TOPOLOGY_STATEFUL_START_CLEAN - Static variable in class org.apache.heron.api.Config
-
Boolean flag that says that the stateful topology should start from clean state, i.e.
- TOPOLOGY_STMGR_RAM - Static variable in class org.apache.heron.api.Config
-
Stream Manager RAM requirement
- TOPOLOGY_STMGRS - Static variable in class org.apache.heron.api.Config
-
The number of stmgr instances that should spin up to service this topology.
- TOPOLOGY_TEAM_EMAIL - Static variable in class org.apache.heron.api.Config
-
Email of the team which owns this topology.
- TOPOLOGY_TEAM_ENVIRONMENT - Static variable in class org.apache.heron.api.Config
-
Name of the of the environment this topology should run in.
- TOPOLOGY_TEAM_NAME - Static variable in class org.apache.heron.api.Config
-
Name of the team which owns this topology.
- TOPOLOGY_TICK_TUPLE_FREQ_MS - Static variable in class org.apache.heron.api.Config
-
How often (in milliseconds) a tick tuple from the "__system" component and "__tick" stream should be sent to tasks.
- TOPOLOGY_TIMER_EVENTS - Static variable in class org.apache.heron.api.Config
-
Timer events registered for a topology.
- TOPOLOGY_UPDATE_DEACTIVATE_WAIT_SECS - Static variable in class org.apache.heron.api.Config
-
Amount of time to wait after deactivating a topology before updating it
- TOPOLOGY_UPDATE_REACTIVATE_WAIT_SECS - Static variable in class org.apache.heron.api.Config
-
After updating a topology, amount of time to wait for it to come back up before reactivating it
- TOPOLOGY_WORKER_CHILDOPTS - Static variable in class org.apache.heron.api.Config
-
Topology-specific options for the worker child process.
- TopologyBuilder - Class in org.apache.heron.api.topology
-
TopologyBuilder exposes the Java API for specifying a topology for Heron to execute.
- TopologyBuilder() - Constructor for class org.apache.heron.api.topology.TopologyBuilder
- TopologyContext - Interface in org.apache.heron.api.topology
-
A TopologyContext is given to bolts and spouts in their "prepare" and "open" methods, respectively.
- TopologySubmissionException - Exception in org.apache.heron.api.exception
-
Thrown to indicate that the application has attempted to submit an invalid topology.
- TopologySubmissionException(String) - Constructor for exception org.apache.heron.api.exception.TopologySubmissionException
- TopologySubmissionException(String, Throwable) - Constructor for exception org.apache.heron.api.exception.TopologySubmissionException
- TopologyUtils - Class in org.apache.heron.api.utils
-
Utility to process TopologyAPI.Topology proto
- toSink(Sink<R>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Uses the sink to consume every element of this streamlet
- toSink(Sink<R>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Applies the sink's put function to every element of the stream This function does not return anything.
- toString() - Method in class org.apache.heron.api.bolt.BaseWindowedBolt.Count
- toString() - Method in class org.apache.heron.api.Pair
- toString() - Method in class org.apache.heron.api.tuple.Fields
- toString() - Method in class org.apache.heron.api.windowing.EventImpl
- toString() - Method in class org.apache.heron.api.windowing.evictors.CountEvictionPolicy
- toString() - Method in class org.apache.heron.api.windowing.evictors.TimeEvictionPolicy
- toString() - Method in class org.apache.heron.api.windowing.evictors.WatermarkCountEvictionPolicy
- toString() - Method in class org.apache.heron.api.windowing.evictors.WatermarkTimeEvictionPolicy
- toString() - Method in class org.apache.heron.api.windowing.triggers.CountTriggerPolicy
- toString() - Method in class org.apache.heron.api.windowing.triggers.TimeTriggerPolicy
- toString() - Method in class org.apache.heron.api.windowing.triggers.WatermarkCountTriggerPolicy
- toString() - Method in class org.apache.heron.api.windowing.triggers.WatermarkTimeTriggerPolicy
- toString() - Method in class org.apache.heron.api.windowing.TupleFieldTimestampExtractor
- toString() - Method in class org.apache.heron.api.windowing.TupleWindowImpl
- toString() - Method in class org.apache.heron.api.windowing.WaterMarkEvent
- toString() - Method in class org.apache.heron.api.windowing.WindowManager
- toString() - Method in enum org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- toString() - Method in class org.apache.heron.streamlet.KeyedWindow
- toString() - Method in class org.apache.heron.streamlet.KeyValue
- toString() - Method in class org.apache.heron.streamlet.Window
- track(TopologyAPI.StreamId, long) - Method in class org.apache.heron.api.windowing.WaterMarkEventGenerator
-
Tracks the timestamp of the event in the stream, returns true if the event can be considered for processing or false if its a late event.
- track(Event<T>) - Method in interface org.apache.heron.api.windowing.EvictionPolicy
-
Tracks the event to later decide whether
EvictionPolicy.evict(Event)
should evict it or not. - track(Event<T>) - Method in class org.apache.heron.api.windowing.evictors.CountEvictionPolicy
- track(Event<T>) - Method in class org.apache.heron.api.windowing.evictors.TimeEvictionPolicy
- track(Event<T>) - Method in class org.apache.heron.api.windowing.evictors.WatermarkCountEvictionPolicy
- track(Event<T>) - Method in interface org.apache.heron.api.windowing.TriggerPolicy
-
Tracks the event and could use this to invoke the trigger.
- track(Event<T>) - Method in class org.apache.heron.api.windowing.triggers.CountTriggerPolicy
- track(Event<T>) - Method in class org.apache.heron.api.windowing.triggers.TimeTriggerPolicy
- track(Event<T>) - Method in class org.apache.heron.api.windowing.triggers.WatermarkCountTriggerPolicy
- track(Event<T>) - Method in class org.apache.heron.api.windowing.triggers.WatermarkTimeTriggerPolicy
- transform(I, Consumer<O>) - Method in interface org.apache.heron.streamlet.SerializableTransformer
- transform(SerializableTransformer<R, ? extends T>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Returns a new Streamlet by applying the transformFunction on each element of this streamlet.
- transform(SerializableTransformer<R, ? extends T>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Returns a new Streamlet by applying the transformFunction on each element of this streamlet.
- TRANSFORM - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- TransformOperator<R,T> - Class in org.apache.heron.streamlet.impl.operators
-
TransformOperator is the class that implements the transform functionality.
- TransformOperator(SerializableTransformer<? super R, ? extends T>) - Constructor for class org.apache.heron.streamlet.impl.operators.TransformOperator
- TransformStreamlet<R,T> - Class in org.apache.heron.streamlet.impl.streamlets
-
TransformStreamlet represents a Streamlet that is made up of applying the user supplied transform function to each element of the parent streamlet.
- TransformStreamlet(StreamletImpl<R>, SerializableTransformer<? super R, ? extends T>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.TransformStreamlet
- TriggerHandler - Interface in org.apache.heron.api.windowing
-
The callback fired by
TriggerPolicy
when the trigger condition is satisfied. - triggerPolicy - Variable in class org.apache.heron.api.windowing.WindowManager
- TriggerPolicy<T extends Serializable,S> - Interface in org.apache.heron.api.windowing
-
Triggers the window calculations based on the policy.
- TumblingCountWindow(int) - Static method in interface org.apache.heron.streamlet.WindowConfig
-
Creates a count based tumbling window of size windowSize
- TumblingTimeWindow(Duration) - Static method in interface org.apache.heron.streamlet.WindowConfig
-
Creates a time based tumbling window of windowDuration
- tuple(Object...) - Static method in class org.apache.heron.api.utils.Utils
- Tuple - Interface in org.apache.heron.api.tuple
-
The tuple is the main data structure in Heron.
- TupleFieldTimestampExtractor - Class in org.apache.heron.api.windowing
-
A
TimestampExtractor
that extracts timestamp from a specific field in the tuple. - TupleUtils - Class in org.apache.heron.api.utils
- TupleWindow - Interface in org.apache.heron.api.windowing
- TupleWindowImpl - Class in org.apache.heron.api.windowing
-
Holds the expired, new and current tuples in a window.
- TupleWindowImpl(List<Tuple>, List<Tuple>, List<Tuple>, Long, Long) - Constructor for class org.apache.heron.api.windowing.TupleWindowImpl
U
- union(Streamlet<? extends R>) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Returns a new Streamlet that is the union of this and the ‘other’ streamlet.
- union(Streamlet<? extends R>) - Method in interface org.apache.heron.streamlet.Streamlet
-
Returns a new Streamlet that is the union of this and the ‘other’ streamlet.
- UNION - org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
- UnionOperator<I> - Class in org.apache.heron.streamlet.impl.operators
-
UnionOperator is the class that implements the union functionality.
- UnionOperator() - Constructor for class org.apache.heron.streamlet.impl.operators.UnionOperator
- UnionStreamlet<I> - Class in org.apache.heron.streamlet.impl.streamlets
-
UnionStreamlet is a Streamlet composed of all the elements of two parent streamlets.
- UnionStreamlet(StreamletImpl<I>, StreamletImpl<? extends I>) - Constructor for class org.apache.heron.streamlet.impl.streamlets.UnionStreamlet
- update(TopologyContext) - Method in class org.apache.heron.api.bolt.BasicBoltExecutor
- update(TopologyContext) - Method in interface org.apache.heron.api.topology.IUpdatable
- update(T) - Method in class org.apache.heron.api.metric.CombinedMetric
- update(U) - Method in class org.apache.heron.api.metric.ReducedMetric
- Utils - Class in org.apache.heron.api.utils
V
- validate(Map<String, Object>, BaseWindowedBolt.Count, Long, BaseWindowedBolt.Count, Long) - Method in class org.apache.heron.api.bolt.WindowedBoltExecutor
- validateTopology(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
-
Throw a IllegalArgumentException if verifyTopology returns false
- value - Variable in class org.apache.heron.api.bolt.BaseWindowedBolt.Count
- valueOf(String) - Static method in enum org.apache.heron.api.Config.TopologyReliabilityMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.heron.api.metric.GlobalMetrics
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.heron.api.windowing.EvictionPolicy.Action
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.heron.streamlet.Config.DeliverySemantics
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.heron.streamlet.Config.Serializer
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.heron.streamlet.JoinType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.heron.api.Config.TopologyReliabilityMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.heron.api.metric.GlobalMetrics
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.heron.api.windowing.EvictionPolicy.Action
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.heron.streamlet.Config.DeliverySemantics
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.heron.streamlet.Config.Serializer
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.heron.streamlet.impl.StreamletBaseImpl.StreamletNamePrefix
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.heron.streamlet.JoinType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- Values - Class in org.apache.heron.api.tuple
-
A convenience class for making tuple values using new Values("field1", 2, 3) syntax.
- Values() - Constructor for class org.apache.heron.api.tuple.Values
- Values(Object...) - Constructor for class org.apache.heron.api.tuple.Values
- verifyTopology(TopologyAPI.Topology) - Static method in class org.apache.heron.api.utils.TopologyUtils
-
Verify if the given topology has all the necessary information
W
- WatermarkCountEvictionPolicy<T extends Serializable> - Class in org.apache.heron.api.windowing.evictors
-
An eviction policy that tracks count based on watermark ts and evicts events up to the watermark based on a threshold count.
- WatermarkCountEvictionPolicy(int) - Constructor for class org.apache.heron.api.windowing.evictors.WatermarkCountEvictionPolicy
- WatermarkCountTriggerPolicy<T extends Serializable> - Class in org.apache.heron.api.windowing.triggers
-
A trigger policy that tracks event counts and sets the context for eviction policy to evict based on latest watermark time.
- WatermarkCountTriggerPolicy(int) - Constructor for class org.apache.heron.api.windowing.triggers.WatermarkCountTriggerPolicy
- WaterMarkEvent<T extends Serializable> - Class in org.apache.heron.api.windowing
-
Watermark event used for tracking progress of time when processing event based ts.
- WaterMarkEvent(long) - Constructor for class org.apache.heron.api.windowing.WaterMarkEvent
- waterMarkEventGenerator - Variable in class org.apache.heron.api.bolt.WindowedBoltExecutor
- WaterMarkEventGenerator<T extends Serializable> - Class in org.apache.heron.api.windowing
-
Tracks tuples across input streams and periodically emits watermark events.
- WaterMarkEventGenerator(WindowManager<T>, long, int, Set<TopologyAPI.StreamId>, Map<String, Object>) - Constructor for class org.apache.heron.api.windowing.WaterMarkEventGenerator
-
Creates a new WatermarkEventGenerator.
- WatermarkTimeEvictionPolicy<T extends Serializable> - Class in org.apache.heron.api.windowing.evictors
-
An eviction policy that evicts events based on time duration taking watermark time and event lag into account.
- WatermarkTimeEvictionPolicy(long) - Constructor for class org.apache.heron.api.windowing.evictors.WatermarkTimeEvictionPolicy
-
Constructs a WatermarkTimeEvictionPolicy that evicts events older than the given window length in millis.
- WatermarkTimeEvictionPolicy(long, long) - Constructor for class org.apache.heron.api.windowing.evictors.WatermarkTimeEvictionPolicy
-
Constructs a WatermarkTimeEvictionPolicy that evicts events older than the given window length in millis.
- WatermarkTimeTriggerPolicy<T extends Serializable> - Class in org.apache.heron.api.windowing.triggers
-
Handles watermark events and triggers
TriggerHandler.onTrigger()
for each window interval that has events to be processed up to the watermark ts. - WatermarkTimeTriggerPolicy(long) - Constructor for class org.apache.heron.api.windowing.triggers.WatermarkTimeTriggerPolicy
- Window - Class in org.apache.heron.streamlet
-
Window is a container containing information about a particular window.
- Window<T> - Interface in org.apache.heron.api.windowing
-
A view of events in a sliding window.
- Window(long, long, long) - Constructor for class org.apache.heron.streamlet.Window
- WindowConfig - Interface in org.apache.heron.streamlet
-
WindowConfig allows Streamlet API users to program window configuration for operations that rely on windowing.
- windowConfiguration - Variable in class org.apache.heron.api.bolt.BaseWindowedBolt
- WindowedBoltExecutor - Class in org.apache.heron.api.bolt
-
An
IWindowedBolt
wrapper that does the windowing of tuples. - WindowedBoltExecutor(IWindowedBolt) - Constructor for class org.apache.heron.api.bolt.WindowedBoltExecutor
- WindowingConfigs - Class in org.apache.heron.api.windowing
- WindowingConfigs() - Constructor for class org.apache.heron.api.windowing.WindowingConfigs
- windowLifecycleListener - Variable in class org.apache.heron.api.windowing.WindowManager
- WindowLifecycleListener<T> - Interface in org.apache.heron.api.windowing
-
A callback for expiry, activation of events tracked by the
WindowManager
- windowManager - Variable in class org.apache.heron.api.windowing.triggers.AbstractBaseTriggerPolicy
- WindowManager<T extends Serializable> - Class in org.apache.heron.api.windowing
-
Tracks a window of events and fires
WindowLifecycleListener
callbacks on expiry of events or activation of the window due toTriggerPolicy
. - WindowManager(WindowLifecycleListener<T>) - Constructor for class org.apache.heron.api.windowing.WindowManager
-
For testing purpose See
org.apache.heron.api.windowing.WindowManagerTest
- WindowManager(WindowLifecycleListener<T>, Collection<Event<T>>) - Constructor for class org.apache.heron.api.windowing.WindowManager
-
Constructs a
WindowManager
- withCustomEvictor(EvictionPolicy<Tuple, ?>) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
Sets a custom eviction policy to use for this bolt
- withCustomTrigger(TriggerPolicy<Tuple, ?>) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
Sets a custom trigger policy to use for this bolt
- withLag(Duration) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
Specify the maximum time lag of the tuple timestamp in milliseconds.
- withLag(Duration) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
Specify the maximum time lag of the tuple timestamp in milliseconds.
- withLateTupleStream(String) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
Specify a stream id on which late tuples are going to be emitted.
- withLateTupleStream(String) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
Specify a stream id on which late tuples are going to be emitted.
- withStream(String) - Method in class org.apache.heron.streamlet.impl.StreamletImpl
-
Set the id of the stream to be used by the children nodes.
- withStream(String) - Method in interface org.apache.heron.streamlet.Streamlet
-
Set the id of the stream to be used by the children nodes.
- withTimestampExtractor(TimestampExtractor) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
Specify the timestamp extractor implementation.
- withTimestampExtractor(TimestampExtractor) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
Specify the timestamp extractor implementation.
- withTimestampField(String) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
Specify a field in the tuple that represents the timestamp as a long value.
- withTimestampField(String) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
Specify a field in the tuple that represents the timestamp as a long value.
- withTumblingWindow(Duration) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
A time duration based tumbling window.
- withTumblingWindow(Duration) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
A time duration based tumbling window.
- withTumblingWindow(BaseWindowedBolt.Count) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
A count based tumbling window.
- withTumblingWindow(BaseWindowedBolt.Count) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
A count based tumbling window.
- withWatermarkInterval(Duration) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
Specify the watermark event generation interval.
- withWatermarkInterval(Duration) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
Specify the watermark event generation interval.
- withWindow(Duration) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
A time duration based window that slides with every incoming tuple.
- withWindow(Duration) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
A time duration based window that slides with every incoming tuple.
- withWindow(Duration, Duration) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
Time duration based sliding window configuration.
- withWindow(Duration, Duration) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
Time duration based sliding window configuration.
- withWindow(Duration, BaseWindowedBolt.Count) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
Time duration and count based sliding window configuration.
- withWindow(Duration, BaseWindowedBolt.Count) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
Time duration and count based sliding window configuration.
- withWindow(BaseWindowedBolt.Count) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
A tuple count based window that slides with every incoming tuple.
- withWindow(BaseWindowedBolt.Count) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
A tuple count based window that slides with every incoming tuple.
- withWindow(BaseWindowedBolt.Count, Duration) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
Tuple count and time duration based sliding window configuration.
- withWindow(BaseWindowedBolt.Count, Duration) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
Tuple count and time duration based sliding window configuration.
- withWindow(BaseWindowedBolt.Count, BaseWindowedBolt.Count) - Method in class org.apache.heron.api.bolt.BaseStatefulWindowedBolt
-
Tuple count based sliding window configuration.
- withWindow(BaseWindowedBolt.Count, BaseWindowedBolt.Count) - Method in class org.apache.heron.api.bolt.BaseWindowedBolt
-
Tuple count based sliding window configuration.
- write(Kryo, Output, Object) - Method in class org.apache.heron.api.serializer.SerializableSerializer
Z
- zeroIfNaNOrInf(double) - Static method in class org.apache.heron.api.utils.Utils
All Classes All Packages