X-Git-Url: https://git.opendaylight.org/gerrit/gitweb?p=controller.git;a=blobdiff_plain;f=opendaylight%2Fmd-sal%2Fsamples%2Ftoaster-provider%2Fsrc%2Fmain%2Fjava%2Forg%2Fopendaylight%2Fcontroller%2Fsample%2Ftoaster%2Fprovider%2FOpendaylightToaster.java;h=0fcd474d9c0e631185a37e28836f40b8e66dd822;hp=2dab924e7709dc74fcb3047272d068f9e459c2d5;hb=05522e0190cec637f190ceb5aedf785039f08e57;hpb=c4940d6fa1f6928b7189afb2dc6964fb2f2cbae2 diff --git a/opendaylight/md-sal/samples/toaster-provider/src/main/java/org/opendaylight/controller/sample/toaster/provider/OpendaylightToaster.java b/opendaylight/md-sal/samples/toaster-provider/src/main/java/org/opendaylight/controller/sample/toaster/provider/OpendaylightToaster.java index 2dab924e77..0fcd474d9c 100644 --- a/opendaylight/md-sal/samples/toaster-provider/src/main/java/org/opendaylight/controller/sample/toaster/provider/OpendaylightToaster.java +++ b/opendaylight/md-sal/samples/toaster-provider/src/main/java/org/opendaylight/controller/sample/toaster/provider/OpendaylightToaster.java @@ -7,167 +7,425 @@ */ package org.opendaylight.controller.sample.toaster.provider; -import java.util.Collections; +import static org.opendaylight.mdsal.binding.api.DataObjectModification.ModificationType.DELETE; +import static org.opendaylight.mdsal.binding.api.DataObjectModification.ModificationType.WRITE; +import static org.opendaylight.mdsal.common.api.LogicalDatastoreType.CONFIGURATION; +import static org.opendaylight.mdsal.common.api.LogicalDatastoreType.OPERATIONAL; +import static org.opendaylight.yangtools.yang.common.RpcError.ErrorType.APPLICATION; + +import com.google.common.base.Function; +import com.google.common.base.Preconditions; +import com.google.common.util.concurrent.FluentFuture; +import com.google.common.util.concurrent.FutureCallback; +import com.google.common.util.concurrent.Futures; +import com.google.common.util.concurrent.ListenableFuture; +import com.google.common.util.concurrent.MoreExecutors; +import com.google.common.util.concurrent.SettableFuture; +import java.util.Collection; +import java.util.Optional; import java.util.concurrent.Callable; -import java.util.concurrent.ExecutionException; import java.util.concurrent.ExecutorService; import java.util.concurrent.Executors; import java.util.concurrent.Future; import java.util.concurrent.atomic.AtomicLong; - -import org.opendaylight.controller.config.yang.config.toaster_provider.impl.ToasterProviderRuntimeMXBean; -import org.opendaylight.controller.sal.binding.api.NotificationProviderService; -import org.opendaylight.controller.sal.binding.api.data.DataBrokerService; -import org.opendaylight.controller.sal.binding.api.data.DataModificationTransaction; -import org.opendaylight.controller.sal.common.util.Rpcs; +import java.util.concurrent.atomic.AtomicReference; +import org.opendaylight.controller.md.sal.common.util.jmx.AbstractMXBean; +import org.opendaylight.mdsal.binding.api.DataBroker; +import org.opendaylight.mdsal.binding.api.DataObjectModification; +import org.opendaylight.mdsal.binding.api.DataTreeChangeListener; +import org.opendaylight.mdsal.binding.api.DataTreeIdentifier; +import org.opendaylight.mdsal.binding.api.DataTreeModification; +import org.opendaylight.mdsal.binding.api.NotificationPublishService; +import org.opendaylight.mdsal.binding.api.ReadWriteTransaction; +import org.opendaylight.mdsal.binding.api.WriteTransaction; +import org.opendaylight.mdsal.common.api.CommitInfo; +import org.opendaylight.mdsal.common.api.OptimisticLockFailedException; +import org.opendaylight.mdsal.common.api.TransactionCommitFailedException; +import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.CancelToastInput; +import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.CancelToastOutput; +import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.CancelToastOutputBuilder; import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.DisplayString; import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.MakeToastInput; -import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.ToastDone.ToastStatus; -import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.ToastDoneBuilder; +import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.MakeToastOutput; +import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.MakeToastOutputBuilder; +import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.RestockToasterInput; +import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.RestockToasterOutput; +import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.RestockToasterOutputBuilder; import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.Toaster; import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.Toaster.ToasterStatus; import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.ToasterBuilder; -import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.ToasterData; +import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.ToasterOutOfBreadBuilder; +import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.ToasterRestocked; +import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.ToasterRestockedBuilder; import org.opendaylight.yang.gen.v1.http.netconfcentral.org.ns.toaster.rev091120.ToasterService; +import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.toaster.app.config.rev160503.ToasterAppConfig; +import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.controller.toaster.app.config.rev160503.ToasterAppConfigBuilder; +import org.opendaylight.yangtools.concepts.ListenerRegistration; import org.opendaylight.yangtools.yang.binding.InstanceIdentifier; import org.opendaylight.yangtools.yang.common.RpcError; +import org.opendaylight.yangtools.yang.common.RpcError.ErrorType; import org.opendaylight.yangtools.yang.common.RpcResult; +import org.opendaylight.yangtools.yang.common.RpcResultBuilder; import org.slf4j.Logger; import org.slf4j.LoggerFactory; -import com.google.common.util.concurrent.Futures; +public class OpendaylightToaster extends AbstractMXBean + implements ToasterService, ToasterProviderRuntimeMXBean, DataTreeChangeListener, AutoCloseable { + + private static final CancelToastOutput EMPTY_CANCEL_OUTPUT = new CancelToastOutputBuilder().build(); + private static final MakeToastOutput EMPTY_MAKE_OUTPUT = new MakeToastOutputBuilder().build(); + private static final RestockToasterOutput EMPTY_RESTOCK_OUTPUT = new RestockToasterOutputBuilder().build(); -public class OpendaylightToaster implements ToasterData, ToasterService, ToasterProviderRuntimeMXBean, AutoCloseable { + private static final Logger LOG = LoggerFactory.getLogger(OpendaylightToaster.class); - private static final Logger log = LoggerFactory.getLogger(OpendaylightToaster.class); - private static final InstanceIdentifier toasterIID = InstanceIdentifier.builder(Toaster.class).build(); + private static final InstanceIdentifier TOASTER_IID = InstanceIdentifier.builder(Toaster.class).build(); + private static final DisplayString TOASTER_MANUFACTURER = new DisplayString("Opendaylight"); + private static final DisplayString TOASTER_MODEL_NUMBER = new DisplayString("Model 1 - Binding Aware"); - private static final DisplayString toasterManufacturer = new DisplayString("Opendaylight"); - private static final DisplayString toasterModelNumber = new DisplayString("Model 1 - Binding Aware"); + private DataBroker dataBroker; + private NotificationPublishService notificationProvider; + private ListenerRegistration dataTreeChangeListenerRegistration; - private NotificationProviderService notificationProvider; - private DataBrokerService dataProvider; private final ExecutorService executor; - private Future> currentTask; + // This holds the Future for the current make toast task and is used to cancel the current toast. + private final AtomicReference> currentMakeToastTask = new AtomicReference<>(); + + // Thread safe holders + private final AtomicLong amountOfBreadInStock = new AtomicLong(100); + private final AtomicLong toastsMade = new AtomicLong(0); + private final AtomicLong darknessFactor = new AtomicLong(1000); + + private final ToasterAppConfig toasterAppConfig; public OpendaylightToaster() { + this(new ToasterAppConfigBuilder().setManufacturer(TOASTER_MANUFACTURER).setModelNumber(TOASTER_MODEL_NUMBER) + .setMaxMakeToastTries(2).build()); + } + + public OpendaylightToaster(final ToasterAppConfig toasterAppConfig) { + super("OpendaylightToaster", "toaster-provider", null); executor = Executors.newFixedThreadPool(1); + this.toasterAppConfig = toasterAppConfig; + } + + public void setNotificationProvider(final NotificationPublishService notificationPublishService) { + this.notificationProvider = notificationPublishService; + } + + public void setDataBroker(final DataBroker dataBroker) { + this.dataBroker = dataBroker; + } + + public void init() { + LOG.info("Initializing..."); + + Preconditions.checkNotNull(dataBroker, "dataBroker must be set"); + dataTreeChangeListenerRegistration = dataBroker.registerDataTreeChangeListener( + DataTreeIdentifier.create(CONFIGURATION, TOASTER_IID), this); + setToasterStatusUp(null); + + // Register our MXBean. + register(); } + /** + * Implemented from the AutoCloseable interface. + */ @Override - public synchronized Toaster getToaster() { - ToasterBuilder tb = new ToasterBuilder(); - tb // - .setToasterManufacturer(toasterManufacturer) // - .setToasterModelNumber(toasterModelNumber) // - .setToasterStatus(currentTask == null ? ToasterStatus.Up : ToasterStatus.Down); + public void close() { + LOG.info("Closing..."); - return tb.build(); + // Unregister our MXBean. + unregister(); + + // When we close this service we need to shutdown our executor! + executor.shutdown(); + + if (dataTreeChangeListenerRegistration != null) { + dataTreeChangeListenerRegistration.close(); + } + + if (dataBroker != null) { + WriteTransaction tx = dataBroker.newWriteOnlyTransaction(); + tx.delete(OPERATIONAL,TOASTER_IID); + Futures.addCallback(tx.commit(), new FutureCallback() { + @Override + public void onSuccess(final CommitInfo result) { + LOG.debug("Successfully deleted the operational Toaster"); + } + + @Override + public void onFailure(final Throwable failure) { + LOG.error("Delete of the operational Toaster failed", failure); + } + }, MoreExecutors.directExecutor()); + } + } + + private Toaster buildToaster(final ToasterStatus status) { + // note - we are simulating a device whose manufacture and model are + // fixed (embedded) into the hardware. + // This is why the manufacture and model number are hardcoded. + return new ToasterBuilder().setToasterManufacturer(toasterAppConfig.getManufacturer()) + .setToasterModelNumber(toasterAppConfig.getModelNumber()).setToasterStatus(status).build(); } + /** + * Implemented from the DataTreeChangeListener interface. + */ @Override - public synchronized Future> cancelToast() { - if (currentTask != null) { - cancelToastImpl(); + public void onDataTreeChanged(final Collection> changes) { + for (DataTreeModification change: changes) { + DataObjectModification rootNode = change.getRootNode(); + if (rootNode.getModificationType() == WRITE) { + Toaster oldToaster = rootNode.getDataBefore(); + Toaster newToaster = rootNode.getDataAfter(); + LOG.info("onDataTreeChanged - Toaster config with path {} was added or replaced: " + + "old Toaster: {}, new Toaster: {}", change.getRootPath().getRootIdentifier(), + oldToaster, newToaster); + + Long darkness = newToaster.getDarknessFactor(); + if (darkness != null) { + darknessFactor.set(darkness); + } + } else if (rootNode.getModificationType() == DELETE) { + LOG.info("onDataTreeChanged - Toaster config with path {} was deleted: old Toaster: {}", + change.getRootPath().getRootIdentifier(), rootNode.getDataBefore()); + } } - return null; } + /** + * RPC call implemented from the ToasterService interface that cancels the current toast, if any. + */ @Override - public synchronized Future> makeToast(MakeToastInput input) { - log.debug("makeToast - Received input for toast"); - logToastInput(input); - if (currentTask != null) { - return inProgressError(); + public ListenableFuture> cancelToast(final CancelToastInput input) { + Future current = currentMakeToastTask.getAndSet(null); + if (current != null) { + current.cancel(true); } - currentTask = executor.submit(new MakeToastTask(input)); - updateStatus(); - return currentTask; + + // Always return success from the cancel toast call + return Futures.immediateFuture(RpcResultBuilder.success(EMPTY_CANCEL_OUTPUT).build()); } - private Future> inProgressError() { - RpcResult result = Rpcs. getRpcResult(false, null, Collections. emptySet()); - return Futures.immediateFuture(result); + /** + * RPC call implemented from the ToasterService interface that attempts to make toast. + */ + @Override + public ListenableFuture> makeToast(final MakeToastInput input) { + LOG.info("makeToast: " + input); + + final SettableFuture> futureResult = SettableFuture.create(); + + checkStatusAndMakeToast(input, futureResult, toasterAppConfig.getMaxMakeToastTries()); + + return futureResult; } - private void cancelToastImpl() { - currentTask.cancel(true); - ToastDoneBuilder toastDone = new ToastDoneBuilder(); - toastDone.setToastStatus(ToastStatus.Cancelled); - notificationProvider.publish(toastDone.build()); + private static RpcError makeToasterOutOfBreadError() { + return RpcResultBuilder.newError(APPLICATION, "resource-denied", "Toaster is out of bread", "out-of-stock", + null, null); } - public void setNotificationProvider(NotificationProviderService salService) { - this.notificationProvider = salService; + private static RpcError makeToasterInUseError() { + return RpcResultBuilder.newWarning(APPLICATION, "in-use", "Toaster is busy", null, null, null); } - public void setDataProvider(DataBrokerService salDataProvider) { - this.dataProvider = salDataProvider; - updateStatus(); + private void checkStatusAndMakeToast(final MakeToastInput input, + final SettableFuture> futureResult, final int tries) { + // Read the ToasterStatus and, if currently Up, try to write the status to Down. + // If that succeeds, then we essentially have an exclusive lock and can proceed + // to make toast. + final ReadWriteTransaction tx = dataBroker.newReadWriteTransaction(); + FluentFuture> readFuture = tx.read(OPERATIONAL, TOASTER_IID); + + final ListenableFuture commitFuture = + Futures.transformAsync(readFuture, toasterData -> { + ToasterStatus toasterStatus = ToasterStatus.Up; + if (toasterData.isPresent()) { + toasterStatus = toasterData.get().getToasterStatus(); + } + + LOG.debug("Read toaster status: {}", toasterStatus); + + if (toasterStatus == ToasterStatus.Up) { + + if (outOfBread()) { + LOG.debug("Toaster is out of bread"); + tx.cancel(); + return Futures.immediateFailedFuture( + new TransactionCommitFailedException("", makeToasterOutOfBreadError())); + } + + LOG.debug("Setting Toaster status to Down"); + + // We're not currently making toast - try to update the status to Down + // to indicate we're going to make toast. This acts as a lock to prevent + // concurrent toasting. + tx.put(OPERATIONAL, TOASTER_IID, buildToaster(ToasterStatus.Down)); + return tx.commit(); + } + + LOG.debug("Oops - already making toast!"); + + // Return an error since we are already making toast. This will get + // propagated to the commitFuture below which will interpret the null + // TransactionStatus in the RpcResult as an error condition. + tx.cancel(); + return Futures.immediateFailedFuture( + new TransactionCommitFailedException("", makeToasterInUseError())); + }, MoreExecutors.directExecutor()); + + Futures.addCallback(commitFuture, new FutureCallback() { + @Override + public void onSuccess(final CommitInfo result) { + // OK to make toast + currentMakeToastTask.set(executor.submit(new MakeToastTask(input, futureResult))); + } + + @Override + public void onFailure(final Throwable ex) { + if (ex instanceof OptimisticLockFailedException) { + + // Another thread is likely trying to make toast simultaneously and updated the + // status before us. Try reading the status again - if another make toast is + // now in progress, we should get ToasterStatus.Down and fail. + + if (tries - 1 > 0) { + LOG.debug("Got OptimisticLockFailedException - trying again"); + checkStatusAndMakeToast(input, futureResult, tries - 1); + } else { + futureResult.set(RpcResultBuilder.failed() + .withError(ErrorType.APPLICATION, ex.getMessage()).build()); + } + } else if (ex instanceof TransactionCommitFailedException) { + LOG.debug("Failed to commit Toaster status", ex); + + // Probably already making toast. + futureResult.set(RpcResultBuilder.failed() + .withRpcErrors(((TransactionCommitFailedException)ex).getErrorList()).build()); + } else { + LOG.debug("Unexpected error committing Toaster status", ex); + futureResult.set(RpcResultBuilder.failed().withError(ErrorType.APPLICATION, + "Unexpected error committing Toaster status", ex).build()); + } + } + }, MoreExecutors.directExecutor()); } - private void logToastInput(MakeToastInput input) { - String toastType = input.getToasterToastType().getName(); - String toastDoneness = input.getToasterDoneness().toString(); - log.trace("Toast: {} doneness: {}", toastType, toastDoneness); + /** + * RestConf RPC call implemented from the ToasterService interface. + * Restocks the bread for the toaster, resets the toastsMade counter to 0, and sends a + * ToasterRestocked notification. + */ + @Override + public ListenableFuture> restockToaster(final RestockToasterInput input) { + LOG.info("restockToaster: " + input); + + amountOfBreadInStock.set(input.getAmountOfBreadToStock()); + + if (amountOfBreadInStock.get() > 0) { + ToasterRestocked reStockedNotification = new ToasterRestockedBuilder() + .setAmountOfBread(input.getAmountOfBreadToStock()).build(); + notificationProvider.offerNotification(reStockedNotification); + } + + return Futures.immediateFuture(RpcResultBuilder.success(EMPTY_RESTOCK_OUTPUT).build()); } - private final AtomicLong toastsMade = new AtomicLong(0); + /** + * JMX RPC call implemented from the ToasterProviderRuntimeMXBean interface. + */ + @Override + public void clearToastsMade() { + LOG.info("clearToastsMade"); + toastsMade.set(0); + } + /** + * Accesssor method implemented from the ToasterProviderRuntimeMXBean interface. + */ @Override public Long getToastsMade() { return toastsMade.get(); } - private void updateStatus() { - if (dataProvider != null) { - final DataModificationTransaction t = dataProvider.beginTransaction(); - t.removeOperationalData(toasterIID); - t.putOperationalData(toasterIID, getToaster()); + private void setToasterStatusUp(final Function resultCallback) { + WriteTransaction tx = dataBroker.newWriteOnlyTransaction(); + tx.put(OPERATIONAL,TOASTER_IID, buildToaster(ToasterStatus.Up)); - try { - t.commit().get(); - } catch (InterruptedException | ExecutionException e) { - log.warn("Failed to update toaster status, operational otherwise", e); + Futures.addCallback(tx.commit(), new FutureCallback() { + @Override + public void onSuccess(final CommitInfo result) { + LOG.info("Successfully set ToasterStatus to Up"); + notifyCallback(true); } - } else { - log.trace("No data provider configured, not updating status"); - } + + @Override + public void onFailure(final Throwable failure) { + // We shouldn't get an OptimisticLockFailedException (or any ex) as no + // other component should be updating the operational state. + LOG.error("Failed to update toaster status", failure); + + notifyCallback(false); + } + + void notifyCallback(final boolean result) { + if (resultCallback != null) { + resultCallback.apply(result); + } + } + }, MoreExecutors.directExecutor()); } - @Override - public void close() throws ExecutionException, InterruptedException { - if (dataProvider != null) { - final DataModificationTransaction t = dataProvider.beginTransaction(); - t.removeOperationalData(toasterIID); - t.commit().get(); - } + private boolean outOfBread() { + return amountOfBreadInStock.get() == 0; } - private class MakeToastTask implements Callable> { + private class MakeToastTask implements Callable { final MakeToastInput toastRequest; + final SettableFuture> futureResult; - public MakeToastTask(MakeToastInput toast) { - toastRequest = toast; + MakeToastTask(final MakeToastInput toastRequest, + final SettableFuture> futureResult) { + this.toastRequest = toastRequest; + this.futureResult = futureResult; } @Override - public RpcResult call() throws InterruptedException { - Thread.sleep(1000 * toastRequest.getToasterDoneness()); + public Void call() { + try { + // make toast just sleeps for n seconds per doneness level. + Thread.sleep(OpendaylightToaster.this.darknessFactor.get() * toastRequest.getToasterDoneness()); - ToastDoneBuilder notifyBuilder = new ToastDoneBuilder(); - notifyBuilder.setToastStatus(ToastStatus.Done); - notificationProvider.publish(notifyBuilder.build()); - log.debug("Toast Done"); - logToastInput(toastRequest); + } catch (InterruptedException e) { + LOG.info("Interrupted while making the toast"); + } - currentTask = null; toastsMade.incrementAndGet(); - updateStatus(); - return Rpcs. getRpcResult(true, null, Collections. emptySet()); + amountOfBreadInStock.getAndDecrement(); + if (outOfBread()) { + LOG.info("Toaster is out of bread!"); + + notificationProvider.offerNotification(new ToasterOutOfBreadBuilder().build()); + } + + // Set the Toaster status back to up - this essentially releases the toasting lock. + // We can't clear the current toast task nor set the Future result until the + // update has been committed so we pass a callback to be notified on completion. + + setToasterStatusUp(result -> { + currentMakeToastTask.set(null); + LOG.debug("Toast done"); + futureResult.set(RpcResultBuilder.success(EMPTY_MAKE_OUTPUT).build()); + return null; + }); + + return null; } } }