Class OrderedProcessingHandler.OrderedProcessingGlobalSequenceHandler<EventT,KeyT,StateT extends MutableState<EventT,?>,ResultT>
- Type Parameters:
EventT
- type of events to be processedKeyT
- type of keys which will be used to group the eventsStateT
- type of internal State which will be used for processingResultT
- type of the result of the processing which will be output
- All Implemented Interfaces:
Serializable
- Enclosing class:
OrderedProcessingHandler<EventT,
KeyT, StateT extends MutableState<EventT, ?>, ResultT>
- See Also:
-
Nested Class Summary
Nested classes/interfaces inherited from class org.apache.beam.sdk.extensions.ordered.OrderedProcessingHandler
OrderedProcessingHandler.OrderedProcessingGlobalSequenceHandler<EventT,
KeyT, StateT extends MutableState<EventT, ?>, ResultT> -
Field Summary
Fields inherited from class org.apache.beam.sdk.extensions.ordered.OrderedProcessingHandler
DEFAULT_MAX_ELEMENTS_TO_OUTPUT
-
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionHow frequently the combiner should reevaluate the maximum range? This parameter only affects the behaviour of streaming pipelines.@UnknownKeyFor @NonNull @Initialized Combine.Globally
<TimestampedValue<KV<KeyT, KV<Long, EventT>>>, ContiguousSequenceRange> Provide the global sequence combiner.int
Number of new elements to trigger the re-evaluation.Methods inherited from class org.apache.beam.sdk.extensions.ordered.OrderedProcessingHandler
getEventCoder, getEventExaminer, getKeyCoder, getMaxOutputElementsPerBundle, getResultCoder, getStateCoder, getStatusUpdateFrequency, isProduceStatusUpdateOnEveryEvent, setMaxOutputElementsPerBundle, setProduceStatusUpdateOnEveryEvent, setStatusUpdateFrequency
-
Constructor Details
-
OrderedProcessingGlobalSequenceHandler
-
-
Method Details
-
getGlobalSequenceCombiner
public @UnknownKeyFor @NonNull @Initialized Combine.Globally<TimestampedValue<KV<KeyT,KV<Long, getGlobalSequenceCombiner()EventT>>>, ContiguousSequenceRange> Provide the global sequence combiner. Default is to useDefaultSequenceCombiner
.- Returns:
- combiner
-
getContiguousSequenceRangeReevaluationFrequency
How frequently the combiner should reevaluate the maximum range? This parameter only affects the behaviour of streaming pipelines.This parameter is used together with
getMaxElementCountToTriggerContinuousSequenceRangeReevaluation()
. The re-evaluation will occur as soon as the number of new elements exceeds the threshold or the time exceeds the frequency.Notice that some runners cache the output of side inputs and this parameter might not appear to have an effect unless the cache time-to-live is equal or less than this frequency. For Dataflow runner, see invalid input: '{@link <a href="https://beam.apache.org/releases/javadoc/current/org/apache/beam/runners/dataflow/options/DataflowStreamingPipelineOptions.html#getStreamingSideInputCacheExpirationMillis--">this' Dataflow streaming pipeline option}
- Returns:
- frequency of reevaluating the
ContiguousSequenceRange
. Default - every second. - See Also:
-
getMaxElementCountToTriggerContinuousSequenceRangeReevaluation
public int getMaxElementCountToTriggerContinuousSequenceRangeReevaluation()Number of new elements to trigger the re-evaluation.See
getContiguousSequenceRangeReevaluationFrequency()
for additional details.- Returns:
- batch size. Default - 1000.
-