org.elasticsearch.discovery.zen.ZenDiscovery.lifecycleState()方法的使用及代码示例

x33g5p2x  于2022-02-05 转载在 其他  
字(10.5k)|赞(0)|评价(0)|浏览(135)

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

ZenDiscovery.lifecycleState介绍

暂无

代码示例

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

private void handleNodeFailure(final DiscoveryNode node, final String reason) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  if (!localNodeMaster()) {
    // nothing to do here...
    return;
  }
  removeNode(node, "zen-disco-node-failed", reason);
}

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

private void handleMinimumMasterNodesChanged(final int minimumMasterNodes) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  final int prevMinimumMasterNode = ZenDiscovery.this.electMaster.minimumMasterNodes();
  ZenDiscovery.this.electMaster.minimumMasterNodes(minimumMasterNodes);
  if (!localNodeMaster()) {
    // We only set the new value. If the master doesn't see enough nodes it will revoke it's mastership.
    return;
  }
  synchronized (stateMutex) {
    // check if we have enough master nodes, if not, we need to move into joining the cluster again
    if (!electMaster.hasEnoughMasterNodes(committedState.get().nodes())) {
      rejoin("not enough master nodes on change of minimum_master_nodes from [" + prevMinimumMasterNode + "] to [" +
        minimumMasterNodes + "]");
    }
  }
}

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

private void handleMasterGone(final DiscoveryNode masterNode, final Throwable cause, final String reason) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a master failure
    return;
  }
  if (localNodeMaster()) {
    // we might get this on both a master telling us shutting down, and then the disconnect failure
    return;
  }
  logger.info(() -> new ParameterizedMessage("master_left [{}], reason [{}]", masterNode, reason), cause);
  synchronized (stateMutex) {
    if (localNodeMaster() == false && masterNode.equals(committedState.get().nodes().getMasterNode())) {
      // flush any pending cluster states from old master, so it will not be set as master again
      pendingStatesQueue.failAllStatesAndClear(new ElasticsearchException("master left [{}]", reason));
      rejoin("master left (reason = " + reason + ")");
    }
  }
}

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

private void handleLeaveRequest(final DiscoveryNode node) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  if (localNodeMaster()) {
    removeNode(node, "zen-disco-node-left", "left");
  } else if (node.equals(clusterState().nodes().getMasterNode())) {
    handleMasterGone(node, null, "shut_down");
  }
}

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

private void handleNodeFailure(final DiscoveryNode node, final String reason) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  if (!localNodeMaster()) {
    // nothing to do here...
    return;
  }
  removeNode(node, "zen-disco-node-failed", reason);
}

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

private void handleNodeFailure(final DiscoveryNode node, final String reason) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  if (!localNodeMaster()) {
    // nothing to do here...
    return;
  }
  removeNode(node, "zen-disco-node-failed", reason);
}

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

private void handleNodeFailure(final DiscoveryNode node, String reason) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  if (!localNodeMaster()) {
    // nothing to do here...
    return;
  }
  removeNode(node, "zen-disco-node-failed", reason);
}

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

private void handleNodeFailure(final DiscoveryNode node, final String reason) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  if (!localNodeMaster()) {
    // nothing to do here...
    return;
  }
  removeNode(node, "zen-disco-node-failed", reason);
}

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

private void handleMasterGone(final DiscoveryNode masterNode, final Throwable cause, final String reason) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a master failure
    return;
  }
  if (localNodeMaster()) {
    // we might get this on both a master telling us shutting down, and then the disconnect failure
    return;
  }
  logger.info((Supplier<?>) () -> new ParameterizedMessage("master_left [{}], reason [{}]", masterNode, reason), cause);
  clusterService.submitStateUpdateTask("master_failed (" + masterNode + ")", new LocalClusterUpdateTask(Priority.IMMEDIATE) {
    @Override
    public ClusterTasksResult<LocalClusterUpdateTask> execute(ClusterState currentState) {
      if (!masterNode.equals(currentState.nodes().getMasterNode())) {
        // master got switched on us, no need to send anything
        return unchanged();
      }
      // flush any pending cluster states from old master, so it will not be set as master again
      publishClusterState.pendingStatesQueue().failAllStatesAndClear(new ElasticsearchException("master left [{}]", reason));
      return rejoin(currentState, "master left (reason = " + reason + ")");
    }
    @Override
    public void onFailure(String source, Exception e) {
      logger.error((Supplier<?>) () -> new ParameterizedMessage("unexpected failure during [{}]", source), e);
    }
  });
}

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

