Uses of Class
org.apache.flink.runtime.messages.FlinkJobNotFoundException
-
Packages that use FlinkJobNotFoundException Package Description org.apache.flink.runtime.scheduler org.apache.flink.runtime.scheduler.adaptive -
-
Uses of FlinkJobNotFoundException in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that throw FlinkJobNotFoundException Modifier and Type Method Description void
KvStateHandler. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
void
SchedulerBase. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
void
SchedulerNG. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
void
KvStateHandler. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
void
SchedulerBase. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
void
SchedulerNG. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
KvStateLocation
KvStateHandler. requestKvStateLocation(org.apache.flink.api.common.JobID jobId, String registrationName)
KvStateLocation
SchedulerBase. requestKvStateLocation(org.apache.flink.api.common.JobID jobId, String registrationName)
KvStateLocation
SchedulerNG. requestKvStateLocation(org.apache.flink.api.common.JobID jobId, String registrationName)
-
Uses of FlinkJobNotFoundException in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive that throw FlinkJobNotFoundException Modifier and Type Method Description void
AdaptiveScheduler. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)
void
AdaptiveScheduler. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)
KvStateLocation
AdaptiveScheduler. requestKvStateLocation(org.apache.flink.api.common.JobID jobId, String registrationName)
-