Package | Description |
---|---|
org.apache.storm.bolt | |
org.apache.storm.flux.examples | |
org.apache.storm.st.topology.window | |
org.apache.storm.starter.bolt | |
org.apache.storm.topology.base |
Modifier and Type | Class and Description |
---|---|
class |
JoinBolt |
Modifier and Type | Method and Description |
---|---|
BaseWindowedBolt |
JoinBolt.withLag(BaseWindowedBolt.Duration duration) |
BaseWindowedBolt |
JoinBolt.withWatermarkInterval(BaseWindowedBolt.Duration interval) |
Modifier and Type | Class and Description |
---|---|
class |
TestWindowBolt |
Modifier and Type | Class and Description |
---|---|
class |
TimeDataVerificationBolt |
class |
VerificationBolt |
Modifier and Type | Class and Description |
---|---|
class |
SlidingWindowSumBolt
Computes sliding window sum.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseStatefulWindowedBolt<T extends State> |
Modifier and Type | Method and Description |
---|---|
BaseWindowedBolt |
BaseWindowedBolt.withLag(BaseWindowedBolt.Duration duration)
Specify the maximum time lag of the tuple timestamp in milliseconds.
|
BaseWindowedBolt |
BaseWindowedBolt.withLateTupleStream(String streamId)
Specify a stream id on which late tuples are going to be emitted.
|
BaseWindowedBolt |
BaseWindowedBolt.withTimestampExtractor(TimestampExtractor timestampExtractor)
Specify the timestamp extractor implementation.
|
BaseWindowedBolt |
BaseWindowedBolt.withTimestampField(String fieldName)
Specify a field in the tuple that represents the timestamp as a long value.
|
BaseWindowedBolt |
BaseWindowedBolt.withTumblingWindow(BaseWindowedBolt.Count count)
A count based tumbling window.
|
BaseWindowedBolt |
BaseWindowedBolt.withTumblingWindow(BaseWindowedBolt.Duration duration)
A time duration based tumbling window.
|
BaseWindowedBolt |
BaseWindowedBolt.withWatermarkInterval(BaseWindowedBolt.Duration interval)
Specify the watermark event generation interval.
|
BaseWindowedBolt |
BaseWindowedBolt.withWindow(BaseWindowedBolt.Count windowLength)
A tuple count based window that slides with every incoming tuple.
|
BaseWindowedBolt |
BaseWindowedBolt.withWindow(BaseWindowedBolt.Count windowLength,
BaseWindowedBolt.Count slidingInterval)
Tuple count based sliding window configuration.
|
BaseWindowedBolt |
BaseWindowedBolt.withWindow(BaseWindowedBolt.Count windowLength,
BaseWindowedBolt.Duration slidingInterval)
Tuple count and time duration based sliding window configuration.
|
BaseWindowedBolt |
BaseWindowedBolt.withWindow(BaseWindowedBolt.Duration windowLength)
A time duration based window that slides with every incoming tuple.
|
BaseWindowedBolt |
BaseWindowedBolt.withWindow(BaseWindowedBolt.Duration windowLength,
BaseWindowedBolt.Count slidingInterval)
Time duration and count based sliding window configuration.
|
BaseWindowedBolt |
BaseWindowedBolt.withWindow(BaseWindowedBolt.Duration windowLength,
BaseWindowedBolt.Duration slidingInterval)
Time duration based sliding window configuration.
|
Copyright © 2023 The Apache Software Foundation. All rights reserved.