org.elasticsearch.cluster.ClusterState.getClusterName()方法的使用及代码示例

x33g5p2x  于2022-01-18 转载在 其他  
字(14.2k)|赞(0)|评价(0)|浏览(192)

本文整理了Java中org.elasticsearch.cluster.ClusterState.getClusterName()方法的一些代码示例,展示了ClusterState.getClusterName()的具体用法。这些代码示例主要来源于Github/Stackoverflow/Maven等平台,是从一些精选项目中提取出来的代码,具有较强的参考意义,能在一定程度帮忙到你。ClusterState.getClusterName()方法的具体详情如下:
包路径:org.elasticsearch.cluster.ClusterState
类名称:ClusterState
方法名:getClusterName

ClusterState.getClusterName介绍

暂无

代码示例

代码示例来源:origin: org.elasticsearch/elasticsearch

public PingResponse(DiscoveryNode node, DiscoveryNode master, ClusterState state) {
  this(node, master, state.getClusterName(),
    state.blocks().hasGlobalBlock(STATE_NOT_RECOVERED_BLOCK) ?
      ElectMasterService.MasterCandidate.UNRECOVERED_CLUSTER_VERSION : state.version());
}

代码示例来源:origin: org.elasticsearch/elasticsearch

@Override
  public void onTimeout(TimeValue timeout) {
    try {
      listener.onResponse(new ClusterStateResponse(clusterState.getClusterName(), null, 0L, true));
    } catch (Exception e) {
      listener.onFailure(e);
    }
  }
}, metadataVersionPredicate);

代码示例来源:origin: org.elasticsearch/elasticsearch

/**
 * does simple sanity check of the incoming cluster state. Throws an exception on rejections.
 */
static void validateIncomingState(Logger logger, ClusterState incomingState, ClusterState lastState) {
  final ClusterName incomingClusterName = incomingState.getClusterName();
  if (!incomingClusterName.equals(lastState.getClusterName())) {
    logger.warn("received cluster state from [{}] which is also master but with a different cluster name [{}]",
      incomingState.nodes().getMasterNode(), incomingClusterName);
    throw new IllegalStateException("received state from a node that is not part of the cluster");
  }
  if (lastState.nodes().getLocalNode().equals(incomingState.nodes().getLocalNode()) == false) {
    logger.warn("received a cluster state from [{}] and not part of the cluster, should not happen",
      incomingState.nodes().getMasterNode());
    throw new IllegalStateException("received state with a local node that does not match the current local node");
  }
  if (shouldIgnoreOrRejectNewClusterState(logger, lastState, incomingState)) {
    String message = String.format(
      Locale.ROOT,
      "rejecting cluster state version [%d] uuid [%s] received from [%s]",
      incomingState.version(),
      incomingState.stateUUID(),
      incomingState.nodes().getMasterNodeId()
    );
    logger.warn(message);
    throw new IllegalStateException(message);
  }
}

代码示例来源:origin: org.elasticsearch/elasticsearch

private ClusterHealthResponse clusterHealth(ClusterHealthRequest request, ClusterState clusterState, int numberOfPendingTasks,
                        int numberOfInFlightFetch, TimeValue pendingTaskTimeInQueue) {
    if (logger.isTraceEnabled()) {
      logger.trace("Calculating health based on state version [{}]", clusterState.version());
    }

    String[] concreteIndices;
    try {
      concreteIndices = indexNameExpressionResolver.concreteIndexNames(clusterState, request);
    } catch (IndexNotFoundException e) {
      // one of the specified indices is not there - treat it as RED.
      ClusterHealthResponse response = new ClusterHealthResponse(clusterState.getClusterName().value(), Strings.EMPTY_ARRAY,
        clusterState, numberOfPendingTasks, numberOfInFlightFetch, UnassignedInfo.getNumberOfDelayedUnassigned(clusterState),
        pendingTaskTimeInQueue);
      response.setStatus(ClusterHealthStatus.RED);
      return response;
    }

    return new ClusterHealthResponse(clusterState.getClusterName().value(), concreteIndices, clusterState, numberOfPendingTasks,
        numberOfInFlightFetch, UnassignedInfo.getNumberOfDelayedUnassigned(clusterState), pendingTaskTimeInQueue);
  }
}

代码示例来源:origin: org.elasticsearch/elasticsearch

