Search in sources :

Example 1 with TaskManagerLocation

use of org.apache.flink.runtime.taskmanager.TaskManagerLocation in project flink by apache.

the class JobMaster method offerSlots.

@RpcMethod
public Future<Iterable<SlotOffer>> offerSlots(final ResourceID taskManagerId, final Iterable<SlotOffer> slots, final UUID leaderId) throws Exception {
    validateLeaderSessionId(leaderId);
    Tuple2<TaskManagerLocation, TaskExecutorGateway> taskManager = registeredTaskManagers.get(taskManagerId);
    if (taskManager == null) {
        throw new Exception("Unknown TaskManager " + taskManagerId);
    }
    final JobID jid = jobGraph.getJobID();
    final TaskManagerLocation taskManagerLocation = taskManager.f0;
    final TaskExecutorGateway taskExecutorGateway = taskManager.f1;
    final ArrayList<Tuple2<AllocatedSlot, SlotOffer>> slotsAndOffers = new ArrayList<>();
    final RpcTaskManagerGateway rpcTaskManagerGateway = new RpcTaskManagerGateway(taskExecutorGateway, leaderId);
    for (SlotOffer slotOffer : slots) {
        final AllocatedSlot slot = new AllocatedSlot(slotOffer.getAllocationId(), jid, taskManagerLocation, slotOffer.getSlotIndex(), slotOffer.getResourceProfile(), rpcTaskManagerGateway);
        slotsAndOffers.add(new Tuple2<>(slot, slotOffer));
    }
    return slotPoolGateway.offerSlots(slotsAndOffers);
}
Also used : AllocatedSlot(org.apache.flink.runtime.jobmanager.slots.AllocatedSlot) SlotOffer(org.apache.flink.runtime.taskexecutor.slot.SlotOffer) TaskManagerLocation(org.apache.flink.runtime.taskmanager.TaskManagerLocation) Tuple2(org.apache.flink.api.java.tuple.Tuple2) ArrayList(java.util.ArrayList) TaskExecutorGateway(org.apache.flink.runtime.taskexecutor.TaskExecutorGateway) TimeoutException(java.util.concurrent.TimeoutException) CheckpointException(org.apache.flink.runtime.checkpoint.CheckpointException) LeaderIdMismatchException(org.apache.flink.runtime.highavailability.LeaderIdMismatchException) PartitionProducerDisposedException(org.apache.flink.runtime.jobmanager.PartitionProducerDisposedException) JobExecutionException(org.apache.flink.runtime.client.JobExecutionException) IOException(java.io.IOException) JobID(org.apache.flink.api.common.JobID) RpcMethod(org.apache.flink.runtime.rpc.RpcMethod)

Example 2 with TaskManagerLocation

use of org.apache.flink.runtime.taskmanager.TaskManagerLocation in project flink by apache.

the class Scheduler method scheduleTask.

/**
	 * Returns either a {@link SimpleSlot}, or a {@link Future}.
	 */
