Search in sources :

Example 16 with ThreadPool

use of org.opensearch.threadpool.ThreadPool in project asynchronous-search by opensearch-project.

the class AsynchronousSearchRejectionIT method testSearchFailures.

public void testSearchFailures() throws Exception {
    for (int i = 0; i < 10; i++) {
        client().prepareIndex("test").setId(Integer.toString(i)).setSource("field", "1").get();
    }
    int numberOfAsyncOps = randomIntBetween(100, 200);
    final CountDownLatch latch = new CountDownLatch(numberOfAsyncOps);
    final CopyOnWriteArrayList<Object> responses = new CopyOnWriteArrayList<>();
    TestThreadPool threadPool = null;
    try {
        threadPool = new TestThreadPool(AsynchronousSearchProgressListenerIT.class.getName());
        for (int i = 0; i < numberOfAsyncOps; i++) {
            SearchRequest request = client().prepareSearch("test").setSearchType(SearchType.QUERY_THEN_FETCH).setQuery(QueryBuilders.matchQuery("field", "1")).request();
            AtomicReference<SearchResponse> responseRef = new AtomicReference<>();
            AtomicInteger reduceContextInvocation = new AtomicInteger();
            AsynchronousSearchProgressListener listener;
            SearchService service = internalCluster().getInstance(SearchService.class);
            InternalAggregation.ReduceContextBuilder reduceContextBuilder = service.aggReduceContextBuilder(request);
            AtomicReference<Exception> exceptionRef = new AtomicReference<>();
            Function<SearchResponse, AsynchronousSearchResponse> responseFunction = (r) -> null;
            Function<Exception, AsynchronousSearchResponse> failureFunction = (e) -> null;
            listener = new AsynchronousSearchProgressListener(threadPool.relativeTimeInMillis(), responseFunction, failureFunction, threadPool.generic(), threadPool::relativeTimeInMillis, () -> reduceContextBuilder) {

                @Override
                public void onResponse(SearchResponse searchResponse) {
                    assertTrue(responseRef.compareAndSet(null, searchResponse));
                    AsynchronousSearchAssertions.assertSearchResponses(searchResponse, this.partialResponse());
                    latch.countDown();
                }

                @Override
                public void onFailure(Exception exception) {
                    assertTrue(exceptionRef.compareAndSet(null, exception));
                    latch.countDown();
                }
            };
            client().execute(SearchAction.INSTANCE, new SearchRequest(request) {

                @Override
                public SearchTask createTask(long id, String type, String action, TaskId parentTaskId, Map<String, String> headers) {
                    SearchTask task = super.createTask(id, type, action, parentTaskId, headers);
                    task.setProgressListener(listener);
                    return task;
                }
            }, listener);
        }
        latch.await();
    } finally {
        ThreadPool.terminate(threadPool, 100, TimeUnit.MILLISECONDS);
    }
}
Also used : AsynchronousSearchResponse(org.opensearch.search.asynchronous.response.AsynchronousSearchResponse) SearchAction(org.opensearch.action.search.SearchAction) OpenSearchRejectedExecutionException(org.opensearch.common.util.concurrent.OpenSearchRejectedExecutionException) AsynchronousSearchAssertions(org.opensearch.search.asynchronous.utils.AsynchronousSearchAssertions) SubmitAsynchronousSearchAction(org.opensearch.search.asynchronous.action.SubmitAsynchronousSearchAction) AsynchronousSearchIntegTestCase(org.opensearch.search.asynchronous.commons.AsynchronousSearchIntegTestCase) ThreadPool(org.opensearch.threadpool.ThreadPool) AsynchronousSearchProgressListener(org.opensearch.search.asynchronous.listener.AsynchronousSearchProgressListener) TestThreadPool(org.opensearch.threadpool.TestThreadPool) AsynchronousSearchResponse(org.opensearch.search.asynchronous.response.AsynchronousSearchResponse) ResourceNotFoundException(org.opensearch.ResourceNotFoundException) AtomicReference(java.util.concurrent.atomic.AtomicReference) Function(java.util.function.Function) AcknowledgedResponse(org.opensearch.search.asynchronous.response.AcknowledgedResponse) LatchedActionListener(org.opensearch.action.LatchedActionListener) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) Locale(java.util.Locale) Map(java.util.Map) SearchRequest(org.opensearch.action.search.SearchRequest) DeleteAsynchronousSearchAction(org.opensearch.search.asynchronous.action.DeleteAsynchronousSearchAction) ActionListener(org.opensearch.action.ActionListener) SearchResponse(org.opensearch.action.search.SearchResponse) AsynchronousSearchProgressListenerIT(org.opensearch.search.asynchronous.listener.AsynchronousSearchProgressListenerIT) SearchService(org.opensearch.search.SearchService) QueryBuilders(org.opensearch.index.query.QueryBuilders) TimeValue(org.opensearch.common.unit.TimeValue) SearchTask(org.opensearch.action.search.SearchTask) ExceptionsHelper(org.opensearch.ExceptionsHelper) SearchType(org.opensearch.action.search.SearchType) TaskId(org.opensearch.tasks.TaskId) Settings(org.opensearch.common.settings.Settings) DeleteAsynchronousSearchRequest(org.opensearch.search.asynchronous.request.DeleteAsynchronousSearchRequest) Matchers.startsWith(org.hamcrest.Matchers.startsWith) AsynchronousSearchService(org.opensearch.search.asynchronous.service.AsynchronousSearchService) TestLogging(org.opensearch.test.junit.annotations.TestLogging) TimeUnit(java.util.concurrent.TimeUnit) CountDownLatch(java.util.concurrent.CountDownLatch) SubmitAsynchronousSearchRequest(org.opensearch.search.asynchronous.request.SubmitAsynchronousSearchRequest) ShardSearchFailure(org.opensearch.action.search.ShardSearchFailure) Matchers.equalTo(org.hamcrest.Matchers.equalTo) OpenSearchTimeoutException(org.opensearch.OpenSearchTimeoutException) SearchPhaseExecutionException(org.opensearch.action.search.SearchPhaseExecutionException) InternalAggregation(org.opensearch.search.aggregations.InternalAggregation) OpenSearchIntegTestCase(org.opensearch.test.OpenSearchIntegTestCase) CopyOnWriteArrayList(java.util.concurrent.CopyOnWriteArrayList) SearchRequest(org.opensearch.action.search.SearchRequest) DeleteAsynchronousSearchRequest(org.opensearch.search.asynchronous.request.DeleteAsynchronousSearchRequest) SubmitAsynchronousSearchRequest(org.opensearch.search.asynchronous.request.SubmitAsynchronousSearchRequest) TaskId(org.opensearch.tasks.TaskId) TestThreadPool(org.opensearch.threadpool.TestThreadPool) SearchTask(org.opensearch.action.search.SearchTask) SearchService(org.opensearch.search.SearchService) AsynchronousSearchService(org.opensearch.search.asynchronous.service.AsynchronousSearchService) AtomicReference(java.util.concurrent.atomic.AtomicReference) CountDownLatch(java.util.concurrent.CountDownLatch) OpenSearchRejectedExecutionException(org.opensearch.common.util.concurrent.OpenSearchRejectedExecutionException) ResourceNotFoundException(org.opensearch.ResourceNotFoundException) OpenSearchTimeoutException(org.opensearch.OpenSearchTimeoutException) SearchPhaseExecutionException(org.opensearch.action.search.SearchPhaseExecutionException) AsynchronousSearchResponse(org.opensearch.search.asynchronous.response.AsynchronousSearchResponse) SearchResponse(org.opensearch.action.search.SearchResponse) AsynchronousSearchProgressListener(org.opensearch.search.asynchronous.listener.AsynchronousSearchProgressListener) InternalAggregation(org.opensearch.search.aggregations.InternalAggregation) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) CopyOnWriteArrayList(java.util.concurrent.CopyOnWriteArrayList)

