All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.opendaylight.controller.cluster.datastore.TransactionProxy Maven / Gradle / Ivy

There is a newer version: 10.0.4
Show newest version
/*
 * Copyright (c) 2014 Cisco Systems, Inc. and others.  All rights reserved.
 *
 * This program and the accompanying materials are made available under the
 * terms of the Eclipse Public License v1.0 which accompanies this distribution,
 * and is available at http://www.eclipse.org/legal/epl-v10.html
 */
package org.opendaylight.controller.cluster.datastore;

import static com.google.common.base.Preconditions.checkState;
import static java.util.Objects.requireNonNull;

import akka.actor.ActorSelection;
import com.google.common.annotations.VisibleForTesting;
import com.google.common.collect.Iterables;
import com.google.common.util.concurrent.FluentFuture;
import com.google.common.util.concurrent.SettableFuture;
import java.util.ArrayList;
import java.util.List;
import java.util.Map;
import java.util.Map.Entry;
import java.util.Optional;
import java.util.SortedSet;
import java.util.TreeMap;
import java.util.TreeSet;
import org.opendaylight.controller.cluster.access.concepts.TransactionIdentifier;
import org.opendaylight.controller.cluster.datastore.TransactionModificationOperation.DeleteOperation;
import org.opendaylight.controller.cluster.datastore.TransactionModificationOperation.MergeOperation;
import org.opendaylight.controller.cluster.datastore.TransactionModificationOperation.WriteOperation;
import org.opendaylight.controller.cluster.datastore.messages.AbstractRead;
import org.opendaylight.controller.cluster.datastore.messages.DataExists;
import org.opendaylight.controller.cluster.datastore.messages.ReadData;
import org.opendaylight.controller.cluster.datastore.utils.ActorUtils;
import org.opendaylight.controller.cluster.datastore.utils.RootScatterGather;
import org.opendaylight.mdsal.dom.spi.store.AbstractDOMStoreTransaction;
import org.opendaylight.mdsal.dom.spi.store.DOMStoreReadWriteTransaction;
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier.PathArgument;
import org.opendaylight.yangtools.yang.data.api.schema.ContainerNode;
import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
import scala.concurrent.Future;
import scala.concurrent.Promise;

/**
 * A transaction potentially spanning multiple backend shards.
 */
