* @author Robert Varga
*/
@Beta
+@Deprecated(forRemoval = true)
public interface CDSDataTreeProducer extends DOMDataTreeProducer {
/**
* Return a {@link CDSShardAccess} handle. This handle will remain valid
* @author Robert Varga
*/
@Beta
+@Deprecated(forRemoval = true)
public interface CDSShardAccess {
/**
* Return the shard identifier.
return ensureProxy(path);
}
+ @Deprecated(forRemoval = true)
public DOMDataTreeWriteCursor openCursor() {
Preconditions.checkState(cursor == null, "Transaction %s has open cursor", getIdentifier());
cursor = new ClientTransactionCursor(this);
*
* @author Robert Varga
*/
+@Deprecated(forRemoval = true)
final class ClientTransactionCursor implements DOMDataTreeWriteCursor {
private YangInstanceIdentifier current = YangInstanceIdentifier.empty();
private final ClientTransaction parent;
* creates instances of this class has to call {@link #close()} once it is no
* longer valid.
*/
+@Deprecated(forRemoval = true)
final class CDSShardAccessImpl implements CDSShardAccess, LeaderLocationListener, AutoCloseable {
private static final Logger LOG = LoggerFactory.getLogger(CDSShardAccessImpl.class);
listeners.add(listener);
- return new LeaderLocationListenerRegistration<L>() {
+ return new LeaderLocationListenerRegistration<>() {
@Override
public L getInstance() {
return listener;
* Exception thrown when there was a at any point during the creation of a shard via {@link DistributedShardFactory}.
*/
@Beta
+@Deprecated(forRemoval = true)
public class DOMDataTreeShardCreationFailedException extends Exception {
private static final long serialVersionUID = 1L;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
+@Deprecated(forRemoval = true)
public class DistributedShardChangePublisher
extends AbstractRegistrationTree<AbstractDOMDataTreeChangeListenerRegistration<?>>
implements DOMStoreTreeChangePublisher {
* shard/replicas that come along with it.
*/
@Beta
+@Deprecated(forRemoval = true)
public interface DistributedShardFactory {
/**
* Register a new shard that is rooted at the desired prefix with replicas on the provided members.
/**
* Proxy implementation of a shard that creates forwarding producers to the backend shard.
*/
+@Deprecated(forRemoval = true)
class DistributedShardFrontend implements ReadableWriteableDOMDataTreeShard {
private static final Logger LOG = LoggerFactory.getLogger(DistributedShardFrontend.class);
* Shard modification that consists of the whole shard context, provides cursors which correctly delegate to subshards
* if any are present.
*/
+@Deprecated(forRemoval = true)
public class DistributedShardModification extends WriteableNodeWithSubshard {
private final DistributedShardModificationContext context;
/**
* The context for a single shards modification, keeps a ClientTransaction so it can route requests correctly.
*/
+@Deprecated(forRemoval = true)
public class DistributedShardModificationContext {
- private ClientTransaction transaction;
- private DOMDataTreeIdentifier identifier;
+ private final ClientTransaction transaction;
+ private final DOMDataTreeIdentifier identifier;
private DOMDataTreeWriteCursor cursor;
public DistributedShardModificationContext(final ClientTransaction transaction,
* 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.sharding;
import org.opendaylight.mdsal.dom.spi.shard.AbstractDataModificationCursor;
* Internal cursor implementation consisting of WriteCursorStrategies which forwards writes to foreign modifications
* if any.
*/
+@Deprecated(forRemoval = true)
public class DistributedShardModificationCursor extends AbstractDataModificationCursor<DistributedShardModification> {
- private ShardProxyTransaction parent;
+ private final ShardProxyTransaction parent;
public DistributedShardModificationCursor(final DistributedShardModification root,
final ShardProxyTransaction parent) {
/**
* Factory for {@link DistributedShardModification}.
*/
+@Deprecated(forRemoval = true)
public final class DistributedShardModificationFactory {
private final Map<DOMDataTreeIdentifier, ForeignShardModificationContext> childShards;
private final Map<PathArgument, WriteableModificationNode> children;
* 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.sharding;
import org.opendaylight.mdsal.dom.api.DOMDataTreeIdentifier;
/**
* Builder for {@link DistributedShardModificationFactory}.
*/
+@Deprecated(forRemoval = true)
public class DistributedShardModificationFactoryBuilder
extends AbstractShardModificationFactoryBuilder<DistributedShardModificationFactory> {
* This removal is done asynchronously.
*/
@Beta
+@Deprecated(forRemoval = true)
public interface DistributedShardRegistration {
/**
* A layer on top of DOMDataTreeService that distributes producer/shard registrations to remote nodes via
* {@link ShardedDataTreeActor}. Also provides QoL method for addition of prefix based clustered shard into the system.
*/
+@Deprecated(forRemoval = true)
public class DistributedShardedDOMDataTree implements DOMDataTreeService, DOMDataTreeShardingService,
DistributedShardFactory {
* Base class for lookup tasks. Lookup tasks are supposed to run repeatedly until successful lookup or maximum retries
* are hit. This class is NOT thread-safe.
*/
+@Deprecated(forRemoval = true)
abstract class LookupTask implements Runnable {
private final int maxRetries;
private final ActorRef replyTo;
import org.slf4j.LoggerFactory;
@Component(immediate = true, property = "type=default")
+@Deprecated(forRemoval = true)
public final class OSGiDistributedShardedDOMDataTree
implements DOMDataTreeService, DOMDataTreeShardingService, DistributedShardFactory {
private static final Logger LOG = LoggerFactory.getLogger(OSGiDistributedShardedDOMDataTree.class);
* notifies handling actor with {@link PrefixShardCreated} and
* {@link PrefixShardRemoved} messages.
*/
+@Deprecated(forRemoval = true)
public class PrefixedShardConfigUpdateHandler {
private static final Logger LOG = LoggerFactory.getLogger(PrefixedShardConfigUpdateHandler.class);
* by {@link DistributedShardedDOMDataTree} for updating
* prefix-shard-configuration upon creating and de-spawning prefix-based shards.
*/
+@Deprecated(forRemoval = true)
class PrefixedShardConfigWriter {
private static final Logger LOG = LoggerFactory.getLogger(PrefixedShardConfigWriter.class);
* {@link LeaderLocationListener#onLeaderLocationChanged(LeaderLocation)}
* events.
*/
+@Deprecated(forRemoval = true)
public final class RoleChangeListenerActor extends AbstractUntypedActor {
private final LeaderLocationListener leaderLocationListener;
private final ActorRef roleChangeNotifier;
/**
* Proxy producer implementation that creates transactions that forward all calls to {@link DataStoreClient}.
*/
+@Deprecated(forRemoval = true)
class ShardProxyProducer implements DOMDataTreeShardProducer {
private final DOMDataTreeIdentifier shardRoot;
private final Collection<DOMDataTreeIdentifier> prefixes;
* Proxy {@link DOMDataTreeShardWriteTransaction} that creates a proxy cursor that translates all calls into
* {@link ClientTransaction} calls.
*/
+@Deprecated(forRemoval = true)
class ShardProxyTransaction implements DOMDataTreeShardWriteTransaction {
private static final Logger LOG = LoggerFactory.getLogger(ShardProxyTransaction.class);
* Actor that tracks currently open producers/shards on remote nodes and handles notifications of remote
* nodes of newly open producers/shards on the local node.
*/
+@Deprecated(forRemoval = true)
public class ShardedDataTreeActor extends AbstractUntypedPersistentActor {
private static final Logger LOG = LoggerFactory.getLogger(ShardedDataTreeActor.class);
/**
* Resolver for remote {@link ShardedDataTreeActor}'s.
*/
+@Deprecated(forRemoval = true)
public class ShardingServiceAddressResolver {
private final ConcurrentMap<MemberName, Address> memberNameToAddress = new ConcurrentHashMap<>();
* Message sent to the local ShardManager, once the shard configuration shard is ready and the ShardManager should
* start its listener.
*/
+@Deprecated(forRemoval = true)
public final class InitConfigListener {
public static final InitConfigListener INSTANCE = new InitConfigListener();
* create the required frontend/backend shards.
*/
@Beta
+@Deprecated(forRemoval = true)
public class LookupPrefixShard implements Serializable {
private static final long serialVersionUID = 1L;
* with success/failure based on the attempt result.
*/
@Beta
+@Deprecated(forRemoval = true)
public class NotifyProducerCreated implements Serializable {
private static final long serialVersionUID = 1L;
private final Collection<DOMDataTreeIdentifier> subtrees;
* with success/failure based on the attempt result. If the producer doesn't exist on this node report Success.
*/
@Beta
+@Deprecated(forRemoval = true)
public class NotifyProducerRemoved implements Serializable {
private static final long serialVersionUID = 1L;
private final Collection<DOMDataTreeIdentifier> subtrees;
* with only it's member present.
*/
@Beta
+@Deprecated(forRemoval = true)
public class PrefixShardCreated {
private final PrefixShardConfiguration configuration;
* Sent to the local {@link ShardedDataTreeActor} to initiate the lookup of the shard, once the shard is removed from
* the system entirely the actor responds with a success.
*/
+@Deprecated(forRemoval = true)
public class PrefixShardRemovalLookup {
private final DOMDataTreeIdentifier prefix;
* in the backend ShardManager.
*/
@Beta
+@Deprecated(forRemoval = true)
public class PrefixShardRemoved implements Serializable {
private static final long serialVersionUID = 1L;
* attempt to create a producer on the local node.
*/
@Beta
+@Deprecated(forRemoval = true)
public class ProducerCreated {
private final Collection<DOMDataTreeIdentifier> subtrees;
* attempt to close a producer on the local node.
*/
@Beta
+@Deprecated(forRemoval = true)
public class ProducerRemoved {
private final Collection<DOMDataTreeIdentifier> subtrees;
* Message that should be sent to ShardedDataTreeActor when the lookup of the prefix config shard should begin.
* Replied to with Succes once the shard has a leader.
*/
+@Deprecated(forRemoval = true)
public class StartConfigShardLookup {
- private LogicalDatastoreType type;
+ private final LogicalDatastoreType type;
public StartConfigShardLookup(final LogicalDatastoreType type) {
this.type = type;
import org.opendaylight.yangtools.yang.data.api.schema.ContainerNode;
import org.opendaylight.yangtools.yang.data.impl.schema.Builders;
+@Deprecated(forRemoval = true)
public class ClientTransactionCursorTest {
private static final QName NODE_1 = QName.create("ns-1", "node-1");
import scala.concurrent.Future;
import scala.concurrent.duration.FiniteDuration;
+@Deprecated(forRemoval = true)
public class CDSShardAccessImplTest extends AbstractActorTest {
private static final DOMDataTreeIdentifier TEST_ID =
import org.opendaylight.yangtools.yang.data.impl.schema.ImmutableNodes;
import org.opendaylight.yangtools.yang.data.impl.schema.builder.impl.ImmutableContainerNodeBuilder;
+@Deprecated(forRemoval = true)
public class DistributedShardFrontendTest {
private static final DOMDataTreeIdentifier ROOT =
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
+@Deprecated(forRemoval = true)
public class DistributedShardedDOMDataTreeRemotingTest extends AbstractTest {
private static final Logger LOG = LoggerFactory.getLogger(DistributedShardedDOMDataTreeRemotingTest.class);
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
+@Deprecated(forRemoval = true)
public class DistributedShardedDOMDataTreeTest extends AbstractTest {
private static final Logger LOG = LoggerFactory.getLogger(DistributedShardedDOMDataTreeRemotingTest.class);
import org.opendaylight.controller.cluster.notifications.LeaderStateChanged;
import org.opendaylight.controller.cluster.notifications.RegisterRoleChangeListener;
+@Deprecated(forRemoval = true)
public class RoleChangeListenerActorTest extends AbstractActorTest {
@Test
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
+@Deprecated(forRemoval = true)
public class IdIntsDOMDataTreeLIstener implements DOMDataTreeListener {
private static final Logger LOG = LoggerFactory.getLogger(IdIntsDOMDataTreeLIstener.class);
}
@Override
- public void onDataTreeFailed(Collection<DOMDataTreeListeningException> causes) {
+ public void onDataTreeFailed(final Collection<DOMDataTreeListeningException> causes) {
}
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
+@Deprecated(forRemoval = true)
public class PrefixLeaderHandler {
private static final Logger LOG = LoggerFactory.getLogger(PrefixLeaderHandler.class);
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
+@Deprecated(forRemoval = true)
public class PrefixShardHandler {
private static final Logger LOG = LoggerFactory.getLogger(PrefixShardHandler.class);
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
+@Deprecated(forRemoval = true)
public final class ProduceTransactionsHandler extends AbstractTransactionHandler {
private static final Logger LOG = LoggerFactory.getLogger(ProduceTransactionsHandler.class);