private Object scheduleTask(ScheduledUnit task, boolean queueIfNoResource) throws NoResourceAvailableException {
    if (task == null) {
        throw new NullPointerException();
    }
    if (LOG.isDebugEnabled()) {
        LOG.debug("Scheduling task " + task);
    }
    final ExecutionVertex vertex = task.getTaskToExecute().getVertex();
    final Iterable<TaskManagerLocation> preferredLocations = vertex.getPreferredLocationsBasedOnInputs();
    final boolean forceExternalLocation = false && preferredLocations != null && preferredLocations.iterator().hasNext();
    synchronized (globalLock) {
        SlotSharingGroup sharingUnit = task.getSlotSharingGroup();
        if (sharingUnit != null) {
            if (queueIfNoResource) {
                throw new IllegalArgumentException("A task with a vertex sharing group was scheduled in a queued fashion.");
            }
            final SlotSharingGroupAssignment assignment = sharingUnit.getTaskAssignment();
            final CoLocationConstraint constraint = task.getLocationConstraint();
            // sanity check that we do not use an externally forced location and a co-location constraint together
            if (constraint != null && forceExternalLocation) {
                throw new IllegalArgumentException("The scheduling cannot be constrained simultaneously by a " + "co-location constraint and an external location constraint.");
            }
            // get a slot from the group, if the group has one for us (and can fulfill the constraint)
            final SimpleSlot slotFromGroup;
            if (constraint == null) {
                slotFromGroup = assignment.getSlotForTask(vertex);
            } else {
                slotFromGroup = assignment.getSlotForTask(vertex, constraint);
            }
            SimpleSlot newSlot = null;
            SimpleSlot toUse = null;
            // the following needs to make sure any allocated slot is released in case of an error
            try {
                // any slot that is local, or where the assignment was unconstrained is good!
                if (slotFromGroup != null && slotFromGroup.getLocality() != Locality.NON_LOCAL) {
                    // the location, because we are quite happy with the slot
                    if (constraint != null && !constraint.isAssigned()) {
                        constraint.lockLocation();
                    }
                    updateLocalityCounters(slotFromGroup, vertex);
                    return slotFromGroup;
                }
                // the group did not have a local slot for us. see if we can one (or a better one)
                // our location preference is either determined by the location constraint, or by the
                // vertex's preferred locations
                final Iterable<TaskManagerLocation> locations;
                final boolean localOnly;
                if (constraint != null && constraint.isAssigned()) {
                    locations = Collections.singleton(constraint.getLocation());
                    localOnly = true;
                } else {
                    locations = vertex.getPreferredLocationsBasedOnInputs();
                    localOnly = forceExternalLocation;
                }
                newSlot = getNewSlotForSharingGroup(vertex, locations, assignment, constraint, localOnly);
                if (newSlot == null) {
                    if (slotFromGroup == null) {
                        if (constraint != null && constraint.isAssigned()) {
                            // nothing is available on the node where the co-location constraint forces us to
                            throw new NoResourceAvailableException("Could not allocate a slot on instance " + constraint.getLocation() + ", as required by the co-location constraint.");
                        } else if (forceExternalLocation) {
                            // could not satisfy the external location constraint
                            String hosts = getHostnamesFromInstances(preferredLocations);
                            throw new NoResourceAvailableException("Could not schedule task " + vertex + " to any of the required hosts: " + hosts);
                        } else {
                            // simply nothing is available
                            throw new NoResourceAvailableException(task, getNumberOfAvailableInstances(), getTotalNumberOfSlots(), getNumberOfAvailableSlots());
                        }
                    } else {
                        // got a non-local from the group, and no new one, so we use the non-local
                        // slot from the sharing group
                        toUse = slotFromGroup;
                    }
                } else if (slotFromGroup == null || !slotFromGroup.isAlive() || newSlot.getLocality() == Locality.LOCAL) {
                    // then we use the new slot
                    if (slotFromGroup != null) {
                        slotFromGroup.releaseSlot();
                    }
                    toUse = newSlot;
                } else {
                    // both are available and usable. neither is local. in that case, we may
                    // as well use the slot from the sharing group, to minimize the number of
                    // instances that the job occupies
                    newSlot.releaseSlot();
                    toUse = slotFromGroup;
                }
                // the location, because we are going to use that slot
                if (constraint != null && !constraint.isAssigned()) {
                    constraint.lockLocation();
                }
                updateLocalityCounters(toUse, vertex);
            } catch (NoResourceAvailableException e) {
                throw e;
            } catch (Throwable t) {
                if (slotFromGroup != null) {
                    slotFromGroup.releaseSlot();
                }
                if (newSlot != null) {
                    newSlot.releaseSlot();
                }
                ExceptionUtils.rethrow(t, "An error occurred while allocating a slot in a sharing group");
            }
            return toUse;
        } else {
            // 2) === schedule without hints and sharing ===
            SimpleSlot slot = getFreeSlotForTask(vertex, preferredLocations, forceExternalLocation);
            if (slot != null) {
                updateLocalityCounters(slot, vertex);
                return slot;
            } else {
                // no resource available now, so queue the request
                if (queueIfNoResource) {
                    CompletableFuture<SimpleSlot> future = new FlinkCompletableFuture<>();
                    this.taskQueue.add(new QueuedTask(task, future));
                    return future;
                } else if (forceExternalLocation) {
                    String hosts = getHostnamesFromInstances(preferredLocations);
                    throw new NoResourceAvailableException("Could not schedule task " + vertex + " to any of the required hosts: " + hosts);
                } else {
                    throw new NoResourceAvailableException(getNumberOfAvailableInstances(), getTotalNumberOfSlots(), getNumberOfAvailableSlots());
                }
            }
        }
    }
}
Also used : TaskManagerLocation(org.apache.flink.runtime.taskmanager.TaskManagerLocation) SimpleSlot(org.apache.flink.runtime.instance.SimpleSlot) FlinkCompletableFuture(org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture) ExecutionVertex(org.apache.flink.runtime.executiongraph.ExecutionVertex) SlotSharingGroupAssignment(org.apache.flink.runtime.instance.SlotSharingGroupAssignment)

