Class KvStateHandler
- java.lang.Object
-
- org.apache.flink.runtime.scheduler.KvStateHandler
-
public class KvStateHandler extends Object
Handler for common queryable state logic.
-
-
Constructor Summary
Constructors Constructor Description KvStateHandler(ExecutionGraph executionGraph)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
void
notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
KvStateLocation
requestKvStateLocation(org.apache.flink.api.common.JobID jobId, String registrationName)
-
-
-
Constructor Detail
-
KvStateHandler
public KvStateHandler(ExecutionGraph executionGraph)
-
-
Method Detail
-
requestKvStateLocation
public KvStateLocation requestKvStateLocation(org.apache.flink.api.common.JobID jobId, String registrationName) throws UnknownKvStateLocation, FlinkJobNotFoundException
-
notifyKvStateRegistered
public void notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress) throws FlinkJobNotFoundException
- Throws:
FlinkJobNotFoundException
-
notifyKvStateUnregistered
public void notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName) throws FlinkJobNotFoundException
- Throws:
FlinkJobNotFoundException
-
-