You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by ar...@apache.org on 2020/09/24 16:05:16 UTC

[flink] 05/07: [hotfix] Remove unused RecordWriterTest#TrackingBufferRecycler

This is an automated email from the ASF dual-hosted git repository.

arvid pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git

commit b7ed49d829ef031fb99834b377c2d598eedd3d1b
Author: kevin.cyj <ke...@alibaba-inc.com>
AuthorDate: Thu Sep 3 13:26:56 2020 +0800

    [hotfix] Remove unused RecordWriterTest#TrackingBufferRecycler
    
    This closes #13447
---
 .../runtime/io/network/api/writer/RecordWriterTest.java | 17 -----------------
 1 file changed, 17 deletions(-)

diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/api/writer/RecordWriterTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/api/writer/RecordWriterTest.java
index a0956ec..e381544 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/api/writer/RecordWriterTest.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/api/writer/RecordWriterTest.java
@@ -22,7 +22,6 @@ import org.apache.flink.api.common.JobID;
 import org.apache.flink.core.io.IOReadableWritable;
 import org.apache.flink.core.memory.DataInputView;
 import org.apache.flink.core.memory.DataOutputView;
-import org.apache.flink.core.memory.MemorySegment;
 import org.apache.flink.runtime.checkpoint.CheckpointOptions;
 import org.apache.flink.runtime.checkpoint.channel.ChannelStateReader;
 import org.apache.flink.runtime.checkpoint.channel.InputChannelInfo;
@@ -39,7 +38,6 @@ import org.apache.flink.runtime.io.network.buffer.BufferBuilder;
 import org.apache.flink.runtime.io.network.buffer.BufferBuilderAndConsumerTest;
 import org.apache.flink.runtime.io.network.buffer.BufferBuilderTestUtils;
 import org.apache.flink.runtime.io.network.buffer.BufferPool;
-import org.apache.flink.runtime.io.network.buffer.BufferRecycler;
 import org.apache.flink.runtime.io.network.buffer.NetworkBufferPool;
 import org.apache.flink.runtime.io.network.partition.NoOpBufferAvailablityListener;
 import org.apache.flink.runtime.io.network.partition.NoOpResultPartitionConsumableNotifier;
@@ -71,8 +69,6 @@ import org.junit.rules.TemporaryFolder;
 
 import java.io.IOException;
 import java.util.ArrayDeque;
-import java.util.ArrayList;
-import java.util.List;
 import java.util.Random;
 
 import static org.apache.flink.runtime.io.network.partition.PartitionTestUtils.createPartition;
@@ -490,17 +486,4 @@ public class RecordWriterTest {
 			in.readFully(bytes);
 		}
 	}
-
-	private static class TrackingBufferRecycler implements BufferRecycler {
-		private final ArrayList<MemorySegment> recycledMemorySegments = new ArrayList<>();
-
-		@Override
-		public synchronized void recycle(MemorySegment memorySegment) {
-			recycledMemorySegments.add(memorySegment);
-		}
-
-		public synchronized List<MemorySegment> getRecycledMemorySegments() {
-			return recycledMemorySegments;
-		}
-	}
 }