Uses of Class
org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
-
Uses of StreamingRuntimeContext in org.apache.flink.datastream.impl.context
Fields in org.apache.flink.datastream.impl.context declared as StreamingRuntimeContext Modifier and Type Field Description protected StreamingRuntimeContext
DefaultStateManager. operatorContext
Constructors in org.apache.flink.datastream.impl.context with parameters of type StreamingRuntimeContext Constructor Description DefaultPartitionedContext(RuntimeContext context, Supplier<Object> currentKeySupplier, Consumer<Object> currentKeySetter, ProcessingTimeManager processingTimeManager, StreamingRuntimeContext operatorContext, OperatorStateStore operatorStateStore)
DefaultStateManager(Supplier<Object> currentKeySupplier, Consumer<Object> currentKeySetter, StreamingRuntimeContext operatorContext, OperatorStateStore operatorStateStore)
-
Uses of StreamingRuntimeContext in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return StreamingRuntimeContext Modifier and Type Method Description StreamingRuntimeContext
AbstractStreamOperator. getRuntimeContext()
Returns a context that allows the operator to query information about the execution and also to interact with systems such as broadcast variables and managed state.StreamingRuntimeContext
AbstractStreamOperatorV2. getRuntimeContext()
Returns a context that allows the operator to query information about the execution and also to interact with systems such as broadcast variables and managed state. -
Uses of StreamingRuntimeContext in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state
Methods in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state with parameters of type StreamingRuntimeContext Modifier and Type Method Description static JoinRecordAsyncStateView
JoinRecordAsyncStateViews. create(StreamingRuntimeContext ctx, String stateName, JoinInputSideSpec inputSideSpec, InternalTypeInfo<RowData> recordType, long retentionTime)
Creates aJoinRecordAsyncStateView
depends onJoinInputSideSpec
.static OuterJoinRecordAsyncStateView
OuterJoinRecordAsyncStateViews. create(StreamingRuntimeContext ctx, String stateName, JoinInputSideSpec inputSideSpec, InternalTypeInfo<RowData> recordType, long retentionTime)
Creates aOuterJoinRecordAsyncStateView
depends onJoinInputSideSpec
.
-