From 420b1dd124aff58bf85c0818c04167f3a6af9eab Mon Sep 17 00:00:00 2001 From: zentol Date: Mon, 14 May 2018 10:18:48 +0200 Subject: [PATCH] [FLINK-9176][tests] Remove category annotations --- .../program/rest/RestClusterClientTest.java | 3 --- flink-docs/pom.xml | 8 ------ .../avro/AvroExternalJarProgramITCase.java | 3 --- .../runtime/dispatcher/DispatcherTest.java | 3 --- .../FileArchivedExecutionGraphStoreTest.java | 3 --- .../dispatcher/MiniDispatcherTest.java | 3 --- .../heartbeat/HeartbeatManagerTest.java | 3 --- .../PartialConsumePipelinedResultTest.java | 3 --- .../SlotCountExceedingParallelismTest.java | 3 --- .../ScheduleOrUpdateConsumersTest.java | 3 --- .../runtime/jobmaster/JobMasterTest.java | 3 --- .../runtime/jobmaster/JobResultTest.java | 3 --- .../slotpool/AllocatedSlotsTest.java | 3 --- .../slotpool/AvailableSlotsTest.java | 3 --- .../jobmaster/slotpool/DualKeyMapTest.java | 3 --- .../jobmaster/slotpool/SlotPoolRpcTest.java | 3 --- .../slotpool/SlotPoolSchedulingTestBase.java | 3 --- .../jobmaster/slotpool/SlotPoolTest.java | 3 --- .../slotpool/SlotSharingManagerTest.java | 3 --- .../minicluster/MiniClusterITCase.java | 3 --- .../JobLeaderIdServiceTest.java | 3 --- .../ResourceManagerHATest.java | 3 --- .../ResourceManagerJobMasterTest.java | 3 --- .../ResourceManagerTaskExecutorTest.java | 3 --- .../resourcemanager/ResourceManagerTest.java | 3 --- .../slotmanager/SlotManagerTest.java | 3 --- .../slotmanager/SlotProtocolTest.java | 3 --- .../rest/RestServerEndpointITCase.java | 3 --- .../runtime/rest/RestServerEndpointTest.java | 3 --- .../job/BlobServerPortHandlerTest.java | 3 --- .../job/JobExecutionResultHandlerTest.java | 3 --- .../handler/job/JobSubmitHandlerTest.java | 3 --- .../metrics/AbstractMetricsHandlerTest.java | 3 --- .../job/metrics/MetricsHandlerTestBase.java | 3 --- .../rest/messages/MessageParametersTest.java | 3 --- .../RestRequestMarshallingTestBase.java | 3 --- .../RestResponseMarshallingTestBase.java | 3 --- .../metrics/AbstractMetricsHeadersTest.java | 3 --- .../metrics/JobManagerMetricsHeadersTest.java | 3 --- .../job/metrics/JobMetricsHeadersTest.java | 3 --- .../metrics/JobVertexMetricsHeadersTest.java | 3 --- .../metrics/MetricsFilterParameterTest.java | 3 --- .../metrics/SubtaskMetricsHeadersTest.java | 3 --- .../TaskManagerMetricsHeadersTest.java | 3 --- .../TaskManagerIdPathParameterTest.java | 3 --- .../flink/runtime/rpc/AsyncCallsTest.java | 3 --- .../runtime/rpc/FencedRpcEndpointTest.java | 3 --- .../flink/runtime/rpc/RpcConnectionTest.java | 3 --- .../flink/runtime/rpc/RpcEndpointTest.java | 3 --- .../runtime/rpc/akka/AkkaRpcActorTest.java | 3 --- .../runtime/rpc/akka/AkkaRpcServiceTest.java | 3 --- .../rpc/akka/MainThreadValidationTest.java | 3 --- .../rpc/akka/MessageSerializationTest.java | 3 --- .../NetworkBufferCalculationTest.java | 3 --- .../taskexecutor/TaskExecutorITCase.java | 3 --- .../taskexecutor/TaskExecutorTest.java | 3 --- .../TaskManagerServicesConfigurationTest.java | 3 --- .../taskexecutor/TaskManagerServicesTest.java | 3 --- .../TestingTaskExecutorGateway.java | 3 --- .../taskexecutor/slot/TimerServiceTest.java | 3 --- ...TaskCancelAsyncProducerConsumerITCase.java | 3 --- .../testutils/category/LegacyAndNew.java | 26 ------------------- .../flink/test/util/AbstractTestBase.java | 3 --- .../JobMasterTriggerSavepointIT.java | 3 --- .../accumulators/AccumulatorLiveITCase.java | 3 --- .../test/classloading/ClassLoaderITCase.java | 3 --- .../example/client/JobRetrievalITCase.java | 3 --- .../BigUserProgramJobSubmitITCase.java | 3 --- 68 files changed, 232 deletions(-) delete mode 100644 flink-test-utils-parent/flink-test-utils-junit/src/main/java/org/apache/flink/testutils/category/LegacyAndNew.java diff --git a/flink-clients/src/test/java/org/apache/flink/client/program/rest/RestClusterClientTest.java b/flink-clients/src/test/java/org/apache/flink/client/program/rest/RestClusterClientTest.java index fd05cadbec254..df0ce239311db 100644 --- a/flink-clients/src/test/java/org/apache/flink/client/program/rest/RestClusterClientTest.java +++ b/flink-clients/src/test/java/org/apache/flink/client/program/rest/RestClusterClientTest.java @@ -90,7 +90,6 @@ import org.apache.flink.runtime.rpc.RpcUtils; import org.apache.flink.runtime.util.ExecutorThreadFactory; import org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.apache.flink.util.FlinkException; import org.apache.flink.util.OptionalFailure; @@ -107,7 +106,6 @@ import org.junit.Assert; import org.junit.Before; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.mockito.Mock; import org.mockito.MockitoAnnotations; @@ -152,7 +150,6 @@ *

