public class HashBucketAssignerOperator<T> extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<org.apache.flink.api.java.tuple.Tuple2<T,Integer>> implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<T,org.apache.flink.api.java.tuple.Tuple2<T,Integer>>
Constructor and Description |
---|
HashBucketAssignerOperator(String commitUser,
Table table,
Integer numAssigners,
SerializableFunction<TableSchema,PartitionKeyExtractor<T>> extractorFunction,
boolean overwrite) |
Modifier and Type | Method and Description |
---|---|
void |
initializeState(org.apache.flink.runtime.state.StateInitializationContext context) |
void |
prepareSnapshotPreBarrier(long checkpointId) |
void |
processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<T> streamRecord) |
void |
processRecordAttributes(RecordAttributes recordAttributes) |
close, 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, open, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes1, processRecordAttributes2, processWatermark, 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
close, finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, open, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
public HashBucketAssignerOperator(String commitUser, Table table, Integer numAssigners, SerializableFunction<TableSchema,PartitionKeyExtractor<T>> extractorFunction, boolean overwrite)
public void initializeState(org.apache.flink.runtime.state.StateInitializationContext context) throws Exception
initializeState
in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
initializeState
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<org.apache.flink.api.java.tuple.Tuple2<T,Integer>>
Exception
public void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<T> streamRecord) throws Exception
public void processRecordAttributes(RecordAttributes recordAttributes)
public void prepareSnapshotPreBarrier(long checkpointId)
prepareSnapshotPreBarrier
in interface org.apache.flink.streaming.api.operators.StreamOperator<org.apache.flink.api.java.tuple.Tuple2<T,Integer>>
prepareSnapshotPreBarrier
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<org.apache.flink.api.java.tuple.Tuple2<T,Integer>>
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.