Example 17 with ThreadPool

use of org.opensearch.threadpool.ThreadPool in project asynchronous-search by opensearch-project.

the class AsynchronousSearchPartialResponseIT method testCase.

private void testCase(Client client, SearchRequest request) throws Exception {
    AtomicReference<SearchResponse> responseRef = new AtomicReference<>();
    AtomicInteger reduceContextInvocation = new AtomicInteger();
    TestThreadPool threadPool = null;
    AsynchronousSearchProgressListener listener;
    try {
        threadPool = new TestThreadPool(AsynchronousSearchProgressListenerIT.class.getName());
        SearchService service = internalCluster().getInstance(SearchService.class);
        InternalAggregation.ReduceContextBuilder reduceContextBuilder = service.aggReduceContextBuilder(request);
        AtomicReference<Exception> exceptionRef = new AtomicReference<>();
        CountDownLatch latch = new CountDownLatch(1);
        Function<SearchResponse, AsynchronousSearchResponse> responseFunction = (r) -> null;
        Function<Exception, AsynchronousSearchResponse> failureFunction = (e) -> null;
        listener = new AsynchronousSearchProgressListener(threadPool.relativeTimeInMillis(), responseFunction, failureFunction, threadPool.generic(), threadPool::relativeTimeInMillis, () -> reduceContextBuilder) {

            @Override
            public void onResponse(SearchResponse searchResponse) {
                assertTrue(responseRef.compareAndSet(null, searchResponse));
                AsynchronousSearchAssertions.assertSearchResponses(responseRef.get(), this.partialResponse());
                latch.countDown();
            }

            @Override
            protected void onPartialReduce(List<SearchShard> shards, TotalHits totalHits, InternalAggregations aggs, int reducePhase) {
                super.onPartialReduce(shards, totalHits, aggs, reducePhase);
                Terms terms = this.partialResponse().getAggregations().get("keys");
                List<? extends Terms.Bucket> buckets = terms.getBuckets();
                assertThat(buckets.size(), lessThanOrEqualTo(aggregationSize));
                reduceContextInvocation.incrementAndGet();
            }

            @Override
            protected void onFinalReduce(List<SearchShard> shards, TotalHits totalHits, InternalAggregations aggs, int reducePhase) {
                super.onFinalReduce(shards, totalHits, aggs, reducePhase);
                Terms terms = this.partialResponse().getAggregations().get("keys");
                List<? extends Terms.Bucket> buckets = terms.getBuckets();
                assertThat(buckets.size(), equalTo(aggregationSize));
            }

            @Override
            public void onFailure(Exception exception) {
                assertTrue(exceptionRef.compareAndSet(null, exception));
                latch.countDown();
            }
        };
        client.execute(SearchAction.INSTANCE, new SearchRequest(request) {

            @Override
            public SearchTask createTask(long id, String type, String action, TaskId parentTaskId, Map<String, String> headers) {
                SearchTask task = super.createTask(id, type, action, parentTaskId, headers);
                task.setProgressListener(listener);
                return task;
            }
        }, listener);
        latch.await();
        Terms terms = responseRef.get().getAggregations().get("keys");
        assertThat(reduceContextInvocation.get(), equalTo(responseRef.get().getNumReducePhases() - 1));
        List<? extends Terms.Bucket> buckets = terms.getBuckets();
        assertThat(buckets.size(), equalTo(aggregationSize));
    } finally {
        ThreadPool.terminate(threadPool, 100, TimeUnit.MILLISECONDS);
    }
}
Also used : AsynchronousSearchResponse(org.opensearch.search.asynchronous.response.AsynchronousSearchResponse) IndexRequestBuilder(org.opensearch.action.index.IndexRequestBuilder) SearchAction(org.opensearch.action.search.SearchAction) AsynchronousSearchAssertions(org.opensearch.search.asynchronous.utils.AsynchronousSearchAssertions) XContentFactory.jsonBuilder(org.opensearch.common.xcontent.XContentFactory.jsonBuilder) BucketOrder(org.opensearch.search.aggregations.BucketOrder) Arrays(java.util.Arrays) ThreadPool(org.opensearch.threadpool.ThreadPool) TestThreadPool(org.opensearch.threadpool.TestThreadPool) OpenSearchAssertions.assertSearchResponse(org.opensearch.test.hamcrest.OpenSearchAssertions.assertSearchResponse) AsynchronousSearchResponse(org.opensearch.search.asynchronous.response.AsynchronousSearchResponse) AtomicReference(java.util.concurrent.atomic.AtomicReference) Function(java.util.function.Function) AggregationBuilders.terms(org.opensearch.search.aggregations.AggregationBuilders.terms) ArrayList(java.util.ArrayList) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) QueryBuilders.matchAllQuery(org.opensearch.index.query.QueryBuilders.matchAllQuery) InternalAggregations(org.opensearch.search.aggregations.InternalAggregations) Map(java.util.Map) SearchRequest(org.opensearch.action.search.SearchRequest) SearchResponse(org.opensearch.action.search.SearchResponse) SearchService(org.opensearch.search.SearchService) OpenSearchAssertions.assertAcked(org.opensearch.test.hamcrest.OpenSearchAssertions.assertAcked) Client(org.opensearch.client.Client) SearchTask(org.opensearch.action.search.SearchTask) Matchers.lessThanOrEqualTo(org.hamcrest.Matchers.lessThanOrEqualTo) TaskId(org.opensearch.tasks.TaskId) Terms(org.opensearch.search.aggregations.bucket.terms.Terms) SearchShard(org.opensearch.action.search.SearchShard) TotalHits(org.apache.lucene.search.TotalHits) TimeUnit(java.util.concurrent.TimeUnit) CountDownLatch(java.util.concurrent.CountDownLatch) List(java.util.List) Matchers.equalTo(org.hamcrest.Matchers.equalTo) Matchers.is(org.hamcrest.Matchers.is) Aggregator(org.opensearch.search.aggregations.Aggregator) InternalAggregation(org.opensearch.search.aggregations.InternalAggregation) OpenSearchIntegTestCase(org.opensearch.test.OpenSearchIntegTestCase) TotalHits(org.apache.lucene.search.TotalHits) SearchRequest(org.opensearch.action.search.SearchRequest) TaskId(org.opensearch.tasks.TaskId) TestThreadPool(org.opensearch.threadpool.TestThreadPool) SearchTask(org.opensearch.action.search.SearchTask) SearchService(org.opensearch.search.SearchService) ArrayList(java.util.ArrayList) List(java.util.List) SearchShard(org.opensearch.action.search.SearchShard) Terms(org.opensearch.search.aggregations.bucket.terms.Terms) AtomicReference(java.util.concurrent.atomic.AtomicReference) CountDownLatch(java.util.concurrent.CountDownLatch) OpenSearchAssertions.assertSearchResponse(org.opensearch.test.hamcrest.OpenSearchAssertions.assertSearchResponse) AsynchronousSearchResponse(org.opensearch.search.asynchronous.response.AsynchronousSearchResponse) SearchResponse(org.opensearch.action.search.SearchResponse) InternalAggregation(org.opensearch.search.aggregations.InternalAggregation) InternalAggregations(org.opensearch.search.aggregations.InternalAggregations) AtomicInteger(java.util.concurrent.atomic.AtomicInteger)

