Interface InternalAppendingState<K,N,IN,SV,OUT,SYNCOUT>
-
- Type Parameters:
K
- The type of key the state is associated to.N
- The namespace type.IN
- The type of the values that are added into the state.SV
- The type of the intermediate state.OUT
- The type of the values that are returned from the state.SYNCOUT
- Type of the value that can be retrieved from the state by synchronous interface.
- All Superinterfaces:
AppendingState<IN,OUT,SYNCOUT>
,InternalKeyedState<K,N,SV>
,InternalPartitionedState<N>
,State
- All Known Subinterfaces:
InternalAggregatingState<K,N,IN,ACC,OUT>
,InternalMergingState<K,N,IN,SV,OUT,SYNCOUT>
,InternalReducingState<K,N,T>
- All Known Implementing Classes:
AbstractAggregatingState
,AbstractReducingState
,AggregatingStateAdaptor
,ForStAggregatingState
,ForStReducingState
,MergingStateAdaptor
,ReducingStateAdaptor
public interface InternalAppendingState<K,N,IN,SV,OUT,SYNCOUT> extends InternalKeyedState<K,N,SV>, AppendingState<IN,OUT,SYNCOUT>
This class defines the internal interface for appending state.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description StateFuture<SV>
asyncGetInternal()
Get internally stored value.StateFuture<Void>
asyncUpdateInternal(SV valueToStore)
Update internally stored value.SV
getInternal()
Get internally stored value.void
updateInternal(SV valueToStore)
Update internally stored value.-
Methods inherited from interface org.apache.flink.api.common.state.v2.AppendingState
add, asyncAdd, asyncGet, get
-
Methods inherited from interface org.apache.flink.runtime.state.v2.internal.InternalPartitionedState
setCurrentNamespace
-
Methods inherited from interface org.apache.flink.api.common.state.v2.State
asyncClear, clear
-
-
-
-
Method Detail
-
asyncGetInternal
StateFuture<SV> asyncGetInternal()
Get internally stored value.- Returns:
- internally stored value.
-
asyncUpdateInternal
StateFuture<Void> asyncUpdateInternal(SV valueToStore)
Update internally stored value.- Parameters:
valueToStore
- new value to store.
-
getInternal
SV getInternal()
Get internally stored value.- Returns:
- internally stored value.
-
updateInternal
void updateInternal(SV valueToStore)
Update internally stored value.- Parameters:
valueToStore
- new value to store.
-
-