@Override
  protected void doExecute(MainRequest request, ActionListener<MainResponse> listener) {
    ClusterState clusterState = clusterService.state();
    final boolean available = clusterState.getBlocks().hasGlobalBlock(RestStatus.SERVICE_UNAVAILABLE) == false;
    listener.onResponse(
      new MainResponse(nodeName, Version.CURRENT, clusterState.getClusterName(),
          clusterState.metaData().clusterUUID(), Build.CURRENT, available));
  }
}

代码示例来源:origin: org.elasticsearch/elasticsearch

private void deleteShardIfExistElseWhere(ClusterState state, IndexShardRoutingTable indexShardRoutingTable) {
  List<Tuple<DiscoveryNode, ShardActiveRequest>> requests = new ArrayList<>(indexShardRoutingTable.size());
  String indexUUID = indexShardRoutingTable.shardId().getIndex().getUUID();
  ClusterName clusterName = state.getClusterName();
  for (ShardRouting shardRouting : indexShardRoutingTable) {
    assert shardRouting.started() : "expected started shard but was " + shardRouting;
    DiscoveryNode currentNode = state.nodes().get(shardRouting.currentNodeId());
    requests.add(new Tuple<>(currentNode,
      new ShardActiveRequest(clusterName, indexUUID, shardRouting.shardId(), deleteShardTimeout)));
  }
  ShardActiveResponseHandler responseHandler = new ShardActiveResponseHandler(indexShardRoutingTable.shardId(), state.getVersion(),
    requests.size());
  for (Tuple<DiscoveryNode, ShardActiveRequest> request : requests) {
    logger.trace("{} sending shard active check to {}", request.v2().shardId, request.v1());
    transportService.sendRequest(request.v1(), ACTION_SHARD_EXISTS, request.v2(), responseHandler);
  }
}

代码示例来源:origin: com.strapdata.elasticsearch.test/framework

private ClusterName getClusterName() {
  return contextProvider.clusterState().getClusterName();
}

代码示例来源:origin: org.elasticsearch/elasticsearch

final ActionListener<ClusterStateResponse> listener) throws IOException {
logger.trace("Serving cluster state request using version {}", currentState.version());
ClusterState.Builder builder = ClusterState.builder(currentState.getClusterName());
builder.version(currentState.version());
builder.stateUUID(currentState.stateUUID());
listener.onResponse(new ClusterStateResponse(currentState.getClusterName(), builder.build(),
  serializeFullClusterState(currentState, Version.CURRENT).length(), false));

代码示例来源:origin: com.strapdata.elasticsearch/elasticsearch

public PingResponse(DiscoveryNode node, DiscoveryNode master, ClusterState state) {
  this(node, master, state.getClusterName(),
    state.blocks().hasGlobalBlock(STATE_NOT_RECOVERED_BLOCK) ?
      ElectMasterService.MasterCandidate.UNRECOVERED_CLUSTER_VERSION : state.version());
}

代码示例来源:origin: org.apache.servicemix.bundles/org.apache.servicemix.bundles.elasticsearch

public PingResponse(DiscoveryNode node, DiscoveryNode master, ClusterState state) {
  this(node, master, state.getClusterName(),
    state.blocks().hasGlobalBlock(STATE_NOT_RECOVERED_BLOCK) ?
      ElectMasterService.MasterCandidate.UNRECOVERED_CLUSTER_VERSION : state.version());
}

代码示例来源:origin: apache/servicemix-bundles

public PingResponse(DiscoveryNode node, DiscoveryNode master, ClusterState state) {
  this(node, master, state.getClusterName(),
    state.blocks().hasGlobalBlock(STATE_NOT_RECOVERED_BLOCK) ?
      ElectMasterService.MasterCandidate.UNRECOVERED_CLUSTER_VERSION : state.version());
}

代码示例来源:origin: com.strapdata.elasticsearch/elasticsearch

private ClusterHealthResponse clusterHealth(ClusterHealthRequest request, ClusterState clusterState, int numberOfPendingTasks, int numberOfInFlightFetch,
                        TimeValue pendingTaskTimeInQueue) {
    if (logger.isTraceEnabled()) {
      logger.trace("Calculating health based on state version [{}]", clusterState.version());
    }

    String[] concreteIndices;
    try {
      concreteIndices = indexNameExpressionResolver.concreteIndexNames(clusterState, request);
    } catch (IndexNotFoundException e) {
      // one of the specified indices is not there - treat it as RED.
      ClusterHealthResponse response = new ClusterHealthResponse(clusterState.getClusterName().value(), Strings.EMPTY_ARRAY, clusterState,
          numberOfPendingTasks, numberOfInFlightFetch, UnassignedInfo.getNumberOfDelayedUnassigned(clusterState),
          pendingTaskTimeInQueue);
      response.setStatus(ClusterHealthStatus.RED);
      return response;
    }

    return new ClusterHealthResponse(clusterState.getClusterName().value(), concreteIndices, clusterState, numberOfPendingTasks,
        numberOfInFlightFetch, UnassignedInfo.getNumberOfDelayedUnassigned(clusterState), pendingTaskTimeInQueue);
  }
}

