Uses of Class
org.apache.flink.runtime.state.changelog.StateChange
-
Packages that use StateChange Package Description org.apache.flink.runtime.state.changelog org.apache.flink.runtime.state.changelog.inmemory -
-
Uses of StateChange in org.apache.flink.runtime.state.changelog
Methods in org.apache.flink.runtime.state.changelog that return StateChange Modifier and Type Method Description static StateChange
StateChange. ofDataChange(int keyGroup, byte[] change)
static StateChange
StateChange. ofMetadataChange(byte[] change)
Methods in org.apache.flink.runtime.state.changelog that return types with arguments of type StateChange Modifier and Type Method Description org.apache.flink.util.CloseableIterator<StateChange>
StateChangelogHandleReader. getChanges(Handle handle)
org.apache.flink.util.CloseableIterator<StateChange>
StateChangelogHandleStreamHandleReader. getChanges(ChangelogStateHandleStreamImpl handle)
org.apache.flink.util.CloseableIterator<StateChange>
StateChangelogHandleStreamHandleReader.StateChangeIterator. read(StreamStateHandle handle, long offset)
-
Uses of StateChange in org.apache.flink.runtime.state.changelog.inmemory
Methods in org.apache.flink.runtime.state.changelog.inmemory that return types with arguments of type StateChange Modifier and Type Method Description List<StateChange>
InMemoryChangelogStateHandle. getChanges()
Method parameters in org.apache.flink.runtime.state.changelog.inmemory with type arguments of type StateChange Modifier and Type Method Description static InMemoryChangelogStateHandle
InMemoryChangelogStateHandle. restore(List<StateChange> changes, SequenceNumber from, SequenceNumber to, KeyGroupRange keyGroupRange, StateHandleID stateHandleId)
Constructor parameters in org.apache.flink.runtime.state.changelog.inmemory with type arguments of type StateChange Constructor Description InMemoryChangelogStateHandle(List<StateChange> changes, SequenceNumber from, SequenceNumber to, KeyGroupRange keyGroupRange)
-