Search in sources :

Example 1 with ClusterHealthStatus

use of org.elasticsearch.cluster.health.ClusterHealthStatus in project elasticsearch by elastic.

the class CorruptedFileIT method testCorruptPrimaryNoReplica.

/**
     * Tests corruption that happens on a single shard when no replicas are present. We make sure that the primary stays unassigned
     * and all other replicas for the healthy shards happens
     */
public void testCorruptPrimaryNoReplica() throws ExecutionException, InterruptedException, IOException {
    int numDocs = scaledRandomIntBetween(100, 1000);
    internalCluster().ensureAtLeastNumDataNodes(2);
    assertAcked(prepareCreate("test").setSettings(Settings.builder().put(IndexMetaData.SETTING_NUMBER_OF_REPLICAS, "0").put(MergePolicyConfig.INDEX_MERGE_ENABLED, false).put(MockFSIndexStore.INDEX_CHECK_INDEX_ON_CLOSE_SETTING.getKey(), // no checkindex - we corrupt shards on purpose
    false).put(IndexSettings.INDEX_TRANSLOG_FLUSH_THRESHOLD_SIZE_SETTING.getKey(), // no translog based flush - it might change the .liv / segments.N files
    new ByteSizeValue(1, ByteSizeUnit.PB))));
    ensureGreen();
    IndexRequestBuilder[] builders = new IndexRequestBuilder[numDocs];
    for (int i = 0; i < builders.length; i++) {
        builders[i] = client().prepareIndex("test", "type").setSource("field", "value");
    }
    indexRandom(true, builders);
    ensureGreen();
    assertAllSuccessful(client().admin().indices().prepareFlush().setForce(true).execute().actionGet());
    // we have to flush at least once here since we don't corrupt the translog
    SearchResponse countResponse = client().prepareSearch().setSize(0).get();
    assertHitCount(countResponse, numDocs);
    ShardRouting shardRouting = corruptRandomPrimaryFile();
    /*
         * we corrupted the primary shard - now lets make sure we never recover from it successfully
         */
    Settings build = Settings.builder().put(IndexMetaData.SETTING_NUMBER_OF_REPLICAS, "1").build();
    client().admin().indices().prepareUpdateSettings("test").setSettings(build).get();
    client().admin().cluster().prepareReroute().get();
    boolean didClusterTurnRed = awaitBusy(() -> {
        ClusterHealthStatus test = client().admin().cluster().health(Requests.clusterHealthRequest("test")).actionGet().getStatus();
        return test == ClusterHealthStatus.RED;
    }, 5, // sometimes on slow nodes the replication / recovery is just dead slow
    TimeUnit.MINUTES);
    final ClusterHealthResponse response = client().admin().cluster().health(Requests.clusterHealthRequest("test")).get();
    if (response.getStatus() != ClusterHealthStatus.RED) {
        logger.info("Cluster turned red in busy loop: {}", didClusterTurnRed);
        logger.info("cluster state:\n{}\n{}", client().admin().cluster().prepareState().get().getState(), client().admin().cluster().preparePendingClusterTasks().get());
    }
    assertThat(response.getStatus(), is(ClusterHealthStatus.RED));
    ClusterState state = client().admin().cluster().prepareState().get().getState();
    GroupShardsIterator shardIterators = state.getRoutingTable().activePrimaryShardsGrouped(new String[] { "test" }, false);
    for (ShardIterator iterator : shardIterators) {
        ShardRouting routing;
        while ((routing = iterator.nextOrNull()) != null) {
            if (routing.getId() == shardRouting.getId()) {
                assertThat(routing.state(), equalTo(ShardRoutingState.UNASSIGNED));
            } else {
                assertThat(routing.state(), anyOf(equalTo(ShardRoutingState.RELOCATING), equalTo(ShardRoutingState.STARTED)));
            }
        }
    }
    final List<Path> files = listShardFiles(shardRouting);
    Path corruptedFile = null;
    for (Path file : files) {
        if (file.getFileName().toString().startsWith("corrupted_")) {
            corruptedFile = file;
            break;
        }
    }
    assertThat(corruptedFile, notNullValue());
}
Also used : Path(java.nio.file.Path) ClusterState(org.elasticsearch.cluster.ClusterState) ClusterHealthResponse(org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse) ByteSizeValue(org.elasticsearch.common.unit.ByteSizeValue) SearchResponse(org.elasticsearch.action.search.SearchResponse) IndexRequestBuilder(org.elasticsearch.action.index.IndexRequestBuilder) ClusterHealthStatus(org.elasticsearch.cluster.health.ClusterHealthStatus) GroupShardsIterator(org.elasticsearch.cluster.routing.GroupShardsIterator) ShardIterator(org.elasticsearch.cluster.routing.ShardIterator) ShardRouting(org.elasticsearch.cluster.routing.ShardRouting) Settings(org.elasticsearch.common.settings.Settings) IndexSettings(org.elasticsearch.index.IndexSettings)

