Package | Description |
---|---|
org.apache.storm.bolt | |
org.apache.storm.topology.base | |
org.apache.storm.trident | |
org.apache.storm.trident.windowing.config |
Modifier and Type | Method and Description |
---|---|
BaseWindowedBolt |
JoinBolt.withLag(BaseWindowedBolt.Duration duration) |
JoinBolt |
JoinBolt.withTumblingWindow(BaseWindowedBolt.Duration duration) |
BaseWindowedBolt |
JoinBolt.withWatermarkInterval(BaseWindowedBolt.Duration interval) |
JoinBolt |
JoinBolt.withWindow(BaseWindowedBolt.Count windowLength,
BaseWindowedBolt.Duration slidingInterval) |
JoinBolt |
JoinBolt.withWindow(BaseWindowedBolt.Duration windowLength) |
JoinBolt |
JoinBolt.withWindow(BaseWindowedBolt.Duration windowLength,
BaseWindowedBolt.Count slidingInterval) |
JoinBolt |
JoinBolt.withWindow(BaseWindowedBolt.Duration windowLength,
BaseWindowedBolt.Duration slidingInterval) |
Modifier and Type | Method and Description |
---|---|
static BaseWindowedBolt.Duration |
BaseWindowedBolt.Duration.days(int days)
Returns a
BaseWindowedBolt.Duration corresponding to the the given value in days. |
static BaseWindowedBolt.Duration |
BaseWindowedBolt.Duration.hours(int hours)
Returns a
BaseWindowedBolt.Duration corresponding to the the given value in hours. |
static BaseWindowedBolt.Duration |
BaseWindowedBolt.Duration.minutes(int minutes)
Returns a
BaseWindowedBolt.Duration corresponding to the the given value in minutes. |
static BaseWindowedBolt.Duration |
BaseWindowedBolt.Duration.of(int milliseconds)
Returns a
BaseWindowedBolt.Duration corresponding to the the given value in milli seconds. |
static BaseWindowedBolt.Duration |
BaseWindowedBolt.Duration.seconds(int seconds)
Returns a
BaseWindowedBolt.Duration corresponding to the the given value in seconds. |
Modifier and Type | Method and Description |
---|---|
BaseWindowedBolt |
BaseWindowedBolt.withLag(BaseWindowedBolt.Duration duration)
Specify the maximum time lag of the tuple timestamp in milliseconds.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withLag(BaseWindowedBolt.Duration duration)
Specify the maximum time lag of the tuple timestamp in milliseconds.
|
BaseWindowedBolt |
BaseWindowedBolt.withTumblingWindow(BaseWindowedBolt.Duration duration)
A time duration based tumbling window.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withTumblingWindow(BaseWindowedBolt.Duration duration)
A time duration based tumbling window.
|
BaseWindowedBolt |
BaseWindowedBolt.withWatermarkInterval(BaseWindowedBolt.Duration interval)
Specify the watermark event generation interval.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withWatermarkInterval(BaseWindowedBolt.Duration interval)
Specify the watermark event generation interval.
|
BaseWindowedBolt |
BaseWindowedBolt.withWindow(BaseWindowedBolt.Count windowLength,
BaseWindowedBolt.Duration slidingInterval)
Tuple count and time duration based sliding window configuration.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.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.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.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.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.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.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withWindow(BaseWindowedBolt.Duration windowLength,
BaseWindowedBolt.Duration slidingInterval)
Time duration based sliding window configuration.
|
Modifier and Type | Method and Description |
---|---|
Stream |
Stream.slidingWindow(BaseWindowedBolt.Duration windowDuration,
BaseWindowedBolt.Duration slidingInterval,
WindowsStoreFactory windowStoreFactory,
Fields inputFields,
Aggregator aggregator,
Fields functionFields)
Returns a stream of tuples which are aggregated results of a window which slides at duration of
slidingInterval and completes a window at windowDuration |
Stream |
Stream.tumblingWindow(BaseWindowedBolt.Duration windowDuration,
WindowsStoreFactory windowStoreFactory,
Fields inputFields,
Aggregator aggregator,
Fields functionFields)
Returns a stream of tuples which are aggregated results of a window that tumbles at duration of
windowDuration |
Modifier and Type | Method and Description |
---|---|
static TumblingDurationWindow |
TumblingDurationWindow.of(BaseWindowedBolt.Duration windowLength) |
static SlidingDurationWindow |
SlidingDurationWindow.of(BaseWindowedBolt.Duration windowDuration,
BaseWindowedBolt.Duration slidingDuration) |
Copyright © 2022 The Apache Software Foundation. All Rights Reserved.