public class KeyedMapBundleOperator<K,V,IN,OUT> extends AbstractMapBundleOperator<K,V,IN,OUT>
KeyedMapBundleOperator
uses framework's key as bundle map key, thus can only be used
on KeyedStream
.chainingStrategy, config, latencyStats, LOG, metrics, output, processingTimeService
Constructor and Description |
---|
KeyedMapBundleOperator(MapBundleFunction<K,V,IN,OUT> function,
BundleTrigger<IN> bundleTrigger) |
Modifier and Type | Method and Description |
---|---|
protected K |
getKey(IN input)
Get the key for current processing element, which will be used as the map bundle's key.
|
close, finish, finishBundle, open, prepareSnapshotPreBarrier, processElement, processWatermark
getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, setup, snapshotState, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
setKeyContextElement
getMetricGroup, getOperatorID, initializeState, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
processLatencyMarker, processWatermarkStatus
hasKeyContext
public KeyedMapBundleOperator(MapBundleFunction<K,V,IN,OUT> function, BundleTrigger<IN> bundleTrigger)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.