Example 2 with ClusterHealthStatus

use of org.elasticsearch.cluster.health.ClusterHealthStatus in project elasticsearch by elastic.

the class TransportClusterStatsAction method nodeOperation.

@Override
protected ClusterStatsNodeResponse nodeOperation(ClusterStatsNodeRequest nodeRequest) {
    NodeInfo nodeInfo = nodeService.info(true, true, false, true, false, true, false, true, false, false);
    NodeStats nodeStats = nodeService.stats(CommonStatsFlags.NONE, true, true, true, false, true, false, false, false, false, false, false);
    List<ShardStats> shardsStats = new ArrayList<>();
    for (IndexService indexService : indicesService) {
        for (IndexShard indexShard : indexService) {
            if (indexShard.routingEntry() != null && indexShard.routingEntry().active()) {
                // only report on fully started shards
                shardsStats.add(new ShardStats(indexShard.routingEntry(), indexShard.shardPath(), new CommonStats(indicesService.getIndicesQueryCache(), indexShard, SHARD_STATS_FLAGS), indexShard.commitStats(), indexShard.seqNoStats()));
            }
        }
    }
    ClusterHealthStatus clusterStatus = null;
    if (clusterService.state().nodes().isLocalNodeElectedMaster()) {
        clusterStatus = new ClusterStateHealth(clusterService.state()).getStatus();
    }
    return new ClusterStatsNodeResponse(nodeInfo.getNode(), clusterStatus, nodeInfo, nodeStats, shardsStats.toArray(new ShardStats[shardsStats.size()]));
}
Also used : ShardStats(org.elasticsearch.action.admin.indices.stats.ShardStats) ClusterHealthStatus(org.elasticsearch.cluster.health.ClusterHealthStatus) NodeStats(org.elasticsearch.action.admin.cluster.node.stats.NodeStats) ClusterStateHealth(org.elasticsearch.cluster.health.ClusterStateHealth) CommonStats(org.elasticsearch.action.admin.indices.stats.CommonStats) IndexService(org.elasticsearch.index.IndexService) NodeInfo(org.elasticsearch.action.admin.cluster.node.info.NodeInfo) IndexShard(org.elasticsearch.index.shard.IndexShard) ArrayList(java.util.ArrayList)

Example 3 with ClusterHealthStatus

use of org.elasticsearch.cluster.health.ClusterHealthStatus in project elasticsearch by elastic.

the class RestIndicesAction method buildTable.