Example 3 with TaskManagerLocation

use of org.apache.flink.runtime.taskmanager.TaskManagerLocation in project flink by apache.

the class ExecutionGraphMetricsTest method testExecutionGraphRestartTimeMetric.

/**
	 * This test tests that the restarting time metric correctly displays restarting times.
	 */
@Test
public void testExecutionGraphRestartTimeMetric() throws JobException, IOException, InterruptedException {
    final ScheduledExecutorService executor = Executors.newSingleThreadScheduledExecutor();
    try {
        // setup execution graph with mocked scheduling logic
        int parallelism = 1;
        JobVertex jobVertex = new JobVertex("TestVertex");
        jobVertex.setParallelism(parallelism);
        jobVertex.setInvokableClass(NoOpInvokable.class);
        JobGraph jobGraph = new JobGraph("Test Job", jobVertex);
        Configuration config = new Configuration();
        config.setString(ConfigConstants.METRICS_REPORTERS_LIST, "test");
        config.setString(ConfigConstants.METRICS_REPORTER_PREFIX + "test." + ConfigConstants.METRICS_REPORTER_CLASS_SUFFIX, TestingReporter.class.getName());
        Configuration jobConfig = new Configuration();
        Time timeout = Time.seconds(10L);
        MetricRegistry metricRegistry = new MetricRegistry(MetricRegistryConfiguration.fromConfiguration(config));
        assertTrue(metricRegistry.getReporters().size() == 1);
        MetricReporter reporter = metricRegistry.getReporters().get(0);
        assertTrue(reporter instanceof TestingReporter);
        TestingReporter testingReporter = (TestingReporter) reporter;
        MetricGroup metricGroup = new JobManagerMetricGroup(metricRegistry, "localhost");
        Scheduler scheduler = mock(Scheduler.class);
        ResourceID taskManagerId = ResourceID.generate();
        TaskManagerLocation taskManagerLocation = mock(TaskManagerLocation.class);
        when(taskManagerLocation.getResourceID()).thenReturn(taskManagerId);
        when(taskManagerLocation.getHostname()).thenReturn("localhost");
        TaskManagerGateway taskManagerGateway = mock(TaskManagerGateway.class);
        Instance instance = mock(Instance.class);
        when(instance.getTaskManagerLocation()).thenReturn(taskManagerLocation);
        when(instance.getTaskManagerID()).thenReturn(taskManagerId);
        when(instance.getTaskManagerGateway()).thenReturn(taskManagerGateway);
        Slot rootSlot = mock(Slot.class);
        AllocatedSlot mockAllocatedSlot = mock(AllocatedSlot.class);
        when(mockAllocatedSlot.getSlotAllocationId()).thenReturn(new AllocationID());
        SimpleSlot simpleSlot = mock(SimpleSlot.class);
        when(simpleSlot.isAlive()).thenReturn(true);
        when(simpleSlot.getTaskManagerLocation()).thenReturn(taskManagerLocation);
        when(simpleSlot.getTaskManagerID()).thenReturn(taskManagerId);
        when(simpleSlot.getTaskManagerGateway()).thenReturn(taskManagerGateway);
        when(simpleSlot.setExecutedVertex(Matchers.any(Execution.class))).thenReturn(true);
        when(simpleSlot.getRoot()).thenReturn(rootSlot);
        when(simpleSlot.getAllocatedSlot()).thenReturn(mockAllocatedSlot);
        FlinkCompletableFuture<SimpleSlot> future = new FlinkCompletableFuture<>();
        future.complete(simpleSlot);
        when(scheduler.allocateSlot(any(ScheduledUnit.class), anyBoolean())).thenReturn(future);
        when(rootSlot.getSlotNumber()).thenReturn(0);
        when(taskManagerGateway.submitTask(any(TaskDeploymentDescriptor.class), any(Time.class))).thenReturn(FlinkCompletableFuture.completed(Acknowledge.get()));
        TestingRestartStrategy testingRestartStrategy = new TestingRestartStrategy();
        ExecutionGraph executionGraph = new ExecutionGraph(executor, executor, jobGraph.getJobID(), jobGraph.getName(), jobConfig, new SerializedValue<ExecutionConfig>(null), timeout, testingRestartStrategy, Collections.<BlobKey>emptyList(), Collections.<URL>emptyList(), scheduler, getClass().getClassLoader(), metricGroup);
        // get restarting time metric
        Metric metric = testingReporter.getMetric(ExecutionGraph.RESTARTING_TIME_METRIC_NAME);
        assertNotNull(metric);
        assertTrue(metric instanceof Gauge);
        @SuppressWarnings("unchecked") Gauge<Long> restartingTime = (Gauge<Long>) metric;
        // check that the restarting time is 0 since it's the initial start
        assertTrue(0L == restartingTime.getValue());
        executionGraph.attachJobGraph(jobGraph.getVerticesSortedTopologicallyFromSources());
        // start execution
        executionGraph.scheduleForExecution();
        assertTrue(0L == restartingTime.getValue());
        List<ExecutionAttemptID> executionIDs = new ArrayList<>();
        for (ExecutionVertex executionVertex : executionGraph.getAllExecutionVertices()) {
            executionIDs.add(executionVertex.getCurrentExecutionAttempt().getAttemptId());
        }
        // tell execution graph that the tasks are in state running --> job status switches to state running
        for (ExecutionAttemptID executionID : executionIDs) {
            executionGraph.updateState(new TaskExecutionState(jobGraph.getJobID(), executionID, ExecutionState.RUNNING));
        }
        assertEquals(JobStatus.RUNNING, executionGraph.getState());
        assertTrue(0L == restartingTime.getValue());
        // fail the job so that it goes into state restarting
        for (ExecutionAttemptID executionID : executionIDs) {
            executionGraph.updateState(new TaskExecutionState(jobGraph.getJobID(), executionID, ExecutionState.FAILED, new Exception()));
        }
        assertEquals(JobStatus.RESTARTING, executionGraph.getState());
        long firstRestartingTimestamp = executionGraph.getStatusTimestamp(JobStatus.RESTARTING);
        // wait some time so that the restarting time gauge shows a value different from 0
        Thread.sleep(50);
        long previousRestartingTime = restartingTime.getValue();
        // check that the restarting time is monotonically increasing
        for (int i = 0; i < 10; i++) {
            long currentRestartingTime = restartingTime.getValue();
            assertTrue(currentRestartingTime >= previousRestartingTime);
            previousRestartingTime = currentRestartingTime;
        }
        // check that we have measured some restarting time
        assertTrue(previousRestartingTime > 0);
        // restart job
        testingRestartStrategy.restartExecutionGraph();
        executionIDs.clear();
        for (ExecutionVertex executionVertex : executionGraph.getAllExecutionVertices()) {
            executionIDs.add(executionVertex.getCurrentExecutionAttempt().getAttemptId());
        }
        for (ExecutionAttemptID executionID : executionIDs) {
            executionGraph.updateState(new TaskExecutionState(jobGraph.getJobID(), executionID, ExecutionState.RUNNING));
        }
        assertEquals(JobStatus.RUNNING, executionGraph.getState());
        assertTrue(firstRestartingTimestamp != 0);
        previousRestartingTime = restartingTime.getValue();
        // check that the restarting time does not increase after we've reached the running state
        for (int i = 0; i < 10; i++) {
            long currentRestartingTime = restartingTime.getValue();
            assertTrue(currentRestartingTime == previousRestartingTime);
            previousRestartingTime = currentRestartingTime;
        }
        // fail job again
        for (ExecutionAttemptID executionID : executionIDs) {
            executionGraph.updateState(new TaskExecutionState(jobGraph.getJobID(), executionID, ExecutionState.FAILED, new Exception()));
        }
        assertEquals(JobStatus.RESTARTING, executionGraph.getState());
        long secondRestartingTimestamp = executionGraph.getStatusTimestamp(JobStatus.RESTARTING);
        assertTrue(firstRestartingTimestamp != secondRestartingTimestamp);
        Thread.sleep(50);
        previousRestartingTime = restartingTime.getValue();
        // check that the restarting time is increasing again
        for (int i = 0; i < 10; i++) {
            long currentRestartingTime = restartingTime.getValue();
            assertTrue(currentRestartingTime >= previousRestartingTime);
            previousRestartingTime = currentRestartingTime;
        }
        assertTrue(previousRestartingTime > 0);
        // now lets fail the job while it is in restarting and see whether the restarting time then stops to increase
        // for this to work, we have to use a SuppressRestartException
        executionGraph.fail(new SuppressRestartsException(new Exception()));
        assertEquals(JobStatus.FAILED, executionGraph.getState());
        previousRestartingTime = restartingTime.getValue();
        for (int i = 0; i < 10; i++) {
            long currentRestartingTime = restartingTime.getValue();
            assertTrue(currentRestartingTime == previousRestartingTime);
            previousRestartingTime = currentRestartingTime;
        }
    } finally {
        executor.shutdownNow();
    }
}
Also used : JobManagerMetricGroup(org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup) MetricRegistryConfiguration(org.apache.flink.runtime.metrics.MetricRegistryConfiguration) Configuration(org.apache.flink.configuration.Configuration) Instance(org.apache.flink.runtime.instance.Instance) Scheduler(org.apache.flink.runtime.jobmanager.scheduler.Scheduler) MetricGroup(org.apache.flink.metrics.MetricGroup) JobManagerMetricGroup(org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup) TaskManagerGateway(org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway) ArrayList(java.util.ArrayList) Time(org.apache.flink.api.common.time.Time) ExecutionConfig(org.apache.flink.api.common.ExecutionConfig) SimpleSlot(org.apache.flink.runtime.instance.SimpleSlot) FlinkCompletableFuture(org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture) Gauge(org.apache.flink.metrics.Gauge) SuppressRestartsException(org.apache.flink.runtime.execution.SuppressRestartsException) ResourceID(org.apache.flink.runtime.clusterframework.types.ResourceID) TaskDeploymentDescriptor(org.apache.flink.runtime.deployment.TaskDeploymentDescriptor) ScheduledExecutorService(java.util.concurrent.ScheduledExecutorService) AllocatedSlot(org.apache.flink.runtime.jobmanager.slots.AllocatedSlot) TaskManagerLocation(org.apache.flink.runtime.taskmanager.TaskManagerLocation) MetricRegistry(org.apache.flink.runtime.metrics.MetricRegistry) AllocationID(org.apache.flink.runtime.clusterframework.types.AllocationID) ScheduledUnit(org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit) MetricReporter(org.apache.flink.metrics.reporter.MetricReporter) TaskExecutionState(org.apache.flink.runtime.taskmanager.TaskExecutionState) SuppressRestartsException(org.apache.flink.runtime.execution.SuppressRestartsException) JobException(org.apache.flink.runtime.JobException) IOException(java.io.IOException) JobGraph(org.apache.flink.runtime.jobgraph.JobGraph) JobVertex(org.apache.flink.runtime.jobgraph.JobVertex) SimpleSlot(org.apache.flink.runtime.instance.SimpleSlot) Slot(org.apache.flink.runtime.instance.Slot) AllocatedSlot(org.apache.flink.runtime.jobmanager.slots.AllocatedSlot) Metric(org.apache.flink.metrics.Metric) Test(org.junit.Test)

