2 * Copyright (c) 2015 Brocade Communications Systems, Inc. and others. All rights reserved.
4 * This program and the accompanying materials are made available under the
5 * terms of the Eclipse Public License v1.0 which accompanies this distribution,
6 * and is available at http://www.eclipse.org/legal/epl-v10.html
8 package org.opendaylight.controller.cluster.datastore.admin;
10 import akka.actor.ActorRef;
11 import akka.actor.Status.Success;
12 import akka.dispatch.OnComplete;
13 import akka.pattern.Patterns;
14 import akka.util.Timeout;
15 import com.google.common.base.Function;
16 import com.google.common.base.Strings;
17 import com.google.common.base.Throwables;
18 import com.google.common.util.concurrent.FutureCallback;
19 import com.google.common.util.concurrent.Futures;
20 import com.google.common.util.concurrent.ListenableFuture;
21 import com.google.common.util.concurrent.SettableFuture;
22 import java.io.FileOutputStream;
23 import java.util.AbstractMap.SimpleEntry;
24 import java.util.ArrayList;
25 import java.util.List;
26 import java.util.Map.Entry;
28 import java.util.concurrent.Future;
29 import java.util.concurrent.TimeUnit;
30 import org.apache.commons.lang3.SerializationUtils;
31 import org.opendaylight.controller.cluster.datastore.DistributedDataStoreInterface;
32 import org.opendaylight.controller.cluster.datastore.messages.AddShardReplica;
33 import org.opendaylight.controller.cluster.datastore.messages.DatastoreSnapshot;
34 import org.opendaylight.controller.cluster.datastore.messages.DatastoreSnapshotList;
35 import org.opendaylight.controller.cluster.datastore.messages.RemoveShardReplica;
36 import org.opendaylight.controller.cluster.datastore.utils.ActorContext;
37 import org.opendaylight.controller.cluster.raft.client.messages.GetSnapshot;
38 import org.opendaylight.controller.sal.binding.api.BindingAwareBroker.RpcRegistration;
39 import org.opendaylight.controller.sal.binding.api.RpcProviderRegistry;
40 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutput;
41 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddReplicasForAllShardsOutputBuilder;
42 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.AddShardReplicaInput;
43 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.BackupDatastoreInput;
44 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ClusterAdminService;
45 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ConvertMembersToNonvotingForAllShardsInput;
46 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.ConvertMembersToVotingForAllShardsInput;
47 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.DataStoreType;
48 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasInput;
49 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutput;
50 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveAllShardReplicasOutputBuilder;
51 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.RemoveShardReplicaInput;
52 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResult;
53 import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.md.sal.cluster.admin.rev151013.shard.result.output.ShardResultBuilder;
54 import org.opendaylight.yangtools.yang.common.RpcError.ErrorType;
55 import org.opendaylight.yangtools.yang.common.RpcResult;
56 import org.opendaylight.yangtools.yang.common.RpcResultBuilder;
57 import org.slf4j.Logger;
58 import org.slf4j.LoggerFactory;
61 * Implements the yang RPCs defined in the generated ClusterAdminService interface.
63 * @author Thomas Pantelis
65 public class ClusterAdminRpcService implements ClusterAdminService, AutoCloseable {
66 private static final Timeout SHARD_MGR_TIMEOUT = new Timeout(1, TimeUnit.MINUTES);
68 private static final Logger LOG = LoggerFactory.getLogger(ClusterAdminRpcService.class);
70 private final DistributedDataStoreInterface configDataStore;
71 private final DistributedDataStoreInterface operDataStore;
72 private RpcRegistration<ClusterAdminService> rpcRegistration;
74 public ClusterAdminRpcService(DistributedDataStoreInterface configDataStore,
75 DistributedDataStoreInterface operDataStore) {
76 this.configDataStore = configDataStore;
77 this.operDataStore = operDataStore;
80 public void start(RpcProviderRegistry rpcProviderRegistry) {
81 LOG.debug("ClusterAdminRpcService starting");
83 rpcRegistration = rpcProviderRegistry.addRpcImplementation(ClusterAdminService.class, this);
88 if(rpcRegistration != null) {
89 rpcRegistration.close();
94 public Future<RpcResult<Void>> addShardReplica(final AddShardReplicaInput input) {
95 final String shardName = input.getShardName();
96 if(Strings.isNullOrEmpty(shardName)) {
97 return newFailedRpcResultFuture("A valid shard name must be specified");
100 DataStoreType dataStoreType = input.getDataStoreType();
101 if(dataStoreType == null) {
102 return newFailedRpcResultFuture("A valid DataStoreType must be specified");
105 LOG.info("Adding replica for shard {}", shardName);
107 final SettableFuture<RpcResult<Void>> returnFuture = SettableFuture.create();
108 ListenableFuture<Success> future = sendMessageToShardManager(dataStoreType, new AddShardReplica(shardName));
109 Futures.addCallback(future, new FutureCallback<Success>() {
111 public void onSuccess(Success success) {
112 LOG.info("Successfully added replica for shard {}", shardName);
113 returnFuture.set(newSuccessfulResult());
117 public void onFailure(Throwable failure) {
118 onMessageFailure(String.format("Failed to add replica for shard %s", shardName),
119 returnFuture, failure);
127 public Future<RpcResult<Void>> removeShardReplica(RemoveShardReplicaInput input) {
128 final String shardName = input.getShardName();
129 if(Strings.isNullOrEmpty(shardName)) {
130 return newFailedRpcResultFuture("A valid shard name must be specified");
133 DataStoreType dataStoreType = input.getDataStoreType();
134 if(dataStoreType == null) {
135 return newFailedRpcResultFuture("A valid DataStoreType must be specified");
138 final String memberName = input.getMemberName();
139 if(Strings.isNullOrEmpty(memberName)) {
140 return newFailedRpcResultFuture("A valid member name must be specified");
143 LOG.info("Removing replica for shard {} memberName {}, datastoreType {}", shardName, memberName, dataStoreType);
145 final SettableFuture<RpcResult<Void>> returnFuture = SettableFuture.create();
146 ListenableFuture<Success> future = sendMessageToShardManager(dataStoreType,
147 new RemoveShardReplica(shardName, memberName));
148 Futures.addCallback(future, new FutureCallback<Success>() {
150 public void onSuccess(Success success) {
151 LOG.info("Successfully removed replica for shard {}", shardName);
152 returnFuture.set(newSuccessfulResult());
156 public void onFailure(Throwable failure) {
157 onMessageFailure(String.format("Failed to remove replica for shard %s", shardName),
158 returnFuture, failure);
166 public Future<RpcResult<AddReplicasForAllShardsOutput>> addReplicasForAllShards() {
167 LOG.info("Adding replicas for all shards");
169 final List<Entry<ListenableFuture<Success>, ShardResultBuilder>> shardResultData = new ArrayList<>();
170 Function<String, Object> messageSupplier = new Function<String, Object>() {
172 public Object apply(String shardName) {
173 return new AddShardReplica(shardName);
177 sendMessageToManagerForConfiguredShards(DataStoreType.Config, shardResultData, messageSupplier);
178 sendMessageToManagerForConfiguredShards(DataStoreType.Operational, shardResultData, messageSupplier);
180 return waitForShardResults(shardResultData, new Function<List<ShardResult>, AddReplicasForAllShardsOutput>() {
182 public AddReplicasForAllShardsOutput apply(List<ShardResult> shardResults) {
183 return new AddReplicasForAllShardsOutputBuilder().setShardResult(shardResults).build();
185 }, "Failed to add replica");
190 public Future<RpcResult<RemoveAllShardReplicasOutput>> removeAllShardReplicas(RemoveAllShardReplicasInput input) {
191 LOG.info("Removing replicas for all shards");
193 final String memberName = input.getMemberName();
194 if(Strings.isNullOrEmpty(memberName)) {
195 return newFailedRpcResultFuture("A valid member name must be specified");
198 final List<Entry<ListenableFuture<Success>, ShardResultBuilder>> shardResultData = new ArrayList<>();
199 Function<String, Object> messageSupplier = new Function<String, Object>() {
201 public Object apply(String shardName) {
202 return new RemoveShardReplica(shardName, memberName);
206 sendMessageToManagerForConfiguredShards(DataStoreType.Config, shardResultData, messageSupplier);
207 sendMessageToManagerForConfiguredShards(DataStoreType.Operational, shardResultData, messageSupplier);
209 return waitForShardResults(shardResultData, new Function<List<ShardResult>, RemoveAllShardReplicasOutput>() {
211 public RemoveAllShardReplicasOutput apply(List<ShardResult> shardResults) {
212 return new RemoveAllShardReplicasOutputBuilder().setShardResult(shardResults).build();
214 }, "Failed to add replica");
218 public Future<RpcResult<Void>> convertMembersToVotingForAllShards(ConvertMembersToVotingForAllShardsInput input) {
220 return RpcResultBuilder.<Void>failed().withError(ErrorType.APPLICATION, "operation-not-supported",
221 "Not implemented yet").buildFuture();
225 public Future<RpcResult<Void>> convertMembersToNonvotingForAllShards(
226 ConvertMembersToNonvotingForAllShardsInput input) {
228 return RpcResultBuilder.<Void>failed().withError(ErrorType.APPLICATION, "operation-not-supported",
229 "Not implemented yet").buildFuture();
233 public Future<RpcResult<Void>> backupDatastore(final BackupDatastoreInput input) {
234 LOG.debug("backupDatastore: {}", input);
236 if(Strings.isNullOrEmpty(input.getFilePath())) {
237 return newFailedRpcResultFuture("A valid file path must be specified");
240 final SettableFuture<RpcResult<Void>> returnFuture = SettableFuture.create();
241 ListenableFuture<List<DatastoreSnapshot>> future = sendMessageToShardManagers(GetSnapshot.INSTANCE);
242 Futures.addCallback(future, new FutureCallback<List<DatastoreSnapshot>>() {
244 public void onSuccess(List<DatastoreSnapshot> snapshots) {
245 saveSnapshotsToFile(new DatastoreSnapshotList(snapshots), input.getFilePath(), returnFuture);
249 public void onFailure(Throwable failure) {
250 onDatastoreBackupFailure(input.getFilePath(), returnFuture, failure);
257 private static <T> SettableFuture<RpcResult<T>> waitForShardResults(
258 final List<Entry<ListenableFuture<Success>, ShardResultBuilder>> shardResultData,
259 final Function<List<ShardResult>, T> resultDataSupplier,
260 final String failureLogMsgPrefix) {
261 final SettableFuture<RpcResult<T>> returnFuture = SettableFuture.create();
262 final List<ShardResult> shardResults = new ArrayList<>();
263 for(final Entry<ListenableFuture<Success>, ShardResultBuilder> entry: shardResultData) {
264 Futures.addCallback(entry.getKey(), new FutureCallback<Success>() {
266 public void onSuccess(Success result) {
267 synchronized(shardResults) {
268 ShardResultBuilder shardResult = entry.getValue();
269 LOG.debug("onSuccess for shard {}, type {}", shardResult.getShardName(),
270 shardResult.getDataStoreType());
271 shardResults.add(shardResult.setSucceeded(true).build());
277 public void onFailure(Throwable t) {
278 synchronized(shardResults) {
279 ShardResultBuilder shardResult = entry.getValue();
280 LOG.warn("{} for shard {}, type {}", failureLogMsgPrefix, shardResult.getShardName(),
281 shardResult.getDataStoreType(), t);
282 shardResults.add(shardResult.setSucceeded(false).setErrorMessage(
283 Throwables.getRootCause(t).getMessage()).build());
288 void checkIfComplete() {
289 LOG.debug("checkIfComplete: expected {}, actual {}", shardResultData.size(), shardResults.size());
290 if(shardResults.size() == shardResultData.size()) {
291 returnFuture.set(newSuccessfulResult(resultDataSupplier.apply(shardResults)));
299 private <T> void sendMessageToManagerForConfiguredShards(DataStoreType dataStoreType,
300 List<Entry<ListenableFuture<T>, ShardResultBuilder>> shardResultData,
301 Function<String, Object> messageSupplier) {
302 ActorContext actorContext = dataStoreType == DataStoreType.Config ?
303 configDataStore.getActorContext() : operDataStore.getActorContext();
304 Set<String> allShardNames = actorContext.getConfiguration().getAllShardNames();
306 LOG.debug("Sending message to all shards {} for data store {}", allShardNames, actorContext.getDataStoreName());
308 for(String shardName: allShardNames) {
309 ListenableFuture<T> future = this.<T>ask(actorContext.getShardManager(), messageSupplier.apply(shardName),
311 shardResultData.add(new SimpleEntry<ListenableFuture<T>, ShardResultBuilder>(future,
312 new ShardResultBuilder().setShardName(shardName).setDataStoreType(dataStoreType)));
316 @SuppressWarnings("unchecked")
317 private <T> ListenableFuture<List<T>> sendMessageToShardManagers(Object message) {
318 Timeout timeout = SHARD_MGR_TIMEOUT;
319 ListenableFuture<T> configFuture = ask(configDataStore.getActorContext().getShardManager(), message, timeout);
320 ListenableFuture<T> operFuture = ask(operDataStore.getActorContext().getShardManager(), message, timeout);
322 return Futures.allAsList(configFuture, operFuture);
325 private <T> ListenableFuture<T> sendMessageToShardManager(DataStoreType dataStoreType, Object message) {
326 ActorRef shardManager = dataStoreType == DataStoreType.Config ?
327 configDataStore.getActorContext().getShardManager() : operDataStore.getActorContext().getShardManager();
328 return ask(shardManager, message, SHARD_MGR_TIMEOUT);
331 private static void saveSnapshotsToFile(DatastoreSnapshotList snapshots, String fileName,
332 SettableFuture<RpcResult<Void>> returnFuture) {
333 try(FileOutputStream fos = new FileOutputStream(fileName)) {
334 SerializationUtils.serialize(snapshots, fos);
336 returnFuture.set(newSuccessfulResult());
337 LOG.info("Successfully backed up datastore to file {}", fileName);
338 } catch(Exception e) {
339 onDatastoreBackupFailure(fileName, returnFuture, e);
343 private static void onDatastoreBackupFailure(String fileName, SettableFuture<RpcResult<Void>> returnFuture,
345 onMessageFailure(String.format("Failed to back up datastore to file %s", fileName), returnFuture, failure);
348 private static void onMessageFailure(String msg, final SettableFuture<RpcResult<Void>> returnFuture,
350 LOG.error(msg, failure);
351 returnFuture.set(ClusterAdminRpcService.<Void>newFailedRpcResultBuilder(String.format("%s: %s", msg,
352 failure.getMessage())).build());
355 private <T> ListenableFuture<T> ask(ActorRef actor, Object message, Timeout timeout) {
356 final SettableFuture<T> returnFuture = SettableFuture.create();
358 @SuppressWarnings("unchecked")
359 scala.concurrent.Future<T> askFuture = (scala.concurrent.Future<T>) Patterns.ask(actor, message, timeout);
360 askFuture.onComplete(new OnComplete<T>() {
362 public void onComplete(Throwable failure, T resp) {
363 if(failure != null) {
364 returnFuture.setException(failure);
366 returnFuture.set(resp);
369 }, configDataStore.getActorContext().getClientDispatcher());
374 private static <T> ListenableFuture<RpcResult<T>> newFailedRpcResultFuture(String message) {
375 return ClusterAdminRpcService.<T>newFailedRpcResultBuilder(message).buildFuture();
378 private static <T> RpcResultBuilder<T> newFailedRpcResultBuilder(String message) {
379 return newFailedRpcResultBuilder(message, null);
382 private static <T> RpcResultBuilder<T> newFailedRpcResultBuilder(String message, Throwable cause) {
383 return RpcResultBuilder.<T>failed().withError(ErrorType.RPC, message, cause);
386 private static RpcResult<Void> newSuccessfulResult() {
387 return newSuccessfulResult((Void)null);
390 private static <T> RpcResult<T> newSuccessfulResult(T data) {
391 return RpcResultBuilder.<T>success(data).build();