代码示例来源:origin: org.apache.servicemix.bundles/org.apache.servicemix.bundles.elasticsearch

private ClusterHealthResponse clusterHealth(ClusterHealthRequest request, ClusterState clusterState, int numberOfPendingTasks, int numberOfInFlightFetch,
                        TimeValue pendingTaskTimeInQueue) {
    if (logger.isTraceEnabled()) {
      logger.trace("Calculating health based on state version [{}]", clusterState.version());
    }

    String[] concreteIndices;
    try {
      concreteIndices = indexNameExpressionResolver.concreteIndexNames(clusterState, request);
    } catch (IndexNotFoundException e) {
      // one of the specified indices is not there - treat it as RED.
      ClusterHealthResponse response = new ClusterHealthResponse(clusterState.getClusterName().value(), Strings.EMPTY_ARRAY, clusterState,
          numberOfPendingTasks, numberOfInFlightFetch, UnassignedInfo.getNumberOfDelayedUnassigned(clusterState),
          pendingTaskTimeInQueue);
      response.setStatus(ClusterHealthStatus.RED);
      return response;
    }

    return new ClusterHealthResponse(clusterState.getClusterName().value(), concreteIndices, clusterState, numberOfPendingTasks,
        numberOfInFlightFetch, UnassignedInfo.getNumberOfDelayedUnassigned(clusterState), pendingTaskTimeInQueue);
  }
}

代码示例来源:origin: harbby/presto-connectors

private IndexShard getShard(ShardActiveRequest request) {
    ClusterName thisClusterName = clusterService.state().getClusterName();
    if (!thisClusterName.equals(request.clusterName)) {
      logger.trace("shard exists request meant for cluster[{}], but this is cluster[{}], ignoring request", request.clusterName, thisClusterName);
      return null;
    }
    ShardId shardId = request.shardId;
    IndexService indexService = indicesService.indexService(shardId.index().getName());
    if (indexService != null && indexService.indexUUID().equals(request.indexUUID)) {
      return indexService.shard(shardId.id());
    }
    return null;
  }
}

代码示例来源:origin: com.strapdata.elasticsearch/elasticsearch

private void deleteShardIfExistElseWhere(ClusterState state, IndexShardRoutingTable indexShardRoutingTable) {
  List<Tuple<DiscoveryNode, ShardActiveRequest>> requests = new ArrayList<>(indexShardRoutingTable.size());
  String indexUUID = indexShardRoutingTable.shardId().getIndex().getUUID();
  ClusterName clusterName = state.getClusterName();
  for (ShardRouting shardRouting : indexShardRoutingTable) {
    assert shardRouting.started() : "expected started shard but was " + shardRouting;
    DiscoveryNode currentNode = state.nodes().get(shardRouting.currentNodeId());
    requests.add(new Tuple<>(currentNode, new ShardActiveRequest(clusterName, indexUUID, shardRouting.shardId(), deleteShardTimeout)));
  }
  ShardActiveResponseHandler responseHandler = new ShardActiveResponseHandler(indexShardRoutingTable.shardId(), state.getVersion(),
    requests.size());
  for (Tuple<DiscoveryNode, ShardActiveRequest> request : requests) {
    logger.trace("{} sending shard active check to {}", request.v2().shardId, request.v1());
    transportService.sendRequest(request.v1(), ACTION_SHARD_EXISTS, request.v2(), responseHandler);
  }
}

代码示例来源:origin: apache/servicemix-bundles