Example 4 with TaskManagerLocation

use of org.apache.flink.runtime.taskmanager.TaskManagerLocation in project flink by apache.

the class ExecutionVertexLocalityTest method testNoLocalityInputLargeAllToAll.

/**
	 * This test validates that vertices with too many input streams do not have a location
	 * preference any more.
	 */
@Test
public void testNoLocalityInputLargeAllToAll() throws Exception {
    final int parallelism = 100;
    final ExecutionGraph graph = createTestGraph(parallelism, true);
    // set the location for all sources to a distinct location
    for (int i = 0; i < parallelism; i++) {
        ExecutionVertex source = graph.getAllVertices().get(sourceVertexId).getTaskVertices()[i];
        TaskManagerLocation location = new TaskManagerLocation(ResourceID.generate(), InetAddress.getLoopbackAddress(), 10000 + i);
        initializeLocation(source, location);
    }
    // validate that the target vertices have no location preference
    for (int i = 0; i < parallelism; i++) {
        ExecutionVertex target = graph.getAllVertices().get(targetVertexId).getTaskVertices()[i];
        Iterator<TaskManagerLocation> preference = target.getPreferredLocations().iterator();
        assertFalse(preference.hasNext());
    }
}
Also used : TaskManagerLocation(org.apache.flink.runtime.taskmanager.TaskManagerLocation) Test(org.junit.Test)

