|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method package deleteInternal(jobId JobID, key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Parameter Type blobCache : BlobCache to blobService : BlobCacheService in method private createTask(invokable Class<? extends AbstractInvokable>, blobService BlobCacheService, libCache LibraryCacheManager, networkEnvironment NetworkEnvironment, consumableNotifier ResultPartitionConsumableNotifier, partitionProducerStateChecker PartitionProducerStateChecker, executor Executor) : Task in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Change Parameter Type blobCache : BlobCache to blobService : BlobCacheService in method public Task(jobInformation JobInformation, taskInformation TaskInformation, executionAttemptID ExecutionAttemptID, slotAllocationId AllocationID, subtaskIndex int, attemptNumber int, resultPartitionDeploymentDescriptors Collection<ResultPartitionDeploymentDescriptor>, inputGateDeploymentDescriptors Collection<InputGateDeploymentDescriptor>, targetSlotNumber int, taskStateHandles TaskStateSnapshot, memManager MemoryManager, ioManager IOManager, networkEnvironment NetworkEnvironment, bcVarManager BroadcastVariableManager, taskManagerActions TaskManagerActions, inputSplitProvider InputSplitProvider, checkpointResponder CheckpointResponder, 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 |
|
Change Parameter Type requiredJarFiles : Collection<BlobKey> to requiredJarFiles : Collection<PermanentBlobKey> in method public registerJob(id JobID, requiredJarFiles Collection<PermanentBlobKey>, requiredClasspaths Collection<URL>) : void in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager |
From |
To |
|
Change Parameter Type requiredJarFiles : Collection<BlobKey> to requiredJarFiles : Collection<PermanentBlobKey> in method public registerTask(jobId JobID, task ExecutionAttemptID, requiredJarFiles Collection<PermanentBlobKey>, requiredClasspaths Collection<URL>) : void in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method package put(service BlobService, jobId JobID, data byte[], blobType BlobKey.BlobType) : BlobKey in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Change Parameter Type requiredJarFiles : Collection<BlobKey> to requiredJarFiles : Collection<PermanentBlobKey> in method public registerJob(id JobID, requiredJarFiles Collection<PermanentBlobKey>, requiredClasspaths Collection<URL>) : void in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager |
From |
To |
|
Change Parameter Type requiredJarFiles : Collection<BlobKey> to requiredJarFiles : Collection<PermanentBlobKey> in method public ClassloadingProps(blobManagerPort int, requiredJarFiles Collection<PermanentBlobKey>, requiredClasspaths Collection<URL>) in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferFailsStore(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testConcurrentPutOperations(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferSuccessfulGet(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Parameter Type blobCache : BlobCache to blobService : BlobCacheService in method public JobManagerConnection(jobID JobID, resourceID ResourceID, jobMasterGateway JobMasterGateway, taskManagerActions TaskManagerActions, checkpointResponder CheckpointResponder, blobService BlobCacheService, libraryCacheManager LibraryCacheManager, resultPartitionConsumableNotifier ResultPartitionConsumableNotifier, partitionStateChecker PartitionProducerStateChecker) in class org.apache.flink.runtime.taskexecutor.JobManagerConnection |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testConcurrentGetOperations(jobId JobID, blobType BlobKey.BlobType, cacheAccessesHAStore boolean) : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method public deleteFromCache(jobId JobID, key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferSuccessfulGet(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Change Parameter Type blobCache : BlobCache to blobService : BlobCacheService in method private createTask(invokable Class<? extends AbstractInvokable>, blobService BlobCacheService, libCache LibraryCacheManager, config Configuration, execConfig ExecutionConfig) : Task in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method public deleteFromCache(jobId JobID, key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Parameter Type requiredJarFileBlobKeys : Collection<BlobKey> to requiredJarFileBlobKeys : Collection<PermanentBlobKey> in method public JobInformation(jobId JobID, jobName String, serializedExecutionConfig SerializedValue<ExecutionConfig>, jobConfiguration Configuration, requiredJarFileBlobKeys Collection<PermanentBlobKey>, requiredClasspathURLs Collection<URL>) in class org.apache.flink.runtime.executiongraph.JobInformation |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testConcurrentPutOperations(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Parameter Type key : BlobKey to key : PermanentBlobKey in method public getFile(jobId JobID, key PermanentBlobKey) : File in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method public deleteFromCache(jobId JobID, key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method public getFile(jobId JobID, key TransientBlobKey) : File in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferFails(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferFails(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testGetFailsStore(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Change Parameter Type requiredJarFiles : Collection<BlobKey> to requiredJarFiles : Collection<PermanentBlobKey> in method public registerTask(id JobID, execution ExecutionAttemptID, requiredJarFiles Collection<PermanentBlobKey>, requiredClasspaths Collection<URL>) : void in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager |
From |
To |
|
Change Parameter Type requiredJarFiles : Collection<BlobKey> to requiredJarFiles : Collection<PermanentBlobKey> in method public registerJob(id JobID, requiredJarFiles Collection<PermanentBlobKey>, requiredClasspaths Collection<URL>) : void in class org.apache.flink.runtime.execution.librarycache.LibraryCacheManager |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testGetFailsDuringLookup(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Change Parameter Type permanentBlob : boolean to blobType : BlobKey.BlobType in method private testContentAddressableStream(blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobClientTest |
From |
To |
|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method public getFile(jobId JobID, key TransientBlobKey) : File in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testBlobFetchWithTooManyFailures(config Configuration, blobStore BlobStore, jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheRetriesTest |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testBlobFetchRetries(config Configuration, blobStore BlobStore, jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheRetriesTest |
From |
To |
|
Change Parameter Type permanentBlob : boolean to blobType : BlobKey.BlobType in method private testContentAddressableBuffer(blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobClientTest |
From |
To |
|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method public getFile(key TransientBlobKey) : File in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Change Parameter Type keys : Collection<BlobKey> to keys : Collection<? extends BlobKey> in method public checkFilesExist(jobId JobID, keys Collection<? extends BlobKey>, blobService PermanentBlobService, doThrow boolean) : int in class org.apache.flink.runtime.blob.BlobCacheCleanupTest |
From |
To |
|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method public deleteFromCache(key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Change Parameter Type key : BlobKey to key : PermanentBlobKey in method public getFile(jobId JobID, key PermanentBlobKey) : File in class org.apache.flink.runtime.blob.PermanentBlobCache |
From |
To |
|
Change Parameter Type highlyAvailable : boolean to blobType : BlobKey.BlobType in method private putBuffer(jobId JobID, value byte[], blobType BlobKey.BlobType) : BlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method public deleteFromCache(key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method public getFile(jobId JobID, key TransientBlobKey) : File in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferFailsIncoming(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Change Parameter Type blobCache : BlobCache to blobService : BlobCacheService in method private createTask(invokable Class<? extends AbstractInvokable>, blobService BlobCacheService, libCache LibraryCacheManager) : Task in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Change Parameter Type requiredLibraries : Collection<BlobKey> to requiredLibraries : Collection<PermanentBlobKey> in method package LibraryCacheEntry(requiredLibraries Collection<PermanentBlobKey>, requiredClasspaths Collection<URL>, libraryURLs URL[], initialReference ExecutionAttemptID, classLoaderResolveOrder FlinkUserCodeClassLoaders.ResolveOrder) in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager.LibraryCacheEntry |
From |
To |
|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method public deleteFromCache(key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Change Parameter Type key : BlobKey to key : PermanentBlobKey in method public addBlob(key PermanentBlobKey) : void in class org.apache.flink.runtime.jobgraph.JobGraph |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testGetFailsDuringLookup(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerGetTest |
From |
To |
|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method public getFile(key TransientBlobKey) : File in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Parameter Type requiredJarFiles : Collection<BlobKey> to requiredJarFiles : Collection<PermanentBlobKey> in method public registerTask(id JobID, execution ExecutionAttemptID, requiredJarFiles Collection<PermanentBlobKey>, requiredClasspaths Collection<URL>) : void in class org.apache.flink.runtime.execution.librarycache.LibraryCacheManager |
From |
To |
|
Change Parameter Type requiredLibraries : Collection<BlobKey> to requiredLibraries : Collection<PermanentBlobKey> in method public register(task ExecutionAttemptID, requiredLibraries Collection<PermanentBlobKey>, requiredClasspaths Collection<URL>) : void in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager.LibraryCacheEntry |
From |
To |
|
Change Parameter Type requiredJarFiles : List<BlobKey> to requiredJarFiles : List<PermanentBlobKey> in method public ExecutionGraph(futureExecutor ScheduledExecutorService, ioExecutor Executor, jobId JobID, jobName String, jobConfig Configuration, serializedConfig SerializedValue<ExecutionConfig>, timeout Time, restartStrategy RestartStrategy, failoverStrategyFactory FailoverStrategy.Factory, requiredJarFiles List<PermanentBlobKey>, requiredClasspaths List<URL>, slotProvider SlotProvider, userClassLoader ClassLoader) in class org.apache.flink.runtime.executiongraph.ExecutionGraph |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private uploadFileGetTest(config Configuration, jobId JobID, shutdownServerAfterUpload boolean, cacheHasAccessToFs boolean, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheSuccessTest |
From |
To |
|
Change Parameter Type requiredJarFiles : Collection<BlobKey> to requiredJarFiles : Collection<PermanentBlobKey> in method private createTaskDeploymentDescriptor(jobId JobID, jobName String, jobVertexId JobVertexID, executionAttemptId ExecutionAttemptID, serializedExecutionConfig SerializedValue<ExecutionConfig>, taskName String, numberOfKeyGroups int, subtaskIndex int, parallelism int, attemptNumber int, jobConfiguration Configuration, taskConfiguration Configuration, invokableClassName String, producedPartitions Collection<ResultPartitionDeploymentDescriptor>, inputGates Collection<InputGateDeploymentDescriptor>, requiredJarFiles Collection<PermanentBlobKey>, requiredClasspaths Collection<URL>, targetSlotNumber int) : TaskDeploymentDescriptor in class org.apache.flink.runtime.taskmanager.TaskManagerTest |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferFailsStore(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testGetFailsFromCorruptFile(jobId JobID, blobType BlobKey.BlobType, corruptOnHAStore boolean, config Configuration, blobStore BlobStore, expectedException ExpectedException) : void in class org.apache.flink.runtime.blob.BlobCacheCorruptionTest |
From |
To |
|
Change Parameter Type key : BlobKey to key : TransientBlobKey in method public getFile(key TransientBlobKey) : File in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Change Parameter Type permanentBlob : boolean to blobType : BlobKey.BlobType in method package putInputStream(jobId JobID, inputStream InputStream, blobType BlobKey.BlobType) : BlobKey in class org.apache.flink.runtime.blob.BlobClient |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testConcurrentGetOperations(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerGetTest |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testGetFailsIncoming(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferFailsIncoming(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testGetFailsFromCorruptFile(jobId JobID, blobType BlobKey.BlobType, corruptOnHAStore boolean) : void in class org.apache.flink.runtime.blob.BlobCacheCorruptionTest |
From |
To |
|
Change Parameter Type permanentBlob : boolean to blobType : BlobKey.BlobType in method private testGetFailsDuringStreaming(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobClientTest |
From |
To |
|
Change Parameter Type highlyAvailable : boolean to blobType : BlobKey.BlobType in method private putInputStream(jobId JobID, inputStream InputStream, blobType BlobKey.BlobType) : BlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Parameter Type blobCache : BlobCache to blobService : BlobCacheService in method private createTask(invokable Class<? extends AbstractInvokable>, blobService BlobCacheService, libCache LibraryCacheManager, networkEnvironment NetworkEnvironment, consumableNotifier ResultPartitionConsumableNotifier, partitionProducerStateChecker PartitionProducerStateChecker, executor Executor, taskManagerConfig Configuration, execConfig ExecutionConfig) : Task in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutChunkedStreamSuccessfulGet(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Change Parameter Type permanentBlob : boolean to blobType : BlobKey.BlobType in method package putBuffer(jobId JobID, value byte[], offset int, len int, blobType BlobKey.BlobType) : BlobKey in class org.apache.flink.runtime.blob.BlobClient |
From |
To |
|
Change Parameter Type key : BlobKey to key : PermanentBlobKey in method public getFile(jobId JobID, key PermanentBlobKey) : File in class org.apache.flink.runtime.blob.PermanentBlobService |
From |
To |
|
Change Parameter Type permanentBlob : boolean to blobType : BlobKey.BlobType in method private sendPutHeader(outputStream OutputStream, jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobClient |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testJobCleanup(blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerDeleteTest |
From |
To |
|
Change Parameter Type highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutStreamSuccessfulGet(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testDeleteTransientAlreadyDeleted(jobId JobID) : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Change Variable Type key : BlobKey to key : PermanentBlobKey in method public registerTask(jobId JobID, task ExecutionAttemptID, requiredJarFiles Collection<PermanentBlobKey>, requiredClasspaths Collection<URL>) : void in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager |
From |
To |
|
Change Variable Type requiredJars : List<BlobKey> to requiredJars : List<PermanentBlobKey> in method public testSerialization() : void in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorTest |
From |
To |
|
Change Variable Type requiredJarFiles : Collection<BlobKey> to requiredJarFiles : Collection<PermanentBlobKey> in method public retrieveClassLoader(jobID JobID, jobManager JobManagerGateway, config Configuration, highAvailabilityServices HighAvailabilityServices, timeout Time) : ClassLoader in class org.apache.flink.runtime.client.JobClient |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private uploadFileGetTest(config Configuration, jobId JobID, shutdownServerAfterUpload boolean, cacheHasAccessToFs boolean, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheSuccessTest |
From |
To |
|
Change Variable Type keys : Collection<BlobKey> to keys : Collection<PermanentBlobKey> in method public testRegisterAndDownload() : void in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManagerTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testGetFailsIncoming(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Change Variable Type cache1 : BlobCache to cache1 : BlobCacheService in method public testBlobServerRecovery(config Configuration, blobStore BlobStore) : void in class org.apache.flink.runtime.blob.BlobServerRecoveryTest |
From |
To |
|
Change Variable Type key1 : BlobKey to key1 : TransientBlobKey in method private testDeleteTransient(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobServerDeleteTest |
From |
To |
|
Change Variable Type key2b : BlobKey to key2b : TransientBlobKey in method private testPutStreamTransientSuccessfulGet(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type key1a : BlobKey to key1a : TransientBlobKey in method private testPutChunkedStreamTransientSuccessfulGet(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type keys : List<BlobKey> to keys : List<PermanentBlobKey> in method public testLibraryCacheManagerTaskCleanup() : void in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManagerTest |
From |
To |
|
Change Variable Type key2b : BlobKey to key2b : TransientBlobKey in method private testDeleteTransient(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobServerDeleteTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method public main(args String[]) : void in class org.apache.flink.runtime.util.JvmExitOnFatalErrorTest.ProcessEntryPoint |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testConcurrentGetOperations(jobId JobID, blobType BlobKey.BlobType, cacheAccessesHAStore boolean) : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService 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 key2a : BlobKey to key2a : TransientBlobKey in method private testDeleteTransient(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobServerDeleteTest |
From |
To |
|
Change Variable Type key : BlobKey to key : PermanentBlobKey in method public uploadJarFiles(serverAddress InetSocketAddress, clientConfig Configuration, jobId JobID, jars List<Path>) : List<PermanentBlobKey> in class org.apache.flink.runtime.blob.BlobClient |
From |
To |
|
Change Variable Type key1b : BlobKey to key1b : TransientBlobKey in method private testPutChunkedStreamTransientSuccessfulGet(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type blobKey : BlobKey to blobKey : TransientBlobKey in method private testConcurrentDeleteOperations(jobId JobID) : void in class org.apache.flink.runtime.blob.BlobServerDeleteTest |
From |
To |
|
Change Variable Type keys : List<BlobKey> to keys : List<PermanentBlobKey> in method public testJobDeferredCleanup() : void in class org.apache.flink.runtime.blob.BlobCacheCleanupTest |
From |
To |
|
Change Variable Type key2b : BlobKey to key2b : TransientBlobKey in method private testDelete(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testConcurrentDeleteOperations(jobId JobID) : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testPutChunkedStreamTransientSuccessfulGet(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method public testTaskSubmission() : void in class org.apache.flink.runtime.taskexecutor.TaskExecutorTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method private createTask(invokable Class<? extends AbstractInvokable>, config Configuration, execConfig ExecutionConfig) : Task in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method public testGetFailsHaStoreForJobHa() : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testGetFailsFromCorruptFile(jobId JobID, blobType BlobKey.BlobType, corruptOnHAStore boolean, config Configuration, blobStore BlobStore, expectedException ExpectedException) : void in class org.apache.flink.runtime.blob.BlobCacheCorruptionTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method private createTask() : Task in class org.apache.flink.runtime.taskmanager.TaskAsyncCallTest |
From |
To |
|
Change Variable Type blobKeys : List<BlobKey> to blobKeys : List<PermanentBlobKey> in method public uploadUserJars(blobServerAddress InetSocketAddress, blobClientConfig Configuration) : void in class org.apache.flink.runtime.jobgraph.JobGraph |
From |
To |
|
Change Variable Type blobKey : BlobKey to blobKey : PermanentBlobKey in method public testGetFailsHaStoreForJobHa() : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Change Variable Type keys : List<BlobKey> to keys : ArrayList<PermanentBlobKey> in method public testRecoveryRegisterAndDownload() : void in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheRecoveryITCase |
From |
To |
|
Change Variable Type key2a : BlobKey to key2a : TransientBlobKey in method private testDelete(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Change Variable Type blobKey : BlobKey to blobKey : TransientBlobKey in method private testConcurrentDeleteOperations(jobId JobID) : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Change Variable Type cache0 : BlobCache to cache0 : BlobCacheService in method public testBlobCacheRecovery(config Configuration, blobStore BlobStore) : void in class org.apache.flink.runtime.blob.BlobCacheRecoveryTest |
From |
To |
|
Change Variable Type key2a : BlobKey to key2a : TransientBlobKey in method private testPutChunkedStreamTransientSuccessfulGet(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type dataKey2 : BlobKey to dataKey2 : PermanentBlobKey in method public testRegisterAndDownload() : void in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManagerTest |
From |
To |
|
Change Variable Type key2a : BlobKey to key2a : TransientBlobKey in method private testPutStreamTransientSuccessfulGet(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method public testTriggerPartitionStateUpdate() : void in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Change Variable Type keys2 : List<BlobKey> to keys2 : List<PermanentBlobKey> in method public testLibraryCacheManagerJobCleanup() : void in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManagerTest |
From |
To |
|
Change Variable Type lastSubmittedFile : HashMap<String,BlobKey> to lastSubmittedFile : HashMap<String,TransientBlobKey> in method protected respondAsLeader(ctx ChannelHandlerContext, routed Routed, jobManagerGateway JobManagerGateway) : void in class org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandler |
From |
To |
|
Change Variable Type key2b : BlobKey to key2b : TransientBlobKey in method private testPutChunkedStreamTransientSuccessfulGet(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type dataKey1 : BlobKey to dataKey1 : PermanentBlobKey in method public testRegisterAndDownload() : void in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManagerTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method public testConcurrentAsyncCheckpointCannotFailFinishedStreamTask() : void in class org.apache.flink.streaming.runtime.tasks.StreamTaskTerminationTest |
From |
To |
|
Change Variable Type key : BlobKey to key : PermanentBlobKey in method public testJobDeferredCleanup() : void in class org.apache.flink.runtime.blob.BlobCacheCleanupTest |
From |
To |
|
Change Variable Type key1b : BlobKey to key1b : TransientBlobKey in method private testPutStreamTransientSuccessfulGet(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type key : BlobKey to key : TransientBlobKey in method private testDeleteTransientAlreadyDeleted(jobId JobID) : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testPutBufferFails(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type keys : List<BlobKey> to keys : List<PermanentBlobKey> in method private testConcurrentPutOperations(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type keys : List<BlobKey> to keys : List<PermanentBlobKey> in method public testLibraryCacheManagerMixedJobTaskCleanup() : void in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManagerTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testPutStreamTransientSuccessfulGet(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type key : BlobKey to key : TransientBlobKey in method private testDeleteTransientLocalFails(jobId JobID) : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Change Variable Type keys1 : List<BlobKey> to keys1 : List<PermanentBlobKey> in method public testLibraryCacheManagerJobCleanup() : void in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManagerTest |
From |
To |
|
Change Variable Type blobKeyFuture : CompletableFuture<BlobKey> to blobKeyFuture : CompletableFuture<TransientBlobKey> in method protected respondAsLeader(ctx ChannelHandlerContext, routed Routed, jobManagerGateway JobManagerGateway) : void in class org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandler |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method private createTask(invokable Class<? extends AbstractInvokable>, config Configuration) : Task in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testBlobFetchRetries(config Configuration, blobStore BlobStore, jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheRetriesTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testGetFailsStore(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method public testExecutionFailsInNetworkRegistration() : void in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method public testSubmitTaskBeforeAcceptSlot() : void in class org.apache.flink.runtime.taskexecutor.TaskExecutorTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testPutBufferSuccessfulGet(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type key : BlobKey to key : PermanentBlobKey in method public testJobCleanup() : void in class org.apache.flink.runtime.blob.BlobCacheCleanupTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testDeleteTransientLocalFails(jobId JobID) : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method public createTask(invokable Class<? extends AbstractInvokable>, taskConfig StreamConfig, taskManagerConfig Configuration) : Task in class org.apache.flink.streaming.runtime.tasks.StreamTaskTest |
From |
To |
|
Change Variable Type blobKey : BlobKey to blobKey : PermanentBlobKey in method public retrieveClassLoader(jobID JobID, jobManager JobManagerGateway, config Configuration, highAvailabilityServices HighAvailabilityServices, timeout Time) : ClassLoader in class org.apache.flink.runtime.client.JobClient |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method private createTask(taskConfig Configuration) : Task in class org.apache.flink.streaming.runtime.tasks.BlockingCheckpointsTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method public doMocking(taskMock AbstractInvokable) : void in class org.apache.flink.runtime.taskmanager.TaskStopTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testPutBufferFailsIncoming(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type key : BlobKey to key : TransientBlobKey in method private testDeleteTransientAlreadyDeleted(jobId JobID) : void in class org.apache.flink.runtime.blob.BlobServerDeleteTest |
From |
To |
|
Change Variable Type blobKeyFuture : Future<BlobKey> to blobKeyFuture : Future<TransientBlobKey> in method private requestTaskManagerLog(request TaskManagerMessages.RequestTaskManagerLog, timeout Time) : CompletableFuture<TransientBlobKey> in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method private associateWithJobManager(jobID JobID, resourceID ResourceID, jobMasterGateway JobMasterGateway, blobPort int) : JobManagerConnection in class org.apache.flink.runtime.taskexecutor.TaskExecutor |
From |
To |
|
Change Variable Type blobKeys : List<BlobKey> to blobKeys : List<PermanentBlobKey> in method private uploadJarFile(serverAddress InetSocketAddress, blobClientConfig Configuration, testFile File) : void in class org.apache.flink.runtime.blob.BlobClientTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testBlobFetchWithTooManyFailures(config Configuration, blobStore BlobStore, jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheRetriesTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testConcurrentPutOperations(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method public testLibraryCacheRegistrationFailed() : void in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Change Variable Type key1a : BlobKey to key1a : TransientBlobKey in method private testPutStreamTransientSuccessfulGet(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testPutBufferFailsStore(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Variable Type blobCache : BlobCache to blobService : BlobCacheService in method public submitTask(tdd TaskDeploymentDescriptor, jobMasterId JobMasterId, timeout Time) : CompletableFuture<Acknowledge> in class org.apache.flink.runtime.taskexecutor.TaskExecutor |
From |
To |
|
Change Variable Type keys : List<BlobKey> to keys : List<PermanentBlobKey> in method package put(service BlobService, jobId JobID, data byte[], blobType BlobKey.BlobType) : BlobKey in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Change Variable Type keys : List<BlobKey> to keys : List<PermanentBlobKey> in method private testBlobServerCleanup(testCase TestCase) : void in class org.apache.flink.runtime.jobmanager.JobManagerCleanupITCase |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testDelete(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Change Variable Type cache1 : BlobCache to cache1 : BlobCacheService in method public testBlobCacheRecovery(config Configuration, blobStore BlobStore) : void in class org.apache.flink.runtime.blob.BlobCacheRecoveryTest |
From |
To |
|
Change Variable Type blobKey : BlobKey to blobKey : PermanentBlobKey in method public uploadUserJars(blobServerAddress InetSocketAddress, blobClientConfig Configuration) : void in class org.apache.flink.runtime.jobgraph.JobGraph |
From |
To |
|
Change Variable Type key1 : BlobKey to key1 : TransientBlobKey in method private testDelete(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Change Variable Type keys : List<BlobKey> to keys : List<PermanentBlobKey> in method public testJobCleanup() : void in class org.apache.flink.runtime.blob.BlobCacheCleanupTest |
From |
To |
|
Change Variable Type blobKeys : List<BlobKey> to blobKeys : List<PermanentBlobKey> in method public uploadJarFiles(serverAddress InetSocketAddress, clientConfig Configuration, jobId JobID, jars List<Path>) : List<PermanentBlobKey> in class org.apache.flink.runtime.blob.BlobClient |
From |
To |
|
Change Variable Type key : BlobKey to key : TransientBlobKey in method private testDeleteTransientFails(jobId JobID) : void in class org.apache.flink.runtime.blob.BlobServerDeleteTest |
From |
To |
|
Change Variable Type future : CompletableFuture<BlobKey> to future : CompletableFuture<TransientBlobKey> in method public testLogFetchingFailure() : void in class org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandlerTest |
From |
To |
|
Change Variable Type cache : BlobCache to cache : BlobCacheService in method private testGetFailsDuringLookup(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Rename Method public putHA(jobId JobID, value byte[]) : BlobKey renamed to public putPermanent(jobId JobID, value byte[]) : PermanentBlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Method public delete(jobId JobID, key BlobKey) : boolean renamed to public deleteFromCache(jobId JobID, key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Rename Method public testPutStreamSuccessfulGet1() : void renamed to public testPutStreamTransientSuccessfulGet1() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public testGetFailsStoreForJob() : void renamed to public testGetTransientFailsStoreForJob() : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Rename Method public testGetFailsDuringLookup1() : void renamed to public testGetTransientFailsDuringLookup1() : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Rename Method public put(inputStream InputStream) : BlobKey renamed to public putTransient(inputStream InputStream) : TransientBlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Method public put(jobId JobID, inputStream InputStream) : BlobKey renamed to public putTransient(jobId JobID, inputStream InputStream) : TransientBlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Method public testPutStreamSuccessfulGet2() : void renamed to public testPutStreamTransientSuccessfulGet2() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public put(jobId JobID, value byte[]) : BlobKey renamed to public putTransient(jobId JobID, value byte[]) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Rename Method public testGetFailsDuringLookupHa() : void renamed to public testGetPermanentFailsDuringLookup() : void in class org.apache.flink.runtime.blob.BlobServerGetTest |
From |
To |
|
Rename Method public testPutChunkedStreamSuccessfulGet2() : void renamed to public testPutChunkedStreamTransientSuccessfulGet2() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public testGetFailsDuringLookup2() : void renamed to public testGetTransientFailsDuringLookup2() : void in class org.apache.flink.runtime.blob.BlobServerGetTest |
From |
To |
|
Rename Method public getTransientBlobStore() : TransientBlobService renamed to public getTransientBlobService() : TransientBlobService in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Method public testPutStreamSuccessfulGet3() : void renamed to public testPutStreamTransientSuccessfulGet3() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public testExceptionOnCreateCacheDirectoryFailureForJob() : void renamed to public testExceptionOnCreateCacheDirectoryFailureForJobTransient() : void in class org.apache.flink.runtime.blob.BlobUtilsTest |
From |
To |
|
Rename Method public put(value byte[]) : BlobKey renamed to public putTransient(value byte[]) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Rename Method public getPermanentBlobStore() : PermanentBlobService renamed to public getPermanentBlobService() : PermanentBlobService in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Method public delete(key BlobKey) : boolean renamed to public deleteFromCache(key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Method private testPutStreamSuccessfulGet(jobId1 JobID, jobId2 JobID) : void renamed to private testPutStreamTransientSuccessfulGet(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public put(value byte[]) : BlobKey renamed to public putTransient(value byte[]) : TransientBlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Method public testPutStreamSuccessfulGet4() : void renamed to public testPutStreamTransientSuccessfulGet4() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public testGetFailsStoreNoJob() : void renamed to public testGetTransientFailsStoreNoJob() : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Rename Method public delete(key BlobKey) : boolean renamed to public deleteFromCache(key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Rename Method public getTransientBlobStore() : TransientBlobCache renamed to public getTransientBlobService() : TransientBlobCache in class org.apache.flink.runtime.blob.BlobCacheService |
From |
To |
|
Rename Method public put(value byte[]) : BlobKey renamed to public putTransient(value byte[]) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Rename Method public testPutChunkedStreamSuccessfulGet1() : void renamed to public testPutChunkedStreamTransientSuccessfulGet1() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public testGetFailsDuringLookup3() : void renamed to public testGetTransientFailsDuringLookup3() : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Rename Method private testDeleteTransient(jobId1 JobID, jobId2 JobID) : void renamed to private testDelete(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Rename Method public testGetFailsDuringLookup3() : void renamed to public testGetTransientFailsDuringLookup3() : void in class org.apache.flink.runtime.blob.BlobServerGetTest |
From |
To |
|
Rename Method public put(jobId JobID, value byte[]) : BlobKey renamed to public putTransient(jobId JobID, value byte[]) : TransientBlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Method public put(inputStream InputStream) : BlobKey renamed to public putTransient(inputStream InputStream) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Rename Method public put(jobId JobID, inputStream InputStream) : BlobKey renamed to public putTransient(jobId JobID, inputStream InputStream) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Rename Method public delete(key BlobKey) : boolean renamed to public deleteFromCache(key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Rename Method public testConcurrentDeleteOperationsForJob() : void renamed to public testConcurrentDeleteOperationsForJobTransient() : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Rename Method public put(jobId JobID, value byte[]) : BlobKey renamed to public putTransient(jobId JobID, value byte[]) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Rename Method private testPutChunkedStreamSuccessfulGet(jobId1 JobID, jobId2 JobID) : void renamed to private testPutChunkedStreamTransientSuccessfulGet(jobId1 JobID, jobId2 JobID) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public getBlobCache() : BlobCache renamed to public getBlobService() : BlobCacheService in class org.apache.flink.runtime.taskexecutor.JobManagerConnection |
From |
To |
|
Rename Method public putHA(jobId JobID, inputStream InputStream) : BlobKey renamed to public putPermanent(jobId JobID, inputStream InputStream) : PermanentBlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Method public delete(jobId JobID, key BlobKey) : boolean renamed to public deleteFromCache(jobId JobID, key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Method public getHAFile(jobId JobID, key BlobKey) : File renamed to public getFile(jobId JobID, key PermanentBlobKey) : File in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Method public getTransientBlobStore() : TransientBlobService renamed to public getTransientBlobService() : TransientBlobService in class org.apache.flink.runtime.blob.BlobService |
From |
To |
|
Rename Method public getPermanentBlobStore() : PermanentBlobCache renamed to public getPermanentBlobService() : PermanentBlobCache in class org.apache.flink.runtime.blob.BlobCacheService |
From |
To |
|
Rename Method public delete(jobId JobID, key BlobKey) : boolean renamed to public deleteFromCache(jobId JobID, key TransientBlobKey) : boolean in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Rename Method public testConcurrentDeleteOperationsNoJob() : void renamed to public testConcurrentDeleteOperationsNoJobTransient() : void in class org.apache.flink.runtime.blob.BlobServerDeleteTest |
From |
To |
|
Rename Method public put(jobId JobID, inputStream InputStream) : BlobKey renamed to public putTransient(jobId JobID, inputStream InputStream) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Rename Method public put(inputStream InputStream) : BlobKey renamed to public putTransient(inputStream InputStream) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Rename Method public testConcurrentDeleteOperationsNoJob() : void renamed to public testConcurrentDeleteOperationsNoJobTransient() : void in class org.apache.flink.runtime.blob.BlobCacheDeleteTest |
From |
To |
|
Rename Method public testGetFailsDuringLookup2() : void renamed to public testGetTransientFailsDuringLookup2() : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Rename Method public testConcurrentDeleteOperationsForJob() : void renamed to public testConcurrentDeleteOperationsForJobTransient() : void in class org.apache.flink.runtime.blob.BlobServerDeleteTest |
From |
To |
|
Rename Method public testPutBufferSuccessfulGetHa() : void renamed to public testPutBufferPermanentSuccessfulGet() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public testPutChunkedStreamSuccessfulGet4() : void renamed to public testPutChunkedStreamTransientSuccessfulGet4() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public getHAFile(jobId JobID, key BlobKey) : File renamed to public getFile(jobId JobID, key PermanentBlobKey) : File in class org.apache.flink.runtime.blob.PermanentBlobService |
From |
To |
|
Rename Method public testPutBufferSuccessfulGet1() : void renamed to public testPutBufferTransientSuccessfulGet1() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public getHAFile(jobId JobID, key BlobKey) : File renamed to public getFile(jobId JobID, key PermanentBlobKey) : File in class org.apache.flink.runtime.blob.PermanentBlobCache |
From |
To |
|
Rename Method public testPutBufferSuccessfulGet2() : void renamed to public testPutBufferTransientSuccessfulGet2() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public testPutBufferSuccessfulGet3() : void renamed to public testPutBufferTransientSuccessfulGet3() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public testPutChunkedStreamSuccessfulGet3() : void renamed to public testPutChunkedStreamTransientSuccessfulGet3() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Method public getPermanentBlobStore() : PermanentBlobService renamed to public getPermanentBlobService() : PermanentBlobService in class org.apache.flink.runtime.blob.BlobService |
From |
To |
|
Rename Method public testGetFailsStoreForJobHa() : void renamed to public testGetPermanentFailsStoreForJob() : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Rename Method public testGetFailsDuringLookup1() : void renamed to public testGetTransientFailsDuringLookup1() : void in class org.apache.flink.runtime.blob.BlobServerGetTest |
From |
To |
|
Rename Method public testPutBufferSuccessfulGet4() : void renamed to public testPutBufferTransientSuccessfulGet4() : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Change Return Type BlobKey to TransientBlobKey in method public putTransient(jobId JobID, value byte[]) : TransientBlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Return Type BlobKey to TransientBlobKey in method public putTransient(jobId JobID, inputStream InputStream) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Change Return Type List<BlobKey> to List<PermanentBlobKey> in method public getUserJarBlobKeys() : List<PermanentBlobKey> in class org.apache.flink.runtime.jobgraph.JobGraph |
From |
To |
|
Change Return Type BlobKey to TransientBlobKey in method public putTransient(value byte[]) : TransientBlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Return Type BlobKey to TransientBlobKey in method public putTransient(value byte[]) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Change Return Type BlobKey to TransientBlobKey in method public putTransient(inputStream InputStream) : TransientBlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Return Type BlobCache to BlobCacheService in method private createBlobCache() : BlobCacheService in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Change Return Type BlobKey to PermanentBlobKey in method public putPermanent(jobId JobID, value byte[]) : PermanentBlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Return Type BlobKey to TransientBlobKey in method public putTransient(inputStream InputStream) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Change Return Type CompletableFuture<BlobKey> to CompletableFuture<TransientBlobKey> in method public requestTaskManagerStdout(timeout Time) : CompletableFuture<TransientBlobKey> in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway |
From |
To |
|
Change Return Type BlobKey to TransientBlobKey in method public putTransient(inputStream InputStream) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Change Return Type BlobKey to TransientBlobKey in method public putTransient(jobId JobID, inputStream InputStream) : TransientBlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Return Type BlobKey to PermanentBlobKey in method public putPermanent(jobId JobID, inputStream InputStream) : PermanentBlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Change Return Type CompletableFuture<BlobKey> to CompletableFuture<TransientBlobKey> in method public requestTaskManagerLog(timeout Time) : CompletableFuture<TransientBlobKey> in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway |
From |
To |
|
Change Return Type List<BlobKey> to List<PermanentBlobKey> in method public uploadJarFiles(serverAddress InetSocketAddress, clientConfig Configuration, jobId JobID, jars List<Path>) : List<PermanentBlobKey> in class org.apache.flink.runtime.blob.BlobClient |
From |
To |
|
Change Return Type Set<BlobKey> to Set<PermanentBlobKey> in method public getLibraries() : Set<PermanentBlobKey> in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager.LibraryCacheEntry |
From |
To |
|
Change Return Type BlobKey to TransientBlobKey in method public putTransient(jobId JobID, inputStream InputStream) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Change Return Type Collection<BlobKey> to Collection<PermanentBlobKey> in method public getRequiredJarFiles() : Collection<PermanentBlobKey> in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps |
From |
To |
|
Change Return Type BlobKey to TransientBlobKey in method public putTransient(jobId JobID, value byte[]) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobService |
From |
To |
|
Change Return Type CompletableFuture<BlobKey> to CompletableFuture<TransientBlobKey> in method public requestTaskManagerLog(timeout Time) : CompletableFuture<TransientBlobKey> in class org.apache.flink.runtime.executiongraph.utils.SimpleAckingTaskManagerGateway |
From |
To |
|
Change Return Type CompletableFuture<BlobKey> to CompletableFuture<TransientBlobKey> in method public requestTaskManagerLog(timeout Time) : CompletableFuture<TransientBlobKey> in class org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway |
From |
To |
|
Change Return Type BlobKey to TransientBlobKey in method public putTransient(jobId JobID, value byte[]) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Change Return Type CompletableFuture<BlobKey> to CompletableFuture<TransientBlobKey> in method private requestTaskManagerLog(request TaskManagerMessages.RequestTaskManagerLog, timeout Time) : CompletableFuture<TransientBlobKey> in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway |
From |
To |
|
Change Return Type BlobKey to TransientBlobKey in method public putTransient(value byte[]) : TransientBlobKey in class org.apache.flink.runtime.blob.TransientBlobCache |
From |
To |
|
Change Return Type CompletableFuture<BlobKey> to CompletableFuture<TransientBlobKey> in method public requestTaskManagerLog(timeout Time) : CompletableFuture<TransientBlobKey> in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway |
From |
To |
|
Change Return Type BlobCache to BlobCacheService in method public getBlobService() : BlobCacheService in class org.apache.flink.runtime.taskexecutor.JobManagerConnection |
From |
To |
|
Change Return Type CompletableFuture<BlobKey> to CompletableFuture<TransientBlobKey> in method public requestTaskManagerStdout(timeout Time) : CompletableFuture<TransientBlobKey> in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway |
From |
To |
|
Change Return Type Collection<BlobKey> to Collection<PermanentBlobKey> in method public getRequiredJarFileBlobKeys() : Collection<PermanentBlobKey> in class org.apache.flink.runtime.executiongraph.JobInformation |
From |
To |
|
Change Return Type Collection<BlobKey> to Collection<PermanentBlobKey> in method public getRequiredJarFiles() : Collection<PermanentBlobKey> in class org.apache.flink.runtime.executiongraph.ExecutionGraph |
From |
To |
|
Change Return Type CompletableFuture<BlobKey> to CompletableFuture<TransientBlobKey> in method public requestTaskManagerStdout(timeout Time) : CompletableFuture<TransientBlobKey> in class org.apache.flink.runtime.executiongraph.utils.SimpleAckingTaskManagerGateway |
From |
To |
|
Change Return Type CompletableFuture<BlobKey> to CompletableFuture<TransientBlobKey> in method public requestTaskManagerStdout(timeout Time) : CompletableFuture<TransientBlobKey> in class org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferFailsIncoming(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Parameter permanentBlob : boolean to blobType : BlobKey.BlobType in method private testGetFailsDuringStreaming(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobClientTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferFailsStore(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testJobCleanup(blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerDeleteTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferFailsStore(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferFails(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testConcurrentPutOperations(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testGetFailsDuringLookup(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerGetTest |
From |
To |
|
Rename Parameter blobCache : BlobCache to blobService : BlobCacheService in method private createTask(invokable Class<? extends AbstractInvokable>, blobService BlobCacheService, libCache LibraryCacheManager, config Configuration, execConfig ExecutionConfig) : Task in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Rename Parameter permanentBlob : boolean to blobType : BlobKey.BlobType in method package putBuffer(jobId JobID, value byte[], offset int, len int, blobType BlobKey.BlobType) : BlobKey in class org.apache.flink.runtime.blob.BlobClient |
From |
To |
|
Rename Parameter permanentBlob : boolean to blobType : BlobKey.BlobType in method private testContentAddressableStream(blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobClientTest |
From |
To |
|
Rename Parameter permanentBlob : boolean to blobType : BlobKey.BlobType in method private testContentAddressableBuffer(blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobClientTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testConcurrentPutOperations(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Parameter blobCache : BlobCache to blobService : BlobCacheService in method private createTask(invokable Class<? extends AbstractInvokable>, blobService BlobCacheService, libCache LibraryCacheManager) : Task in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method package put(service BlobService, jobId JobID, data byte[], blobType BlobKey.BlobType) : BlobKey in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Rename Parameter blobCache : BlobCache to blobService : BlobCacheService in method private createTask(invokable Class<? extends AbstractInvokable>, blobService BlobCacheService, libCache LibraryCacheManager, networkEnvironment NetworkEnvironment, consumableNotifier ResultPartitionConsumableNotifier, partitionProducerStateChecker PartitionProducerStateChecker, executor Executor, taskManagerConfig Configuration, execConfig ExecutionConfig) : Task in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Rename Parameter highlyAvailable : boolean to blobType : BlobKey.BlobType in method private putInputStream(jobId JobID, inputStream InputStream, blobType BlobKey.BlobType) : BlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferFails(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutStreamSuccessfulGet(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testGetFailsFromCorruptFile(jobId JobID, blobType BlobKey.BlobType, corruptOnHAStore boolean, config Configuration, blobStore BlobStore, expectedException ExpectedException) : void in class org.apache.flink.runtime.blob.BlobCacheCorruptionTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferSuccessfulGet(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCachePutTest |
From |
To |
|
Rename Parameter blobCache : BlobCache to blobService : BlobCacheService in method private createTask(invokable Class<? extends AbstractInvokable>, blobService BlobCacheService, libCache LibraryCacheManager, networkEnvironment NetworkEnvironment, consumableNotifier ResultPartitionConsumableNotifier, partitionProducerStateChecker PartitionProducerStateChecker, executor Executor) : Task in class org.apache.flink.runtime.taskmanager.TaskTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testGetFailsDuringLookup(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testConcurrentGetOperations(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerGetTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testGetFailsIncoming(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testBlobFetchRetries(config Configuration, blobStore BlobStore, jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheRetriesTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testBlobFetchWithTooManyFailures(config Configuration, blobStore BlobStore, jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheRetriesTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testGetFailsFromCorruptFile(jobId JobID, blobType BlobKey.BlobType, corruptOnHAStore boolean) : void in class org.apache.flink.runtime.blob.BlobCacheCorruptionTest |
From |
To |
|
Rename Parameter permanentBlob : boolean to blobType : BlobKey.BlobType in method private sendPutHeader(outputStream OutputStream, jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobClient |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testConcurrentGetOperations(jobId JobID, blobType BlobKey.BlobType, cacheAccessesHAStore boolean) : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Rename Parameter highlyAvailable : boolean to blobType : BlobKey.BlobType in method private putBuffer(jobId JobID, value byte[], blobType BlobKey.BlobType) : BlobKey in class org.apache.flink.runtime.blob.BlobServer |
From |
To |
|
Rename Parameter permanentBlob : boolean to blobType : BlobKey.BlobType in method package putInputStream(jobId JobID, inputStream InputStream, blobType BlobKey.BlobType) : BlobKey in class org.apache.flink.runtime.blob.BlobClient |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferFailsIncoming(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Rename Parameter blobCache : BlobCache to blobService : BlobCacheService in method public Task(jobInformation JobInformation, taskInformation TaskInformation, executionAttemptID ExecutionAttemptID, slotAllocationId AllocationID, subtaskIndex int, attemptNumber int, resultPartitionDeploymentDescriptors Collection<ResultPartitionDeploymentDescriptor>, inputGateDeploymentDescriptors Collection<InputGateDeploymentDescriptor>, targetSlotNumber int, taskStateHandles TaskStateSnapshot, memManager MemoryManager, ioManager IOManager, networkEnvironment NetworkEnvironment, bcVarManager BroadcastVariableManager, taskManagerActions TaskManagerActions, inputSplitProvider InputSplitProvider, checkpointResponder CheckpointResponder, 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 highAvailability : boolean to blobType : BlobKey.BlobType in method private uploadFileGetTest(config Configuration, jobId JobID, shutdownServerAfterUpload boolean, cacheHasAccessToFs boolean, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheSuccessTest |
From |
To |
|
Rename Parameter blobCache : BlobCache to blobService : BlobCacheService in method public JobManagerConnection(jobID JobID, resourceID ResourceID, jobMasterGateway JobMasterGateway, taskManagerActions TaskManagerActions, checkpointResponder CheckpointResponder, blobService BlobCacheService, libraryCacheManager LibraryCacheManager, resultPartitionConsumableNotifier ResultPartitionConsumableNotifier, partitionStateChecker PartitionProducerStateChecker) in class org.apache.flink.runtime.taskexecutor.JobManagerConnection |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutChunkedStreamSuccessfulGet(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testGetFailsStore(jobId JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobCacheGetTest |
From |
To |
|
Rename Parameter highAvailability : boolean to blobType : BlobKey.BlobType in method private testPutBufferSuccessfulGet(jobId1 JobID, jobId2 JobID, blobType BlobKey.BlobType) : void in class org.apache.flink.runtime.blob.BlobServerPutTest |
From |
To |