Class AbstractAsyncStateStreamingJoinOperator
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<OUT>
-
- org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator<RowData>
-
- org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
-
- All Implemented Interfaces:
Serializable
,CheckpointListener
,KeyContext
,KeyContextHandler
,StreamOperator<RowData>
,StreamOperatorStateHandler.CheckpointedStreamOperator
,TwoInputStreamOperator<RowData,RowData,RowData>
,YieldingOperator<RowData>
,AsyncStateProcessing
,AsyncStateProcessingOperator
- Direct Known Subclasses:
AsyncStateStreamingJoinOperator
public abstract class AbstractAsyncStateStreamingJoinOperator extends AbstractAsyncStateStreamOperator<RowData> implements TwoInputStreamOperator<RowData,RowData,RowData>
Abstract implementation for streaming unbounded Join operator based on async state api, which defines some member fields can be shared between different implementations.- See Also:
- Serialized Form
-
-
Field Summary
Fields Modifier and Type Field Description protected TimestampedCollector<RowData>
collector
protected JoinConditionWithNullFilters
joinCondition
protected static String
LEFT_RECORDS_STATE_NAME
protected JoinInputSideSpec
leftInputSideSpec
protected long
leftStateRetentionTime
protected InternalTypeInfo<RowData>
leftType
protected static String
RIGHT_RECORDS_STATE_NAME
protected JoinInputSideSpec
rightInputSideSpec
protected long
rightStateRetentionTime
protected InternalTypeInfo<RowData>
rightType
-
Fields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
combinedWatermark, config, lastRecordAttributes1, lastRecordAttributes2, latencyStats, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
-
-
Constructor Summary
Constructors Constructor Description AbstractAsyncStateStreamingJoinOperator(InternalTypeInfo<RowData> leftType, InternalTypeInfo<RowData> rightType, GeneratedJoinCondition generatedJoinCondition, JoinInputSideSpec leftInputSideSpec, JoinInputSideSpec rightInputSideSpec, boolean[] filterNullKeys, long leftStateRetentionTime, long rightStateRetentionTime)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
close()
This method is called at the very end of the operator's life, both in the case of a successful completion of the operation, and in the case of a failure and canceling.void
open()
This method is called immediately before any elements are processed, it should contain the operator's initialization logic, e.g. state initialization.-
Methods inherited from class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
asyncProcessWithKey, finish, getCurrentKey, getElementOrder, getInternalTimerService, getOrCreateKeyedState, getRecordProcessor, initializeState, isAsyncStateProcessingEnabled, postProcessElement, prepareSnapshotPreBarrier, preserveRecordOrderAndProcess, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark, processWatermarkStatus, processWatermarkStatus, reportOrForwardLatencyMarker, setAsyncKeyedContextElement, setKeyContextElement1, setKeyContextElement2
-
Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
getContainingTask, getExecutionConfig, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark1, processWatermark2, processWatermarkStatus1, processWatermarkStatus2, setCurrentKey, setMailboxExecutor, setProcessingTimeService, setup, snapshotState, snapshotState, useSplittableTimers
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointAborted, notifyCheckpointComplete
-
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContext
getCurrentKey, setCurrentKey
-
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContextHandler
hasKeyContext
-
Methods inherited from interface org.apache.flink.streaming.api.operators.StreamOperator
finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
-
Methods inherited from interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
processElement1, processElement2, processLatencyMarker1, processLatencyMarker2, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus1, processWatermarkStatus2
-
-
-
-
Field Detail
-
LEFT_RECORDS_STATE_NAME
protected static final String LEFT_RECORDS_STATE_NAME
- See Also:
- Constant Field Values
-
RIGHT_RECORDS_STATE_NAME
protected static final String RIGHT_RECORDS_STATE_NAME
- See Also:
- Constant Field Values
-
leftType
protected final InternalTypeInfo<RowData> leftType
-
rightType
protected final InternalTypeInfo<RowData> rightType
-
leftInputSideSpec
protected final JoinInputSideSpec leftInputSideSpec
-
rightInputSideSpec
protected final JoinInputSideSpec rightInputSideSpec
-
leftStateRetentionTime
protected final long leftStateRetentionTime
-
rightStateRetentionTime
protected final long rightStateRetentionTime
-
joinCondition
protected transient JoinConditionWithNullFilters joinCondition
-
collector
protected transient TimestampedCollector<RowData> collector
-
-
Constructor Detail
-
AbstractAsyncStateStreamingJoinOperator
public AbstractAsyncStateStreamingJoinOperator(InternalTypeInfo<RowData> leftType, InternalTypeInfo<RowData> rightType, GeneratedJoinCondition generatedJoinCondition, JoinInputSideSpec leftInputSideSpec, JoinInputSideSpec rightInputSideSpec, boolean[] filterNullKeys, long leftStateRetentionTime, long rightStateRetentionTime)
-
-
Method Detail
-
open
public void open() throws Exception
Description copied from class:AbstractStreamOperator
This method is called immediately before any elements are processed, it should contain the operator's initialization logic, e.g. state initialization.The default implementation does nothing.
- Specified by:
open
in interfaceStreamOperator<RowData>
- Overrides:
open
in classAbstractStreamOperator<RowData>
- Throws:
Exception
- An exception in this method causes the operator to fail.
-
close
public void close() throws Exception
Description copied from interface:StreamOperator
This method is called at the very end of the operator's life, both in the case of a successful completion of the operation, and in the case of a failure and canceling.This method is expected to make a thorough effort to release all resources that the operator has acquired.
NOTE:It can not emit any records! If you need to emit records at the end of processing, do so in the
StreamOperator.finish()
method.- Specified by:
close
in interfaceStreamOperator<RowData>
- Overrides:
close
in classAbstractAsyncStateStreamOperator<RowData>
- Throws:
Exception
-
-