|
Change Parameter Type partitionProvider : IntermediateResultPartitionProvider to partitionProvider : ResultPartitionProvider in method public start(partitionProvider ResultPartitionProvider, taskEventDispatcher TaskEventDispatcher, networkbufferPool NetworkBufferPool) : void in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager |
From |
To |
|
Change Parameter Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public FileChannelInputView(reader BlockChannelReader<MemorySegment>, memManager MemoryManager, memory List<MemorySegment>, sizeOfLastBlock int) in class org.apache.flink.runtime.io.disk.FileChannelInputView |
From |
To |
|
Change Parameter Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in method public requestIntermediateResultPartition(partitionId ResultPartitionID, requestedQueueIndex int, inputChannel RemoteInputChannel) : void in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient |
From |
To |
|
Change Parameter Type consumedPartitions : List<PartitionConsumerDeploymentDescriptor> to inputGates : List<InputGateDeploymentDescriptor> in method public TaskDeploymentDescriptor(jobID JobID, vertexID JobVertexID, executionId ExecutionAttemptID, taskName String, indexInSubtaskGroup int, numberOfSubtasks int, jobConfiguration Configuration, taskConfiguration Configuration, invokableClassName String, producedPartitions List<ResultPartitionDeploymentDescriptor>, inputGates List<InputGateDeploymentDescriptor>, requiredJarFiles List<BlobKey>, targetSlotNumber int, operatorStates StateHandle) in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |
|
Change Parameter Type writer : BufferWriter to writer : ResultPartitionWriter in method public RecordWriter(writer ResultPartitionWriter) in class org.apache.flink.runtime.io.network.api.writer.RecordWriter |
From |
To |
|
Change Parameter Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in method package PartitionRequest(partitionId ResultPartitionID, queueIndex int, receiverId InputChannelID) in class org.apache.flink.runtime.io.network.netty.NettyMessage.PartitionRequest |
From |
To |
|
Change Parameter Type partitionInfo : PartialPartitionInfo to partitionInfo : PartialInputChannelDeploymentDescriptor in method package cachePartitionInfo(partitionInfo PartialInputChannelDeploymentDescriptor) : void in class org.apache.flink.runtime.executiongraph.Execution |
From |
To |
|
Change Parameter Type queueIterator : IntermediateResultPartitionQueueIterator to queueIterator : ResultSubpartitionView in method private SequenceNumberingSubpartitionView(queueIterator ResultSubpartitionView, receiverId InputChannelID) in class org.apache.flink.runtime.io.network.netty.PartitionRequestQueue.SequenceNumberingSubpartitionView |
From |
To |
|
Change Parameter Type partitionInfo : PartitionInfo to icdd : InputChannelDeploymentDescriptor in method public updateInputChannel(icdd InputChannelDeploymentDescriptor) : void in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate |
From |
To |
|
Change Parameter Type remoteAddress : RemoteAddress to connectionId : ConnectionID in method public createPartitionRequestClient(connectionId ConnectionID) : PartitionRequestClient in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager |
From |
To |
|
Change Parameter Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in method public LocalInputChannel(gate SingleInputGate, channelIndex int, partitionId ResultPartitionID, partitionManager ResultPartitionManager, taskEventDispatcher TaskEventDispatcher) in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel |
From |
To |
|
Change Parameter Type partitionID : IntermediateResultPartitionID to partitionID : ResultPartitionID in method public PartialInputChannelDeploymentDescriptor(resultId IntermediateDataSetID, partitionID ResultPartitionID, partitionConnectionInfo InstanceConnectionInfo, partitionConnectionIndex int) in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor |
From |
To |
|
Change Parameter Type buffer : MemorySegment to buffer : T in method public requestFailed(buffer T, e IOException) : void in class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback |
From |
To |
|
Change Parameter Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public HeaderlessChannelReaderInputView(reader BlockChannelReader<MemorySegment>, memory List<MemorySegment>, numBlocks int, numBytesInLastBlock int, waitForFirstBlock boolean) in class org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView |
From |
To |
|
Change Parameter Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public ChannelWriterOutputView(writer BlockChannelWriter<MemorySegment>, segmentSize int) in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView |
From |
To |
|
Change Parameter Type producedPartitions : List<PartitionDeploymentDescriptor> to producedPartitions : List<ResultPartitionDeploymentDescriptor> in method public TaskDeploymentDescriptor(jobID JobID, vertexID JobVertexID, executionId ExecutionAttemptID, taskName String, indexInSubtaskGroup int, numberOfSubtasks int, jobConfiguration Configuration, taskConfiguration Configuration, invokableClassName String, producedPartitions List<ResultPartitionDeploymentDescriptor>, inputGates List<InputGateDeploymentDescriptor>, requiredJarFiles List<BlobKey>, targetSlotNumber int) in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |
|
Change Parameter Type buffer : MemorySegment to buffer : T in method public requestSuccessful(buffer T) : void in class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback |
From |
To |
|
Change Parameter Type remoteAddress : RemoteAddress to connectionId : ConnectionID in method package PartitionRequestClient(tcpChannel Channel, partitionRequestHandler PartitionRequestClientHandler, connectionId ConnectionID, clientFactory PartitionRequestClientFactory) in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient |
From |
To |
|
Change Parameter Type remoteAddress : RemoteAddress to connectionId : ConnectionID in method public closeOpenChannelConnections(connectionId ConnectionID) : void in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactory |
From |
To |
|
Change Parameter Type remoteAddress : RemoteAddress to connectionId : ConnectionID in method public closeOpenChannelConnections(connectionId ConnectionID) : void in class org.apache.flink.runtime.io.network.ConnectionManager |
From |
To |
|
Change Parameter Type updateTaskMsg : TaskManagerMessages.UpdateTask to updateTaskMsg : UpdateTask in method private sendUpdateTaskRpcCall(consumerSlot SimpleSlot, updateTaskMsg UpdateTask) : void in class org.apache.flink.runtime.executiongraph.Execution |
From |
To |
|
Change Parameter Type writer : BufferWriter to writer : ResultPartitionWriter in method public StreamRecordWriter(writer ResultPartitionWriter, channelSelector ChannelSelector<T>) in class org.apache.flink.streaming.io.StreamRecordWriter |
From |
To |
|
Change Parameter Type queue : LinkedBlockingQueue<MemorySegment> to queue : LinkedBlockingQueue<T> in method public QueuingCallback(queue LinkedBlockingQueue<T>) in class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback |
From |
To |
|
Change Parameter Type producerAddress : RemoteAddress to producerAddress : ConnectionID in method public RemoteInputChannel(gate SingleInputGate, channelIndex int, partitionId ResultPartitionID, producerAddress ConnectionID, connectionManager ConnectionManager) in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel |
From |
To |
|
Change Parameter Type remoteAddress : RemoteAddress to connectionId : ConnectionID in method package destroyPartitionRequestClient(connectionId ConnectionID, client PartitionRequestClient) : void in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactory |
From |
To |
|
Change Parameter Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public FileChannelOutputView(writer BlockChannelWriter<MemorySegment>, memManager MemoryManager, memory List<MemorySegment>, segmentSize int) in class org.apache.flink.runtime.io.disk.FileChannelOutputView |
From |
To |
|
Change Parameter Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in method protected InputChannel(inputGate SingleInputGate, channelIndex int, partitionId ResultPartitionID) in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel |
From |
To |
|
Change Parameter Type writer : BufferWriter to writer : ResultPartitionWriter in method public RecordWriter(writer ResultPartitionWriter, channelSelector ChannelSelector<T>) in class org.apache.flink.runtime.io.network.api.writer.RecordWriter |
From |
To |
|
Change Parameter Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in method public RemoteInputChannel(gate SingleInputGate, channelIndex int, partitionId ResultPartitionID, producerAddress ConnectionID, connectionManager ConnectionManager) in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel |
From |
To |
|
Change Parameter Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public ChannelWriterOutputView(writer BlockChannelWriter<MemorySegment>, memory List<MemorySegment>, segmentSize int) in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView |
From |
To |
|
Change Parameter Type remoteAddress : RemoteAddress to connectionId : ConnectionID in method public closeOpenChannelConnections(connectionId ConnectionID) : void in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager |
From |
To |
|
Change Parameter Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in method public sendTaskEvent(partitionId ResultPartitionID, event TaskEvent, inputChannel RemoteInputChannel) : void in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient |
From |
To |
|
Change Parameter Type partitionProvider : IntermediateResultPartitionProvider to partitionProvider : ResultPartitionProvider in method package PartitionRequestServerHandler(partitionProvider ResultPartitionProvider, taskEventDispatcher TaskEventDispatcher, outboundQueue PartitionRequestQueue, networkBufferPool NetworkBufferPool) in class org.apache.flink.runtime.io.network.netty.PartitionRequestServerHandler |
From |
To |
|
Change Parameter Type partitionInfo : PartialPartitionInfo to partitionInfo : PartialInputChannelDeploymentDescriptor in method public cachePartitionInfo(partitionInfo PartialInputChannelDeploymentDescriptor) : void in class org.apache.flink.runtime.executiongraph.ExecutionVertex |
From |
To |
|
Change Parameter Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method package ChannelReaderInputView(reader BlockChannelReader<MemorySegment>, memory List<MemorySegment>, numBlocks int, headerLen int, waitForFirstBlock boolean) in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView |
From |
To |
|
Change Parameter Type partitionManager : IntermediateResultPartitionManager to partitionManager : ResultPartitionManager in method public UnknownInputChannel(gate SingleInputGate, channelIndex int, partitionId ResultPartitionID, partitionManager ResultPartitionManager, taskEventDispatcher TaskEventDispatcher, connectionManager ConnectionManager) in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel |
From |
To |
|
Change Parameter Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in method public registerWriterForIncomingTaskEvents(partitionId ResultPartitionID, writer ResultPartitionWriter) : void in class org.apache.flink.runtime.io.network.TaskEventDispatcher |
From |
To |
|
Change Parameter Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in method public publish(partitionId ResultPartitionID, event TaskEvent) : boolean in class org.apache.flink.runtime.io.network.TaskEventDispatcher |
From |
To |
|
Change Parameter Type remoteAddress : RemoteAddress to connectionId : ConnectionID in method package createPartitionRequestClient(connectionId ConnectionID) : PartitionRequestClient in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactory |
From |
To |
|
Change Parameter Type remoteAddress : RemoteAddress to connectionId : ConnectionID in method public createPartitionRequestClient(connectionId ConnectionID) : PartitionRequestClient in class org.apache.flink.runtime.io.network.ConnectionManager |
From |
To |
|
Change Parameter Type partitionProvider : IntermediateResultPartitionProvider to partitionProvider : ResultPartitionProvider in method package PartitionRequestProtocol(partitionProvider ResultPartitionProvider, taskEventDispatcher TaskEventDispatcher, networkbufferPool NetworkBufferPool) in class org.apache.flink.runtime.io.network.netty.PartitionRequestProtocol |
From |
To |
|
Change Parameter Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public ChannelReaderInputView(reader BlockChannelReader<MemorySegment>, memory List<MemorySegment>, waitForFirstBlock boolean) in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView |
From |
To |
|
Change Parameter Type partitionQueue : IntermediateResultPartitionQueueIterator to partitionQueue : ResultSubpartitionView in method public enqueue(partitionQueue ResultSubpartitionView, receiverId InputChannelID) : void in class org.apache.flink.runtime.io.network.netty.PartitionRequestQueue |
From |
To |
|
Change Parameter Type remoteAddress : RemoteAddress to connectionId : ConnectionID in method public createPartitionRequestClient(connectionId ConnectionID) : PartitionRequestClient in class org.apache.flink.runtime.io.network.LocalConnectionManager |
From |
To |
|
Change Parameter Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method package spill(writer BlockChannelWriter<MemorySegment>) : int in class org.apache.flink.runtime.operators.hash.HashPartition.BuildSideBuffer |
From |
To |
|
Change Parameter Type remoteAddress : RemoteAddress to connectionId : ConnectionID in method public ConnectingChannel(connectionId ConnectionID, clientFactory PartitionRequestClientFactory) in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactory.ConnectingChannel |
From |
To |
|
Change Parameter Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public ChannelReaderInputViewIterator(reader BlockChannelReader<MemorySegment>, returnQueue LinkedBlockingQueue<MemorySegment>, segments List<MemorySegment>, freeMemTarget List<MemorySegment>, accessors TypeSerializer<E>, numBlocks int) in class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator |
From |
To |
|
Change Parameter Type consumedPartitions : List<PartitionConsumerDeploymentDescriptor> to inputGates : List<InputGateDeploymentDescriptor> in method public TaskDeploymentDescriptor(jobID JobID, vertexID JobVertexID, executionId ExecutionAttemptID, taskName String, indexInSubtaskGroup int, numberOfSubtasks int, jobConfiguration Configuration, taskConfiguration Configuration, invokableClassName String, producedPartitions List<ResultPartitionDeploymentDescriptor>, inputGates List<InputGateDeploymentDescriptor>, requiredJarFiles List<BlobKey>, targetSlotNumber int) in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |
|
Change Parameter Type producerAddress : RemoteAddress to producerAddress : ConnectionID in method public toRemoteInputChannel(producerAddress ConnectionID) : RemoteInputChannel in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel |
From |
To |
|
Change Parameter Type writer : BufferWriter to writer : ResultPartitionWriter in method public StreamRecordWriter(writer ResultPartitionWriter) in class org.apache.flink.streaming.io.StreamRecordWriter |
From |
To |
|
Change Parameter Type partition : IntermediateResultPartition to partition : ResultPartition in method public registerIntermediateResultPartition(partition ResultPartition) : void in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager |
From |
To |
|
Change Parameter Type partitionProvider : IntermediateResultPartitionProvider to partitionProvider : ResultPartitionProvider in method public start(partitionProvider ResultPartitionProvider, taskEventDispatcher TaskEventDispatcher, networkbufferPool NetworkBufferPool) : void in class org.apache.flink.runtime.io.network.ConnectionManager |
From |
To |
|
Change Parameter Type writer : BufferWriter to writer : ResultPartitionWriter in method public StreamRecordWriter(writer ResultPartitionWriter, channelSelector ChannelSelector<T>, timeout long) in class org.apache.flink.streaming.io.StreamRecordWriter |
From |
To |
|
Change Parameter Type partitionManager : IntermediateResultPartitionManager to partitionManager : ResultPartitionManager in method public LocalInputChannel(gate SingleInputGate, channelIndex int, partitionId ResultPartitionID, partitionManager ResultPartitionManager, taskEventDispatcher TaskEventDispatcher) in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel |
From |
To |
|
Change Parameter Type spilledBufferSource : BlockChannelReader to spilledBufferSource : BlockChannelReader<MemorySegment> in method private ReadEnd(firstMemSegment MemorySegment, emptyBufferTarget LinkedBlockingQueue<MemorySegment>, fullBufferSource Deque<MemorySegment>, spilledBufferSource BlockChannelReader<MemorySegment>, emptyBuffers List<MemorySegment>, numBuffersSpilled int) in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer.ReadEnd |
From |
To |
|
Change Parameter Type partition : IntermediateResultPartition to partition : ResultPartition in method public ResultPartitionWriter(partition ResultPartition) in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter |
From |
To |
|
Change Parameter Type producedPartitions : List<PartitionDeploymentDescriptor> to producedPartitions : List<ResultPartitionDeploymentDescriptor> in method public TaskDeploymentDescriptor(jobID JobID, vertexID JobVertexID, executionId ExecutionAttemptID, taskName String, indexInSubtaskGroup int, numberOfSubtasks int, jobConfiguration Configuration, taskConfiguration Configuration, invokableClassName String, producedPartitions List<ResultPartitionDeploymentDescriptor>, inputGates List<InputGateDeploymentDescriptor>, requiredJarFiles List<BlobKey>, targetSlotNumber int, operatorStates StateHandle) in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |
|
Change Parameter Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in method package TaskEventRequest(event TaskEvent, partitionId ResultPartitionID, receiverId InputChannelID) in class org.apache.flink.runtime.io.network.netty.NettyMessage.TaskEventRequest |
From |
To |
|
Change Parameter Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public ChannelReaderInputView(reader BlockChannelReader<MemorySegment>, memory List<MemorySegment>, numBlocks int, waitForFirstBlock boolean) in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView |
From |
To |
|
Change Parameter Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in method public UnknownInputChannel(gate SingleInputGate, channelIndex int, partitionId ResultPartitionID, partitionManager ResultPartitionManager, taskEventDispatcher TaskEventDispatcher, connectionManager ConnectionManager) in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel |
From |
To |
|
Change Variable Type inputGates : List<PartitionConsumerDeploymentDescriptor> to inputGates : List<InputGateDeploymentDescriptor> in method public testSerialization() : void in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorTest |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public testWriteReadOneBufferOnly() : void in class org.apache.flink.runtime.io.disk.ChannelViewsTest |
From |
To |
|
Change Variable Type reader : IteratorWrappingMockSingleInputGate<Record> to reader : IteratorWrappingTestSingleInputGate<Record> in method public addInput(inputIterator MutableObjectIterator<Record>) : IteratorWrappingTestSingleInputGate<Record> in class org.apache.flink.runtime.operators.testutils.MockEnvironment |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public go() : void in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread |
From |
To |
|
Change Variable Type pdd : PartitionDeploymentDescriptor to elem : Object in method private collectionToString(collection Collection<?>) : String in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public parallelChannelsTest() : void in class org.apache.flink.runtime.io.disk.iomanager.IOManagerITCase |
From |
To |
|
Change Variable Type partitionInfos : List<PartitionInfo> to inputChannelDeploymentDescriptors : List<InputChannelDeploymentDescriptor> in method package sendPartitionInfos() : void in class org.apache.flink.runtime.executiongraph.Execution |
From |
To |
|
Change Variable Type partialPartitionInfo : PartialPartitionInfo to partialInputChannelDeploymentDescriptor : PartialInputChannelDeploymentDescriptor in method package sendPartitionInfos() : void in class org.apache.flink.runtime.executiongraph.Execution |
From |
To |
|
Change Variable Type updateTaskMessage : TaskManagerMessages.UpdateTask to updateTaskMessage : UpdateTask in method package scheduleOrUpdateConsumers(allConsumers List<List<ExecutionEdge>>) : void in class org.apache.flink.runtime.executiongraph.Execution |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public testWriteReadOneBufferOnly() : void in class org.apache.flink.runtime.io.disk.FileChannelStreamsITCase |
From |
To |
|
Change Variable Type partition : IntermediateResultPartition to partition : ResultPartition in method public shutdown() : void in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public testWriteReadNotAll() : void in class org.apache.flink.runtime.io.disk.ChannelViewsTest |
From |
To |
|
Change Variable Type producerLocation : PartitionLocation to partitionLocation : ResultPartitionLocation in method public fromEdges(edges ExecutionEdge[], consumerSlot SimpleSlot) : InputChannelDeploymentDescriptor[] in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testReadTooMany() : void in class org.apache.flink.runtime.io.disk.FileChannelStreamsITCase |
From |
To |
|
Change Variable Type writer : BufferWriter to writer : ResultPartitionWriter in method public registerTask(task Task) : void in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Change Variable Type producedPartitions : IntermediateResultPartition[] to producedPartitions : ResultPartition[] in method public registerTask(task Task) : void in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public testCloseAndDeleteInputView() : void in class org.apache.flink.runtime.io.disk.FileChannelStreamsTest |
From |
To |
|
Change Variable Type partition : IntermediateResultPartition to partition : ResultPartition in method public registerTask(task Task) : void in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Change Variable Type queue : IntermediateResultPartitionQueue to subpartition : ResultSubpartition in method public finish() : void in class org.apache.flink.runtime.io.network.partition.ResultPartition |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public testWriteReadNotAll() : void in class org.apache.flink.runtime.io.disk.FileChannelStreamsITCase |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public channelReadWriteOneSegment() : void in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsyncTest |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testWriteReadSmallRecords() : void in class org.apache.flink.runtime.io.disk.FileChannelStreamsITCase |
From |
To |
|
Change Variable Type mockWriter : BufferWriter to mockWriter : ResultPartitionWriter in method public addOutput(outputList List<Record>) : void in class org.apache.flink.runtime.operators.testutils.MockEnvironment |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public go() : void in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method private testChannelWithSegments(numSegments int) : void in class org.apache.flink.runtime.io.disk.iomanager.IOManagerPerformanceBenchmark |
From |
To |
|
Change Variable Type queue : IntermediateResultPartitionQueue to subpartition : ResultSubpartition in method public release() : void in class org.apache.flink.runtime.io.network.partition.ResultPartition |
From |
To |
|
Change Variable Type producerLocation : PartitionInfo.PartitionLocation to partitionLocation : ResultPartitionLocation in method package scheduleOrUpdateConsumers(allConsumers List<List<ExecutionEdge>>) : void in class org.apache.flink.runtime.executiongraph.Execution |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method protected mergeChannels(channelIDs List<ChannelWithBlockCount>, readBuffers List<List<MemorySegment>>, writeBuffers List<MemorySegment>) : ChannelWithBlockCount in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread |
From |
To |
|
Change Variable Type writers : BufferWriter[] to writers : ResultPartitionWriter[] in method public registerTask(task Task) : void in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testWriteReadNotAll() : void in class org.apache.flink.runtime.io.disk.ChannelViewsTest |
From |
To |
|
Change Variable Type producedPartitions : List<PartitionDeploymentDescriptor> to producedPartitions : List<ResultPartitionDeploymentDescriptor> in method public testBuildDeploymentDescriptor() : void in class org.apache.flink.runtime.executiongraph.ExecutionGraphDeploymentTest |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public testReadWithoutKnownBlockCount() : void in class org.apache.flink.runtime.io.disk.ChannelViewsTest |
From |
To |
|
Change Variable Type partitionInfo : PartitionInfo to descriptor : InputChannelDeploymentDescriptor in method package scheduleOrUpdateConsumers(allConsumers List<List<ExecutionEdge>>) : void in class org.apache.flink.runtime.executiongraph.Execution |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testWriteReadSmallRecords() : void in class org.apache.flink.runtime.io.disk.ChannelViewsTest |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testWriteReadNotAll() : void in class org.apache.flink.runtime.io.disk.FileChannelStreamsITCase |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public testReadTooMany() : void in class org.apache.flink.runtime.io.disk.ChannelViewsTest |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public testWriteAndReadLongRecords() : void in class org.apache.flink.runtime.io.disk.ChannelViewsTest |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testCloseAndDeleteOutputView() : void in class org.apache.flink.runtime.io.disk.FileChannelStreamsTest |
From |
To |
|
Change Variable Type pcdd : PartitionConsumerDeploymentDescriptor to elem : Object in method private collectionToString(collection Collection<?>) : String in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |
|
Change Variable Type iterator : IntermediateResultPartitionQueueIterator to iterator : ResultSubpartitionView in method public testBackwardsEventWithUninitializedChannel() : void in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateTest |
From |
To |
|
Change Variable Type partitions : List<PartitionDeploymentDescriptor> to partitions : List<ResultPartitionDeploymentDescriptor> in method public RuntimeEnvironment(jobManager ActorRef, owner Task, tdd TaskDeploymentDescriptor, userCodeClassLoader ClassLoader, memoryManager MemoryManager, ioManager IOManager, inputSplitProvider InputSplitProvider, broadcastVariableManager BroadcastVariableManager, networkEnvironment NetworkEnvironment) in class org.apache.flink.runtime.execution.RuntimeEnvironment |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public channelReadWriteMultipleSegments() : void in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsyncTest |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testWriteReadOneBufferOnly() : void in class org.apache.flink.runtime.io.disk.ChannelViewsTest |
From |
To |
|
Change Variable Type ra : RemoteAddress to ra : ConnectionID in method public equals(other Object) : boolean in class org.apache.flink.runtime.io.network.ConnectionID |
From |
To |
|
Change Variable Type consumedPartitions : List<PartitionConsumerDeploymentDescriptor> to consumedPartitions : List<InputGateDeploymentDescriptor> in method public testBuildDeploymentDescriptor() : void in class org.apache.flink.runtime.executiongraph.ExecutionGraphDeploymentTest |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public switchBuffers() : ReadEnd in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public testWriteReadSmallRecords() : void in class org.apache.flink.runtime.io.disk.FileChannelStreamsITCase |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public channelReadWriteMultipleSegments() : void in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsyncTest |
From |
To |
|
Change Variable Type consumedPartitions : List<PartitionConsumerDeploymentDescriptor> to consumedPartitions : List<InputGateDeploymentDescriptor> in method package createDeploymentDescriptor(executionId ExecutionAttemptID, targetSlot SimpleSlot) : TaskDeploymentDescriptor in class org.apache.flink.runtime.executiongraph.ExecutionVertex |
From |
To |
|
Change Variable Type inputGate : MockSingleInputGate to inputGate : TestSingleInputGate in method public testIterativeGetNextBufferOrEvent() : void in class org.apache.flink.runtime.io.network.api.reader.BufferReaderTest |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testWriteReadOneBufferOnly() : void in class org.apache.flink.runtime.io.disk.FileChannelStreamsITCase |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testReadTooMany() : void in class org.apache.flink.runtime.io.disk.ChannelViewsTest |
From |
To |
|
Change Variable Type partitionID : IntermediateResultPartitionID to partition : IntermediateResultPartition in method package scheduleOrUpdateConsumers(allConsumers List<List<ExecutionEdge>>) : void in class org.apache.flink.runtime.executiongraph.Execution |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method protected getMergingIterator(channelIDs List<ChannelWithBlockCount>, inputSegments List<List<MemorySegment>>, readerList List<FileIOChannel>, largeRecords MutableObjectIterator<E>) : MergeIterator<E> in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testWriteAndReadLongRecords() : void in class org.apache.flink.runtime.io.disk.ChannelViewsTest |
From |
To |
|
Change Variable Type partition : IntermediateResultPartition to partition : ResultPartition in method public run() : void in class org.apache.flink.runtime.execution.RuntimeEnvironment |
From |
To |
|
Change Variable Type writer : BlockChannelWriterWithCallback to writer : BlockChannelWriterWithCallback<MemorySegment> in method public testClosingWaits() : void in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannelTest |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public channelReadWriteOneSegment() : void in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsyncTest |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testSeek() : void in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputViewTest |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method private testChannelWithSegments(numSegments int) : void in class org.apache.flink.runtime.io.disk.iomanager.IOManagerPerformanceBenchmark |
From |
To |
|
Change Variable Type reader : IteratorWrappingMockSingleInputGate<Record> to reader : IteratorWrappingTestSingleInputGate<Record> in method public addInput(input MutableObjectIterator<Record>, groupId int, read boolean) : IteratorWrappingTestSingleInputGate<Record> in class org.apache.flink.runtime.operators.testutils.TaskTestBase |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public testWriteReadSmallRecords() : void in class org.apache.flink.runtime.io.disk.ChannelViewsTest |
From |
To |
|
Change Variable Type partitionManager : IntermediateResultPartitionManager to partitionManager : ResultPartitionManager in method public testBackwardsEventWithUninitializedChannel() : void in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateTest |
From |
To |
|
Change Variable Type inReader : BlockChannelReader to inReader : BlockChannelReader<MemorySegment> in method protected buildTableFromSpilledPartition(p HashPartition<BT,PT>) : void in class org.apache.flink.runtime.operators.hash.MutableHashTable |
From |
To |
|
Change Variable Type writers : BlockChannelWriter[] to writers : BlockChannelWriter<MemorySegment>[] in method public parallelChannelsTest() : void in class org.apache.flink.runtime.io.disk.iomanager.IOManagerITCase |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public testWriteAndReadLongRecords() : void in class org.apache.flink.runtime.io.disk.FileChannelStreamsITCase |
From |
To |
|
Change Variable Type reader : IteratorWrappingMockSingleInputGate<?> to reader : IteratorWrappingTestSingleInputGate<?> in method public testUnionDataSinkTask() : void in class org.apache.flink.runtime.operators.DataSinkTaskTest |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testReadWithoutKnownBlockCount() : void in class org.apache.flink.runtime.io.disk.ChannelViewsTest |
From |
To |
|
Change Variable Type inputGate : MockSingleInputGate to inputGate : TestSingleInputGate in method public testGetNextBufferOrEvent() : void in class org.apache.flink.runtime.io.network.api.reader.BufferReaderTest |
From |
To |
|
Change Variable Type consumedPartitions : List<PartitionConsumerDeploymentDescriptor> to consumedPartitions : List<InputGateDeploymentDescriptor> in method public RuntimeEnvironment(jobManager ActorRef, owner Task, tdd TaskDeploymentDescriptor, userCodeClassLoader ClassLoader, memoryManager MemoryManager, ioManager IOManager, inputSplitProvider InputSplitProvider, broadcastVariableManager BroadcastVariableManager, networkEnvironment NetworkEnvironment) in class org.apache.flink.runtime.execution.RuntimeEnvironment |
From |
To |
|
Change Variable Type inputChannel : MockInputChannel to inputChannel : TestInputChannel in method public readEndOfSuperstepEvent() : TestSingleInputGate in class org.apache.flink.runtime.io.network.util.TestSingleInputGate |
From |
To |
|
Change Variable Type readers : BlockChannelReader[] to readers : BlockChannelReader<MemorySegment>[] in method public parallelChannelsTest() : void in class org.apache.flink.runtime.io.disk.iomanager.IOManagerITCase |
From |
To |
|
Change Variable Type producedPartitions : List<PartitionDeploymentDescriptor> to producedPartitions : List<ResultPartitionDeploymentDescriptor> in method package createDeploymentDescriptor(executionId ExecutionAttemptID, targetSlot SimpleSlot) : TaskDeploymentDescriptor in class org.apache.flink.runtime.executiongraph.ExecutionVertex |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public flip() : DataInputView in class org.apache.flink.runtime.io.disk.SpillingBuffer |
From |
To |
|
Change Variable Type inputChannel : MockInputChannel to inputChannel : TestInputChannel in method public readEndOfPartitionEvent() : TestSingleInputGate in class org.apache.flink.runtime.io.network.util.TestSingleInputGate |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method protected mergeChannels(channelIDs List<ChannelWithBlockCount>, readBuffers List<List<MemorySegment>>, writeBuffers List<MemorySegment>) : ChannelWithBlockCount in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread |
From |
To |
|
Change Variable Type serverAddress : RemoteAddress to serverAddress : ConnectionID in method public run() : void in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactoryTest.testResourceReleaseAfterInterruptedConnect.connect |
From |
To |
|
Change Variable Type writer : BlockChannelWriterWithCallback to writer : BlockChannelWriterWithCallback<MemorySegment> in method private testExceptionForwardsToClose(ioMan IOManagerAsync, numBlocks int, failingBlock int) : void in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannelTest |
From |
To |
|
Change Variable Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in method public testWriteAndReadLongRecords() : void in class org.apache.flink.runtime.io.disk.FileChannelStreamsITCase |
From |
To |
|
Change Variable Type reader : IteratorWrappingMockSingleInputGate<Record> to reader : IteratorWrappingTestSingleInputGate<Record> in method public addInput(input MutableObjectIterator<Record>, groupId int) : IteratorWrappingTestSingleInputGate<Record> in class org.apache.flink.runtime.operators.testutils.TaskTestBase |
From |
To |
|
Change Variable Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in method public testReadTooMany() : void in class org.apache.flink.runtime.io.disk.FileChannelStreamsITCase |
From |
To |
|
Change Variable Type producedResults : List<PartitionDeploymentDescriptor> to producedResults : List<ResultPartitionDeploymentDescriptor> in method public testSerialization() : void in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorTest |
From |
To |
|
Rename Method public getNumberOfQueues() : int renamed to public getNumberOfSubpartitions() : int in class org.apache.flink.runtime.io.network.partition.ResultPartition |
From |
To |
|
Rename Method public subscribe(ignored NotificationListener) : boolean renamed to public registerListener(ignored NotificationListener) : boolean in class org.apache.flink.runtime.io.network.netty.PartitionRequestQueue.SequenceNumberingSubpartitionView |
From |
To |
|
Rename Method public releaseAllResources() : void renamed to public release() : void in class org.apache.flink.runtime.io.network.partition.ResultPartition |
From |
To |
|
Rename Method public abstract requestIntermediateResultPartition(queueIndex int) : void renamed to public abstract requestSubpartition(subpartitionIndex int) : void in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel |
From |
To |
|
Rename Method public subscribe(listener NotificationListener) : boolean renamed to public registerListener(listener NotificationListener) : boolean in class org.apache.flink.runtime.io.network.partition.ResultSubpartitionView |
From |
To |
|
Rename Method public getConsumedPartitions() : List<PartitionConsumerDeploymentDescriptor> renamed to public getInputGates() : List<InputGateDeploymentDescriptor> in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |
|
Rename Method public setBufferPool(bufferPool BufferPool) : void renamed to public registerBufferPool(bufferPool BufferPool) : void in class org.apache.flink.runtime.io.network.partition.ResultPartition |
From |
To |
|
Rename Method public requestIntermediateResultPartition(queueIndex int) : void renamed to public requestSubpartition(subpartitionIndex int) : void in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel |
From |
To |
|
Rename Method public destroy() : void renamed to public lazyDestroy() : void in class org.apache.flink.runtime.io.network.buffer.BufferPool |
From |
To |
|
Rename Method public requestIntermediateResultPartition(queueIndex int) : void renamed to public requestSubpartition(subpartitionIndex int) : void in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel |
From |
To |
|
Rename Method public isConsumed() : boolean renamed to public releaseAllResources() : void in class org.apache.flink.runtime.io.network.netty.PartitionRequestQueue.SequenceNumberingSubpartitionView |
From |
To |
|
Rename Method public getPartitionId() : IntermediateResultPartitionID renamed to public getConsumedPartitionLocation() : ResultPartitionLocation in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor |
From |
To |
|
Rename Method public incrementReferenceCounter() : boolean renamed to public increment() : boolean in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter |
From |
To |
|
Rename Method private createServerRemoteAddress(connectionIndex int) : RemoteAddress renamed to private createServerConnectionID(connectionIndex int) : ConnectionID in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactoryTest |
From |
To |
|
Rename Method public isConsumed() : boolean renamed to public releaseAllResources() : void in class org.apache.flink.runtime.io.network.partition.ResultSubpartitionView |
From |
To |
|
Rename Method public discard() : void renamed to public notifySubpartitionConsumed() : void in class org.apache.flink.runtime.io.network.partition.ResultSubpartitionView |
From |
To |
|
Rename Method public getIntermediateDataSetID() : IntermediateDataSetID renamed to public getResultId() : IntermediateDataSetID in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor |
From |
To |
|
Rename Method public destroy() : void renamed to public lazyDestroy() : void in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool |
From |
To |
|
Rename Method public decrementReferenceCounter() : boolean renamed to public decrement() : boolean in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter |
From |
To |
|
Rename Method public getNextReturnedSegment() : MemorySegment renamed to public getNextReturnedBlock() : MemorySegment in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter |
From |
To |
|
Rename Method private maybeNotifyConsumers(doNotify boolean) : void renamed to private notifyPipelinedConsumers() : void in class org.apache.flink.runtime.io.network.partition.ResultPartition |
From |
To |
|
Rename Method public getNextReturnedSegment() : MemorySegment renamed to public getNextReturnedBlock() : MemorySegment in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader |
From |
To |
|
Rename Method public discard() : void renamed to public notifySubpartitionConsumed() : void in class org.apache.flink.runtime.io.network.netty.PartitionRequestQueue.SequenceNumberingSubpartitionView |
From |
To |
|
Change Return Type List<PartitionConsumerDeploymentDescriptor> to List<InputGateDeploymentDescriptor> in method public getInputGates() : List<InputGateDeploymentDescriptor> in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |
|
Change Return Type MockSingleInputGate to TestSingleInputGate in method public readEndOfPartitionEvent(channelIndex int) : TestSingleInputGate in class org.apache.flink.runtime.io.network.util.TestSingleInputGate |
From |
To |
|
Change Return Type IteratorWrappingMockSingleInputGate<Record> to IteratorWrappingTestSingleInputGate<Record> in method public addInput(input MutableObjectIterator<Record>, groupId int) : IteratorWrappingTestSingleInputGate<Record> in class org.apache.flink.runtime.operators.testutils.TaskTestBase |
From |
To |
|
Change Return Type MockSingleInputGate to TestSingleInputGate in method public read(buffer Buffer, channelIndex int) : TestSingleInputGate in class org.apache.flink.runtime.io.network.util.TestSingleInputGate |
From |
To |
|
Change Return Type BufferWriter to ResultPartitionWriter in method public getWriter(index int) : ResultPartitionWriter in class org.apache.flink.runtime.execution.Environment |
From |
To |
|
Change Return Type LinkedBlockingQueue<MemorySegment> to LinkedBlockingQueue<T> in method public getReturnQueue() : LinkedBlockingQueue<T> in class org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriter |
From |
To |
|
Change Return Type IteratorWrappingMockSingleInputGate<Record> to IteratorWrappingTestSingleInputGate<Record> in method public addInput(inputIterator MutableObjectIterator<Record>) : IteratorWrappingTestSingleInputGate<Record> in class org.apache.flink.runtime.operators.testutils.MockEnvironment |
From |
To |
|
Change Return Type BlockChannelWriter to BlockChannelWriter<MemorySegment> in method public createBlockChannelWriter(channelID FileIOChannel.ID, returnQueue LinkedBlockingQueue<MemorySegment>) : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync |
From |
To |
|
Change Return Type BlockChannelReader to BlockChannelReader<MemorySegment> in method public createBlockChannelReader(channelID FileIOChannel.ID, returnQueue LinkedBlockingQueue<MemorySegment>) : BlockChannelReader<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync |
From |
To |
|
Change Return Type List<PartitionDeploymentDescriptor> to List<ResultPartitionDeploymentDescriptor> in method public getProducedPartitions() : List<ResultPartitionDeploymentDescriptor> in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |
|
Change Return Type BufferWriter[] to ResultPartitionWriter[] in method public getWriters() : ResultPartitionWriter[] in class org.apache.flink.runtime.taskmanager.Task |
From |
To |
|
Change Return Type boolean to void in method public releaseAllResources() : void in class org.apache.flink.runtime.io.network.netty.PartitionRequestQueue.SequenceNumberingSubpartitionView |
From |
To |
|
Change Return Type IntermediateResultPartitionID to ResultPartitionID in method public getPartitionId() : ResultPartitionID in class org.apache.flink.runtime.io.network.partition.ResultPartition |
From |
To |
|
Change Return Type RemoteAddress to ConnectionID in method private createServerConnectionID(connectionIndex int) : ConnectionID in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactoryTest |
From |
To |
|
Change Return Type MockInputChannel[] to TestInputChannel[] in method public createInputChannels(inputGate SingleInputGate, numberOfInputChannels int) : TestInputChannel[] in class org.apache.flink.runtime.io.network.util.TestInputChannel |
From |
To |
|
Change Return Type BlockChannelWriter to BlockChannelWriter<MemorySegment> in method public abstract createBlockChannelWriter(channelID FileIOChannel.ID, returnQueue LinkedBlockingQueue<MemorySegment>) : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.IOManager |
From |
To |
|
Change Return Type BlockChannelWriterWithCallback to BlockChannelWriterWithCallback<MemorySegment> in method public createBlockChannelWriter(channelID FileIOChannel.ID, callback RequestDoneCallback<MemorySegment>) : BlockChannelWriterWithCallback<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync |
From |
To |
|
Change Return Type BlockChannelReader to BlockChannelReader<MemorySegment> in method public createBlockChannelReader(channelID FileIOChannel.ID) : BlockChannelReader<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.IOManager |
From |
To |
|
Change Return Type MockSingleInputGate to TestSingleInputGate in method public readEndOfSuperstepEvent() : TestSingleInputGate in class org.apache.flink.runtime.io.network.util.TestSingleInputGate |
From |
To |
|
Change Return Type BlockChannelWriter to BlockChannelWriter<MemorySegment> in method public createBlockChannelWriter(channelID FileIOChannel.ID) : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.IOManager |
From |
To |
|
Change Return Type IntermediateResultPartitionManager to ResultPartitionManager in method public getPartitionManager() : ResultPartitionManager in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Change Return Type MockSingleInputGate to TestSingleInputGate in method public readEndOfPartitionEvent() : TestSingleInputGate in class org.apache.flink.runtime.io.network.util.TestSingleInputGate |
From |
To |
|
Change Return Type IntermediateResultPartitionID to ResultPartitionID in method public getPartitionId() : ResultPartitionID in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter |
From |
To |
|
Change Return Type BlockChannelReader to BlockChannelReader<MemorySegment> in method public abstract createBlockChannelReader(channelID FileIOChannel.ID, returnQueue LinkedBlockingQueue<MemorySegment>) : BlockChannelReader<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.IOManager |
From |
To |
|
Change Return Type IntermediateResultPartitionType to ResultPartitionType in method public getResultType() : ResultPartitionType in class org.apache.flink.runtime.executiongraph.IntermediateResult |
From |
To |
|
Change Return Type BufferWriter[] to ResultPartitionWriter[] in method public getAllWriters() : ResultPartitionWriter[] in class org.apache.flink.runtime.operators.testutils.MockEnvironment |
From |
To |
|
Change Return Type IteratorWrappingMockSingleInputGate<T> to IteratorWrappingTestSingleInputGate<T> in method public read() : IteratorWrappingTestSingleInputGate<T> in class org.apache.flink.runtime.io.network.api.reader.IteratorWrappingTestSingleInputGate |
From |
To |
|
Change Return Type MockSingleInputGate to TestSingleInputGate in method public readEndOfSuperstepEvent(channelIndex int) : TestSingleInputGate in class org.apache.flink.runtime.io.network.util.TestSingleInputGate |
From |
To |
|
Change Return Type MockInputChannel to TestInputChannel in method public readBuffer() : TestInputChannel in class org.apache.flink.runtime.io.network.util.TestInputChannel |
From |
To |
|
Change Return Type PartitionInfo[] to InputChannelDeploymentDescriptor[] in method public fromEdges(edges ExecutionEdge[], consumerSlot SimpleSlot) : InputChannelDeploymentDescriptor[] in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor |
From |
To |
|
Change Return Type BufferWriter[] to ResultPartitionWriter[] in method public getAllWriters() : ResultPartitionWriter[] in class org.apache.flink.runtime.execution.Environment |
From |
To |
|
Change Return Type BlockChannelWriter to BlockChannelWriter<MemorySegment> in method public getBuildSideChannel() : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.operators.hash.HashPartition |
From |
To |
|
Change Return Type BufferWriter to ResultPartitionWriter in method public getWriter(index int) : ResultPartitionWriter in class org.apache.flink.runtime.operators.testutils.MockEnvironment |
From |
To |
|
Change Return Type LinkedBlockingQueue<MemorySegment> to LinkedBlockingQueue<T> in method public getReturnQueue() : LinkedBlockingQueue<T> in class org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader |
From |
To |
|
Change Return Type BlockChannelWriter to BlockChannelWriter<MemorySegment> in method public createBlockChannelWriter(channelID ID, returnQueue LinkedBlockingQueue<MemorySegment>) : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.IOManagerTest.TestIOManager |
From |
To |
|
Change Return Type boolean to void in method public releaseAllResources() : void in class org.apache.flink.runtime.io.network.partition.ResultSubpartitionView |
From |
To |
|
Change Return Type BlockChannelWriterWithCallback to BlockChannelWriterWithCallback<MemorySegment> in method public abstract createBlockChannelWriter(channelID FileIOChannel.ID, callback RequestDoneCallback<MemorySegment>) : BlockChannelWriterWithCallback<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.IOManager |
From |
To |
|
Change Return Type BufferWriter to ResultPartitionWriter in method public getWriter(index int) : ResultPartitionWriter in class org.apache.flink.runtime.execution.RuntimeEnvironment |
From |
To |
|
Change Return Type MockSingleInputGate to TestSingleInputGate in method public readBuffer(channelIndex int) : TestSingleInputGate in class org.apache.flink.runtime.io.network.util.TestSingleInputGate |
From |
To |
|
Change Return Type MockSingleInputGate to TestSingleInputGate in method public readEvent(channelIndex int) : TestSingleInputGate in class org.apache.flink.runtime.io.network.util.TestSingleInputGate |
From |
To |
|
Change Return Type BufferWriter[] to ResultPartitionWriter[] in method public getAllWriters() : ResultPartitionWriter[] in class org.apache.flink.runtime.execution.RuntimeEnvironment |
From |
To |
|
Change Return Type IntermediateResultPartition[] to ResultPartition[] in method public getProducedPartitions() : ResultPartition[] in class org.apache.flink.runtime.execution.RuntimeEnvironment |
From |
To |
|
Change Return Type BlockChannelReader to BlockChannelReader<MemorySegment> in method public createBlockChannelReader(channelID ID, returnQueue LinkedBlockingQueue<MemorySegment>) : BlockChannelReader<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.IOManagerTest.TestIOManager |
From |
To |
|
Change Return Type IteratorWrappingMockSingleInputGate<Record> to IteratorWrappingTestSingleInputGate<Record> in method public addInput(input MutableObjectIterator<Record>, groupId int, read boolean) : IteratorWrappingTestSingleInputGate<Record> in class org.apache.flink.runtime.operators.testutils.TaskTestBase |
From |
To |
|
Change Return Type BlockChannelWriter to BlockChannelWriter<MemorySegment> in method public getProbeSideChannel() : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.operators.hash.HashPartition |
From |
To |
|
Change Return Type MockInputChannel to TestInputChannel in method public readEndOfPartitionEvent() : TestInputChannel in class org.apache.flink.runtime.io.network.util.TestInputChannel |
From |
To |
|
Change Return Type IteratorWrappingMockSingleInputGate<T> to IteratorWrappingTestSingleInputGate<T> in method private wrapIterator(iterator MutableObjectIterator<T>) : IteratorWrappingTestSingleInputGate<T> in class org.apache.flink.runtime.io.network.api.reader.IteratorWrappingTestSingleInputGate |
From |
To |
|
Change Return Type MockInputChannel to TestInputChannel in method public readEvent() : TestInputChannel in class org.apache.flink.runtime.io.network.util.TestInputChannel |
From |
To |
|
Change Return Type IntermediateResultPartitionID to ResultPartitionLocation in method public getConsumedPartitionLocation() : ResultPartitionLocation in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor |
From |
To |
|
Change Return Type MockInputChannel to TestInputChannel in method public readEndOfSuperstepEvent() : TestInputChannel in class org.apache.flink.runtime.io.network.util.TestInputChannel |
From |
To |
|
Change Return Type MockInputChannel to TestInputChannel in method public read(buffer Buffer) : TestInputChannel in class org.apache.flink.runtime.io.network.util.TestInputChannel |
From |
To |
|
Change Return Type BlockChannelWriterWithCallback to BlockChannelWriterWithCallback<MemorySegment> in method public createBlockChannelWriter(channelID ID, callback RequestDoneCallback<MemorySegment>) : BlockChannelWriterWithCallback<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.IOManagerTest.TestIOManager |
From |
To |
|
Change Return Type MockSingleInputGate to TestSingleInputGate in method public readBuffer() : TestSingleInputGate in class org.apache.flink.runtime.io.network.util.TestSingleInputGate |
From |
To |
|
Change Return Type MockSingleInputGate to TestSingleInputGate in method public readEvent() : TestSingleInputGate in class org.apache.flink.runtime.io.network.util.TestSingleInputGate |
From |
To |
|
Change Return Type IntermediateResultPartition[] to ResultPartition[] in method public getProducedPartitions() : ResultPartition[] in class org.apache.flink.runtime.taskmanager.Task |
From |
To |
|
Change Attribute Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in class org.apache.flink.runtime.io.network.netty.NettyMessage.PartitionRequest |
From |
To |
|
Change Attribute Type inputChannels : MockInputChannel[] to inputChannels : TestInputChannel[] in class org.apache.flink.runtime.io.network.util.TestSingleInputGate |
From |
To |
|
Change Attribute Type partitionManager : IntermediateResultPartitionManager to partitionManager : ResultPartitionManager in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel |
From |
To |
|
Change Attribute Type partitionManager : IntermediateResultPartitionManager to partitionManager : ResultPartitionManager in class org.apache.flink.runtime.io.network.partition.consumer.UnknownInputChannel |
From |
To |
|
Change Attribute Type consumedPartitions : List<PartitionConsumerDeploymentDescriptor> to inputGates : List<InputGateDeploymentDescriptor> in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |
|
Change Attribute Type queue : Queue<SequenceNumberingPartitionQueueIterator> to queue : Queue<SequenceNumberingSubpartitionView> in class org.apache.flink.runtime.io.network.netty.PartitionRequestQueue |
From |
To |
|
Change Attribute Type buildSideChannel : BlockChannelWriter to buildSideChannel : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.operators.hash.HashPartition |
From |
To |
|
Change Attribute Type queue : LinkedBlockingQueue<MemorySegment> to queue : LinkedBlockingQueue<T> in class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback |
From |
To |
|
Change Attribute Type queues : IntermediateResultPartitionQueue[] to subpartitions : ResultSubpartition[] in class org.apache.flink.runtime.io.network.partition.ResultPartition |
From |
To |
|
Change Attribute Type producerExecutionID : ExecutionAttemptID to resultId : IntermediateDataSetID in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor |
From |
To |
|
Change Attribute Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView |
From |
To |
|
Change Attribute Type registeredWriters : Table<ExecutionAttemptID,IntermediateResultPartitionID,BufferWriter> to registeredWriters : Map<ResultPartitionID,ResultPartitionWriter> in class org.apache.flink.runtime.io.network.TaskEventDispatcher |
From |
To |
|
Change Attribute Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView |
From |
To |
|
Change Attribute Type writer : BufferWriter to writer : ResultPartitionWriter in class org.apache.flink.runtime.io.network.api.writer.RecordWriter |
From |
To |
|
Change Attribute Type toSync : BufferWriter to toSync : ResultPartitionWriter in class org.apache.flink.runtime.iterative.task.IterationHeadPactTask |
From |
To |
|
Change Attribute Type partitionProvider : IntermediateResultPartitionProvider to partitionProvider : ResultPartitionProvider in class org.apache.flink.runtime.io.network.netty.PartitionRequestServerHandler |
From |
To |
|
Change Attribute Type inputChannel : MockInputChannel to inputChannel : TestInputChannel in class org.apache.flink.runtime.io.network.api.reader.IteratorWrappingTestSingleInputGate |
From |
To |
|
Change Attribute Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.operators.hash.HashPartition.BuildSideBuffer |
From |
To |
|
Change Attribute Type clients : ConcurrentMap<RemoteAddress,Object> to clients : ConcurrentMap<ConnectionID,Object> in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactory |
From |
To |
|
Change Attribute Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in class org.apache.flink.runtime.io.disk.FileChannelInputView |
From |
To |
|
Change Attribute Type producerExecutionId : ExecutionAttemptID to consumedPartitionId : ResultPartitionID in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor |
From |
To |
|
Change Attribute Type queueIterator : IntermediateResultPartitionQueueIterator to queueIterator : ResultSubpartitionView in class org.apache.flink.runtime.io.network.netty.PartitionRequestQueue.SequenceNumberingSubpartitionView |
From |
To |
|
Change Attribute Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.io.disk.SpillingBuffer |
From |
To |
|
Change Attribute Type partialPartitionInfos : ConcurrentLinkedQueue<PartialPartitionInfo> to partialInputChannelDeploymentDescriptors : ConcurrentLinkedQueue<PartialInputChannelDeploymentDescriptor> in class org.apache.flink.runtime.executiongraph.Execution |
From |
To |
|
Change Attribute Type remoteAddress : RemoteAddress to connectionId : ConnectionID in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient |
From |
To |
|
Change Attribute Type currentPartitionQueue : SequenceNumberingPartitionQueueIterator to currentPartitionQueue : SequenceNumberingSubpartitionView in class org.apache.flink.runtime.io.network.netty.PartitionRequestQueue |
From |
To |
|
Change Attribute Type partitionManager : IntermediateResultPartitionManager to partitionManager : ResultPartitionManager in class org.apache.flink.runtime.io.network.NetworkEnvironment |
From |
To |
|
Change Attribute Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in class org.apache.flink.runtime.io.network.partition.ResultPartition |
From |
To |
|
Change Attribute Type remoteAddress : RemoteAddress to connectionId : ConnectionID in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactory.ConnectingChannel |
From |
To |
|
Change Attribute Type resultType : IntermediateResultPartitionType to resultType : ResultPartitionType in class org.apache.flink.runtime.executiongraph.IntermediateResult |
From |
To |
|
Change Attribute Type resultPartitions : IntermediateResultPartition[] to resultPartitions : Map<IntermediateResultPartitionID,IntermediateResultPartition> in class org.apache.flink.runtime.executiongraph.ExecutionVertex |
From |
To |
|
Change Attribute Type outputs : List<BufferWriter> to outputs : List<ResultPartitionWriter> in class org.apache.flink.runtime.operators.testutils.MockEnvironment |
From |
To |
|
Change Attribute Type partitionProvider : IntermediateResultPartitionProvider to partitionProvider : ResultPartitionProvider in class org.apache.flink.runtime.io.network.netty.PartitionRequestProtocol |
From |
To |
|
Change Attribute Type currentWriter : BlockChannelWriter to currentWriter : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer |
From |
To |
|
Change Attribute Type currentSpilledProbeSide : BlockChannelReader to currentSpilledProbeSide : BlockChannelReader<MemorySegment> in class org.apache.flink.runtime.operators.hash.MutableHashTable |
From |
To |
|
Change Attribute Type writers : BufferWriter[] to writers : ResultPartitionWriter[] in class org.apache.flink.runtime.execution.RuntimeEnvironment |
From |
To |
|
Change Attribute Type producerAddress : RemoteAddress to producerAddress : ConnectionID in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel |
From |
To |
|
Change Attribute Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in class org.apache.flink.runtime.io.network.netty.NettyMessage.TaskEventRequest |
From |
To |
|
Change Attribute Type spilledBufferSource : BlockChannelReader to spilledBufferSource : BlockChannelReader<MemorySegment> in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer.ReadEnd |
From |
To |
|
Change Attribute Type partitionID : IntermediateResultPartitionID to partitionID : ResultPartitionID in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor |
From |
To |
|
Change Attribute Type partition : IntermediateResultPartition to partition : ResultPartition in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter |
From |
To |
|
Change Attribute Type partitionType : IntermediateResultPartitionType to partitionType : ResultPartitionType in class org.apache.flink.runtime.io.network.partition.ResultPartition |
From |
To |
|
Change Attribute Type partitionId : IntermediateResultPartitionID to partitionId : ResultPartitionID in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel |
From |
To |
|
Change Attribute Type producedPartitions : IntermediateResultPartition[] to producedPartitions : ResultPartition[] in class org.apache.flink.runtime.execution.RuntimeEnvironment |
From |
To |
|
Change Attribute Type producedPartitions : List<PartitionDeploymentDescriptor> to producedPartitions : List<ResultPartitionDeploymentDescriptor> in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |
|
Change Attribute Type reader : BlockChannelReader to reader : BlockChannelReader<MemorySegment> in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView |
From |
To |
|
Change Attribute Type probeSideChannel : BlockChannelWriter to probeSideChannel : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.operators.hash.HashPartition |
From |
To |
|
Change Attribute Type partitions : Table<ExecutionAttemptID,IntermediateResultPartitionID,IntermediateResultPartition> to registeredPartitions : Table<ExecutionAttemptID,IntermediateResultPartitionID,ResultPartition> in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager |
From |
To |
|
Change Attribute Type queueIterator : IntermediateResultPartitionQueueIterator to queueIterator : ResultSubpartitionView in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel |
From |
To |
|
Change Attribute Type initialBuildSideWriter : BlockChannelWriter to initialBuildSideWriter : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition |
From |
To |
|
Change Attribute Type writer : BlockChannelWriter to writer : BlockChannelWriter<MemorySegment> in class org.apache.flink.runtime.io.disk.FileChannelOutputView |
From |
To |
|
Rename Parameter remoteAddress : RemoteAddress to connectionId : ConnectionID in method package destroyPartitionRequestClient(connectionId ConnectionID, client PartitionRequestClient) : void in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactory |
From |
To |
|
Rename Parameter queueIndex : int to subpartitionIndex : int in method public requestSubpartition(subpartitionIndex int) : void in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel |
From |
To |
|
Rename Parameter slot : SimpleSlot to targetSlot : SimpleSlot in method package createDeploymentDescriptor(executionId ExecutionAttemptID, targetSlot SimpleSlot) : TaskDeploymentDescriptor in class org.apache.flink.runtime.executiongraph.ExecutionVertex |
From |
To |
|
Rename Parameter remoteAddress : RemoteAddress to connectionId : ConnectionID in method public createPartitionRequestClient(connectionId ConnectionID) : PartitionRequestClient in class org.apache.flink.runtime.io.network.LocalConnectionManager |
From |
To |
|
Rename Parameter consumers : List<List<ExecutionEdge>> to allConsumers : List<List<ExecutionEdge>> in method package scheduleOrUpdateConsumers(allConsumers List<List<ExecutionEdge>>) : void in class org.apache.flink.runtime.executiongraph.Execution |
From |
To |
|
Rename Parameter queueIndex : int to subpartitionIndex : int in method public abstract requestSubpartition(subpartitionIndex int) : void in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel |
From |
To |
|
Rename Parameter consumedPartitions : List<PartitionConsumerDeploymentDescriptor> to inputGates : List<InputGateDeploymentDescriptor> in method public TaskDeploymentDescriptor(jobID JobID, vertexID JobVertexID, executionId ExecutionAttemptID, taskName String, indexInSubtaskGroup int, numberOfSubtasks int, jobConfiguration Configuration, taskConfiguration Configuration, invokableClassName String, producedPartitions List<ResultPartitionDeploymentDescriptor>, inputGates List<InputGateDeploymentDescriptor>, requiredJarFiles List<BlobKey>, targetSlotNumber int, operatorStates StateHandle) in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |
|
Rename Parameter producerInstanceConnectionInfo : InstanceConnectionInfo to partitionConnectionInfo : InstanceConnectionInfo in method public PartialInputChannelDeploymentDescriptor(resultId IntermediateDataSetID, partitionID ResultPartitionID, partitionConnectionInfo InstanceConnectionInfo, partitionConnectionIndex int) in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor |
From |
To |
|
Rename Parameter queueIndex : int to subpartitionIndex : int in method public requestSubpartition(subpartitionIndex int) : void in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel |
From |
To |
|
Rename Parameter remoteAddress : RemoteAddress to connectionId : ConnectionID in method public ConnectingChannel(connectionId ConnectionID, clientFactory PartitionRequestClientFactory) in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactory.ConnectingChannel |
From |
To |
|
Rename Parameter remoteAddress : RemoteAddress to connectionId : ConnectionID in method public createPartitionRequestClient(connectionId ConnectionID) : PartitionRequestClient in class org.apache.flink.runtime.io.network.ConnectionManager |
From |
To |
|
Rename Parameter targetQueue : int to subpartitionIndex : int in method public add(buffer Buffer, subpartitionIndex int) : void in class org.apache.flink.runtime.io.network.partition.ResultPartition |
From |
To |
|
Rename Parameter remoteAddress : RemoteAddress to connectionId : ConnectionID in method package PartitionRequestClient(tcpChannel Channel, partitionRequestHandler PartitionRequestClientHandler, connectionId ConnectionID, clientFactory PartitionRequestClientFactory) in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient |
From |
To |
|
Rename Parameter remoteAddress : RemoteAddress to connectionId : ConnectionID in method public closeOpenChannelConnections(connectionId ConnectionID) : void in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactory |
From |
To |
|
Rename Parameter intermediateDataSetID : IntermediateDataSetID to resultId : IntermediateDataSetID in method public PartialInputChannelDeploymentDescriptor(resultId IntermediateDataSetID, partitionID ResultPartitionID, partitionConnectionInfo InstanceConnectionInfo, partitionConnectionIndex int) in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor |
From |
To |
|
Rename Parameter remoteAddress : RemoteAddress to connectionId : ConnectionID in method public closeOpenChannelConnections(connectionId ConnectionID) : void in class org.apache.flink.runtime.io.network.ConnectionManager |
From |
To |
|
Rename Parameter remoteAddress : RemoteAddress to connectionId : ConnectionID in method package createPartitionRequestClient(connectionId ConnectionID) : PartitionRequestClient in class org.apache.flink.runtime.io.network.netty.PartitionRequestClientFactory |
From |
To |
|
Rename Parameter partitionInfo : PartitionInfo to icdd : InputChannelDeploymentDescriptor in method public updateInputChannel(icdd InputChannelDeploymentDescriptor) : void in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate |
From |
To |
|
Rename Parameter remoteAddress : RemoteAddress to connectionId : ConnectionID in method public createPartitionRequestClient(connectionId ConnectionID) : PartitionRequestClient in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager |
From |
To |
|
Rename Parameter remoteAddress : RemoteAddress to connectionId : ConnectionID in method public closeOpenChannelConnections(connectionId ConnectionID) : void in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager |
From |
To |
|
Rename Parameter consumedPartitions : List<PartitionConsumerDeploymentDescriptor> to inputGates : List<InputGateDeploymentDescriptor> in method public TaskDeploymentDescriptor(jobID JobID, vertexID JobVertexID, executionId ExecutionAttemptID, taskName String, indexInSubtaskGroup int, numberOfSubtasks int, jobConfiguration Configuration, taskConfiguration Configuration, invokableClassName String, producedPartitions List<ResultPartitionDeploymentDescriptor>, inputGates List<InputGateDeploymentDescriptor>, requiredJarFiles List<BlobKey>, targetSlotNumber int) in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |