Class DataStatisticsOperator
- java.lang.Object
- 
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<StatisticsOrRecord>
- 
- org.apache.iceberg.flink.sink.shuffle.DataStatisticsOperator
 
 
- 
- All Implemented Interfaces:
- java.io.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.SetupableStreamOperator<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:
- Serialized Form
 
- 
- 
Method SummaryAll Methods Instance Methods Concrete Methods Modifier and Type Method Description voidhandleOperatorEvent(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.AbstractStreamOperatorclose, 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, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, setup, snapshotState, useSplittableTimers
 - 
Methods inherited from class java.lang.Objectclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 - 
Methods inherited from interface org.apache.flink.api.common.state.CheckpointListenernotifyCheckpointAborted, notifyCheckpointComplete
 - 
Methods inherited from interface org.apache.flink.streaming.api.operators.InputprocessLatencyMarker, processRecordAttributes, processWatermark, processWatermarkStatus
 - 
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContextgetCurrentKey, setCurrentKey
 - 
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContextHandlerhasKeyContext
 
- 
 
- 
- 
- 
Method Detail- 
initializeStatepublic void initializeState(org.apache.flink.runtime.state.StateInitializationContext context) throws java.lang.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:
- java.lang.Exception
 
 - 
openpublic void open() throws java.lang.Exception- Specified by:
- openin interface- org.apache.flink.streaming.api.operators.StreamOperator<StatisticsOrRecord>
- Overrides:
- openin class- org.apache.flink.streaming.api.operators.AbstractStreamOperator<StatisticsOrRecord>
- Throws:
- java.lang.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 java.lang.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:
- java.lang.Exception
 
 
- 
 
-