Example 5 with TaskManagerLocation

use of org.apache.flink.runtime.taskmanager.TaskManagerLocation in project flink by apache.

the class ExecutionVertexLocalityTest method testLocalityBasedOnState.

/**
	 * This test validates that stateful vertices schedule based in the state's location
	 * (which is the prior execution's location).
	 */
@Test
public void testLocalityBasedOnState() throws Exception {
    final int parallelism = 10;
    final TaskManagerLocation[] locations = new TaskManagerLocation[parallelism];
    final ExecutionGraph graph = createTestGraph(parallelism, false);
    // set the location for all sources and targets
    for (int i = 0; i < parallelism; i++) {
        ExecutionVertex source = graph.getAllVertices().get(sourceVertexId).getTaskVertices()[i];
        ExecutionVertex target = graph.getAllVertices().get(targetVertexId).getTaskVertices()[i];
        TaskManagerLocation randomLocation = new TaskManagerLocation(ResourceID.generate(), InetAddress.getLoopbackAddress(), 10000 + i);
        TaskManagerLocation location = new TaskManagerLocation(ResourceID.generate(), InetAddress.getLoopbackAddress(), 20000 + i);
        locations[i] = location;
        initializeLocation(source, randomLocation);
        initializeLocation(target, location);
        setState(source.getCurrentExecutionAttempt(), ExecutionState.CANCELED);
        setState(target.getCurrentExecutionAttempt(), ExecutionState.CANCELED);
    }
    // mimic a restart: all vertices get re-initialized without actually being executed
    for (ExecutionJobVertex ejv : graph.getVerticesTopologically()) {
        ejv.resetForNewExecution();
    }
    // set new location for the sources and some state for the targets
    for (int i = 0; i < parallelism; i++) {
        // source location
        ExecutionVertex source = graph.getAllVertices().get(sourceVertexId).getTaskVertices()[i];
        TaskManagerLocation randomLocation = new TaskManagerLocation(ResourceID.generate(), InetAddress.getLoopbackAddress(), 30000 + i);
        initializeLocation(source, randomLocation);
        // target state
        ExecutionVertex target = graph.getAllVertices().get(targetVertexId).getTaskVertices()[i];
        target.getCurrentExecutionAttempt().setInitialState(mock(TaskStateHandles.class));
    }
    // validate that the target vertices have the state's location as the location preference
    for (int i = 0; i < parallelism; i++) {
        ExecutionVertex target = graph.getAllVertices().get(targetVertexId).getTaskVertices()[i];
        Iterator<TaskManagerLocation> preference = target.getPreferredLocations().iterator();
        assertTrue(preference.hasNext());
        assertEquals(locations[i], preference.next());
        assertFalse(preference.hasNext());
    }
}
Also used : TaskStateHandles(org.apache.flink.runtime.state.TaskStateHandles) TaskManagerLocation(org.apache.flink.runtime.taskmanager.TaskManagerLocation) Test(org.junit.Test)

