public class LocalMergeOperator extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<InternalRow> implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<InternalRow,InternalRow>, org.apache.flink.streaming.api.operators.BoundedOneInput
AbstractStreamOperator
which buffer input record and apply merge function when the buffer
is full. Mainly to resolve data skew on primary keys.Constructor and Description |
---|
LocalMergeOperator(TableSchema schema) |
Modifier and Type | Method and Description |
---|---|
void |
close() |
void |
endInput() |
void |
open() |
void |
prepareSnapshotPreBarrier(long checkpointId) |
void |
processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<InternalRow> record) |
void |
processWatermark(org.apache.flink.streaming.api.watermark.Watermark mark) |
finish, getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, setup, snapshotState, snapshotState, useSplittableTimers
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
setKeyContextElement
finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
public LocalMergeOperator(TableSchema schema)
public void open() throws Exception
open
in interface org.apache.flink.streaming.api.operators.StreamOperator<InternalRow>
open
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<InternalRow>
Exception
public void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<InternalRow> record) throws Exception
processElement
in interface org.apache.flink.streaming.api.operators.Input<InternalRow>
Exception
public void processWatermark(org.apache.flink.streaming.api.watermark.Watermark mark)
processWatermark
in interface org.apache.flink.streaming.api.operators.Input<InternalRow>
processWatermark
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<InternalRow>
public void prepareSnapshotPreBarrier(long checkpointId) throws Exception
prepareSnapshotPreBarrier
in interface org.apache.flink.streaming.api.operators.StreamOperator<InternalRow>
prepareSnapshotPreBarrier
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<InternalRow>
Exception
public void endInput() throws Exception
endInput
in interface org.apache.flink.streaming.api.operators.BoundedOneInput
Exception
public void close() throws Exception
close
in interface org.apache.flink.streaming.api.operators.StreamOperator<InternalRow>
close
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<InternalRow>
Exception
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.