
org.apache.flink.runtime.jobmaster.slotpool.SlotPool Maven / Gradle / Ivy
/*
* Licensed to the Apache Software Foundation (ASF) under one
* or more contributor license agreements. See the NOTICE file
* distributed with this work for additional information
* regarding copyright ownership. The ASF licenses this file
* to you under the Apache License, Version 2.0 (the
* "License"); you may not use this file except in compliance
* with the License. You may obtain a copy of the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS,
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
* See the License for the specific language governing permissions and
* limitations under the License.
*/
package org.apache.flink.runtime.jobmaster.slotpool;
import org.apache.flink.api.common.time.Time;
import org.apache.flink.runtime.clusterframework.types.AllocationID;
import org.apache.flink.runtime.clusterframework.types.ResourceID;
import org.apache.flink.runtime.clusterframework.types.ResourceProfile;
import org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor;
import org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway;
import org.apache.flink.runtime.jobmaster.AllocatedSlotReport;
import org.apache.flink.runtime.jobmaster.JobMasterId;
import org.apache.flink.runtime.jobmaster.SlotInfo;
import org.apache.flink.runtime.jobmaster.SlotRequestId;
import org.apache.flink.runtime.resourcemanager.ResourceManagerGateway;
import org.apache.flink.runtime.taskexecutor.slot.SlotOffer;
import org.apache.flink.runtime.taskmanager.TaskManagerLocation;
import javax.annotation.Nullable;
import java.util.Collection;
import java.util.Collections;
import java.util.Optional;
import java.util.concurrent.CompletableFuture;
/** The Interface of a slot pool that manages slots. */
public interface SlotPool extends AllocatedSlotActions, AutoCloseable {
// ------------------------------------------------------------------------
// lifecycle
// ------------------------------------------------------------------------
void start(
JobMasterId jobMasterId,
String newJobManagerAddress,
ComponentMainThreadExecutor jmMainThreadScheduledExecutor)
throws Exception;
void close();
// ------------------------------------------------------------------------
// resource manager connection
// ------------------------------------------------------------------------
/**
* Connects the SlotPool to the given ResourceManager. After this method is called, the SlotPool
* will be able to request resources from the given ResourceManager.
*
* @param resourceManagerGateway The RPC gateway for the resource manager.
*/
void connectToResourceManager(ResourceManagerGateway resourceManagerGateway);
/**
* Disconnects the slot pool from its current Resource Manager. After this call, the pool will
* not be able to request further slots from the Resource Manager, and all currently pending
* requests to the resource manager will be canceled.
*
* The slot pool will still be able to serve slots from its internal pool.
*/
void disconnectResourceManager();
// ------------------------------------------------------------------------
// registering / un-registering TaskManagers and slots
// ------------------------------------------------------------------------
/**
* Registers a TaskExecutor with the given {@link ResourceID} at {@link SlotPool}.
*
* @param resourceID identifying the TaskExecutor to register
* @return true iff a new resource id was registered
*/
boolean registerTaskManager(ResourceID resourceID);
/**
* Releases a TaskExecutor with the given {@link ResourceID} from the {@link SlotPool}.
*
* @param resourceId identifying the TaskExecutor which shall be released from the SlotPool
* @param cause for the releasing of the TaskManager
* @return true iff a given registered resource id was removed
*/
boolean releaseTaskManager(final ResourceID resourceId, final Exception cause);
/**
* Offers multiple slots to the {@link SlotPool}. The slot offerings can be individually
* accepted or rejected by returning the collection of accepted slot offers.
*
* @param taskManagerLocation from which the slot offers originate
* @param taskManagerGateway to talk to the slot offerer
* @param offers slot offers which are offered to the {@link SlotPool}
* @return A collection of accepted slot offers. The remaining slot offers are implicitly
* rejected.
*/
Collection offerSlots(
TaskManagerLocation taskManagerLocation,
TaskManagerGateway taskManagerGateway,
Collection offers);
// ------------------------------------------------------------------------
// allocating and disposing slots
// ------------------------------------------------------------------------
/**
* Returns a list of {@link SlotInfoWithUtilization} objects about all slots that are currently
* available in the slot pool.
*
* @return a list of {@link SlotInfoWithUtilization} objects about all slots that are currently
* available in the slot pool.
*/
Collection getAvailableSlotsInformation();
/**
* Returns a list of {@link SlotInfo} objects about all slots that are currently allocated in
* the slot pool.
*
* @return a list of {@link SlotInfo} objects about all slots that are currently allocated in
* the slot pool.
*/
Collection getAllocatedSlotsInformation();
/**
* Allocates the available slot with the given allocation id under the given request id for the
* given requirement profile. The slot must be able to fulfill the requirement profile,
* otherwise an {@link IllegalStateException} will be thrown.
*
* @param slotRequestId identifying the requested slot
* @param allocationID the allocation id of the requested available slot
* @param requirementProfile resource profile of the requirement for which to allocate the slot
* @return the previously available slot with the given allocation id, if a slot with this
* allocation id exists
*/
Optional allocateAvailableSlot(
SlotRequestId slotRequestId,
AllocationID allocationID,
ResourceProfile requirementProfile);
/**
* Request the allocation of a new slot from the resource manager. This method will not return a
* slot from the already available slots from the pool, but instead will add a new slot to that
* pool that is immediately allocated and returned.
*
* @param slotRequestId identifying the requested slot
* @param resourceProfile resource profile that specifies the resource requirements for the
* requested slot
* @param timeout timeout for the allocation procedure
* @return a newly allocated slot that was previously not available.
*/
default CompletableFuture requestNewAllocatedSlot(
SlotRequestId slotRequestId, ResourceProfile resourceProfile, @Nullable Time timeout) {
return requestNewAllocatedSlot(
slotRequestId, resourceProfile, Collections.emptyList(), timeout);
}
/**
* Request the allocation of a new slot from the resource manager. This method will not return a
* slot from the already available slots from the pool, but instead will add a new slot to that
* pool that is immediately allocated and returned.
*
* @param slotRequestId identifying the requested slot
* @param resourceProfile resource profile that specifies the resource requirements for the
* requested slot
* @param preferredAllocations preferred allocations for the new allocated slot
* @param timeout timeout for the allocation procedure
* @return a newly allocated slot that was previously not available.
*/
CompletableFuture requestNewAllocatedSlot(
SlotRequestId slotRequestId,
ResourceProfile resourceProfile,
Collection preferredAllocations,
@Nullable Time timeout);
/**
* Requests the allocation of a new batch slot from the resource manager. Unlike the normal
* slot, a batch slot will only time out if the slot pool does not contain a suitable slot.
* Moreover, it won't react to failure signals from the resource manager.
*
* @param slotRequestId identifying the requested slot
* @param resourceProfile resource profile that specifies the resource requirements for the
* requested batch slot
* @return a future which is completed with newly allocated batch slot
*/
default CompletableFuture requestNewAllocatedBatchSlot(
SlotRequestId slotRequestId, ResourceProfile resourceProfile) {
return requestNewAllocatedBatchSlot(
slotRequestId, resourceProfile, Collections.emptyList());
}
CompletableFuture requestNewAllocatedBatchSlot(
SlotRequestId slotRequestId,
ResourceProfile resourceProfile,
Collection preferredAllocations);
/**
* Disables batch slot request timeout check. Invoked when someone else wants to take over the
* timeout check responsibility.
*/
void disableBatchSlotRequestTimeoutCheck();
/**
* Create report about the allocated slots belonging to the specified task manager.
*
* @param taskManagerId identifies the task manager
* @return the allocated slots on the task manager
*/
AllocatedSlotReport createAllocatedSlotReport(ResourceID taskManagerId);
/**
* Sets whether the underlying job is currently restarting or not.
*
* @param isJobRestarting whether the job is restarting or not
*/
void setIsJobRestarting(boolean isJobRestarting);
}