// package private for testing
Table buildTable(RestRequest request, Index[] indices, ClusterHealthResponse response, IndicesStatsResponse stats, MetaData indexMetaDatas) {
    final String healthParam = request.param("health");
    final ClusterHealthStatus status;
    if (healthParam != null) {
        status = ClusterHealthStatus.fromString(healthParam);
    } else {
        status = null;
    }
    Table table = getTableWithHeader(request);
    for (final Index index : indices) {
        final String indexName = index.getName();
        ClusterIndexHealth indexHealth = response.getIndices().get(indexName);
        IndexStats indexStats = stats.getIndices().get(indexName);
        IndexMetaData indexMetaData = indexMetaDatas.getIndices().get(indexName);
        IndexMetaData.State state = indexMetaData.getState();
        if (status != null) {
            if (state == IndexMetaData.State.CLOSE || (indexHealth == null && !ClusterHealthStatus.RED.equals(status)) || !indexHealth.getStatus().equals(status)) {
                continue;
            }
        }
        table.startRow();
        table.addCell(state == IndexMetaData.State.OPEN ? (indexHealth == null ? "red*" : indexHealth.getStatus().toString().toLowerCase(Locale.ROOT)) : null);
        table.addCell(state.toString().toLowerCase(Locale.ROOT));
        table.addCell(indexName);
        table.addCell(index.getUUID());
        table.addCell(indexHealth == null ? null : indexHealth.getNumberOfShards());
        table.addCell(indexHealth == null ? null : indexHealth.getNumberOfReplicas());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getDocs().getCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getDocs().getDeleted());
        table.addCell(indexMetaData.getCreationDate());
        table.addCell(new DateTime(indexMetaData.getCreationDate(), DateTimeZone.UTC));
        table.addCell(indexStats == null ? null : indexStats.getTotal().getStore().size());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getStore().size());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getCompletion().getSize());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getCompletion().getSize());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getFieldData().getMemorySize());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getFieldData().getMemorySize());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getFieldData().getEvictions());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getFieldData().getEvictions());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getQueryCache().getMemorySize());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getQueryCache().getMemorySize());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getQueryCache().getEvictions());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getQueryCache().getEvictions());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getRequestCache().getMemorySize());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getRequestCache().getMemorySize());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getRequestCache().getEvictions());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getRequestCache().getEvictions());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getRequestCache().getHitCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getRequestCache().getHitCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getRequestCache().getMissCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getRequestCache().getMissCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getFlush().getTotal());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getFlush().getTotal());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getFlush().getTotalTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getFlush().getTotalTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getGet().current());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getGet().current());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getGet().getTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getGet().getTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getGet().getCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getGet().getCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getGet().getExistsTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getGet().getExistsTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getGet().getExistsCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getGet().getExistsCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getGet().getMissingTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getGet().getMissingTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getGet().getMissingCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getGet().getMissingCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getIndexing().getTotal().getDeleteCurrent());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getIndexing().getTotal().getDeleteCurrent());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getIndexing().getTotal().getDeleteTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getIndexing().getTotal().getDeleteTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getIndexing().getTotal().getDeleteCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getIndexing().getTotal().getDeleteCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getIndexing().getTotal().getIndexCurrent());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getIndexing().getTotal().getIndexCurrent());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getIndexing().getTotal().getIndexTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getIndexing().getTotal().getIndexTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getIndexing().getTotal().getIndexCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getIndexing().getTotal().getIndexCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getIndexing().getTotal().getIndexFailedCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getIndexing().getTotal().getIndexFailedCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getMerge().getCurrent());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getMerge().getCurrent());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getMerge().getCurrentNumDocs());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getMerge().getCurrentNumDocs());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getMerge().getCurrentSize());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getMerge().getCurrentSize());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getMerge().getTotal());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getMerge().getTotal());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getMerge().getTotalNumDocs());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getMerge().getTotalNumDocs());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getMerge().getTotalSize());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getMerge().getTotalSize());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getMerge().getTotalTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getMerge().getTotalTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getRefresh().getTotal());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getRefresh().getTotal());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getRefresh().getTotalTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getRefresh().getTotalTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getRefresh().getListeners());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getRefresh().getListeners());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getTotal().getFetchCurrent());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getTotal().getFetchCurrent());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getTotal().getFetchTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getTotal().getFetchTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getTotal().getFetchCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getTotal().getFetchCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getOpenContexts());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getOpenContexts());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getTotal().getQueryCurrent());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getTotal().getQueryCurrent());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getTotal().getQueryTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getTotal().getQueryTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getTotal().getQueryCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getTotal().getQueryCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getTotal().getScrollCurrent());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getTotal().getScrollCurrent());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getTotal().getScrollTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getTotal().getScrollTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getTotal().getScrollCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getTotal().getScrollCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSegments().getCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSegments().getCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSegments().getMemory());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSegments().getMemory());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSegments().getIndexWriterMemory());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSegments().getIndexWriterMemory());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSegments().getVersionMapMemory());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSegments().getVersionMapMemory());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSegments().getBitsetMemory());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSegments().getBitsetMemory());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getWarmer().current());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getWarmer().current());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getWarmer().total());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getWarmer().total());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getWarmer().totalTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getWarmer().totalTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getTotal().getSuggestCurrent());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getTotal().getSuggestCurrent());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getTotal().getSuggestTime());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getTotal().getSuggestTime());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getSearch().getTotal().getSuggestCount());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getSearch().getTotal().getSuggestCount());
        table.addCell(indexStats == null ? null : indexStats.getTotal().getTotalMemory());
        table.addCell(indexStats == null ? null : indexStats.getPrimaries().getTotalMemory());
        table.endRow();
    }
    return table;
}
Also used : ClusterHealthStatus(org.elasticsearch.cluster.health.ClusterHealthStatus) Table(org.elasticsearch.common.Table) ClusterIndexHealth(org.elasticsearch.cluster.health.ClusterIndexHealth) Index(org.elasticsearch.index.Index) IndexStats(org.elasticsearch.action.admin.indices.stats.IndexStats) DateTime(org.joda.time.DateTime) IndexMetaData(org.elasticsearch.cluster.metadata.IndexMetaData)

Example 4 with ClusterHealthStatus

use of org.elasticsearch.cluster.health.ClusterHealthStatus in project elasticsearch by elastic.

the class IndicesShardStoresRequest method writeTo.

@Override
public void writeTo(StreamOutput out) throws IOException {
    super.writeTo(out);
    out.writeStringArrayNullable(indices);
    out.writeVInt(statuses.size());
    for (ClusterHealthStatus status : statuses) {
        out.writeByte(status.value());
    }
    indicesOptions.writeIndicesOptions(out);
}
Also used : ClusterHealthStatus(org.elasticsearch.cluster.health.ClusterHealthStatus)