Example 18 with ThreadPool

use of org.opensearch.threadpool.ThreadPool in project asynchronous-search by opensearch-project.

the class AsynchronousSearchActiveStoreTests method testGetNonExistentContext.

public void testGetNonExistentContext() {
    DiscoveryNode node = new DiscoveryNode("node", OpenSearchTestCase.buildNewFakeTransportAddress(), Collections.emptyMap(), DiscoveryNodeRole.BUILT_IN_ROLES, Version.CURRENT);
    ThreadPool testThreadPool = null;
    try {
        testThreadPool = new TestThreadPool(this.getClass().getName(), executorBuilder);
        ClusterService mockClusterService = ClusterServiceUtils.createClusterService(testThreadPool, node, clusterSettings);
        AsynchronousSearchActiveStore activeStore = new AsynchronousSearchActiveStore(mockClusterService);
        AsynchronousSearchContextId asContextId = new AsynchronousSearchContextId(UUID.randomUUID().toString(), randomNonNegativeLong());
        Optional<AsynchronousSearchActiveContext> optional = activeStore.getContext(asContextId);
        assertFalse(optional.isPresent());
        assertEquals(activeStore.getAllContexts().size(), 0);
    } finally {
        ThreadPool.terminate(testThreadPool, 10, TimeUnit.SECONDS);
    }
}
Also used : DiscoveryNode(org.opensearch.cluster.node.DiscoveryNode) ClusterService(org.opensearch.cluster.service.ClusterService) AsynchronousSearchContextId(org.opensearch.search.asynchronous.context.AsynchronousSearchContextId) ThreadPool(org.opensearch.threadpool.ThreadPool) TestThreadPool(org.opensearch.threadpool.TestThreadPool) TestThreadPool(org.opensearch.threadpool.TestThreadPool)

