Interface InternalStateAccessible<SV>
-
- All Known Subinterfaces:
InternalAggregatingState<K,N,IN,ACC,OUT>,InternalReducingState<K,N,T>
- All Known Implementing Classes:
AbstractAggregatingState,AbstractReducingState,AggregatingStateAdaptor,ReducingStateAdaptor
public interface InternalStateAccessible<SV>
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description org.apache.flink.api.common.state.v2.StateFuture<SV>asyncGetInternal()Get internally stored value.org.apache.flink.api.common.state.v2.StateFuture<Void>asyncUpdateInternal(SV valueToStore)Update internally stored value.SVgetInternal()Get internally stored value.voidupdateInternal(SV valueToStore)Update internally stored value.
-
-
-
Method Detail
-
asyncGetInternal
org.apache.flink.api.common.state.v2.StateFuture<SV> asyncGetInternal()
Get internally stored value.- Returns:
- internally stored value.
-
asyncUpdateInternal
org.apache.flink.api.common.state.v2.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.
-
-