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 voidKvStateHandler. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)voidSchedulerBase. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)voidSchedulerNG. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)voidKvStateHandler. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)voidSchedulerBase. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)voidSchedulerNG. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)KvStateLocationKvStateHandler. requestKvStateLocation(org.apache.flink.api.common.JobID jobId, String registrationName)KvStateLocationSchedulerBase. requestKvStateLocation(org.apache.flink.api.common.JobID jobId, String registrationName)KvStateLocationSchedulerNG. 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 voidAdaptiveScheduler. notifyKvStateRegistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, org.apache.flink.queryablestate.KvStateID kvStateId, InetSocketAddress kvStateServerAddress)voidAdaptiveScheduler. notifyKvStateUnregistered(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName)KvStateLocationAdaptiveScheduler. requestKvStateLocation(org.apache.flink.api.common.JobID jobId, String registrationName)
-