Class DataStatisticsOperator
java.lang.Object
org.apache.flink.streaming.api.operators.AbstractStreamOperator<StatisticsOrRecord>
org.apache.iceberg.flink.sink.shuffle.DataStatisticsOperator
- All Implemented Interfaces:
- Serializable,- org.apache.flink.api.common.state.CheckpointListener,- org.apache.flink.runtime.operators.coordination.OperatorEventHandler,- org.apache.flink.streaming.api.operators.Input<org.apache.flink.table.data.RowData>,- org.apache.flink.streaming.api.operators.KeyContext,- org.apache.flink.streaming.api.operators.KeyContextHandler,- org.apache.flink.streaming.api.operators.OneInputStreamOperator<org.apache.flink.table.data.RowData,,- StatisticsOrRecord> - org.apache.flink.streaming.api.operators.StreamOperator<StatisticsOrRecord>,- org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator,- org.apache.flink.streaming.api.operators.YieldingOperator<StatisticsOrRecord>
@Internal
public class DataStatisticsOperator
extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<StatisticsOrRecord>
implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<org.apache.flink.table.data.RowData,StatisticsOrRecord>, org.apache.flink.runtime.operators.coordination.OperatorEventHandler 
DataStatisticsOperator collects traffic distribution statistics. A custom partitioner shall be
 attached to the DataStatisticsOperator output. The custom partitioner leverages the statistics to
 shuffle record to improve data clustering while maintaining relative balanced traffic
 distribution to downstream subtasks.
- See Also:
- 
Field SummaryFields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperatorcombinedWatermark, config, lastRecordAttributes1, lastRecordAttributes2, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
- 
Method SummaryModifier and TypeMethodDescriptionvoidhandleOperatorEvent(org.apache.flink.runtime.operators.coordination.OperatorEvent event) voidinitializeState(org.apache.flink.runtime.state.StateInitializationContext context) voidopen()voidprocessElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<org.apache.flink.table.data.RowData> streamRecord) voidsnapshotState(org.apache.flink.runtime.state.StateSnapshotContext context) Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperatorbeforeInitializeStateHandler, close, finish, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, isAsyncStateProcessingEnabled, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark, processWatermark, processWatermark1, processWatermark1, processWatermark2, processWatermark2, processWatermarkStatus, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, setup, snapshotState, useSplittableTimersMethods inherited from class java.lang.Objectclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.apache.flink.api.common.state.CheckpointListenernotifyCheckpointAborted, notifyCheckpointCompleteMethods inherited from interface org.apache.flink.streaming.api.operators.InputprocessLatencyMarker, processRecordAttributes, processWatermark, processWatermark, processWatermarkStatusMethods inherited from interface org.apache.flink.streaming.api.operators.KeyContextgetCurrentKey, setCurrentKeyMethods inherited from interface org.apache.flink.streaming.api.operators.KeyContextHandlerhasKeyContextMethods inherited from interface org.apache.flink.streaming.api.operators.OneInputStreamOperatorsetKeyContextElementMethods inherited from interface org.apache.flink.streaming.api.operators.StreamOperatorclose, finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
- 
Method Details- 
initializeStatepublic void initializeState(org.apache.flink.runtime.state.StateInitializationContext context) throws Exception - Specified by:
- initializeStatein interface- org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
- Overrides:
- initializeStatein class- org.apache.flink.streaming.api.operators.AbstractStreamOperator<StatisticsOrRecord>
- Throws:
- Exception
 
- 
open- Specified by:
- openin interface- org.apache.flink.streaming.api.operators.StreamOperator<StatisticsOrRecord>
- Overrides:
- openin class- org.apache.flink.streaming.api.operators.AbstractStreamOperator<StatisticsOrRecord>
- Throws:
- Exception
 
- 
handleOperatorEventpublic void handleOperatorEvent(org.apache.flink.runtime.operators.coordination.OperatorEvent event) - Specified by:
- handleOperatorEventin interface- org.apache.flink.runtime.operators.coordination.OperatorEventHandler
 
- 
processElementpublic void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<org.apache.flink.table.data.RowData> streamRecord) - Specified by:
- processElementin interface- org.apache.flink.streaming.api.operators.Input<org.apache.flink.table.data.RowData>
 
- 
snapshotStatepublic void snapshotState(org.apache.flink.runtime.state.StateSnapshotContext context) throws Exception - Specified by:
- snapshotStatein interface- org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
- Overrides:
- snapshotStatein class- org.apache.flink.streaming.api.operators.AbstractStreamOperator<StatisticsOrRecord>
- Throws:
- Exception
 
 
-