Example 19 with ThreadPool

use of org.opensearch.threadpool.ThreadPool in project asynchronous-search by opensearch-project.

the class AsynchronousSearchServiceFreeContextTests method testFreeContextPermitAcquisitionFailure.

public void testFreeContextPermitAcquisitionFailure() throws InterruptedException {
    DiscoveryNode discoveryNode = new DiscoveryNode("node", OpenSearchTestCase.buildNewFakeTransportAddress(), emptyMap(), DiscoveryNodeRole.BUILT_IN_ROLES, Version.CURRENT);
    ThreadPool testThreadPool = null;
    try {
        testThreadPool = new TestThreadPool(OPEN_DISTRO_ASYNC_SEARCH_GENERIC_THREAD_POOL_NAME, executorBuilder);
        ClusterService mockClusterService = getClusterService(discoveryNode, testThreadPool);
        MockClient mockClient = new MockClient(testThreadPool);
        AsynchronousSearchActiveStore mockStore = mock(AsynchronousSearchActiveStore.class);
        AsynchronousSearchPersistenceService persistenceService = new AsynchronousSearchPersistenceService(mockClient, mockClusterService, testThreadPool);
        AsynchronousSearchService asService = new AsynchronousSearchService(persistenceService, mockStore, mockClient, mockClusterService, testThreadPool, new InternalAsynchronousSearchStats(), new NamedWriteableRegistry(emptyList()));
        TimeValue keepAlive = timeValueDays(9);
        boolean keepOnCompletion = true;
        User user1 = randomBoolean() ? randomUser() : null;
        SearchRequest searchRequest = new SearchRequest();
        SubmitAsynchronousSearchRequest submitAsynchronousSearchRequest = new SubmitAsynchronousSearchRequest(searchRequest);
        submitAsynchronousSearchRequest.keepOnCompletion(keepOnCompletion);
        submitAsynchronousSearchRequest.keepAlive(keepAlive);
        AsynchronousSearchProgressListener asProgressListener = mockAsynchronousSearchProgressListener(testThreadPool);
        AsynchronousSearchContextId asContextId = new AsynchronousSearchContextId(UUID.randomUUID().toString(), randomNonNegativeLong());
        MockAsynchronousSearchActiveContext asActiveContext = new MockAsynchronousSearchActiveContext(asContextId, discoveryNode.getId(), keepAlive, true, testThreadPool, testThreadPool::absoluteTimeInMillis, asProgressListener, user1);
        // bootstrap search
        AsynchronousSearchTask task = new AsynchronousSearchTask(randomNonNegativeLong(), "transport", SearchAction.NAME, TaskId.EMPTY_TASK_ID, emptyMap(), asActiveContext, null, (c) -> {
        });
        asActiveContext.setTask(task);
        simulateUncheckedException = true;
        persisted = false;
        when(mockStore.getContext(asContextId)).thenReturn(Optional.of(asActiveContext));
        CountDownLatch latch = new CountDownLatch(1);
        asService.freeContext(asActiveContext.getAsynchronousSearchId(), asActiveContext.getContextId(), null, new LatchedActionListener<>(wrap(r -> fail("Expected resource_not_found_exception. Got acknowledgement " + r), e -> {
            assertTrue(e.getClass().getName(), e instanceof ResourceNotFoundException);
        }), latch));
        latch.await();
        assertEquals(1, (int) mockClient.deleteCount);
        mockClusterService.stop();
    } finally {
        ThreadPool.terminate(testThreadPool, 30, TimeUnit.SECONDS);
    }
}
Also used : NamedWriteableRegistry(org.opensearch.common.io.stream.NamedWriteableRegistry) SubmitAsynchronousSearchRequest(org.opensearch.search.asynchronous.request.SubmitAsynchronousSearchRequest) SearchRequest(org.opensearch.action.search.SearchRequest) DiscoveryNode(org.opensearch.cluster.node.DiscoveryNode) TestClientUtils.randomUser(org.opensearch.search.asynchronous.utils.TestClientUtils.randomUser) User(org.opensearch.commons.authuser.User) SubmitAsynchronousSearchRequest(org.opensearch.search.asynchronous.request.SubmitAsynchronousSearchRequest) AsynchronousSearchContextId(org.opensearch.search.asynchronous.context.AsynchronousSearchContextId) TestThreadPool(org.opensearch.threadpool.TestThreadPool) ThreadPool(org.opensearch.threadpool.ThreadPool) InternalAsynchronousSearchStats(org.opensearch.search.asynchronous.stats.InternalAsynchronousSearchStats) TestThreadPool(org.opensearch.threadpool.TestThreadPool) CountDownLatch(java.util.concurrent.CountDownLatch) AsynchronousSearchActiveStore(org.opensearch.search.asynchronous.context.active.AsynchronousSearchActiveStore) AsynchronousSearchProgressListener(org.opensearch.search.asynchronous.listener.AsynchronousSearchProgressListener) AsynchronousSearchTestCase.mockAsynchronousSearchProgressListener(org.opensearch.search.asynchronous.commons.AsynchronousSearchTestCase.mockAsynchronousSearchProgressListener) AsynchronousSearchTask(org.opensearch.search.asynchronous.task.AsynchronousSearchTask) ClusterService(org.opensearch.cluster.service.ClusterService) ResourceNotFoundException(org.opensearch.ResourceNotFoundException) TimeValue(org.opensearch.common.unit.TimeValue)

