|
Change Parameter Type slot : AllocatedSlot to slot : PhysicalSlot in method public SlotAndLocality(slot PhysicalSlot, locality Locality) in class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality |
From |
To |
|
Change Parameter Type slotPool : SlotPool to slotPool : SlotPoolImpl in method private setupSlotPool(slotPool SlotPoolImpl, resourceManagerGateway ResourceManagerGateway, mainThreadExecutable ComponentMainThreadExecutor) : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Change Parameter Type schedulingStrategy : SchedulingStrategy to schedulingStrategy : SlotSelectionStrategy in method public SlotPoolResource(schedulingStrategy SlotSelectionStrategy) in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolResource |
From |
To |
|
Change Parameter Type releaseSlotConsumer : Consumer<Tuple3<SlotRequestId,SlotSharingGroupId,Throwable>> to releaseSlotConsumer : Consumer<Tuple2<SlotRequestId,Throwable>> in method public setReleaseSlotConsumer(releaseSlotConsumer Consumer<Tuple2<SlotRequestId,Throwable>>) : void in class org.apache.flink.runtime.jobmaster.slotpool.TestingAllocatedSlotActions |
From |
To |
|
Change Parameter Type slotPool : TestingSlotPool to slotPool : SlotPool in method private TestingSlotPoolSlotProvider(slotPool SlotPool, testingScheduler TestingScheduler) in class org.apache.flink.runtime.jobmanager.scheduler.SchedulerTestBase.TestingSlotPoolSlotProvider |
From |
To |
|
Change Parameter Type baseIterator : Iterator<Set<MultiTaskSlot>> to baseIterator : Iterator<Map<AllocationID,MultiTaskSlot>> in method private ResolvedRootSlotIterator(baseIterator Iterator<Map<AllocationID,MultiTaskSlot>>) in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.ResolvedRootSlotIterator |
From |
To |
|
Change Parameter Type slotPoolGateway : SlotPoolGateway to scheduler : Scheduler in method private allocateSlot(scheduler Scheduler, slotRequestId SlotRequestId) : CompletableFuture<LogicalSlot> in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Move Method private allocateSingleSlot(slotRequestId SlotRequestId, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : CompletableFuture<LogicalSlot> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private allocateSingleSlot(slotRequestId SlotRequestId, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : CompletableFuture<LogicalSlot> from class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl |
From |
To |
|
Move Method public allocateSlot(slotRequestId SlotRequestId, task ScheduledUnit, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : CompletableFuture<LogicalSlot> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to public allocateSlot(slotRequestId SlotRequestId, scheduledUnit ScheduledUnit, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : CompletableFuture<LogicalSlot> from class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl |
From |
To |
|
Move Method private allocateCoLocatedMultiTaskSlot(coLocationConstraint CoLocationConstraint, multiTaskSlotManager SlotSharingManager, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : SlotSharingManager.MultiTaskSlotLocality from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private allocateCoLocatedMultiTaskSlot(coLocationConstraint CoLocationConstraint, multiTaskSlotManager SlotSharingManager, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : SlotSharingManager.MultiTaskSlotLocality from class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl |
From |
To |
|
Move Method private allocateMultiTaskSlot(groupId AbstractID, slotSharingManager SlotSharingManager, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : SlotSharingManager.MultiTaskSlotLocality from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private allocateMultiTaskSlot(groupId AbstractID, slotSharingManager SlotSharingManager, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : SlotSharingManager.MultiTaskSlotLocality from class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl |
From |
To |
|
Move Method private releaseSharedSlot(slotRequestId SlotRequestId, slotSharingGroupId SlotSharingGroupId, cause Throwable) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private releaseSharedSlot(slotRequestId SlotRequestId, slotSharingGroupId SlotSharingGroupId, cause Throwable) : void from class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl |
From |
To |
|
Move Method private allocateSharedSlot(slotRequestId SlotRequestId, task ScheduledUnit, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : CompletableFuture<LogicalSlot> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private allocateSharedSlot(slotRequestId SlotRequestId, scheduledUnit ScheduledUnit, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : CompletableFuture<LogicalSlot> from class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl |
From |
To |
|
Pull Up Attribute private ssc1 : SimpleSlotContext from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected ssc1 : SimpleSlotContext from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private aidX : AllocationID from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected aidX : AllocationID from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private aid1 : AllocationID from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected aid1 : AllocationID from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private aid3 : AllocationID from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected aid3 : AllocationID from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private tml1 : TaskManagerLocation from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected tml1 : TaskManagerLocation from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private resourceProfile : ResourceProfile from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected resourceProfile : ResourceProfile from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private taskManagerGateway : TaskManagerGateway from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected taskManagerGateway : TaskManagerGateway from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private tml2 : TaskManagerLocation from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected tml2 : TaskManagerLocation from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private tmlX : TaskManagerLocation from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected tmlX : TaskManagerLocation from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private tml3 : TaskManagerLocation from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected tml3 : TaskManagerLocation from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private aid2 : AllocationID from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected aid2 : AllocationID from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private ssc4 : SimpleSlotContext from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected ssc4 : SimpleSlotContext from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private aid4 : AllocationID from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected aid4 : AllocationID from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private ssc3 : SimpleSlotContext from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected ssc3 : SimpleSlotContext from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private candidates : Set<SlotContext> from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected candidates : Set<SlotContext> from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private ssc2 : SimpleSlotContext from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected ssc2 : SimpleSlotContext from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Pull Up Attribute private tml4 : TaskManagerLocation from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to protected tml4 : TaskManagerLocation from class org.apache.flink.runtime.clusterframework.types.SlotSelectionStrategyTestBase |
From |
To |
|
Push Down Attribute private idleSlotTimeout : Time from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private idleSlotTimeout : Time from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Attribute private rpcTimeout : Time from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private rpcTimeout : Time from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Attribute private allocatedSlots : AllocatedSlots from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private allocatedSlots : AllocatedSlots from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Attribute private jobMasterId : JobMasterId from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private jobMasterId : JobMasterId from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Attribute private registeredTaskManagers : HashSet<ResourceID> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private registeredTaskManagers : HashSet<ResourceID> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Attribute private jobManagerAddress : String from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private jobManagerAddress : String from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Attribute private resourceManagerGateway : ResourceManagerGateway from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private resourceManagerGateway : ResourceManagerGateway from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Attribute private pendingRequests : DualKeyMap<SlotRequestId,AllocationID,PendingRequest> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private pendingRequests : DualKeyMap<SlotRequestId,AllocationID,PendingRequest> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Attribute private jobId : JobID from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private jobId : JobID from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Attribute private availableSlots : AvailableSlots from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private availableSlots : AvailableSlots from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Attribute private clock : Clock from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private clock : Clock from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Attribute private waitingForResourceManager : HashMap<SlotRequestId,PendingRequest> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private waitingForResourceManager : HashMap<SlotRequestId,PendingRequest> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Change Variable Type resolvedRootSlot1 : SlotSharingManager.MultiTaskSlotLocality to slotInfos : Collection<SlotInfo> in method public testGetResolvedSlot() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManagerTest |
From |
To |
|
Change Variable Type multiTaskSlots : Set<MultiTaskSlot> to multiTaskSlots : Map<AllocationID,MultiTaskSlot> in method public release(cause Throwable) : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot |
From |
To |
|
Change Variable Type match : SlotContext to match : Optional<SlotSelectionStrategy.SlotInfoAndLocality> in method public matchNoRequirements() : void in class org.apache.flink.runtime.clusterframework.types.LocationPreferenceSlotSelectionStrategyTest |
From |
To |
|
Change Variable Type slotPoolGateway : SlotPoolGateway to slotPoolGateway : SlotPool in method public testSimpleCoLocatedSlotScheduling() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolCoLocationTest |
From |
To |
|
Change Variable Type slotPoolGateway : SlotPoolGateway to slotPool : SlotPoolImpl in method public testSingleQueuedSharedSlotScheduling() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolSlotSharingTest |
From |
To |
|
Change Variable Type currentReleaseSlotConsumer : Consumer<Tuple3<SlotRequestId,SlotSharingGroupId,Throwable>> to currentReleaseSlotConsumer : Consumer<Tuple2<SlotRequestId,Throwable>> in method public releaseSlot(slotRequestId SlotRequestId, cause Throwable) : void in class org.apache.flink.runtime.jobmaster.slotpool.TestingAllocatedSlotActions |
From |
To |
|
Change Variable Type match : SlotContext to match : Optional<SlotSelectionStrategy.SlotInfoAndLocality> in method public matchPreferredLocation() : void in class org.apache.flink.runtime.clusterframework.types.LocationPreferenceSlotSelectionStrategyTest |
From |
To |
|
Change Variable Type match : SlotContext to match : Optional<SlotSelectionStrategy.SlotInfoAndLocality> in method public matchPreviousLocationAvailableButAlsoBlacklisted() : void in class org.apache.flink.runtime.clusterframework.types.LocationPreferenceSlotSelectionStrategyTest |
From |
To |
|
Change Variable Type slotPoolGateway : SlotPoolGateway to scheduler : Scheduler in method public testFulfillingSlotRequestsWithUnusedOfferedSlots() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Change Variable Type emptyTaskExecutorFuture : CompletableFuture<SerializableOptional<ResourceID>> to resourceIdOptional : Optional<ResourceID> in method private internalFailAllocation(allocationId AllocationID, cause Exception) : void in class org.apache.flink.runtime.jobmaster.JobMaster |
From |
To |
|
Change Variable Type allocatedSlots : SlotPool.AllocatedSlots to allocatedSlots : SlotPoolImpl.AllocatedSlots in method public testOperations() : void in class org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotsTest |
From |
To |
|
Change Variable Type match : SlotContext to match : Optional<SlotSelectionStrategy.SlotInfoAndLocality> in method public testResourceProfileRespected() : void in class org.apache.flink.runtime.clusterframework.types.LocationPreferenceSlotSelectionStrategyTest |
From |
To |
|
Change Variable Type availableSlots : SlotPool.AvailableSlots to availableSlots : SlotPoolImpl.AvailableSlots in method public testAddAndRemove() : void in class org.apache.flink.runtime.jobmaster.slotpool.AvailableSlotsTest |
From |
To |
|
Change Variable Type slotPoolGateway : SlotPoolGateway to scheduler : Scheduler in method public testAllocationFulfilledByReturnedSlot() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Change Variable Type booleanCompletableFuture : CompletableFuture<Boolean> to booleanCompletableFuture : boolean in method public testSingleQueuedSharedSlotScheduling() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolSlotSharingTest |
From |
To |
|
Change Variable Type slotPoolGateway : SlotPoolGateway to scheduler : Scheduler in method public testSlotRequestCancellationUponFailingRequest() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Change Variable Type offerFuture1 : CompletableFuture<Boolean> to offerFuture1 : boolean in method public testQueuedMultipleSlotSharingGroups() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolSlotSharingTest |
From |
To |
|
Change Variable Type slotPoolGateway : SlotPoolGateway to slotPool : SlotPoolImpl in method public testQueuedSharedSlotScheduling() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolSlotSharingTest |
From |
To |
|
Change Variable Type multiTaskSlots : Set<MultiTaskSlot> to multiTaskSlots : Map<AllocationID,MultiTaskSlot> in method public size() : int in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.ResolvedRootSlotValues |
From |
To |
|
Change Variable Type slotPoolGateway : SlotPoolGateway to slotPoolGateway : SlotPool in method public testFailingQueuedSharedSlotScheduling() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolSlotSharingTest |
From |
To |
|
Change Variable Type slotPoolGateway : SlotPoolGateway to slotPool : SlotPoolImpl in method public testQueuedMultipleSlotSharingGroups() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolSlotSharingTest |
From |
To |
|
Change Variable Type responseFuture : CompletableFuture<SerializableOptional<ResourceID>> to responseFuture : Optional<ResourceID> in method public testFailingAllocationFailsPendingSlotRequests() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Change Variable Type match : SlotContext to match : Optional<SlotSelectionStrategy.SlotInfoAndLocality> in method public matchPreferredLocationNotAvailable() : void in class org.apache.flink.runtime.clusterframework.types.LocationPreferenceSlotSelectionStrategyTest |
From |
To |
|
Change Variable Type slotPoolGateway : SlotPoolGateway to slotPool : SlotPoolImpl in method public testShutdownReleasesAllSlots() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Change Variable Type offerFuture2 : CompletableFuture<Boolean> to offerFuture2 : boolean in method public testQueuedMultipleSlotSharingGroups() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolSlotSharingTest |
From |
To |
|
Change Variable Type slotPoolGateway : SlotPoolGateway to scheduler : Scheduler in method public testReleasingIdleSlotFailed() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Change Variable Type offerFuture : CompletableFuture<Boolean> to offerFuture : boolean in method public testQueuedSharedSlotScheduling() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolSlotSharingTest |
From |
To |
|
Change Variable Type emptyTaskExecutorFuture : CompletableFuture<SerializableOptional<ResourceID>> to emptyTaskExecutorFuture : Optional<ResourceID> in method public testFreeFailedSlots() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Rename Method public returnAllocatedSlot(logicalSlot LogicalSlot) : CompletableFuture<Boolean> renamed to public returnLogicalSlot(logicalSlot LogicalSlot) : void in class org.apache.flink.runtime.executiongraph.utils.SimpleSlotProvider |
From |
To |
|
Rename Method public returnAllocatedSlot(logicalSlot LogicalSlot) : CompletableFuture<Boolean> renamed to public returnLogicalSlot(logicalSlot LogicalSlot) : void in class org.apache.flink.runtime.jobmaster.SlotOwner |
From |
To |
|
Rename Method public failSync(t Throwable) : void renamed to public fail(t Throwable) : void in class org.apache.flink.runtime.executiongraph.Execution |
From |
To |
|
Rename Method public failSync(cause Throwable) : void renamed to public fail(cause Throwable) : void in class org.apache.flink.runtime.jobmaster.slotpool.DummyPayload |
From |
To |
|
Rename Method public returnAllocatedSlot(logicalSlot LogicalSlot) : CompletableFuture<Boolean> renamed to public returnLogicalSlot(logicalSlot LogicalSlot) : void in class org.apache.flink.runtime.executiongraph.ExecutionTest.SingleSlotTestingSlotOwner |
From |
To |
|
Rename Method public failSync(cause Throwable) : void renamed to public fail(cause Throwable) : void in class org.apache.flink.runtime.jobmaster.LogicalSlot.Payload |
From |
To |
|
Rename Method public returnAllocatedSlot(logicalSlot LogicalSlot) : CompletableFuture<Boolean> renamed to public returnLogicalSlot(logicalSlot LogicalSlot) : void in class org.apache.flink.runtime.jobmanager.slots.TestingSlotOwner |
From |
To |
|
Rename Method public matchPreviousAllocationOverridesPreferredLocation() : void renamed to public testResourceProfileRespected() : void in class org.apache.flink.runtime.clusterframework.types.LocationPreferenceSlotSelectionStrategyTest |
From |
To |
|
Rename Method public getSlotPoolGateway() : SlotPoolGateway renamed to public getSlotPool() : SlotPoolImpl in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolResource |
From |
To |
|
Rename Method public returnAllocatedSlot(logicalSlot LogicalSlot) : CompletableFuture<Boolean> renamed to public returnLogicalSlot(logicalSlot LogicalSlot) : void in class org.apache.flink.runtime.instance.Instance |
From |
To |
|
Rename Method public failSync(cause Throwable) : void renamed to public fail(cause Throwable) : void in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlotTest.CountingFailPayload |
From |
To |
|
Rename Method public failSync(cause Throwable) : void renamed to public fail(cause Throwable) : void in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlotTest.ManualTestingPayload |
From |
To |
|
Rename Method public failSync(cause Throwable) : void renamed to public fail(cause Throwable) : void in class org.apache.flink.runtime.jobmaster.TestingPayload |
From |
To |
|
Push Down Method public releaseTaskManager(resourceId ResourceID, cause Exception) : CompletableFuture<Acknowledge> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to public releaseTaskManager(resourceId ResourceID, cause Exception) : boolean from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private clear() : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private clear() : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private requestNewAllocatedSlot(slotRequestId SlotRequestId, resourceProfile ResourceProfile, allocationTimeout Time) : CompletableFuture<AllocatedSlot> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private requestNewAllocatedSlotInternal(slotRequestId SlotRequestId, resourceProfile ResourceProfile, timeout Time) : CompletableFuture<AllocatedSlot> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method package getWaitingForResourceManager() : Map<SlotRequestId,PendingRequest> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to package getWaitingForResourceManager() : Map<SlotRequestId,PendingRequest> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private releaseTaskManagerInternal(resourceId ResourceID, cause Exception) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private releaseTaskManagerInternal(resourceId ResourceID, cause Exception) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method package getPendingRequests() : DualKeyMap<SlotRequestId,AllocationID,PendingRequest> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to package getPendingRequests() : DualKeyMap<SlotRequestId,AllocationID,PendingRequest> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method public matchPreviousLocationNotAvailableButByLocality() : void from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to public matchPreviousLocationNotAvailableButByLocality() : void from class org.apache.flink.runtime.clusterframework.types.PreviousAllocationSlotSelectionStrategyTest |
From |
To |
|
Push Down Method protected timeoutPendingSlotRequest(slotRequestId SlotRequestId) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to protected timeoutPendingSlotRequest(slotRequestId SlotRequestId) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method public connectToResourceManager(resourceManagerGateway ResourceManagerGateway) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to public connectToResourceManager(resourceManagerGateway ResourceManagerGateway) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private failPendingRequest(pendingRequest PendingRequest, e Exception) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private failPendingRequest(pendingRequest PendingRequest, e Exception) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private pollMatchingPendingRequest(slot AllocatedSlot) : PendingRequest from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private pollMatchingPendingRequest(slot AllocatedSlot) : PendingRequest from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method package triggerCheckIdleSlot() : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to package triggerCheckIdleSlot() : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private checkIdleSlot() : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private checkIdleSlot() : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private tryFulfillSlotRequestOrMakeAvailable(allocatedSlot AllocatedSlot) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private tryFulfillSlotRequestOrMakeAvailable(allocatedSlot AllocatedSlot) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method public start(jobMasterId JobMasterId, newJobManagerAddress String) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to public start(jobMasterId JobMasterId, newJobManagerAddress String, componentMainThreadExecutor ComponentMainThreadExecutor) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method protected getAllocatedSlots() : AllocatedSlots from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to protected getAllocatedSlots() : AllocatedSlots from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method public SlotPool(rpcService RpcService, jobId JobID, schedulingStrategy SchedulingStrategy, clock Clock, rpcTimeout Time, idleSlotTimeout Time) from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to public SlotPoolImpl(jobId JobID, clock Clock, rpcTimeout Time, idleSlotTimeout Time) from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private stashRequestWaitingForResourceManager(pendingRequest PendingRequest) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private stashRequestWaitingForResourceManager(pendingRequest PendingRequest) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method public disconnectResourceManager() : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to public disconnectResourceManager() : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method protected SlotPool(rpcService RpcService, jobId JobID, schedulingStrategy SchedulingStrategy) from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to public SlotPoolImpl(jobId JobID) from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private removePendingRequest(requestId SlotRequestId) : PendingRequest from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private removePendingRequest(requestId SlotRequestId) : PendingRequest from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method public failAllocation(allocationID AllocationID, cause Exception) : CompletableFuture<SerializableOptional<ResourceID>> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to public failAllocation(allocationID AllocationID, cause Exception) : Optional<ResourceID> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method protected getAvailableSlots() : AvailableSlots from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to protected getAvailableSlots() : AvailableSlots from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method public matchPreviousLocationNotAvailableAndAllOthersBlacklisted() : void from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to public matchPreviousLocationNotAvailableAndAllOthersBlacklisted() : void from class org.apache.flink.runtime.clusterframework.types.PreviousAllocationSlotSelectionStrategyTest |
From |
To |
|
Push Down Method public matchPreviousLocationNotAvailableAndSomeOthersBlacklisted() : void from class org.apache.flink.runtime.clusterframework.types.SlotProfileTest to public matchPreviousLocationNotAvailableAndSomeOthersBlacklisted() : void from class org.apache.flink.runtime.clusterframework.types.PreviousAllocationSlotSelectionStrategyTest |
From |
To |
|
Push Down Method private requestSlotFromResourceManager(resourceManagerGateway ResourceManagerGateway, pendingRequest PendingRequest) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private requestSlotFromResourceManager(resourceManagerGateway ResourceManagerGateway, pendingRequest PendingRequest) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private tryFailingAllocatedSlot(allocationID AllocationID, cause Exception) : CompletableFuture<SerializableOptional<ResourceID>> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private tryFailingAllocatedSlot(allocationID AllocationID, cause Exception) : Optional<ResourceID> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method public registerTaskManager(resourceID ResourceID) : CompletableFuture<Acknowledge> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to public registerTaskManager(resourceID ResourceID) : boolean from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private releaseSingleSlot(slotRequestId SlotRequestId, cause Throwable) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private releaseSingleSlot(slotRequestId SlotRequestId, cause Throwable) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private printStatus() : String from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private printStatus() : String from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private slotRequestToResourceManagerFailed(slotRequestID SlotRequestId, failure Throwable) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private slotRequestToResourceManagerFailed(slotRequestID SlotRequestId, failure Throwable) : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method public offerSlot(taskManagerLocation TaskManagerLocation, taskManagerGateway TaskManagerGateway, slotOffer SlotOffer) : CompletableFuture<Boolean> from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to package offerSlot(taskManagerLocation TaskManagerLocation, taskManagerGateway TaskManagerGateway, slotOffer SlotOffer) : boolean from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Push Down Method private scheduledLogStatus() : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPool to private scheduledLogStatus() : void from class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Rename Variable slotPoolGateway : SlotPoolGateway to slotPool : SlotPoolImpl in method public testSingleQueuedSharedSlotScheduling() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolSlotSharingTest |
From |
To |
|
Rename Variable slotPoolGateway : SlotPoolGateway to scheduler : Scheduler in method public testAllocationFulfilledByReturnedSlot() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Rename Variable resolvedRootSlot1 : SlotSharingManager.MultiTaskSlotLocality to slotInfos : Collection<SlotInfo> in method public testGetResolvedSlot() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManagerTest |
From |
To |
|
Rename Variable slotPoolGateway : SlotPoolGateway to slotPool : SlotPoolImpl in method public testQueuedMultipleSlotSharingGroups() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolSlotSharingTest |
From |
To |
|
Rename Variable slotPoolGateway : SlotPoolGateway to scheduler : Scheduler in method public testSlotRequestCancellationUponFailingRequest() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Rename Variable slotPoolGateway : SlotPoolGateway to slotPool : SlotPoolImpl in method public testShutdownReleasesAllSlots() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Rename Variable slotPoolGateway : SlotPoolGateway to scheduler : Scheduler in method public testReleasingIdleSlotFailed() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Rename Variable slotPoolGateway : SlotPoolGateway to scheduler : Scheduler in method public testFulfillingSlotRequestsWithUnusedOfferedSlots() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Rename Variable slotPoolGateway : SlotPoolGateway to slotPool : SlotPoolImpl in method public testQueuedSharedSlotScheduling() : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolSlotSharingTest |
From |
To |
|
Rename Variable emptyTaskExecutorFuture : CompletableFuture<SerializableOptional<ResourceID>> to resourceIdOptional : Optional<ResourceID> in method private internalFailAllocation(allocationId AllocationID, cause Exception) : void in class org.apache.flink.runtime.jobmaster.JobMaster |
From |
To |
|
Change Return Type CompletableFuture<Boolean> to void in method public returnLogicalSlot(logicalSlot LogicalSlot) : void in class org.apache.flink.runtime.instance.Instance |
From |
To |
|
Change Return Type CompletableFuture<Boolean> to boolean in method package containsAllocatedSlot(allocationId AllocationID) : boolean in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolInteractionsTest.TestingSlotPool |
From |
To |
|
Change Return Type CompletableFuture<Boolean> to void in method public returnLogicalSlot(logicalSlot LogicalSlot) : void in class org.apache.flink.runtime.executiongraph.ExecutionTest.SingleSlotTestingSlotOwner |
From |
To |
|
Change Return Type SlotPoolGateway to SlotPoolImpl in method public getSlotPool() : SlotPoolImpl in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolResource |
From |
To |
|
Change Return Type CompletableFuture<Acknowledge> to void in method public releaseSlot(slotRequestId SlotRequestId, cause Throwable) : void in class org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotActions |
From |
To |
|
Change Return Type CompletableFuture<Integer> to int in method package getNumberOfWaitingForResourceRequests() : int in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolInteractionsTest.TestingSlotPool |
From |
To |
|
Change Return Type CompletableFuture<Acknowledge> to void in method public cancelSlotRequest(slotRequestId SlotRequestId, slotSharingGroupId SlotSharingGroupId, cause Throwable) : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotProvider |
From |
To |
|
Change Return Type CompletableFuture<Boolean> to boolean in method package containsAvailableSlot(allocationId AllocationID) : boolean in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolInteractionsTest.TestingSlotPool |
From |
To |
|
Change Return Type CompletableFuture<SerializableOptional<ResourceID>> to Optional<ResourceID> in method public failAllocation(allocationID AllocationID, cause Exception) : Optional<ResourceID> in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Change Return Type CompletableFuture<Acknowledge> to void in method public releaseSlot(slotRequestId SlotRequestId, cause Throwable) : void in class org.apache.flink.runtime.jobmaster.slotpool.TestingAllocatedSlotActions |
From |
To |
|
Change Return Type CompletableFuture<Boolean> to void in method public returnLogicalSlot(logicalSlot LogicalSlot) : void in class org.apache.flink.runtime.jobmaster.SlotOwner |
From |
To |
|
Change Return Type CompletableFuture<Boolean> to void in method public returnLogicalSlot(logicalSlot LogicalSlot) : void in class org.apache.flink.runtime.executiongraph.utils.SimpleSlotProvider |
From |
To |
|
Change Return Type CompletableFuture<Acknowledge> to void in method private releaseEmptyTaskManager(resourceId ResourceID) : void in class org.apache.flink.runtime.jobmaster.JobMaster |
From |
To |
|
Change Return Type CompletableFuture<Boolean> to boolean in method package offerSlot(taskManagerLocation TaskManagerLocation, taskManagerGateway TaskManagerGateway, slotOffer SlotOffer) : boolean in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Change Return Type CompletableFuture<Acknowledge> to void in method public cancelSlotRequest(slotRequestId SlotRequestId, slotSharingGroupId SlotSharingGroupId, cause Throwable) : void in class org.apache.flink.runtime.executiongraph.TestingSlotProvider |
From |
To |
|
Change Return Type CompletableFuture<Acknowledge> to boolean in method public registerTaskManager(resourceID ResourceID) : boolean in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Change Return Type CompletableFuture<Acknowledge> to void in method public releaseSlot(slotRequestId SlotRequestId, cause Throwable) : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolInteractionsTest.TestingSlotPool |
From |
To |
|
Change Return Type CompletableFuture<Acknowledge> to void in method public cancelSlotRequest(slotRequestId SlotRequestId, slotSharingGroupId SlotSharingGroupId, cause Throwable) : void in class org.apache.flink.runtime.executiongraph.utils.SimpleSlotProvider |
From |
To |
|
Change Return Type SlotPoolGateway to void in method private setupSlotPool(slotPool SlotPoolImpl, resourceManagerGateway ResourceManagerGateway, mainThreadExecutable ComponentMainThreadExecutor) : void in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Change Return Type CompletableFuture<Acknowledge> to void in method public cancelSlotRequest(slotRequestId SlotRequestId, slotSharingGroupId SlotSharingGroupId, cause Throwable) : void in class org.apache.flink.runtime.executiongraph.ProgrammedSlotProvider |
From |
To |
|
Change Return Type AllocatedSlot to PhysicalSlot in method public getSlot() : PhysicalSlot in class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality |
From |
To |
|
Change Return Type CompletableFuture<SerializableOptional<ResourceID>> to Optional<ResourceID> in method private tryFailingAllocatedSlot(allocationID AllocationID, cause Exception) : Optional<ResourceID> in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Change Return Type CompletableFuture<Acknowledge> to boolean in method public releaseTaskManager(resourceId ResourceID, cause Exception) : boolean in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Change Return Type CompletableFuture<Boolean> to void in method public returnLogicalSlot(logicalSlot LogicalSlot) : void in class org.apache.flink.runtime.jobmanager.slots.TestingSlotOwner |
From |
To |
|
Change Return Type CompletableFuture<Acknowledge> to Acknowledge in method private suspendExecution(cause Exception) : Acknowledge in class org.apache.flink.runtime.jobmaster.JobMaster |
From |
To |
|
Change Return Type CompletableFuture<Integer> to int in method package getNumberOfPendingRequests() : int in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolInteractionsTest.TestingSlotPool |
From |
To |
|
Change Attribute Type slot : AllocatedSlot to slot : PhysicalSlot in class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality |
From |
To |
|
Change Attribute Type releaseSlotConsumer : Consumer<Tuple3<SlotRequestId,SlotSharingGroupId,Throwable>> to releaseSlotConsumer : Consumer<Tuple2<SlotRequestId,Throwable>> in class org.apache.flink.runtime.jobmaster.slotpool.TestingAllocatedSlotActions |
From |
To |
|
Change Attribute Type slotPool : SlotPool to slotPool : SlotPoolImpl in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolResource |
From |
To |
|
Change Attribute Type slotProvider : SlotProvider to scheduler : TestingScheduler in class org.apache.flink.runtime.jobmanager.scheduler.SchedulerTestBase.TestingSlotPoolSlotProvider |
From |
To |
|
Change Attribute Type baseIterator : Iterator<Set<MultiTaskSlot>> to baseIterator : Iterator<Map<AllocationID,MultiTaskSlot>> in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.ResolvedRootSlotIterator |
From |
To |
|
Change Attribute Type resolvedRootSlots : Map<TaskManagerLocation,Set<MultiTaskSlot>> to resolvedRootSlots : Map<TaskManagerLocation,Map<AllocationID,MultiTaskSlot>> in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager |
From |
To |
|
Change Attribute Type schedulingStrategy : SchedulingStrategy to schedulingStrategy : SlotSelectionStrategy in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolResource |
From |
To |
|
Change Attribute Type slotPool : TestingSlotPool to slotPool : SlotPool in class org.apache.flink.runtime.jobmanager.scheduler.SchedulerTestBase.TestingSlotPoolSlotProvider |
From |
To |
|
Change Attribute Type rpcService : RpcService to mainThreadExecutor : ComponentMainThreadExecutor in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolResource |
From |
To |
|
Rename Parameter task : ScheduledUnit to scheduledUnit : ScheduledUnit in method public allocateSlot(slotRequestId SlotRequestId, scheduledUnit ScheduledUnit, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : CompletableFuture<LogicalSlot> in class org.apache.flink.runtime.jobmaster.slotpool.SlotProvider |
From |
To |
|
Rename Parameter task : ScheduledUnit to scheduledUnit : ScheduledUnit in method private allocateSharedSlot(slotRequestId SlotRequestId, scheduledUnit ScheduledUnit, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : CompletableFuture<LogicalSlot> in class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl |
From |
To |
|
Rename Parameter allocationTimeout : Time to timeout : Time in method private requestNewAllocatedSlotInternal(slotRequestId SlotRequestId, resourceProfile ResourceProfile, timeout Time) : CompletableFuture<AllocatedSlot> in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl |
From |
To |
|
Rename Parameter task : ScheduledUnit to scheduledUnit : ScheduledUnit in method public allocateSlot(scheduledUnit ScheduledUnit, allowQueued boolean, slotProfile SlotProfile, allocationTimeout Time) : CompletableFuture<LogicalSlot> in class org.apache.flink.runtime.jobmaster.slotpool.SlotProvider |
From |
To |
|
Rename Parameter timeout : Time to allocationTimeout : Time in method public allocateSlot(slotRequestId SlotRequestId, scheduledUnit ScheduledUnit, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : CompletableFuture<LogicalSlot> in class org.apache.flink.runtime.jobmaster.slotpool.SlotProvider |
From |
To |
|
Rename Parameter allowQueued : boolean to allowQueuedScheduling : boolean in method public allocateSlot(slotRequestId SlotRequestId, scheduledUnit ScheduledUnit, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : CompletableFuture<LogicalSlot> in class org.apache.flink.runtime.jobmaster.slotpool.SlotProvider |
From |
To |
|
Rename Parameter slotPoolGateway : SlotPoolGateway to scheduler : Scheduler in method private allocateSlot(scheduler Scheduler, slotRequestId SlotRequestId) : CompletableFuture<LogicalSlot> in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolTest |
From |
To |
|
Rename Parameter task : ScheduledUnit to scheduledUnit : ScheduledUnit in method public allocateSlot(slotRequestId SlotRequestId, scheduledUnit ScheduledUnit, slotProfile SlotProfile, allowQueuedScheduling boolean, allocationTimeout Time) : CompletableFuture<LogicalSlot> in class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl |
From |
To |
|
Rename Parameter timeout : Time to allocationTimeout : Time in method public allocateSlot(scheduledUnit ScheduledUnit, allowQueued boolean, slotProfile SlotProfile, allocationTimeout Time) : CompletableFuture<LogicalSlot> in class org.apache.flink.runtime.jobmaster.slotpool.SlotProvider |
From |
To |