private void handleMinimumMasterNodesChanged(final int minimumMasterNodes) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  final int prevMinimumMasterNode = ZenDiscovery.this.electMaster.minimumMasterNodes();
  ZenDiscovery.this.electMaster.minimumMasterNodes(minimumMasterNodes);
  if (!localNodeMaster()) {
    // We only set the new value. If the master doesn't see enough nodes it will revoke it's mastership.
    return;
  }
  synchronized (stateMutex) {
    // check if we have enough master nodes, if not, we need to move into joining the cluster again
    if (!electMaster.hasEnoughMasterNodes(committedState.get().nodes())) {
      rejoin("not enough master nodes on change of minimum_master_nodes from [" + prevMinimumMasterNode + "] to [" + minimumMasterNodes + "]");
    }
  }
}

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

private void handleMinimumMasterNodesChanged(final int minimumMasterNodes) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  final int prevMinimumMasterNode = ZenDiscovery.this.electMaster.minimumMasterNodes();
  ZenDiscovery.this.electMaster.minimumMasterNodes(minimumMasterNodes);
  if (!localNodeMaster()) {
    // We only set the new value. If the master doesn't see enough nodes it will revoke it's mastership.
    return;
  }
  synchronized (stateMutex) {
    // check if we have enough master nodes, if not, we need to move into joining the cluster again
    if (!electMaster.hasEnoughMasterNodes(committedState.get().nodes())) {
      rejoin("not enough master nodes on change of minimum_master_nodes from [" + prevMinimumMasterNode + "] to [" + minimumMasterNodes + "]");
    }
  }
}

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

private void handleMasterGone(final DiscoveryNode masterNode, final String reason) {
  if (lifecycleState() != Lifecycle.State.STARTED) {

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

private void handleMinimumMasterNodesChanged(final int minimumMasterNodes) {
  if (lifecycleState() != Lifecycle.State.STARTED) {

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

private void handleLeaveRequest(final DiscoveryNode node) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  if (localNodeMaster()) {
    removeNode(node, "zen-disco-node-left", "left");
  } else if (node.equals(nodes().masterNode())) {
    handleMasterGone(node, "shut_down");
  }
}

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

private void handleMasterGone(final DiscoveryNode masterNode, final Throwable cause, final String reason) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a master failure
    return;
  }
  if (localNodeMaster()) {
    // we might get this on both a master telling us shutting down, and then the disconnect failure
    return;
  }
  logger.info(() -> new ParameterizedMessage("master_left [{}], reason [{}]", masterNode, reason), cause);
  synchronized (stateMutex) {
    if (localNodeMaster() == false && masterNode.equals(committedState.get().nodes().getMasterNode())) {
      // flush any pending cluster states from old master, so it will not be set as master again
      pendingStatesQueue.failAllStatesAndClear(new ElasticsearchException("master left [{}]", reason));
      rejoin("master left (reason = " + reason + ")");
    }
  }
}

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

private void handleMasterGone(final DiscoveryNode masterNode, final Throwable cause, final String reason) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a master failure
    return;
  }
  if (localNodeMaster()) {
    // we might get this on both a master telling us shutting down, and then the disconnect failure
    return;
  }
  logger.info(() -> new ParameterizedMessage("master_left [{}], reason [{}]", masterNode, reason), cause);
  synchronized (stateMutex) {
    if (localNodeMaster() == false && masterNode.equals(committedState.get().nodes().getMasterNode())) {
      // flush any pending cluster states from old master, so it will not be set as master again
      pendingStatesQueue.failAllStatesAndClear(new ElasticsearchException("master left [{}]", reason));
      rejoin("master left (reason = " + reason + ")");
    }
  }
}

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

private void handleMinimumMasterNodesChanged(final int minimumMasterNodes) {
  if (lifecycleState() != Lifecycle.State.STARTED) {

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

private void handleLeaveRequest(final DiscoveryNode node) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  if (localNodeMaster()) {
    removeNode(node, "zen-disco-node-left", "left");
  } else if (node.equals(clusterState().nodes().getMasterNode())) {
    handleMasterGone(node, null, "shut_down");
  }
}

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

private void handleLeaveRequest(final DiscoveryNode node) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  if (localNodeMaster()) {
    removeNode(node, "zen-disco-node-left", "left");
  } else if (node.equals(clusterState().nodes().getMasterNode())) {
    handleMasterGone(node, null, "shut_down");
  }
}

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

private void handleLeaveRequest(final DiscoveryNode node) {
  if (lifecycleState() != Lifecycle.State.STARTED) {
    // not started, ignore a node failure
    return;
  }
  if (localNodeMaster()) {
    removeNode(node, "zen-disco-node-left", "left");
  } else if (node.equals(clusterState().nodes().getMasterNode())) {
    handleMasterGone(node, null, "shut_down");
  }
}

相关文章