Example 20 with ThreadPool

use of org.opensearch.threadpool.ThreadPool in project asynchronous-search by opensearch-project.

the class AsynchronousSearchServiceFreeContextTests method testFreePersistedContextUserNotMatches.

public void testFreePersistedContextUserNotMatches() throws InterruptedException {
    DiscoveryNode discoveryNode = new DiscoveryNode("node", OpenSearchTestCase.buildNewFakeTransportAddress(), emptyMap(), DiscoveryNodeRole.BUILT_IN_ROLES, Version.CURRENT);
    ThreadPool testThreadPool = null;
    try {
        testThreadPool = new TestThreadPool(OPEN_DISTRO_ASYNC_SEARCH_GENERIC_THREAD_POOL_NAME, executorBuilder);
        ClusterService mockClusterService = getClusterService(discoveryNode, testThreadPool);
        MockClient mockClient = new MockClient(testThreadPool);
        AsynchronousSearchActiveStore asActiveStore = new AsynchronousSearchActiveStore(mockClusterService);
        AsynchronousSearchPersistenceService persistenceService = new AsynchronousSearchPersistenceService(mockClient, mockClusterService, testThreadPool);
        AsynchronousSearchService asService = new AsynchronousSearchService(persistenceService, asActiveStore, mockClient, mockClusterService, testThreadPool, new InternalAsynchronousSearchStats(), new NamedWriteableRegistry(emptyList()));
        AsynchronousSearchContextId asContextId = new AsynchronousSearchContextId(UUID.randomUUID().toString(), randomNonNegativeLong());
        AsynchronousSearchId asId = new AsynchronousSearchId(discoveryNode.getId(), randomNonNegativeLong(), asContextId);
        persisted = true;
        userMatches = false;
        CountDownLatch latch = new CountDownLatch(1);
        asService.freeContext(AsynchronousSearchIdConverter.buildAsyncId(asId), asContextId, randomUser(), new LatchedActionListener<>(ActionListener.wrap(r -> {
            fail("Expected resource_not_found_exception due to user mismatch security exception. received delete " + "acknowledgement : " + r);
        }, e -> assertTrue("expected resource_not_found_exception got " + e.getClass().getName(), e instanceof ResourceNotFoundException)), latch));
        latch.await();
        mockClusterService.stop();
    } finally {
        ThreadPool.terminate(testThreadPool, 30, TimeUnit.SECONDS);
    }
}
Also used : NamedWriteableRegistry(org.opensearch.common.io.stream.NamedWriteableRegistry) DiscoveryNode(org.opensearch.cluster.node.DiscoveryNode) AsynchronousSearchContextId(org.opensearch.search.asynchronous.context.AsynchronousSearchContextId) TestThreadPool(org.opensearch.threadpool.TestThreadPool) ThreadPool(org.opensearch.threadpool.ThreadPool) InternalAsynchronousSearchStats(org.opensearch.search.asynchronous.stats.InternalAsynchronousSearchStats) TestThreadPool(org.opensearch.threadpool.TestThreadPool) CountDownLatch(java.util.concurrent.CountDownLatch) AsynchronousSearchActiveStore(org.opensearch.search.asynchronous.context.active.AsynchronousSearchActiveStore) ClusterService(org.opensearch.cluster.service.ClusterService) AsynchronousSearchId(org.opensearch.search.asynchronous.id.AsynchronousSearchId) ResourceNotFoundException(org.opensearch.ResourceNotFoundException)

Aggregations

ThreadPool (org.opensearch.threadpool.ThreadPool)238 TestThreadPool (org.opensearch.threadpool.TestThreadPool)133 Settings (org.opensearch.common.settings.Settings)106 ClusterService (org.opensearch.cluster.service.ClusterService)103 DiscoveryNode (org.opensearch.cluster.node.DiscoveryNode)95 ActionListener (org.opensearch.action.ActionListener)83 CountDownLatch (java.util.concurrent.CountDownLatch)79 TimeValue (org.opensearch.common.unit.TimeValue)73 Collections (java.util.Collections)69 List (java.util.List)67 AtomicBoolean (java.util.concurrent.atomic.AtomicBoolean)63 OpenSearchTestCase (org.opensearch.test.OpenSearchTestCase)62 ArrayList (java.util.ArrayList)59 TimeUnit (java.util.concurrent.TimeUnit)57 Before (org.junit.Before)57 TransportService (org.opensearch.transport.TransportService)57 Version (org.opensearch.Version)53 ShardId (org.opensearch.index.shard.ShardId)51 ClusterState (org.opensearch.cluster.ClusterState)50 PlainActionFuture (org.opensearch.action.support.PlainActionFuture)48