private void deleteShardIfExistElseWhere(ClusterState state, IndexShardRoutingTable indexShardRoutingTable) {
  List<Tuple<DiscoveryNode, ShardActiveRequest>> requests = new ArrayList<>(indexShardRoutingTable.size());
  String indexUUID = indexShardRoutingTable.shardId().getIndex().getUUID();
  ClusterName clusterName = state.getClusterName();
  for (ShardRouting shardRouting : indexShardRoutingTable) {
    assert shardRouting.started() : "expected started shard but was " + shardRouting;
    DiscoveryNode currentNode = state.nodes().get(shardRouting.currentNodeId());
    requests.add(new Tuple<>(currentNode, new ShardActiveRequest(clusterName, indexUUID, shardRouting.shardId(), deleteShardTimeout)));
  }
  ShardActiveResponseHandler responseHandler = new ShardActiveResponseHandler(indexShardRoutingTable.shardId(), state.getVersion(),
    requests.size());
  for (Tuple<DiscoveryNode, ShardActiveRequest> request : requests) {
    logger.trace("{} sending shard active check to {}", request.v2().shardId, request.v1());
    transportService.sendRequest(request.v1(), ACTION_SHARD_EXISTS, request.v2(), responseHandler);
  }
}

代码示例来源:origin: org.apache.servicemix.bundles/org.apache.servicemix.bundles.elasticsearch

private void deleteShardIfExistElseWhere(ClusterState state, IndexShardRoutingTable indexShardRoutingTable) {
  List<Tuple<DiscoveryNode, ShardActiveRequest>> requests = new ArrayList<>(indexShardRoutingTable.size());
  String indexUUID = indexShardRoutingTable.shardId().getIndex().getUUID();
  ClusterName clusterName = state.getClusterName();
  for (ShardRouting shardRouting : indexShardRoutingTable) {
    assert shardRouting.started() : "expected started shard but was " + shardRouting;
    DiscoveryNode currentNode = state.nodes().get(shardRouting.currentNodeId());
    requests.add(new Tuple<>(currentNode, new ShardActiveRequest(clusterName, indexUUID, shardRouting.shardId(), deleteShardTimeout)));
  }
  ShardActiveResponseHandler responseHandler = new ShardActiveResponseHandler(indexShardRoutingTable.shardId(), state.getVersion(),
    requests.size());
  for (Tuple<DiscoveryNode, ShardActiveRequest> request : requests) {
    logger.trace("{} sending shard active check to {}", request.v2().shardId, request.v1());
    transportService.sendRequest(request.v1(), ACTION_SHARD_EXISTS, request.v2(), responseHandler);
  }
}

代码示例来源:origin: com.strapdata.elasticsearch/elasticsearch

@Override
  protected void doExecute(MainRequest request, ActionListener<MainResponse> listener) {
    ClusterState clusterState = clusterService.state();
    assert Node.NODE_NAME_SETTING.exists(settings);
    final boolean available = clusterState.getBlocks().hasGlobalBlock(RestStatus.SERVICE_UNAVAILABLE) == false;
    listener.onResponse(
      new MainResponse(Node.NODE_NAME_SETTING.get(settings), Version.CURRENT, clusterState.getClusterName(),
          clusterState.metaData().clusterUUID(), Build.CURRENT, available));
  }
}

代码示例来源:origin: apache/servicemix-bundles

@Override
  protected void doExecute(MainRequest request, ActionListener<MainResponse> listener) {
    ClusterState clusterState = clusterService.state();
    assert Node.NODE_NAME_SETTING.exists(settings);
    final boolean available = clusterState.getBlocks().hasGlobalBlock(RestStatus.SERVICE_UNAVAILABLE) == false;
    listener.onResponse(
      new MainResponse(Node.NODE_NAME_SETTING.get(settings), Version.CURRENT, clusterState.getClusterName(),
          clusterState.metaData().clusterUUID(), Build.CURRENT, available));
  }
}

代码示例来源:origin: org.apache.servicemix.bundles/org.apache.servicemix.bundles.elasticsearch

@Override
  protected void doExecute(MainRequest request, ActionListener<MainResponse> listener) {
    ClusterState clusterState = clusterService.state();
    assert Node.NODE_NAME_SETTING.exists(settings);
    final boolean available = clusterState.getBlocks().hasGlobalBlock(RestStatus.SERVICE_UNAVAILABLE) == false;
    listener.onResponse(
      new MainResponse(Node.NODE_NAME_SETTING.get(settings), Version.CURRENT, clusterState.getClusterName(),
          clusterState.metaData().clusterUUID(), Build.CURRENT, available));
  }
}

相关文章