Merge pull request #12613 from rjernst/refactor/integ-tests

Rename integ tests to IT suffix
This commit is contained in:
Ryan Ernst 2015-08-03 14:57:26 -07:00
commit d349deb9b7
298 changed files with 330 additions and 330 deletions

View File

@ -124,7 +124,7 @@ import static org.hamcrest.Matchers.instanceOf;
@ClusterScope(scope = Scope.SUITE, numClientNodes = 1, minNumDataNodes = 2)
@Slow
public class IndicesRequestTests extends ElasticsearchIntegrationTest {
public class IndicesRequestIT extends ElasticsearchIntegrationTest {
private final List<String> indices = new ArrayList<>();

View File

@ -32,7 +32,7 @@ import java.util.concurrent.atomic.AtomicReference;
/**
*/
public class ListenerActionTests extends ElasticsearchIntegrationTest {
public class ListenerActionIT extends ElasticsearchIntegrationTest {
@Test
public void verifyThreadedListeners() throws Throwable {

View File

@ -41,7 +41,7 @@ import static org.hamcrest.Matchers.equalTo;
/**
*/
@ClusterScope(scope = ElasticsearchIntegrationTest.Scope.SUITE, numDataNodes = 2)
public class RejectionActionTests extends ElasticsearchIntegrationTest {
public class RejectionActionIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -40,7 +40,7 @@ import static org.hamcrest.Matchers.lessThan;
/**
*/
@Slow
public class HotThreadsTest extends ElasticsearchIntegrationTest {
public class HotThreadsIT extends ElasticsearchIntegrationTest {
@Test
public void testHotThreadsDontFail() throws ExecutionException, InterruptedException {

View File

@ -38,7 +38,7 @@ import static org.hamcrest.Matchers.hasSize;
* The @ClusterScope TEST is needed because this class updates the cluster setting "cluster.blocks.read_only".
*/
@ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST)
public class RepositoryBlocksTests extends ElasticsearchIntegrationTest {
public class RepositoryBlocksIT extends ElasticsearchIntegrationTest {
@Test
public void testPutRepositoryWithBlocks() {

View File

@ -46,7 +46,7 @@ import static org.hamcrest.Matchers.hasSize;
* The @ClusterScope TEST is needed because this class updates the cluster setting "cluster.blocks.read_only".
*/
@ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST)
public class SnapshotBlocksTests extends ElasticsearchIntegrationTest {
public class SnapshotBlocksIT extends ElasticsearchIntegrationTest {
protected static final String INDEX_NAME = "test-blocks-1";
protected static final String OTHER_INDEX_NAME = "test-blocks-2";

View File

@ -39,7 +39,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAcke
import static org.hamcrest.Matchers.is;
@ClusterScope(scope = Scope.SUITE, numDataNodes = 1, numClientNodes = 0)
public class ClusterStatsTests extends ElasticsearchIntegrationTest {
public class ClusterStatsIT extends ElasticsearchIntegrationTest {
private void assertCounts(ClusterStatsNodes.Counts counts, int total, int masterOnly, int dataOnly, int masterData, int client) {
assertThat(counts.getTotal(), Matchers.equalTo(total));

View File

@ -28,7 +28,7 @@ import java.util.Arrays;
import static org.elasticsearch.cluster.metadata.IndexMetaData.*;
@ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST)
public class PendingTasksBlocksTests extends ElasticsearchIntegrationTest {
public class PendingTasksBlocksIT extends ElasticsearchIntegrationTest {
@Test
public void testPendingTasksWithBlocks() {

View File

@ -31,7 +31,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertNoFa
import static org.hamcrest.Matchers.equalTo;
@ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST)
public class ClearIndicesCacheBlocksTests extends ElasticsearchIntegrationTest {
public class ClearIndicesCacheBlocksIT extends ElasticsearchIntegrationTest {
@Test
public void testClearIndicesCacheWithBlocks() {

View File

@ -38,7 +38,7 @@ import static org.hamcrest.Matchers.*;
import static org.hamcrest.core.IsNull.notNullValue;
@ClusterScope(scope = Scope.TEST)
public class CreateIndexTests extends ElasticsearchIntegrationTest{
public class CreateIndexIT extends ElasticsearchIntegrationTest{
@Test
public void testCreationDate_Given() {

View File

@ -26,7 +26,7 @@ import org.junit.Test;
import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertBlocked;
@ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST)
public class DeleteIndexBlocksTests extends ElasticsearchIntegrationTest{
public class DeleteIndexBlocksIT extends ElasticsearchIntegrationTest{
@Test
public void testDeleteIndexWithBlocks() {

View File

@ -31,7 +31,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertNoFa
import static org.hamcrest.Matchers.equalTo;
@ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST)
public class FlushBlocksTests extends ElasticsearchIntegrationTest {
public class FlushBlocksIT extends ElasticsearchIntegrationTest {
@Test
public void testFlushWithBlocks() {

View File

@ -42,7 +42,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertBloc
import static org.hamcrest.Matchers.*;
@ElasticsearchIntegrationTest.SuiteScopeTest
public class GetIndexTests extends ElasticsearchIntegrationTest {
public class GetIndexIT extends ElasticsearchIntegrationTest {
private static final String[] allFeatures = { "_alias", "_aliases", "_mapping", "_mappings", "_settings", "_warmer", "_warmers" };

View File

@ -31,7 +31,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertNoFa
import static org.hamcrest.Matchers.equalTo;
@ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST)
public class OptimizeBlocksTests extends ElasticsearchIntegrationTest {
public class OptimizeBlocksIT extends ElasticsearchIntegrationTest {
@Test
public void testOptimizeWithBlocks() {

View File

@ -32,7 +32,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertNoFa
import static org.hamcrest.Matchers.equalTo;
@ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST)
public class RefreshBlocksTests extends ElasticsearchIntegrationTest {
public class RefreshBlocksIT extends ElasticsearchIntegrationTest {
@Test
public void testRefreshWithBlocks() {

View File

@ -30,7 +30,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertBloc
import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertNoFailures;
@ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST)
public class IndicesSegmentsBlocksTests extends ElasticsearchIntegrationTest {
public class IndicesSegmentsBlocksIT extends ElasticsearchIntegrationTest {
@Test
public void testIndicesSegmentsWithBlocks() {

View File

@ -49,7 +49,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertNoTi
import static org.hamcrest.Matchers.*;
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST)
public class IndicesShardStoreRequestTests extends ElasticsearchIntegrationTest {
public class IndicesShardStoreRequestIT extends ElasticsearchIntegrationTest {
@Test
public void testEmpty() {

View File

@ -30,7 +30,7 @@ import java.util.Arrays;
import static org.elasticsearch.cluster.metadata.IndexMetaData.*;
@ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST)
public class IndicesStatsBlocksTests extends ElasticsearchIntegrationTest {
public class IndicesStatsBlocksIT extends ElasticsearchIntegrationTest {
@Test
public void testIndicesStatsWithBlocks() {

View File

@ -28,7 +28,7 @@ import org.junit.Test;
import static org.elasticsearch.common.io.Streams.copyToStringFromClasspath;
public class BulkIntegrationTests extends ElasticsearchIntegrationTest {
public class BulkIntegrationIT extends ElasticsearchIntegrationTest {
@Test
public void testBulkIndexCreatesMapping() throws Exception {

View File

@ -26,7 +26,7 @@ import org.elasticsearch.test.ElasticsearchIntegrationTest.Scope;
import org.junit.Test;
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
public class BulkProcessorClusterSettingsTests extends ElasticsearchIntegrationTest {
public class BulkProcessorClusterSettingsIT extends ElasticsearchIntegrationTest {
@Test
public void testBulkProcessorAutoCreateRestrictions() throws Exception {

View File

@ -47,7 +47,7 @@ import java.util.concurrent.atomic.AtomicInteger;
import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAcked;
import static org.hamcrest.Matchers.*;
public class BulkProcessorTests extends ElasticsearchIntegrationTest {
public class BulkProcessorIT extends ElasticsearchIntegrationTest {
@Test
public void testThatBulkProcessorCountIsCorrect() throws InterruptedException {

View File

@ -38,7 +38,7 @@ import java.io.IOException;
import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAcked;
import static org.hamcrest.Matchers.equalTo;
public class GetTermVectorsCheckDocFreqTests extends ElasticsearchIntegrationTest {
public class GetTermVectorsCheckDocFreqIT extends ElasticsearchIntegrationTest {
@Override
protected int numberOfShards() {

View File

@ -69,7 +69,7 @@ import static org.hamcrest.Matchers.*;
*
*/
@Slow
public class IndexAliasesTests extends ElasticsearchIntegrationTest {
public class IndexAliasesIT extends ElasticsearchIntegrationTest {
@Test
public void testAliases() throws Exception {

View File

@ -36,7 +36,7 @@ import static org.elasticsearch.common.settings.Settings.settingsBuilder;
import static org.hamcrest.Matchers.notNullValue;
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST)
public class SimpleBlocksTests extends ElasticsearchIntegrationTest {
public class SimpleBlocksIT extends ElasticsearchIntegrationTest {
@Test
public void verifyIndexAndClusterReadOnly() throws Exception {

View File

@ -35,7 +35,7 @@ import static org.elasticsearch.index.query.QueryBuilders.termQuery;
import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAcked;
import static org.hamcrest.Matchers.equalTo;
public class BroadcastActionsTests extends ElasticsearchIntegrationTest {
public class BroadcastActionsIT extends ElasticsearchIntegrationTest {
@Override
protected int maximumNumberOfReplicas() {

View File

@ -72,7 +72,7 @@ import static org.hamcrest.Matchers.greaterThanOrEqualTo;
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST, numDataNodes = 0)
@LuceneTestCase.SuppressFileSystems("ExtrasFS")
@LuceneTestCase.Slow
public class OldIndexBackwardsCompatibilityTests extends ElasticsearchIntegrationTest {
public class OldIndexBackwardsCompatibilityIT extends ElasticsearchIntegrationTest {
// TODO: test for proper exception on unsupported indexes (maybe via separate test?)
// We have a 0.20.6.zip etc for this.

View File

@ -32,7 +32,7 @@ import static org.hamcrest.Matchers.is;
*
*/
@ClusterScope(scope = Scope.SUITE)
public class NodeClientTests extends ElasticsearchIntegrationTest {
public class NodeClientIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -40,7 +40,7 @@ import static org.hamcrest.Matchers.is;
import static org.hamcrest.Matchers.startsWith;
@ClusterScope(scope = Scope.TEST, numDataNodes = 0, transportClientRatio = 1.0)
public class TransportClientTests extends ElasticsearchIntegrationTest {
public class TransportClientIT extends ElasticsearchIntegrationTest {
@Test
public void testPickingUpChangesInDiscoveryNode() {

View File

@ -47,7 +47,7 @@ import static org.hamcrest.Matchers.greaterThanOrEqualTo;
@ClusterScope(scope = Scope.TEST, numClientNodes = 0)
@TestLogging("discovery.zen:TRACE")
public class TransportClientRetryTests extends ElasticsearchIntegrationTest {
public class TransportClientRetryIT extends ElasticsearchIntegrationTest {
@Test
public void testRetry() throws IOException, ExecutionException, InterruptedException {

View File

@ -27,7 +27,7 @@ import org.junit.Test;
import static org.hamcrest.Matchers.equalTo;
public class ClusterHealthTests extends ElasticsearchIntegrationTest {
public class ClusterHealthIT extends ElasticsearchIntegrationTest {
@Test

View File

@ -62,18 +62,18 @@ import static org.hamcrest.Matchers.greaterThanOrEqualTo;
* Integration tests for the ClusterInfoService collecting information
*/
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST, numDataNodes = 0)
public class ClusterInfoServiceTests extends ElasticsearchIntegrationTest {
public class ClusterInfoServiceIT extends ElasticsearchIntegrationTest {
public static class Plugin extends AbstractPlugin {
@Override
public String name() {
return "ClusterInfoServiceTests";
return "ClusterInfoServiceIT";
}
@Override
public String description() {
return "ClusterInfoServiceTests";
return "ClusterInfoServiceIT";
}
public void onModule(ActionModule module) {

View File

@ -58,7 +58,7 @@ import static org.hamcrest.Matchers.*;
*
*/
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
public class ClusterServiceTests extends ElasticsearchIntegrationTest {
public class ClusterServiceIT extends ElasticsearchIntegrationTest {
@Test
public void testTimeoutUpdateTask() throws Exception {

View File

@ -55,7 +55,7 @@ import static org.hamcrest.Matchers.is;
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.SUITE, numDataNodes = 0, numClientNodes = 0)
public class ClusterStateDiffTests extends ElasticsearchIntegrationTest {
public class ClusterStateDiffIT extends ElasticsearchIntegrationTest {
@Test
public void testClusterStateDiffSerialization() throws Exception {

View File

@ -45,7 +45,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertHitC
import static org.hamcrest.Matchers.*;
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
public class MinimumMasterNodesTests extends ElasticsearchIntegrationTest {
public class MinimumMasterNodesIT extends ElasticsearchIntegrationTest {
@Test
@TestLogging("cluster.service:TRACE,discovery.zen:TRACE,gateway:TRACE,transport.tracer:TRACE")

View File

@ -57,7 +57,7 @@ import static org.hamcrest.Matchers.lessThan;
/**
*/
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
public class NoMasterNodeTests extends ElasticsearchIntegrationTest {
public class NoMasterNodeIT extends ElasticsearchIntegrationTest {
@Test
public void testNoMasterActions() throws Exception {

View File

@ -44,7 +44,7 @@ import static org.hamcrest.Matchers.*;
* Checking simple filtering capabilites of the cluster state
*
*/
public class SimpleClusterStateTests extends ElasticsearchIntegrationTest {
public class SimpleClusterStateIT extends ElasticsearchIntegrationTest {
@Before
public void indexData() throws Exception {

View File

@ -37,7 +37,7 @@ import static org.hamcrest.Matchers.equalTo;
*
*/
@ClusterScope(scope= Scope.TEST, numDataNodes =0)
public class SimpleDataNodesTests extends ElasticsearchIntegrationTest {
public class SimpleDataNodesIT extends ElasticsearchIntegrationTest {
@Test
public void testDataNodes() throws Exception {

View File

@ -38,7 +38,7 @@ import static org.hamcrest.Matchers.*;
*/
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
@Slow
public class SpecificMasterNodesTests extends ElasticsearchIntegrationTest {
public class SpecificMasterNodesIT extends ElasticsearchIntegrationTest {
protected final Settings.Builder settingsBuilder() {
return Settings.builder().put("discovery.type", "zen");

View File

@ -34,7 +34,7 @@ import static org.hamcrest.Matchers.equalTo;
/**
*/
@ClusterScope(scope= Scope.TEST, numDataNodes =0)
public class UpdateSettingsValidationTests extends ElasticsearchIntegrationTest {
public class UpdateSettingsValidationIT extends ElasticsearchIntegrationTest {
@Test
public void testUpdateSettingsValidation() throws Exception {

View File

@ -42,7 +42,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAcke
import static org.hamcrest.Matchers.equalTo;
@ClusterScope(scope = TEST, minNumDataNodes = 2)
public class AckClusterUpdateSettingsTests extends ElasticsearchIntegrationTest {
public class AckClusterUpdateSettingsIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -57,7 +57,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAcke
import static org.hamcrest.Matchers.*;
@ClusterScope(minNumDataNodes = 2)
public class AckTests extends ElasticsearchIntegrationTest {
public class AckIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -45,9 +45,9 @@ import static org.hamcrest.Matchers.equalTo;
/**
*/
@ClusterScope(scope= ElasticsearchIntegrationTest.Scope.TEST, numDataNodes =0, minNumDataNodes = 2)
public class AwarenessAllocationTests extends ElasticsearchIntegrationTest {
public class AwarenessAllocationIT extends ElasticsearchIntegrationTest {
private final ESLogger logger = Loggers.getLogger(AwarenessAllocationTests.class);
private final ESLogger logger = Loggers.getLogger(AwarenessAllocationIT.class);
@Override
protected int numberOfReplicas() {

View File

@ -61,9 +61,9 @@ import static org.hamcrest.Matchers.hasSize;
/**
*/
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
public class ClusterRerouteTests extends ElasticsearchIntegrationTest {
public class ClusterRerouteIT extends ElasticsearchIntegrationTest {
private final ESLogger logger = Loggers.getLogger(ClusterRerouteTests.class);
private final ESLogger logger = Loggers.getLogger(ClusterRerouteIT.class);
@Test
public void rerouteWithCommands_disableAllocationSettings() throws Exception {

View File

@ -38,9 +38,9 @@ import static org.elasticsearch.test.ElasticsearchIntegrationTest.*;
import static org.hamcrest.Matchers.equalTo;
@ClusterScope(scope= Scope.TEST, numDataNodes =0)
public class FilteringAllocationTests extends ElasticsearchIntegrationTest {
public class FilteringAllocationIT extends ElasticsearchIntegrationTest {
private final ESLogger logger = Loggers.getLogger(FilteringAllocationTests.class);
private final ESLogger logger = Loggers.getLogger(FilteringAllocationIT.class);
@Test
public void testDecommissionNodeNoReplicas() throws Exception {

View File

@ -33,7 +33,7 @@ import static org.elasticsearch.test.ElasticsearchIntegrationTest.*;
import static org.hamcrest.Matchers.instanceOf;
@ClusterScope(scope= Scope.TEST, numDataNodes =0)
public class ShardsAllocatorModuleTests extends ElasticsearchIntegrationTest {
public class ShardsAllocatorModuleIT extends ElasticsearchIntegrationTest {
public void testLoadDefaultShardsAllocator() throws IOException {
assertAllocatorInstance(Settings.Builder.EMPTY_SETTINGS, BalancedShardsAllocator.class);

View File

@ -28,7 +28,7 @@ import static org.elasticsearch.common.settings.Settings.settingsBuilder;
import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAcked;
import static org.hamcrest.Matchers.equalTo;
public class SimpleAllocationTests extends ElasticsearchIntegrationTest {
public class SimpleAllocationIT extends ElasticsearchIntegrationTest {
@Override
protected int numberOfShards() {

View File

@ -37,7 +37,7 @@ import static org.hamcrest.Matchers.equalTo;
/**
*/
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST, numDataNodes = 0)
public class DelayedAllocationTests extends ElasticsearchIntegrationTest {
public class DelayedAllocationIT extends ElasticsearchIntegrationTest {
/**
* Verifies that when there is no delay timeout, a 1/1 index shard will immediately

View File

@ -37,7 +37,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertSear
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST, numDataNodes = 0, minNumDataNodes = 0, maxNumDataNodes = 0)
@LuceneTestCase.SuppressFileSystems("*") // extra files break the single data cluster expectation when unzipping the static index
public class RoutingBackwardCompatibilityUponUpgradeTests extends ElasticsearchIntegrationTest {
public class RoutingBackwardCompatibilityUponUpgradeIT extends ElasticsearchIntegrationTest {
public void testDefaultRouting() throws Exception {
test("default_routing_1_x", DjbHashFunction.class, false);

View File

@ -33,7 +33,7 @@ import static org.hamcrest.Matchers.equalTo;
* works as expected.
*/
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST, numDataNodes = 0)
public class EnableAllocationDeciderIntegrationTest extends ElasticsearchIntegrationTest {
public class EnableAllocationDeciderIT extends ElasticsearchIntegrationTest {
public void testEnableRebalance() throws InterruptedException {
final String firstNode = internalCluster().startNode();

View File

@ -51,7 +51,7 @@ import static org.hamcrest.Matchers.greaterThan;
import static org.hamcrest.Matchers.greaterThanOrEqualTo;
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST, numDataNodes = 0)
public class MockDiskUsagesTests extends ElasticsearchIntegrationTest {
public class MockDiskUsagesIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -42,7 +42,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertBloc
import static org.hamcrest.Matchers.*;
@ClusterScope(scope = TEST)
public class ClusterSettingsTests extends ElasticsearchIntegrationTest {
public class ClusterSettingsIT extends ElasticsearchIntegrationTest {
@Test
public void clusterNonExistingSettingsUpdate() {
@ -209,8 +209,8 @@ public class ClusterSettingsTests extends ElasticsearchIntegrationTest {
private void createNode(Settings settings) {
internalCluster().startNode(Settings.builder()
.put(ClusterName.SETTING, "ClusterSettingsTests")
.put("node.name", "ClusterSettingsTests")
.put(ClusterName.SETTING, "ClusterSettingsIT")
.put("node.name", "ClusterSettingsIT")
.put(IndexMetaData.SETTING_NUMBER_OF_SHARDS, 1)
.put(IndexMetaData.SETTING_NUMBER_OF_REPLICAS, 0)
.put(EsExecutors.PROCESSORS, 1) // limit the number of threads created

View File

@ -39,7 +39,7 @@ import static org.hamcrest.Matchers.equalTo;
import static org.hamcrest.Matchers.nullValue;
@ClusterScope(scope = SUITE, numDataNodes = 1)
public class SettingsFilteringTests extends ElasticsearchIntegrationTest {
public class SettingsFilteringIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -38,7 +38,7 @@ import static org.hamcrest.Matchers.equalTo;
/**
*/
@ClusterScope(scope= Scope.SUITE, numDataNodes = 2)
public class ClusterSearchShardsTests extends ElasticsearchIntegrationTest {
public class ClusterSearchShardsIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -24,7 +24,7 @@ import com.google.common.collect.Sets;
import org.apache.lucene.util.CollectionUtil;
import org.apache.lucene.util.LuceneTestCase;
import org.apache.lucene.util.TestUtil;
import org.elasticsearch.bwcompat.OldIndexBackwardsCompatibilityTests;
import org.elasticsearch.bwcompat.OldIndexBackwardsCompatibilityIT;
import org.elasticsearch.cluster.metadata.IndexMetaData;
import org.elasticsearch.common.Strings;
import org.elasticsearch.common.collect.Tuple;
@ -134,7 +134,7 @@ public class MultiDataPathUpgraderTests extends ElasticsearchTestCase {
*/
public void testUpgradeRealIndex() throws IOException, URISyntaxException {
List<Path> indexes = new ArrayList<>();
Path dir = getDataPath("/" + OldIndexBackwardsCompatibilityTests.class.getPackage().getName().replace('.', '/')); // the files are in the same pkg as the OldIndexBackwardsCompatibilityTests test
Path dir = getDataPath("/" + OldIndexBackwardsCompatibilityIT.class.getPackage().getName().replace('.', '/')); // the files are in the same pkg as the OldIndexBackwardsCompatibilityTests test
try (DirectoryStream<Path> stream = Files.newDirectoryStream(dir, "index-*.zip")) {
for (Path path : stream) {
indexes.add(path);
@ -177,7 +177,7 @@ public class MultiDataPathUpgraderTests extends ElasticsearchTestCase {
multiDataPath[i++] = nodePath.indicesPath;
}
logger.info("--> injecting index [{}] into multiple data paths", indexName);
OldIndexBackwardsCompatibilityTests.copyIndex(logger, src, indexName, multiDataPath);
OldIndexBackwardsCompatibilityIT.copyIndex(logger, src, indexName, multiDataPath);
final ShardPath shardPath = new ShardPath(nodeEnvironment.availableShardPaths(new ShardId(indexName, 0))[0], nodeEnvironment.availableShardPaths(new ShardId(indexName, 0))[0], IndexMetaData.INDEX_UUID_NA_VALUE, new ShardId(indexName, 0));
logger.info("{}", FileSystemUtils.files(shardPath.resolveIndex()));

View File

@ -36,7 +36,7 @@ import static org.hamcrest.Matchers.equalTo;
/**
*
*/
public class WriteConsistencyLevelTests extends ElasticsearchIntegrationTest {
public class WriteConsistencyLevelIT extends ElasticsearchIntegrationTest {
@Test

View File

@ -42,7 +42,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAcke
import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertHitCount;
import static org.hamcrest.Matchers.is;
public class SimpleCountTests extends ElasticsearchIntegrationTest {
public class SimpleCountIT extends ElasticsearchIntegrationTest {
@Test
public void testCountRandomPreference() throws InterruptedException, ExecutionException {

View File

@ -76,7 +76,7 @@ import static org.hamcrest.Matchers.*;
*/
@LuceneTestCase.Slow
@ClusterScope(scope = Scope.TEST, numDataNodes = 0, transportClientRatio = 0)
public class DiscoveryWithServiceDisruptionsTests extends ElasticsearchIntegrationTest {
public class DiscoveryWithServiceDisruptionsIT extends ElasticsearchIntegrationTest {
private static final TimeValue DISRUPTION_HEALING_OVERHEAD = TimeValue.timeValueSeconds(40); // we use 30s as timeout in many places.

View File

@ -37,7 +37,7 @@ import static org.hamcrest.Matchers.equalTo;
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
@Slow
public class ZenUnicastDiscoveryTests extends ElasticsearchIntegrationTest {
public class ZenUnicastDiscoveryIT extends ElasticsearchIntegrationTest {
private ClusterDiscoveryConfiguration discoveryConfig;

View File

@ -60,7 +60,7 @@ import static org.hamcrest.Matchers.*;
*/
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST, numDataNodes = 0, numClientNodes = 0)
@Slow
public class ZenDiscoveryTests extends ElasticsearchIntegrationTest {
public class ZenDiscoveryIT extends ElasticsearchIntegrationTest {
@Test
public void testChangeRejoinOnMasterOptionIsDynamic() throws Exception {

View File

@ -26,7 +26,7 @@ import static org.elasticsearch.client.Requests.createIndexRequest;
/**
*
*/
public class AliasedIndexDocumentActionsTests extends DocumentActionsTests {
public class AliasedIndexDocumentActionsTests extends DocumentActionsIT {
@Override
protected void createIndex() {

View File

@ -61,7 +61,7 @@ import static org.hamcrest.Matchers.equalTo;
import static org.hamcrest.Matchers.is;
import static org.hamcrest.Matchers.nullValue;
public class BulkTests extends ElasticsearchIntegrationTest {
public class BulkIT extends ElasticsearchIntegrationTest {
@Test
public void testBulkUpdate_simple() throws Exception {

View File

@ -46,7 +46,7 @@ import static org.hamcrest.Matchers.nullValue;
/**
*
*/
public class DocumentActionsTests extends ElasticsearchIntegrationTest {
public class DocumentActionsIT extends ElasticsearchIntegrationTest {
protected void createIndex() {
createIndex(getConcreteIndexName());

View File

@ -39,7 +39,7 @@ import static org.hamcrest.Matchers.*;
/**
*/
public class ShardInfoTests extends ElasticsearchIntegrationTest {
public class ShardInfoIT extends ElasticsearchIntegrationTest {
private int numCopies;
private int numNodes;

View File

@ -29,7 +29,7 @@ import static org.elasticsearch.index.query.QueryBuilders.boolQuery;
import static org.elasticsearch.index.query.QueryBuilders.rangeQuery;
import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertExists;
public class SimpleExistsTests extends ElasticsearchIntegrationTest {
public class SimpleExistsIT extends ElasticsearchIntegrationTest {
@Test

View File

@ -50,7 +50,7 @@ import static org.hamcrest.Matchers.notNullValue;
/**
*/
public class ExplainActionTests extends ElasticsearchIntegrationTest {
public class ExplainActionIT extends ElasticsearchIntegrationTest {
@Test
public void testSimple() throws Exception {

View File

@ -38,7 +38,7 @@ import static org.hamcrest.Matchers.*;
/**
*/
public class FieldStatsIntegrationTests extends ElasticsearchIntegrationTest {
public class FieldStatsIntegrationIT extends ElasticsearchIntegrationTest {
public void testRandom() throws Exception {
assertAcked(prepareCreate("test").addMapping(

View File

@ -51,9 +51,9 @@ import static org.hamcrest.Matchers.nullValue;
*/
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
@Slow
public class GatewayIndexStateTests extends ElasticsearchIntegrationTest {
public class GatewayIndexStateIT extends ElasticsearchIntegrationTest {
private final ESLogger logger = Loggers.getLogger(GatewayIndexStateTests.class);
private final ESLogger logger = Loggers.getLogger(GatewayIndexStateIT.class);
@Test
public void testMappingMetaDataParsed() throws Exception {

View File

@ -48,7 +48,7 @@ import static org.hamcrest.Matchers.equalTo;
*/
@LuceneTestCase.Slow
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
public class MetaDataWriteDataNodesTests extends ElasticsearchIntegrationTest {
public class MetaDataWriteDataNodesIT extends ElasticsearchIntegrationTest {
@Test
public void testMetaWrittenAlsoOnDataNode() throws Exception {

View File

@ -45,7 +45,7 @@ import static org.hamcrest.Matchers.*;
*
*/
@ClusterScope(numDataNodes =0, scope= Scope.TEST)
public class QuorumGatewayTests extends ElasticsearchIntegrationTest {
public class QuorumGatewayIT extends ElasticsearchIntegrationTest {
@Override
protected int numberOfReplicas() {

View File

@ -41,7 +41,7 @@ import static org.hamcrest.Matchers.hasItem;
*/
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
@Slow
public class RecoverAfterNodesTests extends ElasticsearchIntegrationTest {
public class RecoverAfterNodesIT extends ElasticsearchIntegrationTest {
private final static TimeValue BLOCK_WAIT_TIMEOUT = TimeValue.timeValueSeconds(10);

View File

@ -57,7 +57,7 @@ import static org.hamcrest.Matchers.*;
*/
@ClusterScope(numDataNodes = 0, scope = Scope.TEST)
@Slow
public class RecoveryFromGatewayTests extends ElasticsearchIntegrationTest {
public class RecoveryFromGatewayIT extends ElasticsearchIntegrationTest {
@Test
@Slow

View File

@ -56,7 +56,7 @@ import static org.elasticsearch.common.xcontent.XContentFactory.jsonBuilder;
import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAcked;
import static org.hamcrest.Matchers.*;
public class GetActionTests extends ElasticsearchIntegrationTest {
public class GetActionIT extends ElasticsearchIntegrationTest {
@Test
public void simpleGetTests() {

View File

@ -33,7 +33,7 @@ import static org.hamcrest.CoreMatchers.is;
import static org.hamcrest.Matchers.*;
@ClusterScope(scope = Scope.SUITE, numDataNodes = 1)
public class HttpPublishPortTests extends ElasticsearchIntegrationTest {
public class HttpPublishPortIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -42,7 +42,7 @@ import static org.hamcrest.Matchers.*;
*
*/
@ClusterScope(scope = Scope.TEST, numDataNodes = 1)
public class NettyPipeliningDisabledIntegrationTest extends ElasticsearchIntegrationTest {
public class NettyPipeliningDisabledIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -40,7 +40,7 @@ import static org.hamcrest.Matchers.is;
@ClusterScope(scope = Scope.TEST, numDataNodes = 1)
public class NettyPipeliningEnabledIntegrationTest extends ElasticsearchIntegrationTest {
public class NettyPipeliningEnabledIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -31,7 +31,7 @@ import java.util.HashMap;
import java.util.Map;
import java.util.concurrent.ExecutionException;
public class IndexRequestBuilderTests extends ElasticsearchIntegrationTest {
public class IndexRequestBuilderIT extends ElasticsearchIntegrationTest {
@Test

View File

@ -66,7 +66,7 @@ import static org.hamcrest.Matchers.*;
* Tests for indices that use shadow replicas and a shared filesystem
*/
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.TEST, numDataNodes = 0)
public class IndexWithShadowReplicasTests extends ElasticsearchIntegrationTest {
public class IndexWithShadowReplicasIT extends ElasticsearchIntegrationTest {
private Settings nodeSettings() {
return Settings.builder()

View File

@ -48,7 +48,7 @@ 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)
public class TransportIndexFailuresTest extends ElasticsearchIntegrationTest {
public class TransportIndexFailuresIT extends ElasticsearchIntegrationTest {
private static final Settings nodeSettings = Settings.settingsBuilder()
.put("discovery.type", "zen") // <-- To override the local setting if set externally

View File

@ -32,7 +32,7 @@ import java.util.Collection;
import java.util.HashSet;
import java.util.Set;
public class InternalEngineIntegrationTest extends ElasticsearchIntegrationTest {
public class InternalEngineIT extends ElasticsearchIntegrationTest {
@Test
public void testSetIndexCompoundOnFlush() {

View File

@ -43,7 +43,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertNoFa
/**
*/
@ClusterScope(numDataNodes = 1, scope = Scope.SUITE)
public class InternalEngineMergeTests extends ElasticsearchIntegrationTest {
public class InternalEngineMergeIT extends ElasticsearchIntegrationTest {
@Test
@Slow

View File

@ -40,7 +40,7 @@ import org.apache.lucene.store.MockDirectoryWrapper;
import org.apache.lucene.util.IOUtils;
import org.apache.lucene.util.TestUtil;
import org.elasticsearch.Version;
import org.elasticsearch.bwcompat.OldIndexBackwardsCompatibilityTests;
import org.elasticsearch.bwcompat.OldIndexBackwardsCompatibilityIT;
import org.elasticsearch.cluster.metadata.IndexMetaData;
import org.elasticsearch.common.Base64;
import org.elasticsearch.common.Nullable;
@ -1750,7 +1750,7 @@ public class InternalEngineTests extends ElasticsearchTestCase {
public void testUpgradeOldIndex() throws IOException {
List<Path> indexes = new ArrayList<>();
Path dir = getDataPath("/" + OldIndexBackwardsCompatibilityTests.class.getPackage().getName().replace('.', '/')); // the files are in the same pkg as the OldIndexBackwardsCompatibilityTests test
Path dir = getDataPath("/" + OldIndexBackwardsCompatibilityIT.class.getPackage().getName().replace('.', '/')); // the files are in the same pkg as the OldIndexBackwardsCompatibilityTests test
try (DirectoryStream<Path> stream = Files.newDirectoryStream(dir, "index-*.zip")) {
for (Path path : stream) {
indexes.add(path);

View File

@ -36,7 +36,7 @@ import static org.elasticsearch.index.query.QueryBuilders.matchAllQuery;
import static org.elasticsearch.search.aggregations.AggregationBuilders.terms;
import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAcked;
public class FieldDataFilterIntegrationTests extends ElasticsearchIntegrationTest {
public class FieldDataFilterIntegrationIT extends ElasticsearchIntegrationTest {
@Override
protected int numberOfReplicas() {

View File

@ -29,7 +29,7 @@ import static org.hamcrest.Matchers.greaterThan;
/**
*/
public class FieldDataLoadingTests extends ElasticsearchIntegrationTest {
public class FieldDataLoadingIT extends ElasticsearchIntegrationTest {
@Test
public void testEagerFieldDataLoading() throws Exception {

View File

@ -30,7 +30,7 @@ import java.util.concurrent.CountDownLatch;
import java.util.concurrent.atomic.AtomicReference;
public class DynamicMappingIntegrationTests extends ElasticsearchIntegrationTest {
public class DynamicMappingIntegrationIT extends ElasticsearchIntegrationTest {
public void testConflictingDynamicMappings() {
// we don't use indexRandom because the order of requests is important here

View File

@ -53,7 +53,7 @@ import static org.hamcrest.Matchers.not;
* Tests for transforming the source document before indexing.
*/
@SuppressCodecs("*") // requires custom completion format
public class TransformOnIndexMapperIntegrationTest extends ElasticsearchIntegrationTest {
public class TransformOnIndexMapperIT extends ElasticsearchIntegrationTest {
@Test
public void searchOnTransformed() throws Exception {
setup(true);

View File

@ -36,7 +36,7 @@ import static org.hamcrest.Matchers.equalTo;
/**
*/
public class CopyToMapperIntegrationTests extends ElasticsearchIntegrationTest {
public class CopyToMapperIntegrationIT extends ElasticsearchIntegrationTest {
@Test

View File

@ -42,7 +42,7 @@ import java.util.List;
import static org.elasticsearch.common.xcontent.XContentFactory.jsonBuilder;
import static org.hamcrest.Matchers.*;
public class TokenCountFieldMapperIntegrationTests extends ElasticsearchIntegrationTest {
public class TokenCountFieldMapperIntegrationIT extends ElasticsearchIntegrationTest {
@ParametersFactory
public static Iterable<Object[]> buildParameters() {
List<Object[]> parameters = new ArrayList<>();
@ -57,7 +57,7 @@ public class TokenCountFieldMapperIntegrationTests extends ElasticsearchIntegrat
private final boolean storeCountedFields;
private final boolean loadCountedFields;
public TokenCountFieldMapperIntegrationTests(@Name("storeCountedFields") boolean storeCountedFields,
public TokenCountFieldMapperIntegrationIT(@Name("storeCountedFields") boolean storeCountedFields,
@Name("loadCountedFields") boolean loadCountedFields) {
this.storeCountedFields = storeCountedFields;
this.loadCountedFields = loadCountedFields;

View File

@ -30,7 +30,7 @@ import org.junit.Test;
import static org.hamcrest.Matchers.equalTo;
public class ExternalValuesMapperIntegrationTests extends ElasticsearchIntegrationTest {
public class ExternalValuesMapperIntegrationIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -41,7 +41,7 @@ import static org.hamcrest.Matchers.*;
/**
*/
public class MultiFieldsIntegrationTests extends ElasticsearchIntegrationTest {
public class MultiFieldsIntegrationIT extends ElasticsearchIntegrationTest {
@Test
public void testMultiFields() throws Exception {

View File

@ -32,7 +32,7 @@ import static org.elasticsearch.common.xcontent.XContentFactory.jsonBuilder;
import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAcked;
import static org.hamcrest.Matchers.*;
public class SizeMappingIntegrationTests extends ElasticsearchIntegrationTest {
public class SizeMappingIntegrationIT extends ElasticsearchIntegrationTest {
@Test // issue 5053
public void testThatUpdatingMappingShouldNotRemoveSizeMappingConfiguration() throws Exception {

View File

@ -36,7 +36,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertAcke
import static org.hamcrest.Matchers.containsString;
import static org.hamcrest.Matchers.equalTo;
public class UpdateMappingOnClusterTests extends ElasticsearchIntegrationTest {
public class UpdateMappingOnClusterIT extends ElasticsearchIntegrationTest {
private static final String INDEX = "index";
private static final String TYPE = "type";

View File

@ -58,7 +58,7 @@ import static org.hamcrest.Matchers.is;
* Full integration test of the template query plugin.
*/
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.SUITE)
public class TemplateQueryTest extends ElasticsearchIntegrationTest {
public class TemplateQueryIT extends ElasticsearchIntegrationTest {
@Before
public void setup() throws IOException {

View File

@ -36,7 +36,7 @@ import static org.elasticsearch.index.query.QueryBuilders.constantScoreQuery;
import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.assertHitCount;
import static org.hamcrest.Matchers.instanceOf;
public class CustomQueryParserTests extends ElasticsearchIntegrationTest {
public class CustomQueryParserIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -90,7 +90,7 @@ import static org.elasticsearch.test.hamcrest.ElasticsearchAssertions.*;
import static org.hamcrest.Matchers.*;
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.SUITE)
public class CorruptedFileTest extends ElasticsearchIntegrationTest {
public class CorruptedFileIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -58,7 +58,7 @@ import static org.hamcrest.Matchers.notNullValue;
* Integration test for corrupted translog files
*/
@ElasticsearchIntegrationTest.ClusterScope(scope= ElasticsearchIntegrationTest.Scope.SUITE, numDataNodes = 0)
public class CorruptedTranslogTests extends ElasticsearchIntegrationTest {
public class CorruptedTranslogIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -48,7 +48,7 @@ import static org.hamcrest.CoreMatchers.equalTo;
import static org.hamcrest.Matchers.greaterThan;
@ElasticsearchIntegrationTest.ClusterScope(scope = ElasticsearchIntegrationTest.Scope.SUITE)
public class ExceptionRetryTests extends ElasticsearchIntegrationTest {
public class ExceptionRetryIT extends ElasticsearchIntegrationTest {
@Override
protected Settings nodeSettings(int nodeOrdinal) {

View File

@ -46,7 +46,7 @@ import static org.hamcrest.Matchers.*;
/**
*/
@ElasticsearchIntegrationTest.ClusterScope(minNumDataNodes = 2)
public class SuggestStatsTests extends ElasticsearchIntegrationTest {
public class SuggestStatsIT extends ElasticsearchIntegrationTest {
@Override
protected int numberOfReplicas() {

View File

@ -29,7 +29,7 @@ import org.apache.lucene.util.LuceneTestCase;
import org.apache.lucene.util.TestUtil;
import org.elasticsearch.ElasticsearchException;
import org.elasticsearch.Version;
import org.elasticsearch.bwcompat.OldIndexBackwardsCompatibilityTests;
import org.elasticsearch.bwcompat.OldIndexBackwardsCompatibilityIT;
import org.elasticsearch.common.bytes.BytesArray;
import org.elasticsearch.common.io.FileSystemUtils;
import org.elasticsearch.common.io.stream.BytesStreamOutput;
@ -1142,7 +1142,7 @@ public class TranslogTests extends ElasticsearchTestCase {
public void testUpgradeOldTranslogFiles() throws IOException {
List<Path> indexes = new ArrayList<>();
Path dir = getDataPath("/" + OldIndexBackwardsCompatibilityTests.class.getPackage().getName().replace('.', '/')); // the files are in the same pkg as the OldIndexBackwardsCompatibilityTests test
Path dir = getDataPath("/" + OldIndexBackwardsCompatibilityIT.class.getPackage().getName().replace('.', '/')); // the files are in the same pkg as the OldIndexBackwardsCompatibilityTests test
try (DirectoryStream<Path> stream = Files.newDirectoryStream(dir, "index-*.zip")) {
for (Path path : stream) {
indexes.add(path);

View File

@ -43,7 +43,7 @@ import static org.hamcrest.Matchers.lessThanOrEqualTo;
/**
*
*/
public class IndexActionTests extends ElasticsearchIntegrationTest {
public class IndexActionIT extends ElasticsearchIntegrationTest {
/**
* This test tries to simulate load while creating an index and indexing documents

View File

@ -53,7 +53,7 @@ import static org.hamcrest.Matchers.*;
*
*/
@ClusterScope(scope = Scope.TEST, numDataNodes = 0)
public class IndexLifecycleActionTests extends ElasticsearchIntegrationTest {
public class IndexLifecycleActionIT extends ElasticsearchIntegrationTest {
@Slow
@Test

Some files were not shown because too many files have changed in this diff Show More