These tests verify that the client uses the appropriate headers for each * request, properly constructs the request bodies/parameters and processes the responses correctly. */ -@Category(New.class) public class RestClusterClientTest extends TestLogger { private static final String REST_ADDRESS = "http://localhost:1234"; diff --git a/flink-docs/pom.xml b/flink-docs/pom.xml index 223fe9d16c0f7..dfe33be9a0b5e 100644 --- a/flink-docs/pom.xml +++ b/flink-docs/pom.xml @@ -95,14 +95,6 @@ under the License. 1.11.2 test - - - - org.apache.flink - flink-test-utils-junit - ${project.version} - test - diff --git a/flink-formats/flink-avro/src/test/java/org/apache/flink/formats/avro/AvroExternalJarProgramITCase.java b/flink-formats/flink-avro/src/test/java/org/apache/flink/formats/avro/AvroExternalJarProgramITCase.java index 6766947326ea5..2f959b35b16a0 100644 --- a/flink-formats/flink-avro/src/test/java/org/apache/flink/formats/avro/AvroExternalJarProgramITCase.java +++ b/flink-formats/flink-avro/src/test/java/org/apache/flink/formats/avro/AvroExternalJarProgramITCase.java @@ -24,13 +24,11 @@ import org.apache.flink.runtime.minicluster.MiniCluster; import org.apache.flink.runtime.minicluster.MiniClusterConfiguration; import org.apache.flink.test.util.TestEnvironment; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.AfterClass; import org.junit.BeforeClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.io.File; import java.util.Collections; @@ -38,7 +36,6 @@ /** * IT case for the {@link AvroExternalJarProgram}. */ -@Category(New.class) public class AvroExternalJarProgramITCase extends TestLogger { private static final String JAR_FILE = "maven-test-jar.jar"; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/dispatcher/DispatcherTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/dispatcher/DispatcherTest.java index 18a8ec1f0d8ed..8d8bce615cec5 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/dispatcher/DispatcherTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/dispatcher/DispatcherTest.java @@ -65,7 +65,6 @@ import org.apache.flink.runtime.testtasks.NoOpInvokable; import org.apache.flink.runtime.testutils.InMemorySubmittedJobGraphStore; import org.apache.flink.runtime.util.TestingFatalErrorHandler; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.apache.flink.util.FlinkException; import org.apache.flink.util.TestLogger; @@ -76,7 +75,6 @@ import org.junit.BeforeClass; import org.junit.Rule; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.junit.rules.TemporaryFolder; import org.junit.rules.TestName; @@ -116,7 +114,6 @@ /** * Test for the {@link Dispatcher} component. */ -@Category(New.class) public class DispatcherTest extends TestLogger { private static RpcService rpcService; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/dispatcher/FileArchivedExecutionGraphStoreTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/dispatcher/FileArchivedExecutionGraphStoreTest.java index 90c5beb145374..c289634bc0733 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/dispatcher/FileArchivedExecutionGraphStoreTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/dispatcher/FileArchivedExecutionGraphStoreTest.java @@ -28,7 +28,6 @@ import org.apache.flink.runtime.rest.handler.legacy.utils.ArchivedExecutionGraphBuilder; import org.apache.flink.runtime.testingUtils.TestingUtils; import org.apache.flink.runtime.webmonitor.WebMonitorUtils; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.Preconditions; import org.apache.flink.util.TestLogger; @@ -41,7 +40,6 @@ import org.hamcrest.Matchers; import org.junit.ClassRule; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.junit.rules.TemporaryFolder; import java.io.File; @@ -60,7 +58,6 @@ /** * Tests for the {@link FileArchivedExecutionGraphStore}. */ -@Category(New.class) public class FileArchivedExecutionGraphStoreTest extends TestLogger { private static final List GLOBALLY_TERMINAL_JOB_STATUS = Arrays.stream(JobStatus.values()) diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/dispatcher/MiniDispatcherTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/dispatcher/MiniDispatcherTest.java index 6dfb243ff9f19..41f70186f5913 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/dispatcher/MiniDispatcherTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/dispatcher/MiniDispatcherTest.java @@ -44,7 +44,6 @@ import org.apache.flink.runtime.rpc.RpcUtils; import org.apache.flink.runtime.rpc.TestingRpcService; import org.apache.flink.runtime.util.TestingFatalErrorHandler; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.After; @@ -53,7 +52,6 @@ import org.junit.BeforeClass; import org.junit.ClassRule; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.junit.rules.TemporaryFolder; import javax.annotation.Nonnull; @@ -73,7 +71,6 @@ /** * Tests for the {@link MiniDispatcher}. */ -@Category(New.class) public class MiniDispatcherTest extends TestLogger { private static final Time timeout = Time.seconds(10L); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/heartbeat/HeartbeatManagerTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/heartbeat/HeartbeatManagerTest.java index 1d4babf53f83e..e4e86bb280336 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/heartbeat/HeartbeatManagerTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/heartbeat/HeartbeatManagerTest.java @@ -24,11 +24,9 @@ import org.apache.flink.runtime.concurrent.ScheduledExecutor; import org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter; import org.apache.flink.runtime.util.DirectExecutorService; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.slf4j.Logger; import org.slf4j.LoggerFactory; @@ -57,7 +55,6 @@ /** * Tests for the {@link HeartbeatManager}. */ -@Category(New.class) public class HeartbeatManagerTest extends TestLogger { private static final Logger LOG = LoggerFactory.getLogger(HeartbeatManagerTest.class); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/partition/PartialConsumePipelinedResultTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/partition/PartialConsumePipelinedResultTest.java index 7169796bea9df..2eec34cdae2e8 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/partition/PartialConsumePipelinedResultTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/partition/PartialConsumePipelinedResultTest.java @@ -34,15 +34,12 @@ import org.apache.flink.runtime.minicluster.MiniCluster; import org.apache.flink.runtime.minicluster.MiniClusterConfiguration; import org.apache.flink.runtime.testingUtils.TestingUtils; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.AfterClass; import org.junit.BeforeClass; import org.junit.Test; -import org.junit.experimental.categories.Category; -@Category(New.class) public class PartialConsumePipelinedResultTest extends TestLogger { // Test configuration diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmanager/SlotCountExceedingParallelismTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmanager/SlotCountExceedingParallelismTest.java index 2f3f555754720..6d58928d5e9e4 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmanager/SlotCountExceedingParallelismTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmanager/SlotCountExceedingParallelismTest.java @@ -32,18 +32,15 @@ import org.apache.flink.runtime.minicluster.MiniCluster; import org.apache.flink.runtime.minicluster.MiniClusterConfiguration; import org.apache.flink.runtime.testingUtils.TestingUtils; -import org.apache.flink.testutils.category.New; import org.apache.flink.types.IntValue; import org.apache.flink.util.TestLogger; import org.junit.AfterClass; import org.junit.BeforeClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.BitSet; -@Category(New.class) public class SlotCountExceedingParallelismTest extends TestLogger { // Test configuration diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmanager/scheduler/ScheduleOrUpdateConsumersTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmanager/scheduler/ScheduleOrUpdateConsumersTest.java index e16c3ed3b9a3b..aee526dc15338 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmanager/scheduler/ScheduleOrUpdateConsumersTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmanager/scheduler/ScheduleOrUpdateConsumersTest.java @@ -31,7 +31,6 @@ import org.apache.flink.runtime.minicluster.MiniCluster; import org.apache.flink.runtime.minicluster.MiniClusterConfiguration; import org.apache.flink.runtime.testingUtils.TestingUtils; -import org.apache.flink.testutils.category.New; import org.apache.flink.types.IntValue; import org.apache.flink.util.TestLogger; @@ -40,13 +39,11 @@ import org.junit.AfterClass; import org.junit.BeforeClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.List; import static org.apache.flink.runtime.jobmanager.SlotCountExceedingParallelismTest.SubtaskIndexReceiver.CONFIG_KEY; -@Category(New.class) public class ScheduleOrUpdateConsumersTest extends TestLogger { private static final int NUMBER_OF_TMS = 2; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/JobMasterTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/JobMasterTest.java index 2f6168140df72..4d1a021b0d8ba 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/JobMasterTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/JobMasterTest.java @@ -59,7 +59,6 @@ import org.apache.flink.runtime.taskmanager.LocalTaskManagerLocation; import org.apache.flink.runtime.taskmanager.TaskManagerLocation; import org.apache.flink.runtime.util.TestingFatalErrorHandler; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.hamcrest.Matchers; @@ -69,7 +68,6 @@ import org.junit.BeforeClass; import org.junit.ClassRule; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.junit.rules.TemporaryFolder; import javax.annotation.Nonnull; @@ -86,7 +84,6 @@ /** * Tests for {@link JobMaster}. */ -@Category(New.class) public class JobMasterTest extends TestLogger { @ClassRule diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/JobResultTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/JobResultTest.java index 3d793374b27e1..84c9da5e7de3a 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/JobResultTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/JobResultTest.java @@ -19,12 +19,10 @@ package org.apache.flink.runtime.jobmaster; import org.apache.flink.api.common.JobID; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.SerializedThrowable; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import static org.hamcrest.Matchers.equalTo; import static org.junit.Assert.assertThat; @@ -33,7 +31,6 @@ /** * Tests for {@link JobResult}. */ -@Category(New.class) public class JobResultTest extends TestLogger { @Test diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/AllocatedSlotsTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/AllocatedSlotsTest.java index e18412bfedf51..4dee92441daf9 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/AllocatedSlotsTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/AllocatedSlotsTest.java @@ -25,18 +25,15 @@ import org.apache.flink.runtime.jobmaster.SlotRequestId; import org.apache.flink.runtime.taskmanager.LocalTaskManagerLocation; import org.apache.flink.runtime.taskmanager.TaskManagerLocation; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import static org.junit.Assert.assertEquals; import static org.junit.Assert.assertFalse; import static org.junit.Assert.assertNull; import static org.junit.Assert.assertTrue; -@Category(New.class) public class AllocatedSlotsTest extends TestLogger { @Test diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/AvailableSlotsTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/AvailableSlotsTest.java index 4e9ca8852ba42..d477c69faa392 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/AvailableSlotsTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/AvailableSlotsTest.java @@ -24,11 +24,9 @@ import org.apache.flink.runtime.clusterframework.types.SlotProfile; import org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway; import org.apache.flink.runtime.taskmanager.TaskManagerLocation; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import static org.junit.Assert.assertEquals; import static org.junit.Assert.assertFalse; @@ -37,7 +35,6 @@ import static org.mockito.Mockito.mock; import static org.mockito.Mockito.when; -@Category(New.class) public class AvailableSlotsTest extends TestLogger { static final ResourceProfile DEFAULT_TESTING_PROFILE = new ResourceProfile(1.0, 512); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/DualKeyMapTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/DualKeyMapTest.java index 503173a3c23bc..1500d243cdb54 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/DualKeyMapTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/DualKeyMapTest.java @@ -19,12 +19,10 @@ package org.apache.flink.runtime.jobmaster.slotpool; import org.apache.flink.api.java.tuple.Tuple2; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.hamcrest.Matchers; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.HashSet; import java.util.Random; @@ -36,7 +34,6 @@ /** * Tests for the {@link DualKeyMap}. */ -@Category(New.class) public class DualKeyMapTest extends TestLogger { @Test diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotPoolRpcTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotPoolRpcTest.java index 52d7237bbfd4e..5dfffad9c3411 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotPoolRpcTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotPoolRpcTest.java @@ -46,7 +46,6 @@ import org.apache.flink.runtime.testingUtils.TestingUtils; import org.apache.flink.runtime.util.clock.Clock; import org.apache.flink.runtime.util.clock.SystemClock; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.apache.flink.util.Preconditions; import org.apache.flink.util.TestLogger; @@ -55,7 +54,6 @@ import org.junit.AfterClass; import org.junit.BeforeClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import javax.annotation.Nullable; @@ -72,7 +70,6 @@ /** * Tests for the SlotPool using a proper RPC setup. */ -@Category(New.class) public class SlotPoolRpcTest extends TestLogger { private static RpcService rpcService; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotPoolSchedulingTestBase.java b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotPoolSchedulingTestBase.java index a4575996ee7e3..04268da522278 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotPoolSchedulingTestBase.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotPoolSchedulingTestBase.java @@ -24,14 +24,12 @@ import org.apache.flink.runtime.rpc.RpcUtils; import org.apache.flink.runtime.rpc.TestingRpcService; import org.apache.flink.runtime.testingUtils.TestingUtils; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.After; import org.junit.AfterClass; import org.junit.Before; import org.junit.BeforeClass; -import org.junit.experimental.categories.Category; import java.util.concurrent.ExecutionException; import java.util.concurrent.TimeoutException; @@ -39,7 +37,6 @@ /** * Test base for {@link SlotPool} related scheduling test cases. */ -@Category(New.class) public class SlotPoolSchedulingTestBase extends TestLogger { private static final JobID jobId = new JobID(); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotPoolTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotPoolTest.java index a20332b25aec9..6f88e40dba154 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotPoolTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotPoolTest.java @@ -44,7 +44,6 @@ import org.apache.flink.runtime.taskmanager.TaskManagerLocation; import org.apache.flink.runtime.testingUtils.TestingUtils; import org.apache.flink.runtime.util.clock.ManualClock; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.apache.flink.util.FlinkException; import org.apache.flink.util.TestLogger; @@ -53,7 +52,6 @@ import org.junit.After; import org.junit.Before; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.slf4j.Logger; import org.slf4j.LoggerFactory; @@ -77,7 +75,6 @@ import static org.junit.Assert.assertTrue; import static org.junit.Assert.fail; -@Category(New.class) public class SlotPoolTest extends TestLogger { private static final Logger LOG = LoggerFactory.getLogger(SlotPoolTest.class); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotSharingManagerTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotSharingManagerTest.java index 9297f59544873..c325a6932dc29 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotSharingManagerTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/jobmaster/slotpool/SlotSharingManagerTest.java @@ -29,13 +29,11 @@ import org.apache.flink.runtime.jobmaster.SlotContext; import org.apache.flink.runtime.jobmaster.SlotRequestId; import org.apache.flink.runtime.taskmanager.LocalTaskManagerLocation; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.AbstractID; import org.apache.flink.util.FlinkException; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.Collections; import java.util.Objects; @@ -52,7 +50,6 @@ /** * Test cases for the {@link SlotSharingManager}. */ -@Category(New.class) public class SlotSharingManagerTest extends TestLogger { private static final SlotSharingGroupId SLOT_SHARING_GROUP_ID = new SlotSharingGroupId(); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/minicluster/MiniClusterITCase.java b/flink-runtime/src/test/java/org/apache/flink/runtime/minicluster/MiniClusterITCase.java index c9ac4c65257f4..a72e654568c26 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/minicluster/MiniClusterITCase.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/minicluster/MiniClusterITCase.java @@ -27,19 +27,16 @@ import org.apache.flink.runtime.jobgraph.JobVertex; import org.apache.flink.runtime.jobgraph.ScheduleMode; import org.apache.flink.runtime.testtasks.NoOpInvokable; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.BeforeClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.io.IOException; /** * Integration test cases for the {@link MiniCluster}. */ -@Category(New.class) public class MiniClusterITCase extends TestLogger { private static Configuration configuration; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/JobLeaderIdServiceTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/JobLeaderIdServiceTest.java index 25d7b5b989404..9346ac06d200a 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/JobLeaderIdServiceTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/JobLeaderIdServiceTest.java @@ -24,10 +24,8 @@ import org.apache.flink.runtime.highavailability.TestingHighAvailabilityServices; import org.apache.flink.runtime.jobmaster.JobMasterId; import org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.mockito.ArgumentCaptor; import org.mockito.invocation.InvocationOnMock; import org.mockito.stubbing.Answer; @@ -56,7 +54,6 @@ import static org.mockito.Mockito.times; import static org.mockito.Mockito.verify; -@Category(New.class) public class JobLeaderIdServiceTest extends TestLogger { /** diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerHATest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerHATest.java index 7843d7d8e7604..f42c708f0a472 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerHATest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerHATest.java @@ -31,11 +31,9 @@ import org.apache.flink.runtime.rpc.TestingRpcService; import org.apache.flink.runtime.testingUtils.TestingUtils; import org.apache.flink.runtime.util.TestingFatalErrorHandler; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Assert; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.UUID; import java.util.concurrent.CompletableFuture; @@ -45,7 +43,6 @@ /** * resourceManager HA test, including grant leadership and revoke leadership */ -@Category(New.class) public class ResourceManagerHATest extends TestLogger { @Test diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerJobMasterTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerJobMasterTest.java index 312adafbcc048..532732d78629d 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerJobMasterTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerJobMasterTest.java @@ -43,13 +43,11 @@ import org.apache.flink.runtime.rpc.exceptions.FencingTokenException; import org.apache.flink.runtime.testingUtils.TestingUtils; import org.apache.flink.runtime.util.TestingFatalErrorHandler; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.apache.flink.util.TestLogger; import org.junit.After; import org.junit.Before; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.UUID; import java.util.concurrent.CompletableFuture; @@ -60,7 +58,6 @@ import static org.junit.Assert.fail; import static org.mockito.Mockito.*; -@Category(New.class) public class ResourceManagerJobMasterTest extends TestLogger { private TestingRpcService rpcService; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerTaskExecutorTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerTaskExecutorTest.java index d49ba571efff9..58dc6ca40b178 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerTaskExecutorTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerTaskExecutorTest.java @@ -40,13 +40,11 @@ import org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess; import org.apache.flink.runtime.testingUtils.TestingUtils; import org.apache.flink.runtime.util.TestingFatalErrorHandler; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.apache.flink.util.TestLogger; import org.junit.After; import org.junit.Before; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.UUID; import java.util.concurrent.CompletableFuture; @@ -61,7 +59,6 @@ import static org.mockito.Mockito.mock; import static org.mockito.Mockito.when; -@Category(New.class) public class ResourceManagerTaskExecutorTest extends TestLogger { private final Time timeout = Time.seconds(10L); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerTest.java index 7dab6854513a8..f1737fe340505 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/ResourceManagerTest.java @@ -35,20 +35,17 @@ import org.apache.flink.runtime.taskexecutor.TestingTaskExecutorGateway; import org.apache.flink.runtime.testingUtils.TestingUtils; import org.apache.flink.runtime.util.TestingFatalErrorHandler; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.After; import org.junit.Assert; import org.junit.Before; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.UUID; import java.util.concurrent.CompletableFuture; import java.util.concurrent.ExecutionException; -@Category(New.class) public class ResourceManagerTest extends TestLogger { private TestingRpcService rpcService; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/slotmanager/SlotManagerTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/slotmanager/SlotManagerTest.java index 59de473c6cb7f..5089bd673ecf9 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/slotmanager/SlotManagerTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/slotmanager/SlotManagerTest.java @@ -39,11 +39,9 @@ import org.apache.flink.runtime.taskexecutor.TestingTaskExecutorGateway; import org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException; import org.apache.flink.runtime.testingUtils.TestingUtils; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.mockito.ArgumentCaptor; import java.util.Arrays; @@ -74,7 +72,6 @@ import static org.mockito.Mockito.verify; import static org.mockito.Mockito.when; -@Category(New.class) public class SlotManagerTest extends TestLogger { /** diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/slotmanager/SlotProtocolTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/slotmanager/SlotProtocolTest.java index eac530d6a7ca7..8f6317c427f27 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/slotmanager/SlotProtocolTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/resourcemanager/slotmanager/SlotProtocolTest.java @@ -34,13 +34,11 @@ import org.apache.flink.runtime.taskexecutor.SlotStatus; import org.apache.flink.runtime.taskexecutor.TaskExecutorGateway; import org.apache.flink.runtime.testingUtils.TestingUtils; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExecutorUtils; import org.apache.flink.util.TestLogger; import org.junit.AfterClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.mockito.Mockito; import java.util.Collections; @@ -55,7 +53,6 @@ import static org.mockito.Mockito.timeout; import static org.mockito.Mockito.verify; -@Category(New.class) public class SlotProtocolTest extends TestLogger { private static final long timeout = 10000L; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/RestServerEndpointITCase.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/RestServerEndpointITCase.java index d4e75a79f64f3..dad3b4f858867 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/RestServerEndpointITCase.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/RestServerEndpointITCase.java @@ -47,7 +47,6 @@ import org.apache.flink.runtime.testingUtils.TestingUtils; import org.apache.flink.runtime.webmonitor.RestfulGateway; import org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.apache.flink.util.TestLogger; @@ -62,7 +61,6 @@ import org.junit.Before; import org.junit.Rule; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.junit.rules.TemporaryFolder; import org.junit.runner.RunWith; import org.junit.runners.Parameterized; @@ -102,7 +100,6 @@ /** * IT cases for {@link RestClient} and {@link RestServerEndpoint}. */ -@Category(New.class) @RunWith(Parameterized.class) public class RestServerEndpointITCase extends TestLogger { diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/RestServerEndpointTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/RestServerEndpointTest.java index bdb3f5dc1944d..f7fcc621e6a2f 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/RestServerEndpointTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/RestServerEndpointTest.java @@ -18,13 +18,11 @@ package org.apache.flink.runtime.rest; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Assume; import org.junit.Rule; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.junit.rules.TemporaryFolder; import org.slf4j.helpers.NOPLogger; @@ -44,7 +42,6 @@ /** * Test cases for the {@link RestServerEndpoint}. */ -@Category(New.class) public class RestServerEndpointTest extends TestLogger { @Rule diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/BlobServerPortHandlerTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/BlobServerPortHandlerTest.java index 6c81313c364e8..15c2eb4040bac 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/BlobServerPortHandlerTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/BlobServerPortHandlerTest.java @@ -28,14 +28,12 @@ import org.apache.flink.runtime.rest.messages.EmptyRequestBody; import org.apache.flink.runtime.rpc.RpcUtils; import org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.apache.flink.shaded.netty4.io.netty.handler.codec.http.HttpResponseStatus; import org.junit.Assert; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.Collections; import java.util.concurrent.CompletableFuture; @@ -48,7 +46,6 @@ /** * Tests for the {@link BlobServerPortHandler}. */ -@Category(New.class) public class BlobServerPortHandlerTest extends TestLogger { private static final int PORT = 64; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/JobExecutionResultHandlerTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/JobExecutionResultHandlerTest.java index e32e16a6480dc..43a7efce043d4 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/JobExecutionResultHandlerTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/JobExecutionResultHandlerTest.java @@ -33,7 +33,6 @@ import org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody; import org.apache.flink.runtime.rest.messages.queue.QueueStatus; import org.apache.flink.runtime.webmonitor.TestingRestfulGateway; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.apache.flink.util.TestLogger; @@ -41,7 +40,6 @@ import org.junit.Before; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.Collections; import java.util.concurrent.CompletableFuture; @@ -57,7 +55,6 @@ /** * Tests for {@link JobExecutionResultHandler}. */ -@Category(New.class) public class JobExecutionResultHandlerTest extends TestLogger { private static final JobID TEST_JOB_ID = new JobID(); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/JobSubmitHandlerTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/JobSubmitHandlerTest.java index ac09186230dc2..212af5f02be9f 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/JobSubmitHandlerTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/JobSubmitHandlerTest.java @@ -28,14 +28,12 @@ import org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody; import org.apache.flink.runtime.rpc.RpcUtils; import org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.apache.flink.shaded.netty4.io.netty.handler.codec.http.HttpResponseStatus; import org.junit.Assert; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.Collections; import java.util.concurrent.CompletableFuture; @@ -47,7 +45,6 @@ /** * Tests for the {@link JobSubmitHandler}. */ -@Category(New.class) public class JobSubmitHandlerTest extends TestLogger { @Test diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/metrics/AbstractMetricsHandlerTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/metrics/AbstractMetricsHandlerTest.java index c22b169dab314..4f6cc7ae572e4 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/metrics/AbstractMetricsHandlerTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/metrics/AbstractMetricsHandlerTest.java @@ -35,12 +35,10 @@ import org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody; import org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter; import org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Before; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.mockito.Mock; import org.mockito.MockitoAnnotations; @@ -61,7 +59,6 @@ /** * Tests for {@link AbstractMetricsHandler}. */ -@Category(New.class) public class AbstractMetricsHandlerTest extends TestLogger { private static final String TEST_METRIC_NAME = "test_counter"; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/metrics/MetricsHandlerTestBase.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/metrics/MetricsHandlerTestBase.java index bf37cc95e29c0..f8a0b398762ce 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/metrics/MetricsHandlerTestBase.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/handler/job/metrics/MetricsHandlerTestBase.java @@ -29,12 +29,10 @@ import org.apache.flink.runtime.rest.messages.job.metrics.Metric; import org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody; import org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Before; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.mockito.Mock; import org.mockito.MockitoAnnotations; @@ -51,7 +49,6 @@ /** * Unit test base class for subclasses of {@link AbstractMetricsHandler}. */ -@Category(New.class) public abstract class MetricsHandlerTestBase extends TestLogger { private static final String TEST_METRIC_NAME = "test_counter"; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/MessageParametersTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/MessageParametersTest.java index 5bc9b60a9b4e3..104673dfdc603 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/MessageParametersTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/MessageParametersTest.java @@ -19,12 +19,10 @@ package org.apache.flink.runtime.rest.messages; import org.apache.flink.api.common.JobID; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Assert; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.Collection; import java.util.Collections; @@ -32,7 +30,6 @@ /** * Tests for {@link MessageParameters}. */ -@Category(New.class) public class MessageParametersTest extends TestLogger { @Test public void testResolveUrl() { diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/RestRequestMarshallingTestBase.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/RestRequestMarshallingTestBase.java index c5ae563264c1d..64a0e4af18b60 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/RestRequestMarshallingTestBase.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/RestRequestMarshallingTestBase.java @@ -19,19 +19,16 @@ package org.apache.flink.runtime.rest.messages; import org.apache.flink.runtime.rest.util.RestMapperUtils; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ObjectMapper; import org.junit.Assert; import org.junit.Test; -import org.junit.experimental.categories.Category; /** * Test base for verifying that marshalling / unmarshalling REST {@link RequestBody}s work properly. */ -@Category(New.class) public abstract class RestRequestMarshallingTestBase extends TestLogger { /** diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/RestResponseMarshallingTestBase.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/RestResponseMarshallingTestBase.java index fa7ec4c2d62bc..6dfc7eb08ddd1 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/RestResponseMarshallingTestBase.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/RestResponseMarshallingTestBase.java @@ -19,7 +19,6 @@ package org.apache.flink.runtime.rest.messages; import org.apache.flink.runtime.rest.util.RestMapperUtils; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.JavaType; @@ -27,7 +26,6 @@ import org.junit.Assert; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.Collection; import java.util.Collections; @@ -35,7 +33,6 @@ /** * Test base for verifying that marshalling / unmarshalling REST {@link ResponseBody}s work properly. */ -@Category(New.class) public abstract class RestResponseMarshallingTestBase extends TestLogger { /** diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/AbstractMetricsHeadersTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/AbstractMetricsHeadersTest.java index cd5fc069998e4..279a61d3ab17d 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/AbstractMetricsHeadersTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/AbstractMetricsHeadersTest.java @@ -21,14 +21,12 @@ import org.apache.flink.runtime.rest.HttpMethodWrapper; import org.apache.flink.runtime.rest.messages.EmptyMessageParameters; import org.apache.flink.runtime.rest.messages.EmptyRequestBody; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.apache.flink.shaded.netty4.io.netty.handler.codec.http.HttpResponseStatus; import org.junit.Before; import org.junit.Test; -import org.junit.experimental.categories.Category; import static org.hamcrest.Matchers.equalTo; import static org.junit.Assert.assertThat; @@ -36,7 +34,6 @@ /** * Tests for {@link AbstractMetricsHeaders}. */ -@Category(New.class) public class AbstractMetricsHeadersTest extends TestLogger { private AbstractMetricsHeaders metricsHandlerHeaders; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/JobManagerMetricsHeadersTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/JobManagerMetricsHeadersTest.java index 74c7603062a30..c1b0b0497e32e 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/JobManagerMetricsHeadersTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/JobManagerMetricsHeadersTest.java @@ -18,11 +18,9 @@ package org.apache.flink.runtime.rest.messages.job.metrics; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import static org.hamcrest.Matchers.equalTo; import static org.hamcrest.Matchers.instanceOf; @@ -31,7 +29,6 @@ /** * Tests for {@link JobManagerMetricsHeaders}. */ -@Category(New.class) public class JobManagerMetricsHeadersTest extends TestLogger { private final JobManagerMetricsHeaders jobManagerMetricsHeaders = diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/JobMetricsHeadersTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/JobMetricsHeadersTest.java index 581144252a1f9..b1a98e2c7a933 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/JobMetricsHeadersTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/JobMetricsHeadersTest.java @@ -19,11 +19,9 @@ package org.apache.flink.runtime.rest.messages.job.metrics; import org.apache.flink.runtime.rest.messages.JobIDPathParameter; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import static org.hamcrest.Matchers.equalTo; import static org.hamcrest.Matchers.instanceOf; @@ -32,7 +30,6 @@ /** * Tests for {@link JobMetricsHeaders}. */ -@Category(New.class) public class JobMetricsHeadersTest extends TestLogger { private final JobMetricsHeaders jobMetricsHeaders = JobMetricsHeaders.getInstance(); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/JobVertexMetricsHeadersTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/JobVertexMetricsHeadersTest.java index 5dd256704e571..82988f2013e3c 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/JobVertexMetricsHeadersTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/JobVertexMetricsHeadersTest.java @@ -20,11 +20,9 @@ import org.apache.flink.runtime.rest.messages.JobIDPathParameter; import org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import static org.hamcrest.Matchers.equalTo; import static org.hamcrest.Matchers.instanceOf; @@ -33,7 +31,6 @@ /** * Tests for {@link JobVertexMetricsHeaders}. */ -@Category(New.class) public class JobVertexMetricsHeadersTest extends TestLogger { private final JobVertexMetricsHeaders jobVertexMetricsHeaders = JobVertexMetricsHeaders diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/MetricsFilterParameterTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/MetricsFilterParameterTest.java index f30132dc391c3..13f6911dd04a8 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/MetricsFilterParameterTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/MetricsFilterParameterTest.java @@ -18,12 +18,10 @@ package org.apache.flink.runtime.rest.messages.job.metrics; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Before; import org.junit.Test; -import org.junit.experimental.categories.Category; import static org.hamcrest.Matchers.equalTo; import static org.junit.Assert.assertFalse; @@ -32,7 +30,6 @@ /** * Tests for {@link MetricsFilterParameter}. */ -@Category(New.class) public class MetricsFilterParameterTest extends TestLogger { private MetricsFilterParameter metricsFilterParameter; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/SubtaskMetricsHeadersTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/SubtaskMetricsHeadersTest.java index f99c423515ebd..b567bb478bdfa 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/SubtaskMetricsHeadersTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/SubtaskMetricsHeadersTest.java @@ -21,11 +21,9 @@ import org.apache.flink.runtime.rest.messages.JobIDPathParameter; import org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter; import org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import static org.hamcrest.Matchers.equalTo; import static org.hamcrest.Matchers.instanceOf; @@ -34,7 +32,6 @@ /** * Tests for {@link SubtaskMetricsHeaders}. */ -@Category(New.class) public class SubtaskMetricsHeadersTest extends TestLogger { private final SubtaskMetricsHeaders subtaskMetricsHeaders = SubtaskMetricsHeaders.getInstance(); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/TaskManagerMetricsHeadersTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/TaskManagerMetricsHeadersTest.java index 66b0d8ecc411e..f1ccc24c00c69 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/TaskManagerMetricsHeadersTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/job/metrics/TaskManagerMetricsHeadersTest.java @@ -19,11 +19,9 @@ package org.apache.flink.runtime.rest.messages.job.metrics; import org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import static org.hamcrest.Matchers.equalTo; import static org.hamcrest.Matchers.instanceOf; @@ -32,7 +30,6 @@ /** * Tests for {@link TaskManagerMetricsHeaders}. */ -@Category(New.class) public class TaskManagerMetricsHeadersTest extends TestLogger { private final TaskManagerMetricsHeaders taskManagerMetricsHeaders = diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/taskmanager/TaskManagerIdPathParameterTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/taskmanager/TaskManagerIdPathParameterTest.java index 9c6291584a0e4..3acde48a3dd74 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/taskmanager/TaskManagerIdPathParameterTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rest/messages/taskmanager/TaskManagerIdPathParameterTest.java @@ -19,12 +19,10 @@ package org.apache.flink.runtime.rest.messages.taskmanager; import org.apache.flink.runtime.clusterframework.types.ResourceID; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Before; import org.junit.Test; -import org.junit.experimental.categories.Category; import static org.hamcrest.Matchers.equalTo; import static org.junit.Assert.assertThat; @@ -33,7 +31,6 @@ /** * Tests for {@link TaskManagerIdPathParameter}. */ -@Category(New.class) public class TaskManagerIdPathParameterTest extends TestLogger { private TaskManagerIdPathParameter taskManagerIdPathParameter; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/AsyncCallsTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/AsyncCallsTest.java index c194d447f42b3..1331bb74e0d5d 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/AsyncCallsTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/AsyncCallsTest.java @@ -25,7 +25,6 @@ import org.apache.flink.runtime.messages.Acknowledge; import org.apache.flink.runtime.rpc.akka.AkkaRpcService; import org.apache.flink.runtime.rpc.exceptions.FencingTokenException; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.apache.flink.util.TestLogger; @@ -33,7 +32,6 @@ import akka.actor.Terminated; import org.junit.AfterClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.Arrays; import java.util.UUID; @@ -52,7 +50,6 @@ import static org.junit.Assert.assertTrue; import static org.junit.Assert.fail; -@Category(New.class) public class AsyncCallsTest extends TestLogger { // ------------------------------------------------------------------------ diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/FencedRpcEndpointTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/FencedRpcEndpointTest.java index 00ff3d7bc5c24..20b75beb61a1c 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/FencedRpcEndpointTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/FencedRpcEndpointTest.java @@ -23,7 +23,6 @@ import org.apache.flink.runtime.messages.Acknowledge; import org.apache.flink.runtime.rpc.exceptions.FencingTokenException; import org.apache.flink.runtime.rpc.exceptions.RpcException; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.apache.flink.util.FlinkException; import org.apache.flink.util.TestLogger; @@ -31,7 +30,6 @@ import org.junit.AfterClass; import org.junit.BeforeClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.UUID; import java.util.concurrent.CompletableFuture; @@ -46,7 +44,6 @@ import static org.junit.Assert.assertTrue; import static org.junit.Assert.fail; -@Category(New.class) public class FencedRpcEndpointTest extends TestLogger { private static final Time timeout = Time.seconds(10L); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/RpcConnectionTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/RpcConnectionTest.java index 78137e86ff76b..ce3e7ea08f96a 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/RpcConnectionTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/RpcConnectionTest.java @@ -27,12 +27,10 @@ import org.apache.flink.runtime.rpc.akka.AkkaRpcService; import org.apache.flink.runtime.rpc.exceptions.RpcConnectionException; import org.apache.flink.runtime.taskexecutor.TaskExecutorGateway; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import akka.actor.Terminated; import org.junit.Test; -import org.junit.experimental.categories.Category; import scala.Option; import scala.Tuple2; @@ -49,7 +47,6 @@ * This test validates that the RPC service gives a good message when it cannot * connect to an RpcEndpoint. */ -@Category(New.class) public class RpcConnectionTest extends TestLogger { @Test diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/RpcEndpointTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/RpcEndpointTest.java index 1ca39496f9227..9aa452071f112 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/RpcEndpointTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/RpcEndpointTest.java @@ -22,7 +22,6 @@ import org.apache.flink.runtime.akka.AkkaUtils; import org.apache.flink.runtime.concurrent.FutureUtils; import org.apache.flink.runtime.rpc.akka.AkkaRpcService; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import akka.actor.ActorSystem; @@ -30,7 +29,6 @@ import org.junit.AfterClass; import org.junit.BeforeClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.Arrays; import java.util.concurrent.CompletableFuture; @@ -42,7 +40,6 @@ /** * Tests for the RpcEndpoint and its self gateways. */ -@Category(New.class) public class RpcEndpointTest extends TestLogger { private static final Time TIMEOUT = Time.seconds(10L); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/AkkaRpcActorTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/AkkaRpcActorTest.java index a92235c04f6d0..bf77031df453a 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/AkkaRpcActorTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/AkkaRpcActorTest.java @@ -28,7 +28,6 @@ import org.apache.flink.runtime.rpc.TestingRpcService; import org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException; import org.apache.flink.runtime.rpc.exceptions.RpcConnectionException; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.FlinkException; import org.apache.flink.util.Preconditions; import org.apache.flink.util.TestLogger; @@ -38,7 +37,6 @@ import org.junit.AfterClass; import org.junit.BeforeClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.concurrent.CompletableFuture; import java.util.concurrent.ExecutionException; @@ -51,7 +49,6 @@ import static org.junit.Assert.assertTrue; import static org.junit.Assert.fail; -@Category(New.class) public class AkkaRpcActorTest extends TestLogger { // ------------------------------------------------------------------------ diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/AkkaRpcServiceTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/AkkaRpcServiceTest.java index d73ee40ec047e..3bf86a837fe0a 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/AkkaRpcServiceTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/AkkaRpcServiceTest.java @@ -23,14 +23,12 @@ import org.apache.flink.runtime.akka.AkkaUtils; import org.apache.flink.runtime.concurrent.FutureUtils; import org.apache.flink.runtime.concurrent.ScheduledExecutor; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import akka.actor.ActorSystem; import akka.actor.Terminated; import org.junit.AfterClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.Arrays; import java.util.concurrent.Callable; @@ -46,7 +44,6 @@ import static org.junit.Assert.assertTrue; import static org.junit.Assert.fail; -@Category(New.class) public class AkkaRpcServiceTest extends TestLogger { // ------------------------------------------------------------------------ diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/MainThreadValidationTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/MainThreadValidationTest.java index 34f8eb85c2103..2ce2905538c01 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/MainThreadValidationTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/MainThreadValidationTest.java @@ -25,16 +25,13 @@ import org.apache.flink.runtime.rpc.RpcGateway; import org.apache.flink.runtime.rpc.RpcService; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.concurrent.CompletableFuture; import static org.junit.Assert.assertTrue; -@Category(New.class) public class MainThreadValidationTest extends TestLogger { @Test diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/MessageSerializationTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/MessageSerializationTest.java index 02c0094048582..9a2a1feb477ce 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/MessageSerializationTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/rpc/akka/MessageSerializationTest.java @@ -24,7 +24,6 @@ import org.apache.flink.runtime.rpc.RpcEndpoint; import org.apache.flink.runtime.rpc.RpcGateway; import org.apache.flink.runtime.rpc.RpcService; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import akka.actor.ActorSystem; @@ -34,7 +33,6 @@ import org.junit.AfterClass; import org.junit.BeforeClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.io.IOException; import java.util.ArrayList; @@ -51,7 +49,6 @@ /** * Tests that akka rpc invocation messages are properly serialized and errors reported */ -@Category(New.class) public class MessageSerializationTest extends TestLogger { private static ActorSystem actorSystem1; private static ActorSystem actorSystem2; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/NetworkBufferCalculationTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/NetworkBufferCalculationTest.java index 2116c2f36c8a0..83e3c36a9f44f 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/NetworkBufferCalculationTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/NetworkBufferCalculationTest.java @@ -22,11 +22,9 @@ import org.apache.flink.core.memory.MemoryType; import org.apache.flink.runtime.state.LocalRecoveryConfig; import org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration; -import org.apache.flink.testutils.category.LegacyAndNew; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.net.InetAddress; @@ -35,7 +33,6 @@ /** * Tests the network buffer calculation from heap size. */ -@Category(LegacyAndNew.class) public class NetworkBufferCalculationTest extends TestLogger { /** diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskExecutorITCase.java b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskExecutorITCase.java index 885d99f616cd9..59d254ff16372 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskExecutorITCase.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskExecutorITCase.java @@ -58,12 +58,10 @@ import org.apache.flink.runtime.taskmanager.TaskManagerLocation; import org.apache.flink.runtime.testingUtils.TestingUtils; import org.apache.flink.runtime.util.TestingFatalErrorHandler; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.hamcrest.Matchers; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.mockito.Mockito; import java.io.File; @@ -86,7 +84,6 @@ import static org.mockito.Mockito.verify; import static org.mockito.Mockito.when; -@Category(New.class) public class TaskExecutorITCase extends TestLogger { private final Time timeout = Time.seconds(10L); diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskExecutorTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskExecutorTest.java index 465619e278e64..c24459d2962a9 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskExecutorTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskExecutorTest.java @@ -88,7 +88,6 @@ import org.apache.flink.runtime.taskmanager.TaskManagerLocation; import org.apache.flink.runtime.testingUtils.TestingUtils; import org.apache.flink.runtime.util.TestingFatalErrorHandler; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.FlinkException; import org.apache.flink.util.SerializedValue; import org.apache.flink.util.TestLogger; @@ -97,7 +96,6 @@ import org.junit.Before; import org.junit.Rule; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.junit.rules.TemporaryFolder; import org.junit.rules.TestName; import org.mockito.ArgumentCaptor; @@ -139,7 +137,6 @@ import static org.mockito.Mockito.verify; import static org.mockito.Mockito.when; -@Category(New.class) public class TaskExecutorTest extends TestLogger { @Rule diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskManagerServicesConfigurationTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskManagerServicesConfigurationTest.java index 9cf76f20d5553..960a13d861abe 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskManagerServicesConfigurationTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskManagerServicesConfigurationTest.java @@ -20,18 +20,15 @@ import org.apache.flink.configuration.Configuration; import org.apache.flink.configuration.TaskManagerOptions; -import org.apache.flink.testutils.category.LegacyAndNew; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import static org.junit.Assert.*; /** * Unit test for {@link TaskManagerServicesConfiguration}. */ -@Category(LegacyAndNew.class) public class TaskManagerServicesConfigurationTest extends TestLogger { /** * Verifies that {@link TaskManagerServicesConfiguration#hasNewNetworkBufConf(Configuration)} diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskManagerServicesTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskManagerServicesTest.java index 097fc61369fb5..77d6ec77a5aff 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskManagerServicesTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TaskManagerServicesTest.java @@ -20,11 +20,9 @@ import org.apache.flink.configuration.Configuration; import org.apache.flink.configuration.TaskManagerOptions; -import org.apache.flink.testutils.category.LegacyAndNew; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.Random; @@ -35,7 +33,6 @@ /** * Unit test for {@link TaskManagerServices}. */ -@Category(LegacyAndNew.class) public class TaskManagerServicesTest extends TestLogger { /** diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TestingTaskExecutorGateway.java b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TestingTaskExecutorGateway.java index 43b0be249bced..4957a5ab1cfe5 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TestingTaskExecutorGateway.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/TestingTaskExecutorGateway.java @@ -34,10 +34,8 @@ import org.apache.flink.runtime.messages.Acknowledge; import org.apache.flink.runtime.messages.StackTraceSampleResponse; import org.apache.flink.runtime.resourcemanager.ResourceManagerId; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.Preconditions; -import org.junit.experimental.categories.Category; import java.util.concurrent.CompletableFuture; import java.util.function.Consumer; @@ -45,7 +43,6 @@ /** * Simple {@link TaskExecutorGateway} implementation for testing purposes. */ -@Category(New.class) public class TestingTaskExecutorGateway implements TaskExecutorGateway { private final String address; diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/slot/TimerServiceTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/slot/TimerServiceTest.java index 642c7900cd4ea..77906226feda4 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/slot/TimerServiceTest.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/taskexecutor/slot/TimerServiceTest.java @@ -19,11 +19,9 @@ package org.apache.flink.runtime.taskexecutor.slot; import org.apache.flink.runtime.clusterframework.types.AllocationID; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.mockito.internal.util.reflection.Whitebox; import java.util.Map; @@ -39,7 +37,6 @@ import static org.mockito.Mockito.verify; import static org.mockito.Mockito.when; -@Category(New.class) public class TimerServiceTest extends TestLogger { /** * Test all timeouts registered can be unregistered diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/taskmanager/TaskCancelAsyncProducerConsumerITCase.java b/flink-runtime/src/test/java/org/apache/flink/runtime/taskmanager/TaskCancelAsyncProducerConsumerITCase.java index 62ae19b997158..fe7e66101a062 100644 --- a/flink-runtime/src/test/java/org/apache/flink/runtime/taskmanager/TaskCancelAsyncProducerConsumerITCase.java +++ b/flink-runtime/src/test/java/org/apache/flink/runtime/taskmanager/TaskCancelAsyncProducerConsumerITCase.java @@ -37,12 +37,10 @@ import org.apache.flink.runtime.minicluster.MiniCluster; import org.apache.flink.runtime.minicluster.MiniClusterConfiguration; import org.apache.flink.runtime.testingUtils.TestingUtils; -import org.apache.flink.testutils.category.New; import org.apache.flink.types.LongValue; import org.apache.flink.util.TestLogger; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.time.Duration; import java.util.Arrays; @@ -53,7 +51,6 @@ import static org.junit.Assert.assertNotNull; import static org.junit.Assert.assertTrue; -@Category(New.class) public class TaskCancelAsyncProducerConsumerITCase extends TestLogger { // The Exceptions thrown by the producer/consumer Threads diff --git a/flink-test-utils-parent/flink-test-utils-junit/src/main/java/org/apache/flink/testutils/category/LegacyAndNew.java b/flink-test-utils-parent/flink-test-utils-junit/src/main/java/org/apache/flink/testutils/category/LegacyAndNew.java deleted file mode 100644 index 180f87eba1eb2..0000000000000 --- a/flink-test-utils-parent/flink-test-utils-junit/src/main/java/org/apache/flink/testutils/category/LegacyAndNew.java +++ /dev/null @@ -1,26 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one - * or more contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. The ASF licenses this file - * to you under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance - * with the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - */ - -package org.apache.flink.testutils.category; - -/** - * Category marker interface for tests relevant for the legacy and - * new architecture. - */ -public interface LegacyAndNew { -} diff --git a/flink-test-utils-parent/flink-test-utils/src/main/java/org/apache/flink/test/util/AbstractTestBase.java b/flink-test-utils-parent/flink-test-utils/src/main/java/org/apache/flink/test/util/AbstractTestBase.java index c53ed8b4d5eeb..65b351daa696e 100644 --- a/flink-test-utils-parent/flink-test-utils/src/main/java/org/apache/flink/test/util/AbstractTestBase.java +++ b/flink-test-utils-parent/flink-test-utils/src/main/java/org/apache/flink/test/util/AbstractTestBase.java @@ -19,11 +19,9 @@ package org.apache.flink.test.util; import org.apache.flink.configuration.Configuration; -import org.apache.flink.testutils.category.LegacyAndNew; import org.apache.flink.util.FileUtils; import org.junit.ClassRule; -import org.junit.experimental.categories.Category; import org.junit.rules.TemporaryFolder; import java.io.File; @@ -56,7 +54,6 @@ * * */ -@Category(LegacyAndNew.class) public abstract class AbstractTestBase extends TestBaseUtils { private static final int DEFAULT_PARALLELISM = 4; diff --git a/flink-tests/src/test/java/org/apache/flink/runtime/jobmaster/JobMasterTriggerSavepointIT.java b/flink-tests/src/test/java/org/apache/flink/runtime/jobmaster/JobMasterTriggerSavepointIT.java index db3313cd7c464..8ff85e05c2182 100644 --- a/flink-tests/src/test/java/org/apache/flink/runtime/jobmaster/JobMasterTriggerSavepointIT.java +++ b/flink-tests/src/test/java/org/apache/flink/runtime/jobmaster/JobMasterTriggerSavepointIT.java @@ -36,14 +36,12 @@ import org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration; import org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings; import org.apache.flink.test.util.AbstractTestBase; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.junit.Assume; import org.junit.Before; import org.junit.Rule; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.junit.rules.TemporaryFolder; import java.io.IOException; @@ -67,7 +65,6 @@ * * @see org.apache.flink.runtime.jobmaster.JobMaster */ -@Category(New.class) public class JobMasterTriggerSavepointIT extends AbstractTestBase { private static CountDownLatch invokeLatch; diff --git a/flink-tests/src/test/java/org/apache/flink/test/accumulators/AccumulatorLiveITCase.java b/flink-tests/src/test/java/org/apache/flink/test/accumulators/AccumulatorLiveITCase.java index 379e8aba52be7..347c2e3f65787 100644 --- a/flink-tests/src/test/java/org/apache/flink/test/accumulators/AccumulatorLiveITCase.java +++ b/flink-tests/src/test/java/org/apache/flink/test/accumulators/AccumulatorLiveITCase.java @@ -42,14 +42,12 @@ import org.apache.flink.streaming.api.datastream.DataStream; import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment; import org.apache.flink.test.util.MiniClusterResource; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.Collector; import org.apache.flink.util.TestLogger; import org.junit.Before; import org.junit.ClassRule; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.slf4j.Logger; import org.slf4j.LoggerFactory; @@ -63,7 +61,6 @@ /** * Tests the availability of accumulator results during runtime. */ -@Category(New.class) public class AccumulatorLiveITCase extends TestLogger { private static final Logger LOG = LoggerFactory.getLogger(AccumulatorLiveITCase.class); diff --git a/flink-tests/src/test/java/org/apache/flink/test/classloading/ClassLoaderITCase.java b/flink-tests/src/test/java/org/apache/flink/test/classloading/ClassLoaderITCase.java index 089ade443a7b4..fed65b4381894 100644 --- a/flink-tests/src/test/java/org/apache/flink/test/classloading/ClassLoaderITCase.java +++ b/flink-tests/src/test/java/org/apache/flink/test/classloading/ClassLoaderITCase.java @@ -36,7 +36,6 @@ import org.apache.flink.test.testdata.KMeansData; import org.apache.flink.test.util.SuccessException; import org.apache.flink.test.util.TestEnvironment; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.apache.flink.util.TestLogger; @@ -47,7 +46,6 @@ import org.junit.BeforeClass; import org.junit.Rule; import org.junit.Test; -import org.junit.experimental.categories.Category; import org.junit.rules.ExpectedException; import org.junit.rules.TemporaryFolder; import org.slf4j.Logger; @@ -71,7 +69,6 @@ /** * Test job classloader. */ -@Category(New.class) public class ClassLoaderITCase extends TestLogger { private static final Logger LOG = LoggerFactory.getLogger(ClassLoaderITCase.class); diff --git a/flink-tests/src/test/java/org/apache/flink/test/example/client/JobRetrievalITCase.java b/flink-tests/src/test/java/org/apache/flink/test/example/client/JobRetrievalITCase.java index 6b747e07408fb..d8ed2ee1df115 100644 --- a/flink-tests/src/test/java/org/apache/flink/test/example/client/JobRetrievalITCase.java +++ b/flink-tests/src/test/java/org/apache/flink/test/example/client/JobRetrievalITCase.java @@ -30,7 +30,6 @@ import org.apache.flink.runtime.jobgraph.JobVertex; import org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable; import org.apache.flink.test.util.MiniClusterResource; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.ExceptionUtils; import org.apache.flink.util.TestLogger; @@ -38,7 +37,6 @@ import org.junit.Before; import org.junit.ClassRule; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.util.Optional; import java.util.concurrent.Semaphore; @@ -49,7 +47,6 @@ /** * Tests retrieval of a job from a running Flink cluster. */ -@Category(New.class) public class JobRetrievalITCase extends TestLogger { private static final Semaphore lock = new Semaphore(1); diff --git a/flink-tests/src/test/java/org/apache/flink/test/streaming/runtime/BigUserProgramJobSubmitITCase.java b/flink-tests/src/test/java/org/apache/flink/test/streaming/runtime/BigUserProgramJobSubmitITCase.java index 5fb3e4dd601f0..bef3ebdb94872 100644 --- a/flink-tests/src/test/java/org/apache/flink/test/streaming/runtime/BigUserProgramJobSubmitITCase.java +++ b/flink-tests/src/test/java/org/apache/flink/test/streaming/runtime/BigUserProgramJobSubmitITCase.java @@ -30,12 +30,10 @@ import org.apache.flink.streaming.api.environment.StreamExecutionEnvironment; import org.apache.flink.streaming.api.functions.sink.SinkFunction; import org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator; -import org.apache.flink.testutils.category.New; import org.apache.flink.util.TestLogger; import org.junit.AfterClass; import org.junit.Test; -import org.junit.experimental.categories.Category; import java.net.URI; import java.util.ArrayList; @@ -50,7 +48,6 @@ * Integration test that verifies that a user program with a big(ger) payload is successfully * submitted and run. */ -@Category(New.class) public class BigUserProgramJobSubmitITCase extends TestLogger { // ------------------------------------------------------------------------