@Internal public class DistributedPrePartitionOperator extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<PartitioningEvent> implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<Event,PartitioningEvent>, Serializable
SchemaOperator
.Constructor and Description |
---|
DistributedPrePartitionOperator(int downstreamParallelism,
HashFunctionProvider<DataChangeEvent> hashFunctionProvider) |
Modifier and Type | Method and Description |
---|---|
void |
open() |
void |
processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<Event> element) |
void |
snapshotState(org.apache.flink.runtime.state.StateSnapshotContext context) |
close, finish, 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, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, setup, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
setKeyContextElement
close, finish, getMetricGroup, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
public DistributedPrePartitionOperator(int downstreamParallelism, HashFunctionProvider<DataChangeEvent> hashFunctionProvider)
public void open() throws Exception
open
in interface org.apache.flink.streaming.api.operators.StreamOperator<PartitioningEvent>
open
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<PartitioningEvent>
Exception
public void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<Event> element) throws Exception
public void snapshotState(org.apache.flink.runtime.state.StateSnapshotContext context) throws Exception
snapshotState
in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
snapshotState
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<PartitioningEvent>
Exception
Copyright © 2025 The Apache Software Foundation. All rights reserved.