Aggregations

TaskManagerLocation (org.apache.flink.runtime.taskmanager.TaskManagerLocation)84 Test (org.junit.Test)42 ResourceID (org.apache.flink.runtime.clusterframework.types.ResourceID)25 JobVertexID (org.apache.flink.runtime.jobgraph.JobVertexID)18 AccessExecutionVertex (org.apache.flink.runtime.executiongraph.AccessExecutionVertex)15 SimpleSlot (org.apache.flink.runtime.instance.SimpleSlot)15 ArrayList (java.util.ArrayList)14 JobID (org.apache.flink.api.common.JobID)13 InetAddress (java.net.InetAddress)12 ExecutionException (java.util.concurrent.ExecutionException)12 AllocationID (org.apache.flink.runtime.clusterframework.types.AllocationID)12 ExecutionState (org.apache.flink.runtime.execution.ExecutionState)12 Instance (org.apache.flink.runtime.instance.Instance)12 LocalTaskManagerLocation (org.apache.flink.runtime.taskmanager.LocalTaskManagerLocation)11 JobGraph (org.apache.flink.runtime.jobgraph.JobGraph)10 HashMap (java.util.HashMap)9 ActorTaskManagerGateway (org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway)9 Collection (java.util.Collection)8 SchedulerTestUtils.getRandomInstance (org.apache.flink.runtime.jobmanager.scheduler.SchedulerTestUtils.getRandomInstance)8 List (java.util.List)7