Example 5 with ClusterHealthStatus

use of org.elasticsearch.cluster.health.ClusterHealthStatus in project graylog2-server by Graylog2.

the class MongoIndexSet method cycle.

@Override
public void cycle() {
    if (!getConfig().isWritable()) {
        LOG.debug("Not cycling non-writable index set <{}> ({})", getConfig().id(), getConfig().title());
        return;
    }
    int oldTargetNumber;
    try {
        oldTargetNumber = getNewestIndexNumber();
    } catch (NoTargetIndexException ex) {
        oldTargetNumber = -1;
    }
    final int newTargetNumber = oldTargetNumber + 1;
    final String newTarget = buildIndexName(newTargetNumber);
    final String oldTarget = buildIndexName(oldTargetNumber);
    if (oldTargetNumber == -1) {
        LOG.info("Cycling from <none> to <{}>.", newTarget);
    } else {
        LOG.info("Cycling from <{}> to <{}>.", oldTarget, newTarget);
    }
    // Create new index.
    LOG.info("Creating target index <{}>.", newTarget);
    if (!indices.create(newTarget, this)) {
        throw new RuntimeException("Could not create new target index <" + newTarget + ">.");
    }
    LOG.info("Waiting for allocation of index <{}>.", newTarget);
    ClusterHealthStatus healthStatus = indices.waitForRecovery(newTarget);
    LOG.debug("Health status of index <{}>: {}", newTarget, healthStatus);
    addDeflectorIndexRange(newTarget);
    LOG.info("Index <{}> has been successfully allocated.", newTarget);
    // Point deflector to new index.
    final String indexAlias = getWriteIndexAlias();
    LOG.info("Pointing index alias <{}> to new index <{}>.", indexAlias, newTarget);
    final Activity activity = new Activity(IndexSet.class);
    if (oldTargetNumber == -1) {
        // Only pointing, not cycling.
        pointTo(newTarget);
        activity.setMessage("Cycled index alias <" + indexAlias + "> from <none> to <" + newTarget + ">.");
    } else {
        // Re-pointing from existing old index to the new one.
        LOG.debug("Switching over index alias <{}>.", indexAlias);
        pointTo(newTarget, oldTarget);
        setIndexReadOnlyAndCalculateRange(oldTarget);
        activity.setMessage("Cycled index alias <" + indexAlias + "> from <" + oldTarget + "> to <" + newTarget + ">.");
    }
    LOG.info("Successfully pointed index alias <{}> to index <{}>.", indexAlias, newTarget);
    activityWriter.write(activity);
    auditEventSender.success(AuditActor.system(nodeId), ES_WRITE_INDEX_UPDATE, ImmutableMap.of("indexName", newTarget));
}
Also used : ClusterHealthStatus(org.elasticsearch.cluster.health.ClusterHealthStatus) Activity(org.graylog2.shared.system.activities.Activity)

Aggregations

ClusterHealthStatus (org.elasticsearch.cluster.health.ClusterHealthStatus)7 SearchResponse (org.elasticsearch.action.search.SearchResponse)2 Path (java.nio.file.Path)1 ArrayList (java.util.ArrayList)1 ClusterHealthResponse (org.elasticsearch.action.admin.cluster.health.ClusterHealthResponse)1 NodeInfo (org.elasticsearch.action.admin.cluster.node.info.NodeInfo)1 NodeStats (org.elasticsearch.action.admin.cluster.node.stats.NodeStats)1 RefreshResponse (org.elasticsearch.action.admin.indices.refresh.RefreshResponse)1 CommonStats (org.elasticsearch.action.admin.indices.stats.CommonStats)1 IndexStats (org.elasticsearch.action.admin.indices.stats.IndexStats)1 ShardStats (org.elasticsearch.action.admin.indices.stats.ShardStats)1 IndexRequestBuilder (org.elasticsearch.action.index.IndexRequestBuilder)1 Client (org.elasticsearch.client.Client)1 ClusterState (org.elasticsearch.cluster.ClusterState)1 ClusterIndexHealth (org.elasticsearch.cluster.health.ClusterIndexHealth)1 ClusterStateHealth (org.elasticsearch.cluster.health.ClusterStateHealth)1 IndexMetaData (org.elasticsearch.cluster.metadata.IndexMetaData)1 GroupShardsIterator (org.elasticsearch.cluster.routing.GroupShardsIterator)1 ShardIterator (org.elasticsearch.cluster.routing.ShardIterator)1 ShardRouting (org.elasticsearch.cluster.routing.ShardRouting)1