public class ExecutionOrderEnforcerOperator<IN> extends AbstractStreamOperatorV2<IN> implements MultipleInputStreamOperator<IN>
The operator must be chained with the source, which is generally ensured by the ExecutionOrderEnforcerOperatorFactory
. If chaining is explicitly disabled, the enforcer can not
work as expected.
The operator is used only for dynamic filtering at present.
config, latencyStats, LOG, metrics, output, processingTimeService
Constructor and Description |
---|
ExecutionOrderEnforcerOperator(StreamOperatorParameters<IN> parameters) |
Modifier and Type | Method and Description |
---|---|
List<Input> |
getInputs() |
close, finish, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, initializeState, initializeState, internalSetKeyContextElement, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, open, prepareSnapshotPreBarrier, processWatermark, processWatermarkStatus, reportOrForwardLatencyMarker, reportWatermark, setCurrentKey, setKeyContextElement1, setKeyContextElement2, snapshotState, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
close, finish, getMetricGroup, getOperatorID, initializeState, open, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
public ExecutionOrderEnforcerOperator(StreamOperatorParameters<IN> parameters)
public List<Input> getInputs()
getInputs
in interface MultipleInputStreamOperator<IN>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.