|
Rename Method public useRealNonMockNetworkEnvironment() : Builder renamed to public useRealNonMockShuffleEnvironment() : Builder in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment.Builder |
From |
To |
|
Rename Method public setNetworkEnvironment(networkEnvironment NetworkEnvironment) : TaskManagerServicesBuilder renamed to public setShuffleEnvironment(shuffleEnvironment ShuffleEnvironment<?,?>) : TaskManagerServicesBuilder in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesBuilder |
From |
To |
|
Rename Method public getUnreleasedPartitions() : Collection<ResultPartitionID> renamed to public getPartitionsOccupyingLocalResources() : Collection<ResultPartitionID> in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Rename Method public isShutdown() : boolean renamed to public isClosed() : boolean in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Rename Method private createNetworkEnvironment(taskManagerLocation ResourceID, localCommunication boolean, configuration Configuration, testingRpcService RpcService, mockNetworkEnvironment boolean) : NetworkEnvironment renamed to private createShuffleEnvironment(taskManagerLocation ResourceID, localCommunication boolean, configuration Configuration, testingRpcService RpcService, mockShuffleEnvironment boolean) : ShuffleEnvironment<?,?> in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment |
From |
To |
|
Rename Method public setNetworkEnvironment(optionalNetworkEnvironment NetworkEnvironment) : Builder renamed to public setShuffleEnvironment(optionalShuffleEnvironment ShuffleEnvironment<?,?>) : Builder in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment.Builder |
From |
To |
|
Rename Method public shutdown() : void renamed to public close() : void in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Rename Method public getNetworkEnvironment() : NetworkEnvironment renamed to public getShuffleEnvironment() : ShuffleEnvironment in class org.apache.flink.runtime.taskexecutor.TaskManagerServices |
From |
To |
|
Change Parameter Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method private TaskBuilder(shuffleEnvironment ShuffleEnvironment<?,?>) in class org.apache.flink.runtime.taskmanager.TaskTest.TaskBuilder |
From |
To |
|
Change Parameter Type optionalNetworkEnvironment : NetworkEnvironment to optionalShuffleEnvironment : ShuffleEnvironment<?,?> in method public setShuffleEnvironment(optionalShuffleEnvironment ShuffleEnvironment<?,?>) : Builder in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment.Builder |
From |
To |
|
Change Parameter Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method private TaskSubmissionTestEnvironment(jobId JobID, jobMasterId JobMasterId, slotSize int, testingJobMasterGateway TestingJobMasterGateway, configuration Configuration, taskManagerActionListeners List<Tuple3<ExecutionAttemptID,ExecutionState,CompletableFuture<Void>>>, testingRpcService TestingRpcService, shuffleEnvironment ShuffleEnvironment<?,?>) in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment |
From |
To |
|
Change Parameter Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method public setShuffleEnvironment(shuffleEnvironment ShuffleEnvironment<?,?>) : TaskManagerServicesBuilder in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesBuilder |
From |
To |
|
Change Parameter Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method package TaskManagerServices(taskManagerLocation TaskManagerLocation, memoryManager MemoryManager, ioManager IOManager, shuffleEnvironment ShuffleEnvironment, kvStateService KvStateService, broadcastVariableManager BroadcastVariableManager, taskSlotTable TaskSlotTable, jobManagerTable JobManagerTable, jobLeaderService JobLeaderService, taskManagerStateStore TaskExecutorLocalStateStoresManager, taskEventDispatcher TaskEventDispatcher) in class org.apache.flink.runtime.taskexecutor.TaskManagerServices |
From |
To |
|
Change Parameter Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method public Task(jobInformation JobInformation, taskInformation TaskInformation, executionAttemptID ExecutionAttemptID, slotAllocationId AllocationID, subtaskIndex int, attemptNumber int, resultPartitionDeploymentDescriptors Collection<ResultPartitionDeploymentDescriptor>, inputGateDeploymentDescriptors Collection<InputGateDeploymentDescriptor>, targetSlotNumber int, memManager MemoryManager, ioManager IOManager, shuffleEnvironment ShuffleEnvironment<?,?>, kvStateService KvStateService, bcVarManager BroadcastVariableManager, taskEventDispatcher TaskEventDispatcher, taskStateManager TaskStateManager, taskManagerActions TaskManagerActions, inputSplitProvider InputSplitProvider, checkpointResponder CheckpointResponder, aggregateManager GlobalAggregateManager, blobService BlobCacheService, libraryCache LibraryCacheManager, fileCache FileCache, taskManagerConfig TaskManagerRuntimeInfo, metricGroup TaskMetricGroup, resultPartitionConsumableNotifier ResultPartitionConsumableNotifier, partitionProducerStateChecker PartitionProducerStateChecker, executor Executor) in class org.apache.flink.runtime.taskmanager.Task |
From |
To |
|
Rename Variable network : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method public createTask(invokable Class<? extends AbstractInvokable>, taskConfig StreamConfig, taskManagerConfig Configuration, taskStateManager TestTaskStateManager, taskManagerActions TaskManagerActions) : Task in class org.apache.flink.streaming.runtime.tasks.StreamTaskTest |
From |
To |
|
Rename Variable networkEnv : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method public testConcurrentAsyncCheckpointCannotFailFinishedStreamTask() : void in class org.apache.flink.streaming.runtime.tasks.StreamTaskTerminationTest |
From |
To |
|
Rename Variable networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method public testUpdateTaskInputPartitionsFailure() : void in class org.apache.flink.runtime.taskexecutor.TaskExecutorSubmissionTest |
From |
To |
|
Rename Variable networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method private createShuffleEnvironment(taskManagerLocation ResourceID, localCommunication boolean, configuration Configuration, testingRpcService RpcService, mockShuffleEnvironment boolean) : ShuffleEnvironment<?,?> in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment |
From |
To |
|
Rename Variable network : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method public fromConfiguration(taskManagerServicesConfiguration TaskManagerServicesConfiguration, taskManagerMetricGroup MetricGroup, taskIOExecutor Executor) : TaskManagerServices in class org.apache.flink.runtime.taskexecutor.TaskManagerServices |
From |
To |
|
Rename Variable networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method public main(args String[]) : void in class org.apache.flink.runtime.util.JvmExitOnFatalErrorTest.ProcessEntryPoint |
From |
To |
|
Rename Variable networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method private createTask(streamConfig StreamConfig, taskConfig Configuration, state StreamStateHandle, mode int) : Task in class org.apache.flink.streaming.runtime.tasks.InterruptSensitiveRestoreTest |
From |
To |
|
Rename Variable networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method private createTask(invokableClass Class<? extends AbstractInvokable>) : Task in class org.apache.flink.streaming.runtime.tasks.SynchronousCheckpointITCase |
From |
To |
|
Rename Variable network : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method private createTask(op StreamOperator<?>, backend StateBackend, checkpointResponder CheckpointResponder, failOnCheckpointErrors boolean) : Task in class org.apache.flink.streaming.runtime.tasks.TaskCheckpointingBehaviourTest |
From |
To |
|
Change Return Type NetworkEnvironment to ShuffleEnvironment in method public getShuffleEnvironment() : ShuffleEnvironment in class org.apache.flink.runtime.taskexecutor.TaskManagerServices |
From |
To |
|
Change Return Type SingleInputGate[] to Collection<SingleInputGate> in method public createInputGates(ownerName String, executionAttemptID ExecutionAttemptID, partitionProducerStateProvider PartitionProducerStateProvider, inputGateDeploymentDescriptors Collection<InputGateDeploymentDescriptor>, parentGroup MetricGroup, inputGroup MetricGroup, buffersGroup MetricGroup) : Collection<SingleInputGate> in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Change Return Type NetworkEnvironment to ShuffleEnvironment<?,?> in method private createShuffleEnvironment(taskManagerLocation ResourceID, localCommunication boolean, configuration Configuration, testingRpcService RpcService, mockShuffleEnvironment boolean) : ShuffleEnvironment<?,?> in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment |
From |
To |
|
Change Return Type ResultPartition[] to Collection<ResultPartition> in method public createResultPartitionWriters(ownerName String, executionAttemptID ExecutionAttemptID, resultPartitionDeploymentDescriptors Collection<ResultPartitionDeploymentDescriptor>, outputGroup MetricGroup, buffersGroup MetricGroup) : Collection<ResultPartition> in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Rename Attribute networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Rename Attribute networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in class org.apache.flink.runtime.taskmanager.TaskTest.TaskBuilder |
From |
To |
|
Rename Attribute mockNetworkEnvironment : boolean to mockShuffleEnvironment : boolean in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment.Builder |
From |
To |
|
Rename Attribute networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesBuilder |
From |
To |
|
Rename Attribute isShutdown : boolean to isClosed : boolean in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Rename Attribute networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in class org.apache.flink.runtime.taskexecutor.TaskManagerServices |
From |
To |
|
Rename Attribute optionalNetworkEnvironment : Optional<NetworkEnvironment> to optionalShuffleEnvironment : Optional<ShuffleEnvironment<?,?>> in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment.Builder |
From |
To |
|
Rename Attribute networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in class org.apache.flink.runtime.taskmanager.TaskAsyncCallTest |
From |
To |
|
Rename Attribute networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in class org.apache.flink.runtime.taskexecutor.TaskExecutor |
From |
To |
|
Change Variable Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method private createShuffleEnvironment(taskManagerLocation ResourceID, localCommunication boolean, configuration Configuration, testingRpcService RpcService, mockShuffleEnvironment boolean) : ShuffleEnvironment<?,?> in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment |
From |
To |
|
Change Variable Type network : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method public fromConfiguration(taskManagerServicesConfiguration TaskManagerServicesConfiguration, taskManagerMetricGroup MetricGroup, taskIOExecutor Executor) : TaskManagerServices in class org.apache.flink.runtime.taskexecutor.TaskManagerServices |
From |
To |
|
Change Variable Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method public main(args String[]) : void in class org.apache.flink.runtime.util.JvmExitOnFatalErrorTest.ProcessEntryPoint |
From |
To |
|
Change Variable Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method private createTask(invokableClass Class<? extends AbstractInvokable>) : Task in class org.apache.flink.streaming.runtime.tasks.SynchronousCheckpointITCase |
From |
To |
|
Change Variable Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method private createTask(streamConfig StreamConfig, taskConfig Configuration, state StreamStateHandle, mode int) : Task in class org.apache.flink.streaming.runtime.tasks.InterruptSensitiveRestoreTest |
From |
To |
|
Change Variable Type network : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method private createTask(op StreamOperator<?>, backend StateBackend, checkpointResponder CheckpointResponder, failOnCheckpointErrors boolean) : Task in class org.apache.flink.streaming.runtime.tasks.TaskCheckpointingBehaviourTest |
From |
To |
|
Change Variable Type network : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method public createTask(invokable Class<? extends AbstractInvokable>, taskConfig StreamConfig, taskManagerConfig Configuration, taskStateManager TestTaskStateManager, taskManagerActions TaskManagerActions) : Task in class org.apache.flink.streaming.runtime.tasks.StreamTaskTest |
From |
To |
|
Change Variable Type networkEnv : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method public testConcurrentAsyncCheckpointCannotFailFinishedStreamTask() : void in class org.apache.flink.streaming.runtime.tasks.StreamTaskTerminationTest |
From |
To |
|
Change Variable Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method public testUpdateTaskInputPartitionsFailure() : void in class org.apache.flink.runtime.taskexecutor.TaskExecutorSubmissionTest |
From |
To |
|
Change Attribute Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in class org.apache.flink.runtime.taskmanager.TaskAsyncCallTest |
From |
To |
|
Change Attribute Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in class org.apache.flink.runtime.taskexecutor.TaskExecutor |
From |
To |
|
Change Attribute Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Change Attribute Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in class org.apache.flink.runtime.taskmanager.TaskTest.TaskBuilder |
From |
To |
|
Change Attribute Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesBuilder |
From |
To |
|
Change Attribute Type networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in class org.apache.flink.runtime.taskexecutor.TaskManagerServices |
From |
To |
|
Change Attribute Type optionalNetworkEnvironment : Optional<NetworkEnvironment> to optionalShuffleEnvironment : Optional<ShuffleEnvironment<?,?>> in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment.Builder |
From |
To |
|
Rename Parameter optionalNetworkEnvironment : NetworkEnvironment to optionalShuffleEnvironment : ShuffleEnvironment<?,?> in method public setShuffleEnvironment(optionalShuffleEnvironment ShuffleEnvironment<?,?>) : Builder in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment.Builder |
From |
To |
|
Rename Parameter executionId : ExecutionAttemptID to executionAttemptID : ExecutionAttemptID in method public createResultPartitionWriters(ownerName String, executionAttemptID ExecutionAttemptID, resultPartitionDeploymentDescriptors Collection<ResultPartitionDeploymentDescriptor>, outputGroup MetricGroup, buffersGroup MetricGroup) : Collection<ResultPartition> in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Rename Parameter networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method private TaskSubmissionTestEnvironment(jobId JobID, jobMasterId JobMasterId, slotSize int, testingJobMasterGateway TestingJobMasterGateway, configuration Configuration, taskManagerActionListeners List<Tuple3<ExecutionAttemptID,ExecutionState,CompletableFuture<Void>>>, testingRpcService TestingRpcService, shuffleEnvironment ShuffleEnvironment<?,?>) in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment |
From |
To |
|
Rename Parameter networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method public setShuffleEnvironment(shuffleEnvironment ShuffleEnvironment<?,?>) : TaskManagerServicesBuilder in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesBuilder |
From |
To |
|
Rename Parameter networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment in method package TaskManagerServices(taskManagerLocation TaskManagerLocation, memoryManager MemoryManager, ioManager IOManager, shuffleEnvironment ShuffleEnvironment, kvStateService KvStateService, broadcastVariableManager BroadcastVariableManager, taskSlotTable TaskSlotTable, jobManagerTable JobManagerTable, jobLeaderService JobLeaderService, taskManagerStateStore TaskExecutorLocalStateStoresManager, taskEventDispatcher TaskEventDispatcher) in class org.apache.flink.runtime.taskexecutor.TaskManagerServices |
From |
To |
|
Rename Parameter networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method public Task(jobInformation JobInformation, taskInformation TaskInformation, executionAttemptID ExecutionAttemptID, slotAllocationId AllocationID, subtaskIndex int, attemptNumber int, resultPartitionDeploymentDescriptors Collection<ResultPartitionDeploymentDescriptor>, inputGateDeploymentDescriptors Collection<InputGateDeploymentDescriptor>, targetSlotNumber int, memManager MemoryManager, ioManager IOManager, shuffleEnvironment ShuffleEnvironment<?,?>, kvStateService KvStateService, bcVarManager BroadcastVariableManager, taskEventDispatcher TaskEventDispatcher, taskStateManager TaskStateManager, taskManagerActions TaskManagerActions, inputSplitProvider InputSplitProvider, checkpointResponder CheckpointResponder, aggregateManager GlobalAggregateManager, blobService BlobCacheService, libraryCache LibraryCacheManager, fileCache FileCache, taskManagerConfig TaskManagerRuntimeInfo, metricGroup TaskMetricGroup, resultPartitionConsumableNotifier ResultPartitionConsumableNotifier, partitionProducerStateChecker PartitionProducerStateChecker, executor Executor) in class org.apache.flink.runtime.taskmanager.Task |
From |
To |
|
Rename Parameter executionId : ExecutionAttemptID to executionAttemptID : ExecutionAttemptID in method public createInputGates(ownerName String, executionAttemptID ExecutionAttemptID, partitionProducerStateProvider PartitionProducerStateProvider, inputGateDeploymentDescriptors Collection<InputGateDeploymentDescriptor>, parentGroup MetricGroup, inputGroup MetricGroup, buffersGroup MetricGroup) : Collection<SingleInputGate> in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Rename Parameter taskName : String to ownerName : String in method public createResultPartitionWriters(ownerName String, executionAttemptID ExecutionAttemptID, resultPartitionDeploymentDescriptors Collection<ResultPartitionDeploymentDescriptor>, outputGroup MetricGroup, buffersGroup MetricGroup) : Collection<ResultPartition> in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Rename Parameter mockNetworkEnvironment : boolean to mockShuffleEnvironment : boolean in method private createShuffleEnvironment(taskManagerLocation ResourceID, localCommunication boolean, configuration Configuration, testingRpcService RpcService, mockShuffleEnvironment boolean) : ShuffleEnvironment<?,?> in class org.apache.flink.runtime.taskexecutor.TaskSubmissionTestEnvironment |
From |
To |
|
Rename Parameter taskName : String to ownerName : String in method public createInputGates(ownerName String, executionAttemptID ExecutionAttemptID, partitionProducerStateProvider PartitionProducerStateProvider, inputGateDeploymentDescriptors Collection<InputGateDeploymentDescriptor>, parentGroup MetricGroup, inputGroup MetricGroup, buffersGroup MetricGroup) : Collection<SingleInputGate> in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Rename Parameter networkEnvironment : NetworkEnvironment to shuffleEnvironment : ShuffleEnvironment<?,?> in method private TaskBuilder(shuffleEnvironment ShuffleEnvironment<?,?>) in class org.apache.flink.runtime.taskmanager.TaskTest.TaskBuilder |
From |
To |