[TEST] remove outdated TestLogging annotation

Conflicts:
	src/test/java/org/elasticsearch/bwcompat/UnicastBackwardsCompatibilityTest.java
	src/test/java/org/elasticsearch/recovery/RelocationTests.java
This commit is contained in:
Simon Willnauer 2014-11-28 10:40:38 +01:00
parent 600f02b407
commit c524e469ec
28 changed files with 0 additions and 55 deletions

View File

@ -151,7 +151,6 @@ public class BasicBackwardsCompatibilityTest extends ElasticsearchBackwardsCompa
}
@Test
@TestLogging("action.search.type:TRACE,action.support.replication:TRACE,cluster.service:TRACE,indices.recovery:TRACE,index.shard.service:TRACE")
public void testRecoverFromPreviousVersion() throws ExecutionException, InterruptedException {
if (backwardsCluster().numNewDataNodes() == 0) {
backwardsCluster().startNewNode();

View File

@ -169,7 +169,6 @@ public class MinimumMasterNodesTests extends ElasticsearchIntegrationTest {
}
@Test
@TestLogging("cluster.service:TRACE,discovery:TRACE,indices.cluster:TRACE")
public void multipleNodesShutdownNonMasterNodes() throws Exception {
Settings settings = settingsBuilder()
.put("discovery.type", "zen")

View File

@ -55,7 +55,6 @@ import static org.hamcrest.Matchers.*;
public class NoMasterNodeTests extends ElasticsearchIntegrationTest {
@Test
@TestLogging("action:TRACE,cluster.service:TRACE")
public void testNoMasterActions() throws Exception {
// note, sometimes, we want to check with the fact that an index gets created, sometimes not...
boolean autoCreateIndex = randomBoolean();

View File

@ -49,7 +49,6 @@ public class SameShardRoutingTests extends ElasticsearchAllocationTestCase {
private final ESLogger logger = Loggers.getLogger(SameShardRoutingTests.class);
@Test
@TestLogging("cluster.routing.allocation:TRACE")
public void sameHost() {
AllocationService strategy = createAllocationService(settingsBuilder().put(SameShardAllocationDecider.SAME_HOST_SETTING, true).build());

View File

@ -259,7 +259,6 @@ public class DiskThresholdDeciderTests extends ElasticsearchAllocationTestCase {
}
@Test
@TestLogging("cluster.routing.allocation.decider:TRACE")
public void diskThresholdWithAbsoluteSizesTest() {
Settings diskSettings = settingsBuilder()
.put(DiskThresholdDecider.CLUSTER_ROUTING_ALLOCATION_DISK_THRESHOLD_ENABLED, true)

View File

@ -74,7 +74,6 @@ import static org.hamcrest.Matchers.*;
/**
*/
@LuceneTestCase.Slow
@TestLogging("discovery.zen:TRACE")
@ClusterScope(scope = Scope.TEST, numDataNodes = 0, transportClientRatio = 0)
public class DiscoveryWithServiceDisruptions extends ElasticsearchIntegrationTest {
@ -241,7 +240,6 @@ public class DiscoveryWithServiceDisruptions extends ElasticsearchIntegrationTes
/** Verify that nodes fault detection works after master (re) election */
@Test
@TestLogging(value = "cluster.service:TRACE,indices.recovery:TRACE")
public void testNodesFDAfterMasterReelection() throws Exception {
startCluster(3);
@ -269,7 +267,6 @@ public class DiscoveryWithServiceDisruptions extends ElasticsearchIntegrationTes
* Verify that the proper block is applied when nodes loose their master
*/
@Test
@TestLogging(value = "cluster.service:TRACE,indices.recovery:TRACE")
public void testVerifyApiBlocksDuringPartition() throws Exception {
startCluster(3);
@ -350,7 +347,6 @@ public class DiscoveryWithServiceDisruptions extends ElasticsearchIntegrationTes
* and verifies that all node agree on the new cluster state
*/
@Test
@TestLogging("discovery.zen:TRACE,action:TRACE,cluster.service:TRACE,indices.recovery:TRACE,indices.cluster:TRACE")
public void testIsolateMasterAndVerifyClusterStateConsensus() throws Exception {
final List<String> nodes = startCluster(3);
@ -554,7 +550,6 @@ public class DiscoveryWithServiceDisruptions extends ElasticsearchIntegrationTes
* Test that cluster recovers from a long GC on master that causes other nodes to elect a new one
*/
@Test
@TestLogging("discovery.zen:TRACE,action:TRACE,cluster.service:TRACE,indices.recovery:TRACE,indices.cluster:TRACE")
public void testMasterNodeGCs() throws Exception {
// TODO: on mac OS multicast threads are shared between nodes and we therefore we can't simulate GC and stop pinging for just one node
// find a way to block thread creation in the generic thread pool to avoid this.
@ -607,7 +602,6 @@ public class DiscoveryWithServiceDisruptions extends ElasticsearchIntegrationTes
* @throws Exception
*/
@Test
@TestLogging("discovery.zen:TRACE,action:TRACE,cluster.service:TRACE,indices.recovery:TRACE,indices.cluster:TRACE")
public void testRejoinDocumentExistsInAllShardCopies() throws Exception {
List<String> nodes = startCluster(3);
@ -663,7 +657,6 @@ public class DiscoveryWithServiceDisruptions extends ElasticsearchIntegrationTes
* The rejoining node should take this master node and connect.
*/
@Test
@TestLogging("discovery.zen:TRACE,action:TRACE")
public void unicastSinglePingResponseContainsMaster() throws Exception {
List<String> nodes = startUnicastCluster(4, new int[]{0}, -1);
// Figure out what is the elected master node
@ -700,7 +693,6 @@ public class DiscoveryWithServiceDisruptions extends ElasticsearchIntegrationTes
}
@Test
@TestLogging("discovery.zen:TRACE,action:TRACE")
public void isolatedUnicastNodes() throws Exception {
List<String> nodes = startUnicastCluster(3, new int[]{0}, -1);
// Figure out what is the elected master node
@ -738,7 +730,6 @@ public class DiscoveryWithServiceDisruptions extends ElasticsearchIntegrationTes
/** Test cluster join with issues in cluster state publishing * */
@Test
@TestLogging("discovery.zen:TRACE,action:TRACE")
public void testClusterJoinDespiteOfPublishingIssues() throws Exception {
List<String> nodes = startCluster(2, 1);
@ -785,7 +776,6 @@ public class DiscoveryWithServiceDisruptions extends ElasticsearchIntegrationTes
@Test
@TestLogging("discovery.zen:TRACE,action:TRACE")
public void testClusterFormingWithASlowNode() throws Exception {
configureCluster(3, 2);

View File

@ -54,7 +54,6 @@ import static org.hamcrest.Matchers.nullValue;
*/
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
@Slow
@TestLogging("action.search:TRACE,index.shard.service:TRACE")
public class LocalGatewayIndexStateTests extends ElasticsearchIntegrationTest {
private final ESLogger logger = Loggers.getLogger(LocalGatewayIndexStateTests.class);

View File

@ -60,7 +60,6 @@ public class RecoveryBackwardsCompatibilityTests extends ElasticsearchBackwardsC
@Test
@LuceneTestCase.Slow
@TestLogging("discovery.zen:TRACE")
public void testReusePeerRecovery() throws Exception {
assertAcked(prepareCreate("test").setSettings(ImmutableSettings.builder().put(indexSettings())
.put(IndexMetaData.SETTING_NUMBER_OF_REPLICAS, 0)

View File

@ -54,7 +54,6 @@ import static org.hamcrest.Matchers.*;
*/
@ClusterScope(numDataNodes = 0, scope = Scope.TEST)
@Slow
@TestLogging("index.shard.service:TRACE,index.gateway.local:TRACE")
public class SimpleRecoveryLocalGatewayTests extends ElasticsearchIntegrationTest {
private ImmutableSettings.Builder settingsBuilder() {

View File

@ -89,7 +89,6 @@ public class NettyHttpServerPipeliningTest extends ElasticsearchTestCase {
}
@Test
@TestLogging("_root:DEBUG")
public void testThatHttpPipeliningWorksWhenEnabled() throws Exception {
Settings settings = settingsBuilder().put("http.pipelining", true).build();
httpServerTransport = new CustomNettyHttpServerTransport(settings);
@ -105,7 +104,6 @@ public class NettyHttpServerPipeliningTest extends ElasticsearchTestCase {
}
@Test
@TestLogging("_root:TRACE")
public void testThatHttpPipeliningCanBeDisabled() throws Exception {
Settings settings = settingsBuilder().put("http.pipelining", false).build();
httpServerTransport = new CustomNettyHttpServerTransport(settings);

View File

@ -50,7 +50,6 @@ import static org.hamcrest.Matchers.equalTo;
* Test failure when index replication actions fail mid-flight
*/
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST, numDataNodes = 0, transportClientRatio = 0)
@TestLogging("discovery.zen:TRACE,action.index:TRACE,indices.recovery:TRACE")
public class TransportIndexFailuresTest extends ElasticsearchIntegrationTest {
private static final Settings nodeSettings = ImmutableSettings.settingsBuilder()

View File

@ -104,7 +104,6 @@ public class CircuitBreakerServiceTests extends ElasticsearchIntegrationTest {
}
@Test
@TestLogging("indices.breaker:TRACE,index.fielddata:TRACE,common.breaker:TRACE")
public void testMemoryBreaker() throws Exception {
if (noopBreakerUsed()) {
logger.info("--> noop breakers used, skipping test");

View File

@ -55,7 +55,6 @@ public class IndicesStoreIntegrationTests extends ElasticsearchIntegrationTest {
private static final Settings SETTINGS = settingsBuilder().put("gateway.type", "local").build();
@Test
@TestLogging("indices.store:TRACE,discovery.zen:TRACE,action:TRACE,cluster.service:TRACE,indices.recovery:TRACE,indices.cluster:TRACE")
public void shardsCleanup() throws Exception {
final String node_1 = internalCluster().startNode(SETTINGS);
final String node_2 = internalCluster().startNode(SETTINGS);
@ -116,7 +115,6 @@ public class IndicesStoreIntegrationTests extends ElasticsearchIntegrationTest {
}
@Test
@TestLogging("indices.store:TRACE")
public void testShardActiveElseWhere() throws Exception {
String node_1 = internalCluster().startNode(SETTINGS);
String node_2 = internalCluster().startNode(SETTINGS);

View File

@ -1577,7 +1577,6 @@ public class PercolatorTests extends ElasticsearchIntegrationTest {
}
@Test
@TestLogging("action.admin.indices.mapping.delete:TRACE")
public void testDeletePercolatorType() throws Exception {
assertAcked(client().admin().indices().prepareCreate("test1"));
assertAcked(client().admin().indices().prepareCreate("test2"));

View File

@ -183,7 +183,6 @@ public class RecoveryPercolatorTests extends ElasticsearchIntegrationTest {
@Test
@Slow
@TestLogging("index.percolator:TRACE,percolator:TRACE")
public void testLoadingPercolateQueriesDuringCloseAndOpen() throws Exception {
internalCluster().startNode();
internalCluster().startNode();

View File

@ -54,7 +54,6 @@ public class FullRollingRestartTests extends ElasticsearchIntegrationTest {
@Test
@Slow
@TestLogging("indices.cluster:TRACE,cluster.service:TRACE,action.count:TRACE,indices.recovery:TRACE")
public void testFullRollingRestart() throws Exception {
internalCluster().startNode();
createIndex("test");

View File

@ -51,7 +51,6 @@ public class RecoveryWhileUnderLoadTests extends ElasticsearchIntegrationTest {
private final ESLogger logger = Loggers.getLogger(RecoveryWhileUnderLoadTests.class);
@Test
@TestLogging("action.search.type:TRACE,action.admin.indices.refresh:TRACE")
@Slow
public void recoverWhileUnderLoadAllocateBackupsTest() throws Exception {
logger.info("--> creating test index ...");
@ -107,7 +106,6 @@ public class RecoveryWhileUnderLoadTests extends ElasticsearchIntegrationTest {
}
@Test
@TestLogging("action.search.type:TRACE,action.admin.indices.refresh:TRACE")
@Slow
public void recoverWhileUnderLoadAllocateBackupsRelocatePrimariesTest() throws Exception {
logger.info("--> creating test index ...");

View File

@ -61,7 +61,6 @@ import org.elasticsearch.search.SearchHits;
import org.elasticsearch.test.BackgroundIndexer;
import org.elasticsearch.test.ElasticsearchIntegrationTest;
import org.elasticsearch.test.ElasticsearchIntegrationTest.ClusterScope;
import org.elasticsearch.test.junit.annotations.TestLogging;
import org.elasticsearch.test.transport.MockTransportService;
import org.elasticsearch.transport.*;
import org.junit.Test;
@ -88,7 +87,6 @@ import static org.hamcrest.Matchers.*;
/**
*/
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
@TestLogging("indices.recovery:TRACE,index.shard.service:TRACE")
public class RelocationTests extends ElasticsearchIntegrationTest {
private final TimeValue ACCEPTABLE_RELOCATION_TIME = new TimeValue(5, TimeUnit.MINUTES);
@ -445,7 +443,6 @@ public class RelocationTests extends ElasticsearchIntegrationTest {
@Test
@Slow
@TestLogging("indices.recovery:TRACE")
public void testCancellationCleansTempFiles() throws Exception {
final String indexName = "test";

View File

@ -48,7 +48,6 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAllS
@ElasticsearchIntegrationTest.SuiteScopeTest
@TestLogging("action.admin.indices.refresh:TRACE,action.search.type:TRACE,cluster.service:TRACE")
public class MinDocCountTests extends AbstractTermsTests {
private static final QueryBuilder QUERY = QueryBuilders.termQuery("match", true);

View File

@ -280,7 +280,6 @@ public class AvgTests extends AbstractNumericTests {
}
@Test
@TestLogging("search:TRACE")
public void testScript_MultiValued_WithParams() throws Exception {
SearchResponse searchResponse = client().prepareSearch("idx")
.setQuery(matchAllQuery())

View File

@ -58,7 +58,6 @@ import static org.hamcrest.Matchers.sameInstance;
*
*/
@ElasticsearchIntegrationTest.SuiteScopeTest
@TestLogging("indices.recovery:TRACE,action.search.type:TRACE")
public class GeoBoundsTests extends ElasticsearchIntegrationTest {
private static final String SINGLE_VALUED_FIELD_NAME = "geo_value";

View File

@ -315,7 +315,6 @@ public class StatsTests extends AbstractNumericTests {
}
@Test
@TestLogging("search:TRACE")
public void testScript_ExplicitSingleValued_WithParams() throws Exception {
SearchResponse searchResponse = client().prepareSearch("idx")
.setQuery(matchAllQuery())

View File

@ -196,7 +196,6 @@ public class SearchWithRandomExceptionsTests extends ElasticsearchIntegrationTes
}
@Test
@TestLogging("action.admin.indices.refresh:TRACE,action.search.type:TRACE,cluster.service:TRACE")
public void testRandomExceptions() throws IOException, InterruptedException, ExecutionException {
String mapping = XContentFactory.jsonBuilder().
startObject().

View File

@ -59,7 +59,6 @@ public class ParentFieldLoadingTest extends ElasticsearchIntegrationTest {
.build();
@Test
@TestLogging("index.warmer:TRACE")
public void testEagerParentFieldLoading() throws Exception {
logger.info("testing lazy loading...");
assertAcked(prepareCreate("test")
@ -126,7 +125,6 @@ public class ParentFieldLoadingTest extends ElasticsearchIntegrationTest {
}
@Test
@TestLogging("index.warmer:TRACE")
public void testChangingEagerParentFieldLoadingAtRuntime() throws Exception {
assertAcked(prepareCreate("test")
.setSettings(indexSettings)

View File

@ -22,7 +22,6 @@ import org.elasticsearch.action.index.IndexRequestBuilder;
import org.elasticsearch.action.search.SearchResponse;
import org.elasticsearch.cluster.routing.allocation.decider.EnableAllocationDecider;
import org.elasticsearch.common.geo.GeoPoint;
import org.elasticsearch.common.lucene.search.function.FieldValueFactorFunction;
import org.elasticsearch.common.settings.ImmutableSettings;
import org.elasticsearch.test.ElasticsearchBackwardsCompatIntegrationTest;
import org.junit.Test;

View File

@ -19,14 +19,12 @@
package org.elasticsearch.search.scroll;
import com.google.common.base.Predicate;
import org.elasticsearch.action.index.IndexRequestBuilder;
import org.elasticsearch.action.search.SearchResponse;
import org.elasticsearch.cluster.routing.allocation.decider.ShardsLimitAllocationDecider;
import org.elasticsearch.common.settings.ImmutableSettings;
import org.elasticsearch.common.unit.TimeValue;
import org.elasticsearch.test.ElasticsearchIntegrationTest;
import org.elasticsearch.test.junit.annotations.TestLogging;
import org.junit.Test;
import java.util.ArrayList;
@ -54,7 +52,6 @@ public class SearchScrollWithFailingNodesTests extends ElasticsearchIntegrationT
}
@Test
@TestLogging("action.search:TRACE")
public void testScanScrollWithShardExceptions() throws Exception {
internalCluster().startNode();
internalCluster().startNode();

View File

@ -51,11 +51,9 @@ import org.elasticsearch.common.xcontent.ToXContent;
import org.elasticsearch.common.xcontent.XContentBuilder;
import org.elasticsearch.common.xcontent.XContentParser;
import org.elasticsearch.index.store.support.AbstractIndexStore;
import org.elasticsearch.node.internal.InternalNode;
import org.elasticsearch.repositories.RepositoryMissingException;
import org.elasticsearch.snapshots.mockstore.MockRepositoryModule;
import org.elasticsearch.test.InternalTestCluster;
import org.elasticsearch.test.junit.annotations.TestLogging;
import org.elasticsearch.threadpool.ThreadPool;
import org.junit.Ignore;
import org.junit.Test;
@ -353,7 +351,6 @@ public class DedicatedClusterSnapshotRestoreTests extends AbstractSnapshotTests
}
@Test
@TestLogging("snapshots:TRACE")
public void restoreIndexWithMissingShards() throws Exception {
logger.info("--> start 2 nodes");
internalCluster().startNode(settingsBuilder().put("gateway.type", "local"));
@ -491,7 +488,6 @@ public class DedicatedClusterSnapshotRestoreTests extends AbstractSnapshotTests
}
@Test
@TestLogging("indices.recovery:TRACE,index.gateway:TRACE,gateway:TRACE")
public void restoreIndexWithShardsMissingInLocalGateway() throws Exception {
logger.info("--> start 2 nodes");
internalCluster().startNode(settingsBuilder().put("gateway.type", "local"));
@ -548,7 +544,6 @@ public class DedicatedClusterSnapshotRestoreTests extends AbstractSnapshotTests
}
@Test
@TestLogging("snapshots:TRACE,repositories:TRACE")
@Ignore
public void chaosSnapshotTest() throws Exception {
final List<String> indices = new CopyOnWriteArrayList<>();

View File

@ -27,7 +27,6 @@ import org.apache.lucene.util.LuceneTestCase.Slow;
import org.elasticsearch.ExceptionsHelper;
import org.elasticsearch.action.ListenableActionFuture;
import org.elasticsearch.action.admin.cluster.repositories.put.PutRepositoryResponse;
import org.elasticsearch.action.admin.cluster.repositories.verify.VerifyRepositoryResponse;
import org.elasticsearch.action.admin.cluster.snapshots.create.CreateSnapshotResponse;
import org.elasticsearch.action.admin.cluster.snapshots.delete.DeleteSnapshotResponse;
import org.elasticsearch.action.admin.cluster.snapshots.get.GetSnapshotsResponse;
@ -52,7 +51,6 @@ import org.elasticsearch.index.store.support.AbstractIndexStore;
import org.elasticsearch.indices.InvalidIndexNameException;
import org.elasticsearch.repositories.RepositoriesService;
import org.elasticsearch.snapshots.mockstore.MockRepositoryModule;
import org.elasticsearch.test.junit.annotations.TestLogging;
import org.junit.Test;
import java.io.File;
@ -605,7 +603,6 @@ public class SharedClusterSnapshotRestoreTests extends AbstractSnapshotTests {
@Test
@TestLogging("snapshots:TRACE")
public void deletionOfFailingToRecoverIndexShouldStopRestore() throws Exception {
File repositoryLocation = newTempDir(LifecycleScope.TEST);
Client client = client();
@ -822,7 +819,6 @@ public class SharedClusterSnapshotRestoreTests extends AbstractSnapshotTests {
}
@Test
@TestLogging("snapshots:TRACE")
public void snapshotClosedIndexTest() throws Exception {
Client client = client();
@ -990,7 +986,6 @@ public class SharedClusterSnapshotRestoreTests extends AbstractSnapshotTests {
}
@Test
@TestLogging("cluster.routing.allocation.decider:TRACE")
public void moveShardWhileSnapshottingTest() throws Exception {
Client client = client();
File repositoryLocation = newTempDir(LifecycleScope.TEST);
@ -1053,7 +1048,6 @@ public class SharedClusterSnapshotRestoreTests extends AbstractSnapshotTests {
}
@Test
@TestLogging("cluster.routing.allocation.decider:TRACE")
public void deleteRepositoryWhileSnapshottingTest() throws Exception {
Client client = client();
File repositoryLocation = newTempDir(LifecycleScope.TEST);
@ -1255,7 +1249,6 @@ public class SharedClusterSnapshotRestoreTests extends AbstractSnapshotTests {
@Test
@TestLogging("cluster.routing.allocation.decider:TRACE")
public void snapshotStatusTest() throws Exception {
Client client = client();
File repositoryLocation = newTempDir(LifecycleScope.TEST);