[Cluster] Refactored ClusterStateUpdateTask protection against execution on a non master
Previous implementation used a marker interface and had no explicit failure call back for the case update task was run on a non master (i.e., the master stepped down after it was submitted). That lead to a couple of instance of checks. This approach moves ClusterStateUpdateTask from an interface to an abstract class, which allows adding a flag to indicate whether it should only run on master nodes (defaults to true). It also adds an explicit onNoLongerMaster call back to allow different error handling for that case. This also removed the need for the NoLongerMaster. Closes #7511
This commit is contained in:
parent
596a4a0735
commit
34f4ca763c
|
@ -137,16 +137,17 @@ public class TransportClusterUpdateSettingsAction extends TransportMasterNodeOpe
|
|||
return new ClusterUpdateSettingsResponse(updateSettingsAcked && acknowledged, transientUpdates.build(), persistentUpdates.build());
|
||||
}
|
||||
|
||||
@Override
|
||||
public void onNoLongerMaster(String source) {
|
||||
logger.debug("failed to preform reroute after cluster settings were updated - current node is no longer a master");
|
||||
listener.onResponse(new ClusterUpdateSettingsResponse(updateSettingsAcked, transientUpdates.build(), persistentUpdates.build()));
|
||||
}
|
||||
|
||||
@Override
|
||||
public void onFailure(String source, Throwable t) {
|
||||
//if the reroute fails we only log
|
||||
if (t instanceof ClusterService.NoLongerMasterException) {
|
||||
logger.debug("failed to preform reroute after cluster settings were updated - current node is no longer a master");
|
||||
listener.onResponse(new ClusterUpdateSettingsResponse(updateSettingsAcked, transientUpdates.build(), persistentUpdates.build()));
|
||||
} else {
|
||||
logger.debug("failed to perform [{}]", t, source);
|
||||
listener.onFailure(new ElasticsearchException("reroute after update settings failed", t));
|
||||
}
|
||||
logger.debug("failed to perform [{}]", t, source);
|
||||
listener.onFailure(new ElasticsearchException("reroute after update settings failed", t));
|
||||
}
|
||||
|
||||
@Override
|
||||
|
|
|
@ -66,11 +66,11 @@ public class BenchmarkService extends AbstractLifecycleComponent<BenchmarkServic
|
|||
/**
|
||||
* Constructs a service component for running benchmarks
|
||||
*
|
||||
* @param settings Settings
|
||||
* @param clusterService Cluster service
|
||||
* @param threadPool Thread pool
|
||||
* @param client Client
|
||||
* @param transportService Transport service
|
||||
* @param settings Settings
|
||||
* @param clusterService Cluster service
|
||||
* @param threadPool Thread pool
|
||||
* @param client Client
|
||||
* @param transportService Transport service
|
||||
*/
|
||||
@Inject
|
||||
public BenchmarkService(Settings settings, ClusterService clusterService, ThreadPool threadPool,
|
||||
|
@ -86,19 +86,22 @@ public class BenchmarkService extends AbstractLifecycleComponent<BenchmarkServic
|
|||
}
|
||||
|
||||
@Override
|
||||
protected void doStart() throws ElasticsearchException { }
|
||||
protected void doStart() throws ElasticsearchException {
|
||||
}
|
||||
|
||||
@Override
|
||||
protected void doStop() throws ElasticsearchException { }
|
||||
protected void doStop() throws ElasticsearchException {
|
||||
}
|
||||
|
||||
@Override
|
||||
protected void doClose() throws ElasticsearchException { }
|
||||
protected void doClose() throws ElasticsearchException {
|
||||
}
|
||||
|
||||
/**
|
||||
* Lists actively running benchmarks on the cluster
|
||||
*
|
||||
* @param request Status request
|
||||
* @param listener Response listener
|
||||
* @param request Status request
|
||||
* @param listener Response listener
|
||||
*/
|
||||
public void listBenchmarks(final BenchmarkStatusRequest request, final ActionListener<BenchmarkStatusResponse> listener) {
|
||||
|
||||
|
@ -171,8 +174,8 @@ public class BenchmarkService extends AbstractLifecycleComponent<BenchmarkServic
|
|||
/**
|
||||
* Executes benchmarks on the cluster
|
||||
*
|
||||
* @param request Benchmark request
|
||||
* @param listener Response listener
|
||||
* @param request Benchmark request
|
||||
* @param listener Response listener
|
||||
*/
|
||||
public void startBenchmark(final BenchmarkRequest request, final ActionListener<BenchmarkResponse> listener) {
|
||||
|
||||
|
@ -228,7 +231,7 @@ public class BenchmarkService extends AbstractLifecycleComponent<BenchmarkServic
|
|||
listener.onFailure(t);
|
||||
}
|
||||
}, (benchmarkResponse.state() != BenchmarkResponse.State.ABORTED) &&
|
||||
(benchmarkResponse.state() != BenchmarkResponse.State.FAILED)));
|
||||
(benchmarkResponse.state() != BenchmarkResponse.State.FAILED)));
|
||||
}
|
||||
|
||||
private final boolean isBenchmarkNode(DiscoveryNode node) {
|
||||
|
@ -403,6 +406,7 @@ public class BenchmarkService extends AbstractLifecycleComponent<BenchmarkServic
|
|||
}
|
||||
|
||||
public abstract T newInstance();
|
||||
|
||||
protected abstract void sendResponse();
|
||||
|
||||
@Override
|
||||
|
@ -593,7 +597,7 @@ public class BenchmarkService extends AbstractLifecycleComponent<BenchmarkServic
|
|||
|
||||
if (bmd != null) {
|
||||
for (BenchmarkMetaData.Entry entry : bmd.entries()) {
|
||||
if (request.benchmarkName().equals(entry.benchmarkId())){
|
||||
if (request.benchmarkName().equals(entry.benchmarkId())) {
|
||||
if (entry.state() != BenchmarkMetaData.State.SUCCESS && entry.state() != BenchmarkMetaData.State.FAILED) {
|
||||
throw new ElasticsearchException("A benchmark with ID [" + request.benchmarkName() + "] is already running in state [" + entry.state() + "]");
|
||||
}
|
||||
|
@ -648,7 +652,7 @@ public class BenchmarkService extends AbstractLifecycleComponent<BenchmarkServic
|
|||
@Override
|
||||
protected BenchmarkMetaData.Entry process(BenchmarkMetaData.Entry entry) {
|
||||
BenchmarkMetaData.State state = entry.state();
|
||||
assert state == BenchmarkMetaData.State.STARTED || state == BenchmarkMetaData.State.ABORTED : "Expected state: STARTED or ABORTED but was: " + entry.state();
|
||||
assert state == BenchmarkMetaData.State.STARTED || state == BenchmarkMetaData.State.ABORTED : "Expected state: STARTED or ABORTED but was: " + entry.state();
|
||||
if (success) {
|
||||
return new BenchmarkMetaData.Entry(entry, BenchmarkMetaData.State.SUCCESS);
|
||||
} else {
|
||||
|
@ -661,7 +665,7 @@ public class BenchmarkService extends AbstractLifecycleComponent<BenchmarkServic
|
|||
private final String[] patterns;
|
||||
|
||||
public AbortBenchmarkTask(String[] patterns, BenchmarkStateListener listener) {
|
||||
super("abort_benchmark", null , listener);
|
||||
super("abort_benchmark", null, listener);
|
||||
this.patterns = patterns;
|
||||
}
|
||||
|
||||
|
@ -675,7 +679,7 @@ public class BenchmarkService extends AbstractLifecycleComponent<BenchmarkServic
|
|||
}
|
||||
}
|
||||
|
||||
public abstract class UpdateBenchmarkStateTask implements ProcessedClusterStateUpdateTask {
|
||||
public abstract class UpdateBenchmarkStateTask extends ProcessedClusterStateUpdateTask {
|
||||
|
||||
private final String reason;
|
||||
protected final String benchmarkId;
|
||||
|
@ -702,7 +706,7 @@ public class BenchmarkService extends AbstractLifecycleComponent<BenchmarkServic
|
|||
ImmutableList.Builder<BenchmarkMetaData.Entry> builder = new ImmutableList.Builder<BenchmarkMetaData.Entry>();
|
||||
for (BenchmarkMetaData.Entry e : bmd.entries()) {
|
||||
if (benchmarkId == null || match(e)) {
|
||||
e = process(e) ;
|
||||
e = process(e);
|
||||
instances.add(e);
|
||||
}
|
||||
// Don't keep finished benchmarks around in cluster state
|
||||
|
@ -741,7 +745,7 @@ public class BenchmarkService extends AbstractLifecycleComponent<BenchmarkServic
|
|||
}
|
||||
}
|
||||
|
||||
public abstract class BenchmarkStateChangeAction<R extends MasterNodeOperationRequest> implements TimeoutClusterStateUpdateTask {
|
||||
public abstract class BenchmarkStateChangeAction<R extends MasterNodeOperationRequest> extends TimeoutClusterStateUpdateTask {
|
||||
protected final R request;
|
||||
|
||||
public BenchmarkStateChangeAction(R request) {
|
||||
|
|
|
@ -28,7 +28,7 @@ import org.elasticsearch.common.unit.TimeValue;
|
|||
* An extension interface to {@link ClusterStateUpdateTask} that allows to be notified when
|
||||
* all the nodes have acknowledged a cluster state update request
|
||||
*/
|
||||
public abstract class AckedClusterStateUpdateTask<Response> implements TimeoutClusterStateUpdateTask {
|
||||
public abstract class AckedClusterStateUpdateTask<Response> extends TimeoutClusterStateUpdateTask {
|
||||
|
||||
private final ActionListener<Response> listener;
|
||||
private final AckedRequest request;
|
||||
|
@ -40,6 +40,7 @@ public abstract class AckedClusterStateUpdateTask<Response> implements TimeoutCl
|
|||
|
||||
/**
|
||||
* Called to determine which nodes the acknowledgement is expected from
|
||||
*
|
||||
* @param discoveryNode a node
|
||||
* @return true if the node is expected to send ack back, false otherwise
|
||||
*/
|
||||
|
@ -50,6 +51,7 @@ public abstract class AckedClusterStateUpdateTask<Response> implements TimeoutCl
|
|||
/**
|
||||
* Called once all the nodes have acknowledged the cluster state update request. Must be
|
||||
* very lightweight execution, since it gets executed on the cluster service thread.
|
||||
*
|
||||
* @param t optional error that might have been thrown
|
||||
*/
|
||||
public void onAllNodesAcked(@Nullable Throwable t) {
|
||||
|
|
|
@ -111,15 +111,4 @@ public interface ClusterService extends LifecycleComponent<ClusterService> {
|
|||
*/
|
||||
List<PendingClusterTask> pendingTasks();
|
||||
|
||||
/**
|
||||
* an exception to indicate a {@link org.elasticsearch.cluster.ClusterStateUpdateTask} was not executed as
|
||||
* the current node is no longer master
|
||||
*/
|
||||
public static class NoLongerMasterException extends ElasticsearchIllegalStateException {
|
||||
|
||||
public NoLongerMasterException(String msg) {
|
||||
super(msg);
|
||||
}
|
||||
|
||||
}
|
||||
}
|
||||
|
|
|
@ -23,5 +23,10 @@ package org.elasticsearch.cluster;
|
|||
* This is a marker interface to indicate that the task should be executed
|
||||
* even if the current node is not a master.
|
||||
*/
|
||||
public interface ClusterStateNonMasterUpdateTask extends ClusterStateUpdateTask {
|
||||
public abstract class ClusterStateNonMasterUpdateTask extends ClusterStateUpdateTask {
|
||||
|
||||
@Override
|
||||
public boolean runOnlyOnMaster() {
|
||||
return false;
|
||||
}
|
||||
}
|
||||
|
|
|
@ -19,19 +19,37 @@
|
|||
|
||||
package org.elasticsearch.cluster;
|
||||
|
||||
import org.elasticsearch.common.Nullable;
|
||||
import org.elasticsearch.common.util.concurrent.EsRejectedExecutionException;
|
||||
|
||||
/**
|
||||
* A task that can update the cluster state.
|
||||
*/
|
||||
public interface ClusterStateUpdateTask {
|
||||
abstract public class ClusterStateUpdateTask {
|
||||
|
||||
/**
|
||||
* Update the cluster state based on the current state. Return the *same instance* if no state
|
||||
* should be changed.
|
||||
*/
|
||||
ClusterState execute(ClusterState currentState) throws Exception;
|
||||
abstract public ClusterState execute(ClusterState currentState) throws Exception;
|
||||
|
||||
/**
|
||||
* A callback called when execute fails.
|
||||
*/
|
||||
void onFailure(String source, Throwable t);
|
||||
abstract public void onFailure(String source, @Nullable Throwable t);
|
||||
|
||||
|
||||
/**
|
||||
* indicates whether this task should only run if current node is master
|
||||
*/
|
||||
public boolean runOnlyOnMaster() {
|
||||
return true;
|
||||
}
|
||||
|
||||
/**
|
||||
* called when the task was rejected because the local node is no longer master
|
||||
*/
|
||||
public void onNoLongerMaster(String source) {
|
||||
onFailure(source, new EsRejectedExecutionException("no longer master. source: [" + source + "]"));
|
||||
}
|
||||
}
|
||||
|
|
|
@ -19,8 +19,13 @@
|
|||
package org.elasticsearch.cluster;
|
||||
|
||||
/**
|
||||
* A combination interface between {@link org.elasticsearch.cluster.ProcessedClusterStateUpdateTask} and
|
||||
* A combination between {@link org.elasticsearch.cluster.ProcessedClusterStateUpdateTask} and
|
||||
* {@link org.elasticsearch.cluster.ClusterStateNonMasterUpdateTask} to allow easy creation of anonymous classes
|
||||
*/
|
||||
public interface ProcessedClusterStateNonMasterUpdateTask extends ProcessedClusterStateUpdateTask, ClusterStateNonMasterUpdateTask {
|
||||
abstract public class ProcessedClusterStateNonMasterUpdateTask extends ProcessedClusterStateUpdateTask {
|
||||
|
||||
@Override
|
||||
public boolean runOnlyOnMaster() {
|
||||
return false;
|
||||
}
|
||||
}
|
||||
|
|
|
@ -23,11 +23,11 @@ package org.elasticsearch.cluster;
|
|||
* An extension interface to {@link ClusterStateUpdateTask} that allows to be notified when
|
||||
* the cluster state update has been processed.
|
||||
*/
|
||||
public interface ProcessedClusterStateUpdateTask extends ClusterStateUpdateTask {
|
||||
public abstract class ProcessedClusterStateUpdateTask extends ClusterStateUpdateTask {
|
||||
|
||||
/**
|
||||
* Called when the result of the {@link #execute(ClusterState)} have been processed
|
||||
* properly by all listeners.
|
||||
*/
|
||||
void clusterStateProcessed(String source, ClusterState oldState, ClusterState newState);
|
||||
public abstract void clusterStateProcessed(String source, ClusterState oldState, ClusterState newState);
|
||||
}
|
||||
|
|
|
@ -25,11 +25,11 @@ import org.elasticsearch.common.unit.TimeValue;
|
|||
* An extension interface to {@link org.elasticsearch.cluster.ClusterStateUpdateTask} that allows to associate
|
||||
* a timeout.
|
||||
*/
|
||||
public interface TimeoutClusterStateUpdateTask extends ProcessedClusterStateUpdateTask {
|
||||
abstract public class TimeoutClusterStateUpdateTask extends ProcessedClusterStateUpdateTask {
|
||||
|
||||
/**
|
||||
* If the cluster state update task wasn't processed by the provided timeout, call
|
||||
* {@link #onFailure(String, Throwable)}
|
||||
*/
|
||||
TimeValue timeout();
|
||||
abstract public TimeValue timeout();
|
||||
}
|
||||
|
|
|
@ -149,12 +149,15 @@ public class RoutingService extends AbstractLifecycleComponent<RoutingService> i
|
|||
return ClusterState.builder(currentState).routingResult(routingResult).build();
|
||||
}
|
||||
|
||||
@Override
|
||||
public void onNoLongerMaster(String source) {
|
||||
// no biggie
|
||||
}
|
||||
|
||||
@Override
|
||||
public void onFailure(String source, Throwable t) {
|
||||
if (!(t instanceof ClusterService.NoLongerMasterException)) {
|
||||
ClusterState state = clusterService.state();
|
||||
logger.error("unexpected failure during [{}], current state:\n{}", t, source, state.prettyPrint());
|
||||
}
|
||||
}
|
||||
});
|
||||
routingTableDirty = false;
|
||||
|
|
|
@ -325,9 +325,9 @@ public class InternalClusterService extends AbstractLifecycleComponent<ClusterSe
|
|||
}
|
||||
logger.debug("processing [{}]: execute", source);
|
||||
ClusterState previousClusterState = clusterState;
|
||||
if (!previousClusterState.nodes().localNodeMaster() && !(updateTask instanceof ClusterStateNonMasterUpdateTask)) {
|
||||
if (!previousClusterState.nodes().localNodeMaster() && updateTask.runOnlyOnMaster()) {
|
||||
logger.debug("failing [{}]: local node is no longer master", source);
|
||||
updateTask.onFailure(source, new NoLongerMasterException("source: " + source));
|
||||
updateTask.onNoLongerMaster(source);
|
||||
return;
|
||||
}
|
||||
ClusterState newClusterState;
|
||||
|
|
|
@ -43,6 +43,7 @@ import org.elasticsearch.common.io.stream.StreamOutput;
|
|||
import org.elasticsearch.common.settings.Settings;
|
||||
import org.elasticsearch.common.unit.TimeValue;
|
||||
import org.elasticsearch.common.util.concurrent.ConcurrentCollections;
|
||||
import org.elasticsearch.common.util.concurrent.EsRejectedExecutionException;
|
||||
import org.elasticsearch.discovery.Discovery;
|
||||
import org.elasticsearch.discovery.DiscoveryService;
|
||||
import org.elasticsearch.discovery.DiscoverySettings;
|
||||
|
@ -476,13 +477,14 @@ public class ZenDiscovery extends AbstractLifecycleComponent<Discovery> implemen
|
|||
return ClusterState.builder(currentState).routingResult(routingResult).build();
|
||||
}
|
||||
|
||||
@Override
|
||||
public void onNoLongerMaster(String source) {
|
||||
// ignoring (already logged)
|
||||
}
|
||||
|
||||
@Override
|
||||
public void onFailure(String source, Throwable t) {
|
||||
if (t instanceof ClusterService.NoLongerMasterException) {
|
||||
logger.debug("not processing {} leave request as we are no longer master", node);
|
||||
} else {
|
||||
logger.error("unexpected failure during [{}]", t, source);
|
||||
}
|
||||
logger.error("unexpected failure during [{}]", t, source);
|
||||
}
|
||||
});
|
||||
} else {
|
||||
|
@ -515,13 +517,14 @@ public class ZenDiscovery extends AbstractLifecycleComponent<Discovery> implemen
|
|||
return ClusterState.builder(currentState).routingResult(routingResult).build();
|
||||
}
|
||||
|
||||
@Override
|
||||
public void onNoLongerMaster(String source) {
|
||||
// already logged
|
||||
}
|
||||
|
||||
@Override
|
||||
public void onFailure(String source, Throwable t) {
|
||||
if (t instanceof ClusterService.NoLongerMasterException) {
|
||||
logger.debug("not processing [{}] as we are no longer master", source);
|
||||
} else {
|
||||
logger.error("unexpected failure during [{}]", t, source);
|
||||
}
|
||||
logger.error("unexpected failure during [{}]", t, source);
|
||||
}
|
||||
|
||||
@Override
|
||||
|
@ -552,13 +555,15 @@ public class ZenDiscovery extends AbstractLifecycleComponent<Discovery> implemen
|
|||
return currentState;
|
||||
}
|
||||
|
||||
|
||||
@Override
|
||||
public void onNoLongerMaster(String source) {
|
||||
// ignoring (already logged)
|
||||
}
|
||||
|
||||
@Override
|
||||
public void onFailure(String source, Throwable t) {
|
||||
if (t instanceof ClusterService.NoLongerMasterException) {
|
||||
logger.debug("not processing [{}] as we are no longer master", source);
|
||||
} else {
|
||||
logger.error("unexpected failure during [{}]", t, source);
|
||||
}
|
||||
logger.error("unexpected failure during [{}]", t, source);
|
||||
}
|
||||
|
||||
@Override
|
||||
|
@ -870,17 +875,27 @@ public class ZenDiscovery extends AbstractLifecycleComponent<Discovery> implemen
|
|||
}
|
||||
|
||||
@Override
|
||||
public void onFailure(String source, Throwable t) {
|
||||
if (t instanceof ClusterService.NoLongerMasterException) {
|
||||
logger.debug("not processing [{}] as we are no longer master", source);
|
||||
} else {
|
||||
logger.error("unexpected failure during [{}]", t, source);
|
||||
}
|
||||
public void onNoLongerMaster(String source) {
|
||||
Exception e = new EsRejectedExecutionException("no longer master. source: [" + source + "]");
|
||||
innerOnFailure(e);
|
||||
}
|
||||
|
||||
void innerOnFailure(Throwable t) {
|
||||
for (Tuple<DiscoveryNode, MembershipAction.JoinCallback> drainedTask : drainedTasks) {
|
||||
drainedTask.v2().onFailure(t);
|
||||
try {
|
||||
drainedTask.v2().onFailure(t);
|
||||
} catch (Exception e) {
|
||||
logger.error("error during task failure", e);
|
||||
}
|
||||
}
|
||||
}
|
||||
|
||||
@Override
|
||||
public void onFailure(String source, Throwable t) {
|
||||
logger.error("unexpected failure during [{}]", t, source);
|
||||
innerOnFailure(t);
|
||||
}
|
||||
|
||||
@Override
|
||||
public void clusterStateProcessed(String source, ClusterState oldState, ClusterState newState) {
|
||||
for (Tuple<DiscoveryNode, MembershipAction.JoinCallback> drainedTask : drainedTasks) {
|
||||
|
@ -1157,13 +1172,14 @@ public class ZenDiscovery extends AbstractLifecycleComponent<Discovery> implemen
|
|||
return rejoin(currentState, "received a request to rejoin the cluster from [" + request.fromNodeId + "]");
|
||||
}
|
||||
|
||||
@Override
|
||||
public void onNoLongerMaster(String source) {
|
||||
// already logged
|
||||
}
|
||||
|
||||
@Override
|
||||
public void onFailure(String source, Throwable t) {
|
||||
if (t instanceof ClusterService.NoLongerMasterException) {
|
||||
logger.debug("not processing [{}] as we are no longer master", source);
|
||||
} else {
|
||||
logger.error("unexpected failure during [{}]", t, source);
|
||||
}
|
||||
logger.error("unexpected failure during [{}]", t, source);
|
||||
}
|
||||
});
|
||||
}
|
||||
|
|
|
@ -708,7 +708,7 @@ public class ClusterServiceTests extends ElasticsearchIntegrationTest {
|
|||
}
|
||||
}
|
||||
|
||||
private static class BlockingTask implements ClusterStateUpdateTask {
|
||||
private static class BlockingTask extends ClusterStateUpdateTask {
|
||||
private final CountDownLatch latch = new CountDownLatch(1);
|
||||
|
||||
@Override
|
||||
|
@ -727,7 +727,7 @@ public class ClusterServiceTests extends ElasticsearchIntegrationTest {
|
|||
|
||||
}
|
||||
|
||||
private static class PrioritiezedTask implements ClusterStateUpdateTask {
|
||||
private static class PrioritiezedTask extends ClusterStateUpdateTask {
|
||||
|
||||
private final Priority priority;
|
||||
private final CountDownLatch latch;
|
||||
|
|
Loading…
Reference in New Issue