public class TransactionProxy extends AbstractDOMStoreTransaction
        implements DOMStoreReadWriteTransaction {
    private enum TransactionState {
        OPEN,
        READY,
        CLOSED,
    }

    private static final Logger LOG = LoggerFactory.getLogger(TransactionProxy.class);
    private static final DeleteOperation ROOT_DELETE_OPERATION = new DeleteOperation(YangInstanceIdentifier.of());

    private final Map txContextWrappers = new TreeMap<>();
    private final AbstractTransactionContextFactory txContextFactory;
    private final TransactionType type;
    private TransactionState state = TransactionState.OPEN;

    @VisibleForTesting
    public TransactionProxy(final AbstractTransactionContextFactory txContextFactory, final TransactionType type) {
        super(txContextFactory.nextIdentifier(), txContextFactory.getActorUtils().getDatastoreContext()
                .isTransactionDebugContextEnabled());
        this.txContextFactory = txContextFactory;
        this.type = requireNonNull(type);

        LOG.debug("New {} Tx - {}", type, getIdentifier());
    }

    @Override
    public FluentFuture exists(final YangInstanceIdentifier path) {
        return executeRead(shardNameFromIdentifier(path), new DataExists(path, DataStoreVersions.CURRENT_VERSION));
    }

    private  FluentFuture executeRead(final String shardName, final AbstractRead readCmd) {
        checkState(type != TransactionType.WRITE_ONLY, "Reads from write-only transactions are not allowed");

        LOG.trace("Tx {} {} {}", getIdentifier(), readCmd.getClass().getSimpleName(), readCmd.getPath());

        final SettableFuture proxyFuture = SettableFuture.create();
        AbstractTransactionContextWrapper contextWrapper = wrapperFromShardName(shardName);
        contextWrapper.maybeExecuteTransactionOperation(new TransactionOperation() {
            @Override
            public void invoke(final TransactionContext transactionContext, final Boolean havePermit) {
                transactionContext.executeRead(readCmd, proxyFuture, havePermit);
            }
        });

        return FluentFuture.from(proxyFuture);
    }

    @Override
    public FluentFuture> read(final YangInstanceIdentifier path) {
        checkState(type != TransactionType.WRITE_ONLY, "Reads from write-only transactions are not allowed");
        requireNonNull(path, "path should not be null");

        LOG.trace("Tx {} read {}", getIdentifier(), path);
        return path.isEmpty() ? readAllData() : singleShardRead(shardNameFromIdentifier(path), path);
    }

    private FluentFuture> singleShardRead(final String shardName,
            final YangInstanceIdentifier path) {
        return executeRead(shardName, new ReadData(path, DataStoreVersions.CURRENT_VERSION));
    }

    private FluentFuture> readAllData() {
        final var actorUtils = getActorUtils();
        return RootScatterGather.gather(actorUtils, actorUtils.getConfiguration().getAllShardNames().stream()
            .map(shardName -> singleShardRead(shardName, YangInstanceIdentifier.of())));
    }

    @Override
    public void delete(final YangInstanceIdentifier path) {
        checkModificationState("delete", path);

        if (path.isEmpty()) {
            deleteAllData();
        } else {
            executeModification(new DeleteOperation(path));
        }
    }

    private void deleteAllData() {
        for (String shardName : getActorUtils().getConfiguration().getAllShardNames()) {
            wrapperFromShardName(shardName).maybeExecuteTransactionOperation(ROOT_DELETE_OPERATION);
        }
    }

    @Override
    public void merge(final YangInstanceIdentifier path, final NormalizedNode data) {
        checkModificationState("merge", path);

        if (path.isEmpty()) {
            mergeAllData(RootScatterGather.castRootNode(data));
        } else {
            executeModification(new MergeOperation(path, data));
        }
    }

    private void mergeAllData(final ContainerNode rootData) {
        if (!rootData.isEmpty()) {
            RootScatterGather.scatterTouched(rootData, this::wrapperFromRootChild).forEach(
                scattered -> scattered.shard().maybeExecuteTransactionOperation(
                    new MergeOperation(YangInstanceIdentifier.of(), scattered.container())));
        }
    }

    @Override
    public void write(final YangInstanceIdentifier path, final NormalizedNode data) {
        checkModificationState("write", path);

        if (path.isEmpty()) {
            writeAllData(RootScatterGather.castRootNode(data));
        } else {
            executeModification(new WriteOperation(path, data));
        }
    }

    private void writeAllData(final ContainerNode rootData) {
        RootScatterGather.scatterAll(rootData, this::wrapperFromRootChild,
            getActorUtils().getConfiguration().getAllShardNames().stream().map(this::wrapperFromShardName)).forEach(
                scattered -> scattered.shard().maybeExecuteTransactionOperation(
                    new WriteOperation(YangInstanceIdentifier.of(), scattered.container())));
    }

    private void executeModification(final TransactionModificationOperation operation) {
        wrapperFromShardName(shardNameFromIdentifier(operation.path())).maybeExecuteTransactionOperation(operation);
    }

    private void checkModificationState(final String opName, final YangInstanceIdentifier path) {
        checkState(type != TransactionType.READ_ONLY, "Modification operation on read-only transaction is not allowed");
        checkState(state == TransactionState.OPEN, "Transaction is sealed - further modifications are not allowed");
        LOG.trace("Tx {} {} {}", getIdentifier(), opName, path);
    }

    private boolean seal(final TransactionState newState) {
        if (state == TransactionState.OPEN) {
            state = newState;
            return true;
        }
        return false;
    }

    @Override
    public final void close() {
        if (!seal(TransactionState.CLOSED)) {
            checkState(state == TransactionState.CLOSED, "Transaction %s is ready, it cannot be closed",
                getIdentifier());
            // Idempotent no-op as per AutoCloseable recommendation
            return;
        }

        for (AbstractTransactionContextWrapper contextWrapper : txContextWrappers.values()) {
            contextWrapper.maybeExecuteTransactionOperation(new TransactionOperation() {
                @Override
                public void invoke(final TransactionContext transactionContext, final Boolean havePermit) {
                    transactionContext.closeTransaction();
                }
            });
        }


        txContextWrappers.clear();
    }

    @Override
    public final AbstractThreePhaseCommitCohort ready() {
        checkState(type != TransactionType.READ_ONLY, "Read-only transactions cannot be readied");

        final boolean success = seal(TransactionState.READY);
        checkState(success, "Transaction %s is %s, it cannot be readied", getIdentifier(), state);

        LOG.debug("Tx {} Readying {} components for commit", getIdentifier(), txContextWrappers.size());

        final AbstractThreePhaseCommitCohort ret = switch (txContextWrappers.size()) {
            case 0 -> NoOpDOMStoreThreePhaseCommitCohort.INSTANCE;
            case 1 -> {
                final Entry e = Iterables.getOnlyElement(
                        txContextWrappers.entrySet());
                yield createSingleCommitCohort(e.getKey(), e.getValue());
            }
            default -> createMultiCommitCohort();
        };
        txContextFactory.onTransactionReady(getIdentifier(), ret.getCohortFutures());

        final Throwable debugContext = getDebugContext();
        return debugContext == null ? ret : new DebugThreePhaseCommitCohort(getIdentifier(), ret, debugContext);
    }

    @SuppressWarnings({ "rawtypes", "unchecked" })
    private AbstractThreePhaseCommitCohort createSingleCommitCohort(final String shardName,
            final AbstractTransactionContextWrapper contextWrapper) {

        LOG.debug("Tx {} Readying transaction for shard {}", getIdentifier(), shardName);

        final OperationCallback.Reference operationCallbackRef =
                new OperationCallback.Reference(OperationCallback.NO_OP_CALLBACK);

        final TransactionContext transactionContext = contextWrapper.getTransactionContext();
        final Future future;
        if (transactionContext == null) {
            final Promise promise = akka.dispatch.Futures.promise();
            contextWrapper.maybeExecuteTransactionOperation(new TransactionOperation() {
                @Override
                public void invoke(final TransactionContext newTransactionContext, final Boolean havePermit) {
                    promise.completeWith(getDirectCommitFuture(newTransactionContext, operationCallbackRef,
                        havePermit));
                }
            });
            future = promise.future();
        } else {
            // avoid the creation of a promise and a TransactionOperation
            future = getDirectCommitFuture(transactionContext, operationCallbackRef, null);
        }

        return new SingleCommitCohortProxy(txContextFactory.getActorUtils(), future, getIdentifier(),
            operationCallbackRef);
    }

    private Future getDirectCommitFuture(final TransactionContext transactionContext,
            final OperationCallback.Reference operationCallbackRef, final Boolean havePermit) {
        TransactionRateLimitingCallback rateLimitingCallback = new TransactionRateLimitingCallback(
                txContextFactory.getActorUtils());
        operationCallbackRef.set(rateLimitingCallback);
        rateLimitingCallback.run();
        return transactionContext.directCommit(havePermit);
    }

    private AbstractThreePhaseCommitCohort createMultiCommitCohort() {

        final List cohorts = new ArrayList<>(txContextWrappers.size());
        final Optional> shardNames = Optional.of(new TreeSet<>(txContextWrappers.keySet()));
        for (Entry e : txContextWrappers.entrySet()) {
            LOG.debug("Tx {} Readying transaction for shard {}", getIdentifier(), e.getKey());

            final AbstractTransactionContextWrapper wrapper = e.getValue();

            // The remote tx version is obtained the via TransactionContext which may not be available yet so
            // we pass a Supplier to dynamically obtain it. Once the ready Future is resolved the
            // TransactionContext is available.
            cohorts.add(new ThreePhaseCommitCohortProxy.CohortInfo(wrapper.readyTransaction(shardNames),
                () -> wrapper.getTransactionContext().getTransactionVersion()));
        }

        return new ThreePhaseCommitCohortProxy(txContextFactory.getActorUtils(), cohorts, getIdentifier());
    }

    private String shardNameFromIdentifier(final YangInstanceIdentifier path) {
        return getActorUtils().getShardStrategyFactory().getStrategy(path).findShard(path);
    }

    private AbstractTransactionContextWrapper wrapperFromRootChild(final PathArgument childId) {
        return wrapperFromShardName(shardNameFromIdentifier(YangInstanceIdentifier.of(childId)));
    }

    private AbstractTransactionContextWrapper wrapperFromShardName(final String shardName) {
        final AbstractTransactionContextWrapper existing = txContextWrappers.get(shardName);
        if (existing != null) {
            return existing;
        }

        final AbstractTransactionContextWrapper fresh = txContextFactory.newTransactionContextWrapper(this, shardName);
        txContextWrappers.put(shardName, fresh);
        return fresh;
    }

    TransactionType getType() {
        return type;
    }

    boolean isReady() {
        return state != TransactionState.OPEN;
    }

    final ActorUtils getActorUtils() {
        return txContextFactory.getActorUtils();
    }
}




© 2015 - 2024 Weber Informatics LLC | Privacy Policy