Package | Description |
---|---|
org.apache.storm.topology.base |
Modifier and Type | Method and Description |
---|---|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withLag(BaseWindowedBolt.Duration duration)
Specify the maximum time lag of the tuple timestamp in milliseconds.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withLateTupleStream(String streamName)
Specify a stream id on which late tuples are going to be emitted.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withMaxEventsInMemory(long maxEventsInMemory)
The maximum number of window events to keep in memory.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withMessageIdField(String fieldName)
Specify the name of the field in the tuple that holds the message id.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withPersistence()
If set, the stateful windowed bolt would use the backend state for window persistence and only keep a sub-set of events in memory as specified by
withMaxEventsInMemory(long) . |
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withTimestampExtractor(TimestampExtractor timestampExtractor)
Specify the timestamp extractor implementation.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withTimestampField(String fieldName)
Specify a field in the tuple that represents the timestamp as a long value.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withTumblingWindow(BaseWindowedBolt.Count count)
A count based tumbling window.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withTumblingWindow(BaseWindowedBolt.Duration duration)
A time duration based tumbling window.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withWatermarkInterval(BaseWindowedBolt.Duration interval)
Specify the watermark event generation interval.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withWindow(BaseWindowedBolt.Count windowLength)
A tuple count based window that slides with every incoming tuple.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withWindow(BaseWindowedBolt.Count windowLength,
BaseWindowedBolt.Count slidingInterval)
Tuple count based sliding window configuration.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withWindow(BaseWindowedBolt.Count windowLength,
BaseWindowedBolt.Duration slidingInterval)
Tuple count and time duration based sliding window configuration.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withWindow(BaseWindowedBolt.Duration windowLength)
A time duration based window that slides with every incoming tuple.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withWindow(BaseWindowedBolt.Duration windowLength,
BaseWindowedBolt.Count slidingInterval)
Time duration and count based sliding window configuration.
|
BaseStatefulWindowedBolt<T> |
BaseStatefulWindowedBolt.withWindow(BaseWindowedBolt.Duration windowLength,
BaseWindowedBolt.Duration slidingInterval)
Time duration based sliding window configuration.
|
Copyright © 2022 The Apache Software Foundation. All rights reserved.