*
* @author Michael Vorburger.ch
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class AbstractCloseTracked<T extends AbstractCloseTracked<T>> implements CloseTracked<T> {
private final CloseTrackedTrait<T> closeTracker;
*
* @author Michael Vorburger.ch
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface CloseTracked<T extends CloseTracked<T>> {
/**
*
* @author Michael Vorburger.ch
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class CloseTrackedRegistry<T extends CloseTracked<T>> {
private final Object anchor;
*
* @author Michael Vorburger.ch
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class CloseTrackedRegistryReportEntry<T extends CloseTracked<T>> {
private final CloseTracked<T> exampleCloseTracked;
*
* @author Michael Vorburger.ch
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class CloseTrackedTrait<T extends CloseTracked<T>> implements CloseTracked<T> {
// NB: It's important that we keep a Throwable here, and not directly the StackTraceElement[] !
*/
// This generic infra may be moved somewhere else, later
@org.eclipse.jdt.annotation.NonNullByDefault
-@Deprecated
+@Deprecated(forRemoval = true)
package org.opendaylight.controller.md.sal.trace.closetracker.impl;
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
-@Deprecated
+@Deprecated(forRemoval = true)
abstract class AbstractTracingWriteTransaction implements DOMDataWriteTransaction {
private final DOMDataWriteTransaction delegate;
* </ul>
*
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class TracingBroker implements TracingDOMDataBroker {
@SuppressFBWarnings("SLF4J_LOGGER_SHOULD_BE_PRIVATE")
static final Logger LOG = LoggerFactory.getLogger(TracingBroker.class);
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
-@Deprecated
+@Deprecated(forRemoval = true)
class TracingReadOnlyTransaction
extends AbstractCloseTracked<TracingReadOnlyTransaction>
implements DOMDataReadOnlyTransaction {
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
-@Deprecated
+@Deprecated(forRemoval = true)
class TracingReadWriteTransaction
extends AbstractTracingWriteTransaction
implements DOMDataReadWriteTransaction, CloseTracked<TracingReadWriteTransaction> {
import org.opendaylight.controller.md.sal.trace.closetracker.impl.AbstractCloseTracked;
import org.opendaylight.controller.md.sal.trace.closetracker.impl.CloseTrackedRegistry;
-@Deprecated
+@Deprecated(forRemoval = true)
class TracingTransactionChain extends AbstractCloseTracked<TracingTransactionChain> implements DOMTransactionChain {
private final DOMTransactionChain delegate;
import org.opendaylight.controller.md.sal.trace.closetracker.impl.CloseTrackedTrait;
import org.opendaylight.mdsal.common.api.CommitInfo;
-@Deprecated
+@Deprecated(forRemoval = true)
class TracingWriteTransaction extends AbstractTracingWriteTransaction
implements CloseTracked<TracingWriteTransaction> {
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.ActionProviderService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
@SuppressFBWarnings(value = "NM_SAME_SIMPLE_NAME_AS_INTERFACE", justification = "Migration")
public interface ActionProviderService
extends BindingService, org.opendaylight.mdsal.binding.api.ActionProviderService {
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.ActionService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
@SuppressFBWarnings(value = "NM_SAME_SIMPLE_NAME_AS_INTERFACE", justification = "Migration")
public interface ActionService extends BindingService, org.opendaylight.mdsal.binding.api.ActionService {
*
* @deprecated Use {@link BindingService} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface BindingService extends BindingAwareService {
}
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.TransactionChain} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface BindingTransactionChain extends TransactionFactory,
TransactionChain<InstanceIdentifier<?>, DataObject> {
@Override
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.ClusteredDataTreeChangeListener} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface ClusteredDataTreeChangeListener<T extends DataObject> extends DataTreeChangeListener<T> {
}
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.DataBroker} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DataBroker extends AsyncDataBroker<InstanceIdentifier<?>, DataObject>,
TransactionChainFactory<InstanceIdentifier<?>, DataObject>, TransactionFactory, BindingService,
DataTreeChangeService {
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.DataObjectModification} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DataObjectModification<T extends DataObject>
extends org.opendaylight.yangtools.concepts.Identifiable<PathArgument> {
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.DataTreeChangeListener} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DataTreeChangeListener<T extends DataObject> extends EventListener {
/**
* Invoked when there was data change for the supplied path, which was used
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.DataTreeChangeService} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DataTreeChangeService extends BindingService {
/**
* Registers a {@link DataTreeChangeListener} to receive
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.DataTreeIdentifier} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public final class DataTreeIdentifier<T extends DataObject> implements Immutable,
Path<DataTreeIdentifier<?>>, Serializable {
private static final long serialVersionUID = 1L;
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.DataTreeModification} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DataTreeModification<T extends DataObject> {
/**
*
* @deprecated Use org.opendaylight.mdsal.binding.spi.ForwardingDataBroker instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class ForwardingDataBroker extends ForwardingObject implements DataBroker {
@Override
*
* @deprecated Use org.opendaylight.mdsal.binding.spi.ForwardingReadTransaction instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class ForwardingReadOnlyTransaction extends ForwardingObject implements ReadOnlyTransaction {
private final ReadOnlyTransaction delegate;
*
* @deprecated Use org.opendaylight.mdsal.binding.spi.ForwardingReadWriteTransaction instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class ForwardingReadWriteTransaction extends ForwardingObject implements ReadWriteTransaction {
private final ReadWriteTransaction delegate;
*
* @deprecated Use org.opendaylight.mdsal.binding.spi.ForwardingWriteTransaction instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class ForwardingWriteTransaction extends ForwardingObject implements WriteTransaction {
private final WriteTransaction delegate;
import org.opendaylight.yangtools.concepts.Identifiable;
import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
-@Deprecated
+@Deprecated(forRemoval = true)
public interface MountPoint extends Identifiable<InstanceIdentifier<?>> {
<T extends BindingService> Optional<T> getService(Class<T> service);
}
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.MountPointService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface MountPointService extends BindingService {
Optional<MountPoint> getMountPoint(InstanceIdentifier<?> mountPoint);
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.NotificationPublishService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface NotificationPublishService extends BindingService {
/**
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.NotificationRejectedException} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class NotificationRejectedException extends Exception {
private static final long serialVersionUID = 1L;
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.NotificationService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface NotificationService extends BindingService {
/**
* Registers a listener which implements a YANG-generated notification interface derived from
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.ReadTransaction} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface ReadOnlyTransaction extends ReadTransaction, AsyncReadOnlyTransaction<InstanceIdentifier<?>,
DataObject> {
}
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.ReadTransaction} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface ReadTransaction extends AsyncReadTransaction<InstanceIdentifier<?>, DataObject> {
/**
* Reads data from the provided logical data store located at the provided path.
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.ReadWriteTransaction} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface ReadWriteTransaction extends ReadTransaction, WriteTransaction,
AsyncReadWriteTransaction<InstanceIdentifier<?>, DataObject> {
}
import org.opendaylight.yangtools.yang.binding.DataObject;
import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
-@Deprecated
+@Deprecated(forRemoval = true)
public interface TransactionFactory extends AsyncDataTransactionFactory<InstanceIdentifier<?>, DataObject> {
@Override
ReadOnlyTransaction newReadOnlyTransaction();
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.WriteTransaction} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface WriteTransaction extends AsyncWriteTransaction<InstanceIdentifier<?>, DataObject> {
/**
* Stores a piece of data at the specified path. This acts as an add / replace operation, which is to say that whole
import org.osgi.framework.BundleContext;
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class AbstractBindingAwareConsumer extends AbstractBrokerAwareActivator
implements BindingAwareConsumer {
@Override
import org.osgi.framework.BundleContext;
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class AbstractBindingAwareProvider extends AbstractBrokerAwareActivator
implements BindingAwareProvider {
@Override
import org.osgi.util.tracker.ServiceTracker;
import org.osgi.util.tracker.ServiceTrackerCustomizer;
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class AbstractBrokerAwareActivator implements BundleActivator {
private final class Customizer implements ServiceTrackerCustomizer<BindingAwareBroker, BindingAwareBroker> {
private final BundleContext context;
* For more information about session-based access see {@link ConsumerContext}
* and {@link ProviderContext}
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface BindingAwareBroker {
@Deprecated
ConsumerContext registerConsumer(BindingAwareConsumer consumer, BundleContext ctx);
* }
* }
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface BindingAwareConsumer {
/**
* }
* }
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface BindingAwareProvider {
/**
*
* @deprecated Use {@link BindingService} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface BindingAwareService {
}
* @param <T> the interested notification type
* @deprecated Deprecated unused API.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface NotificationListener<T extends Notification> extends EventListener {
/**
* Invoked to deliver a notification.
*
* @deprecated Please use {@link org.opendaylight.mdsal.binding.api.NotificationPublishService}.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface NotificationProviderService extends NotificationService, NotificationPublishService<Notification> {
@Override
*
* @deprecated Please use {@link org.opendaylight.mdsal.binding.api.NotificationService} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface NotificationService extends BindingAwareService {
/**
* Registers a generic listener implementation for a specified notification type.
*/
package org.opendaylight.controller.sal.binding.api;
-@Deprecated
+@Deprecated(forRemoval = true)
public interface RpcAvailabilityListener {
}
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.RpcConsumerRegistry} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface RpcConsumerRegistry extends BindingAwareService, BindingService {
/**
* Returns an implementation of a requested RPC service.
*
* @deprecated Use {@link org.opendaylight.mdsal.binding.api.RpcProviderService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface RpcProviderRegistry extends RpcConsumerRegistry,
RouteChangePublisher<RpcContextIdentifier, InstanceIdentifier<?>> {
/**
import org.opendaylight.yangtools.yang.binding.BaseIdentity;
import org.opendaylight.yangtools.yang.binding.RpcService;
-@Deprecated
+@Deprecated(forRemoval = true)
public final class RpcContextIdentifier implements Immutable {
public final Class<? extends RpcService> rpcService;
import org.opendaylight.yangtools.yang.binding.BaseIdentity;
import org.opendaylight.yangtools.yang.binding.RpcService;
-@Deprecated
+@Deprecated(forRemoval = true)
public interface RpcRoutingContext<C extends BaseIdentity,S extends RpcService> {
Class<C> getContextType();
*
* @param <T> Notification type
*/
-@Deprecated
+@Deprecated(forRemoval = true)
abstract class AbstractNotificationListenerRegistration<T extends Notification>
extends AbstractListenerRegistration<NotificationListener<T>> implements NotificationListenerRegistration<T> {
private final Class<? extends Notification> type;
* @param <N> Notification type
* @param <A> Aggregator type
*/
-@Deprecated
+@Deprecated(forRemoval = true)
abstract class AggregatedNotificationListenerRegistration<N extends Notification, A>
extends AbstractNotificationListenerRegistration<N> {
private final A aggregator;
import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
import org.opendaylight.yangtools.yang.binding.RpcService;
-@Deprecated
+@Deprecated(forRemoval = true)
final class CompositeRoutedRpcRegistration<T extends RpcService> implements RoutedRpcRegistration<T> {
private final Class<T> type;
import org.opendaylight.yangtools.concepts.ObjectRegistration;
import org.opendaylight.yangtools.yang.binding.RpcService;
-@Deprecated
+@Deprecated(forRemoval = true)
final class DelegatedRootRpcRegistration<T extends RpcService> implements RpcRegistration<T> {
private final ObjectRegistration<T> delegate;
import org.opendaylight.mdsal.binding.dom.codec.api.BindingNormalizedNodeSerializer;
import org.opendaylight.yangtools.yang.binding.Notification;
-@Deprecated
+@Deprecated(forRemoval = true)
final class FunctionalNotificationListenerAdapter<N extends Notification> implements DOMNotificationListener {
private final BindingNormalizedNodeSerializer codec;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
-@Deprecated
+@Deprecated(forRemoval = true)
public class HeliumNotificationProviderServiceAdapter extends HeliumNotificationServiceAdapter
implements NotificationProviderService {
private static final Logger LOG = LoggerFactory.getLogger(HeliumNotificationProviderServiceAdapter.class);
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
-@Deprecated
+@Deprecated(forRemoval = true)
public class HeliumNotificationProviderServiceWithInterestListeners extends HeliumNotificationProviderServiceAdapter {
private static final Logger LOG = LoggerFactory.getLogger(
import org.opendaylight.yangtools.yang.binding.Notification;
import org.opendaylight.yangtools.yang.binding.NotificationListener;
-@Deprecated
+@Deprecated(forRemoval = true)
public class HeliumNotificationServiceAdapter
implements org.opendaylight.controller.sal.binding.api.NotificationService, AutoCloseable {
import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
import org.opendaylight.yangtools.yang.binding.RpcService;
-@Deprecated
+@Deprecated(forRemoval = true)
public class HeliumRpcProviderRegistry implements RpcProviderRegistry {
private final RpcConsumerRegistry consumerRegistry;
/**
* An immutable view of the current generation of listeners.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
final class ListenerMapGeneration {
private static final int CACHE_MAX_ENTRIES = 1000;
import org.opendaylight.yangtools.yang.binding.NotificationListener;
import org.opendaylight.yangtools.yang.common.QName;
-@Deprecated
+@Deprecated(forRemoval = true)
final class NotificationInvoker
implements org.opendaylight.controller.sal.binding.api.NotificationListener<Notification> {
*
* @param <T> Type of notification
*/
-@Deprecated
+@Deprecated(forRemoval = true)
interface NotificationListenerRegistration<T extends Notification>
extends ListenerRegistration<NotificationListener<T>> {
/**
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class AbstractForwardedDataBroker implements Delegator<DOMDataBroker>, AutoCloseable {
private static final Logger LOG = LoggerFactory.getLogger(AbstractForwardedDataBroker.class);
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
-@Deprecated
+@Deprecated(forRemoval = true)
abstract class AbstractForwardedTransaction<T extends AsyncTransaction<YangInstanceIdentifier, NormalizedNode<?, ?>>>
implements Delegator<T>, Identifiable<Object> {
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
-@Deprecated
+@Deprecated(forRemoval = true)
public class AbstractReadWriteTransaction extends AbstractWriteTransaction<DOMDataReadWriteTransaction> {
private static final Logger LOG = LoggerFactory.getLogger(AbstractReadWriteTransaction.class);
/**
* Abstract Base Transaction for transactions which are backed by {@link DOMDataWriteTransaction}.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class AbstractWriteTransaction<T extends DOMDataWriteTransaction> extends
AbstractForwardedTransaction<T> {
*
* @author Michael Vorburger.ch, partially based on refactored code originally by Thomas Pantelis
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class BindingBrokerWiring implements AutoCloseable {
private final BindingToNormalizedNodeCodec bindingToNormalizedNodeCodec;
*
* @author Thomas Pantelis
*/
-@Deprecated
+@Deprecated(forRemoval = true)
final class BindingClusteredDOMDataTreeChangeListenerAdapter<T extends DataObject>
extends BindingDOMDataTreeChangeListenerAdapter<T> implements ClusteredDOMDataTreeChangeListener {
BindingClusteredDOMDataTreeChangeListenerAdapter(BindingToNormalizedNodeCodec codec,
import org.opendaylight.controller.md.sal.binding.spi.AdapterBuilder;
import org.opendaylight.controller.md.sal.dom.api.DOMService;
-@Deprecated
+@Deprecated(forRemoval = true)
abstract class BindingDOMAdapterBuilder<T extends BindingService> extends AdapterBuilder<T, DOMService> {
interface Factory<T extends BindingService> {
import org.opendaylight.controller.md.sal.dom.api.DOMService;
import org.opendaylight.controller.sal.binding.api.RpcConsumerRegistry;
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class BindingDOMAdapterLoader extends AdapterLoader<BindingService, DOMService> {
private static final Map<Class<?>, BindingDOMAdapterBuilder.Factory<?>> FACTORIES =
ImmutableMap.<Class<?>, BindingDOMAdapterBuilder.Factory<?>>builder()
* Besides this the DataBrokerImpl and it's collaborators also cache data that
* is already transformed from the binding independent to binding aware format
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class BindingDOMDataBrokerAdapter extends AbstractForwardedDataBroker
implements DataBroker, DataTreeChangeService {
static final Factory<DataBroker> BUILDER_FACTORY = Builder::new;
* to their Binding equivalent.
*
*/
-@Deprecated
+@Deprecated(forRemoval = true)
class BindingDOMDataTreeChangeListenerAdapter<T extends DataObject> implements DOMDataTreeChangeListener {
private final BindingToNormalizedNodeCodec codec;
private final DataTreeChangeListener<T> listener;
* Each registered {@link DataTreeChangeListener} is wrapped using
* adapter and registered directly to DOM service.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
final class BindingDOMDataTreeChangeServiceAdapter implements DataTreeChangeService {
private final BindingToNormalizedNodeCodec codec;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
-@Deprecated
+@Deprecated(forRemoval = true)
final class BindingDOMMountPointListenerAdapter<T extends MountPointListener>
implements ListenerRegistration<T>, DOMMountPointListener {
private static final Logger LOG = LoggerFactory.getLogger(BindingDOMMountPointListenerAdapter.class);
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
-@Deprecated
+@Deprecated(forRemoval = true)
public class BindingDOMMountPointServiceAdapter implements MountPointService {
private static final Logger LOG = LoggerFactory.getLogger(BindingDOMMountPointServiceAdapter.class);
import org.opendaylight.yangtools.yang.common.QName;
import org.opendaylight.yangtools.yang.model.api.SchemaPath;
-@Deprecated
+@Deprecated(forRemoval = true)
class BindingDOMNotificationListenerAdapter implements DOMNotificationListener {
private final BindingNormalizedNodeSerializer codec;
import org.opendaylight.controller.md.sal.dom.api.DOMService;
import org.opendaylight.yangtools.yang.binding.Notification;
-@Deprecated
+@Deprecated(forRemoval = true)
public class BindingDOMNotificationPublishServiceAdapter implements NotificationPublishService, AutoCloseable {
static final Factory<NotificationPublishService> BUILDER_FACTORY = Builder::new;
import org.opendaylight.yangtools.concepts.ListenerRegistration;
import org.opendaylight.yangtools.yang.binding.NotificationListener;
-@Deprecated
+@Deprecated(forRemoval = true)
public class BindingDOMNotificationServiceAdapter implements NotificationService, AutoCloseable {
public static final Factory<NotificationService> BUILDER_FACTORY = Builder::new;
import org.opendaylight.yangtools.yang.binding.DataObject;
import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
-@Deprecated
+@Deprecated(forRemoval = true)
class BindingDOMReadTransactionAdapter extends AbstractForwardedTransaction<DOMDataReadOnlyTransaction> implements
ReadOnlyTransaction {
import org.opendaylight.yangtools.yang.binding.DataObject;
import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
-@Deprecated
+@Deprecated(forRemoval = true)
class BindingDOMReadWriteTransactionAdapter extends
BindingDOMWriteTransactionAdapter<DOMDataReadWriteTransaction> implements ReadWriteTransaction {
import org.opendaylight.yangtools.concepts.AbstractObjectRegistration;
import org.opendaylight.yangtools.yang.binding.RpcService;
-@Deprecated
+@Deprecated(forRemoval = true)
class BindingDOMRpcAdapterRegistration<T extends RpcService> extends AbstractObjectRegistration<T> {
private final DOMRpcImplementationRegistration<?> reg;
import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
import org.opendaylight.yangtools.yang.model.api.SchemaPath;
-@Deprecated
+@Deprecated(forRemoval = true)
public class BindingDOMRpcImplementationAdapter implements DOMRpcImplementation {
private static final Cache<Class<?>, RpcServiceInvoker> SERVICE_INVOKERS =
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
import org.opendaylight.yangtools.yang.model.api.SchemaPath;
-@Deprecated
+@Deprecated(forRemoval = true)
public class BindingDOMRpcProviderServiceAdapter {
private static final Set<YangInstanceIdentifier> GLOBAL = ImmutableSet.of(YangInstanceIdentifier.empty());
import org.opendaylight.mdsal.binding.spec.reflect.BindingReflections;
import org.opendaylight.yangtools.yang.binding.RpcService;
-@Deprecated
+@Deprecated(forRemoval = true)
public class BindingDOMRpcServiceAdapter implements RpcConsumerRegistry {
protected static final Factory<RpcConsumerRegistry> BUILDER_FACTORY = Builder::new;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
-@Deprecated
+@Deprecated(forRemoval = true)
final class BindingDOMTransactionChainAdapter implements BindingTransactionChain, Delegator<DOMTransactionChain> {
private static final Logger LOG = LoggerFactory.getLogger(BindingDOMTransactionChainAdapter.class);
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier.PathArgument;
-@Deprecated
+@Deprecated(forRemoval = true)
class BindingDOMWriteTransactionAdapter<T extends DOMDataWriteTransaction> extends
AbstractWriteTransaction<T> implements WriteTransaction {
import org.opendaylight.yangtools.concepts.AbstractListenerRegistration;
import org.opendaylight.yangtools.concepts.ListenerRegistration;
-@Deprecated
+@Deprecated(forRemoval = true)
class BindingDataTreeChangeListenerRegistration<L extends DataTreeChangeListener<?>>
extends AbstractListenerRegistration<L> {
import org.opendaylight.controller.md.sal.dom.api.DOMService;
import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
-@Deprecated
+@Deprecated(forRemoval = true)
public class BindingMountPointAdapter implements MountPoint {
private final InstanceIdentifier<?> identifier;
import org.opendaylight.yangtools.concepts.AbstractObjectRegistration;
import org.opendaylight.yangtools.yang.binding.RpcService;
-@Deprecated
+@Deprecated(forRemoval = true)
class BindingRpcAdapterRegistration<T extends RpcService> extends AbstractObjectRegistration<T> {
private final DOMRpcImplementationRegistration<?> reg;
import org.opendaylight.controller.md.sal.dom.api.DOMDataBroker;
@Beta
-@Deprecated
+@Deprecated(forRemoval = true)
@NonNullByDefault
public final class BindingToDOMAdapterFactory implements AdapterFactory {
private final BindingToNormalizedNodeCodec codec;
import org.opendaylight.yangtools.yang.model.api.RpcDefinition;
import org.opendaylight.yangtools.yang.model.api.SchemaContext;
-@Deprecated
+@Deprecated(forRemoval = true)
@SuppressFBWarnings(value = "NM_SAME_SIMPLE_NAME_AS_SUPERCLASS", justification = "Migration path")
public class BindingToNormalizedNodeCodec
extends org.opendaylight.mdsal.binding.dom.adapter.BindingToNormalizedNodeCodec {
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
-@Deprecated
+@Deprecated(forRemoval = true)
abstract class ContextReferenceExtractor {
private static final Logger LOG = LoggerFactory.getLogger(ContextReferenceExtractor.class);
private static final ContextReferenceExtractor NULL_EXTRACTOR = new ContextReferenceExtractor() {
import org.opendaylight.yangtools.yang.binding.DataObject;
import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
-@Deprecated
+@Deprecated(forRemoval = true)
final class ControllerActionProviderServiceAdapter implements ActionProviderService {
private static final class Builder extends BindingDOMAdapterBuilder<ActionProviderService> {
@Override
import org.opendaylight.yangtools.yang.binding.Action;
import org.opendaylight.yangtools.yang.binding.DataObject;
-@Deprecated
+@Deprecated(forRemoval = true)
final class ControllerActionServiceAdapter implements ActionService {
private static final class Builder extends BindingDOMAdapterBuilder<ActionService> {
@Override
import org.opendaylight.yangtools.yang.binding.DataObject;
import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
-@Deprecated
+@Deprecated(forRemoval = true)
final class DirectGetterRouteContextExtractor extends ContextReferenceExtractor {
private static final Lookup PUBLIC_LOOKUP = MethodHandles.publicLookup();
import org.opendaylight.yangtools.yang.binding.DataObject;
import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
-@Deprecated
+@Deprecated(forRemoval = true)
final class GetValueRouteContextExtractor extends ContextReferenceExtractor {
private static final Lookup PUBLIC_LOOKUP = MethodHandles.publicLookup();
import org.opendaylight.yangtools.yang.common.RpcResult;
import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
-@Deprecated
+@Deprecated(forRemoval = true)
final class LazyDOMRpcResultFuture implements CheckedFuture<DOMRpcResult, DOMRpcException>, BindingRpcFutureAware {
private final ListenableFuture<RpcResult<?>> bindingFuture;
*
* @param <T> Type of Binding Data Object
*/
-@Deprecated
+@Deprecated(forRemoval = true)
final class LazyDataObjectModification<T extends DataObject> implements DataObjectModification<T> {
private static final Logger LOG = LoggerFactory.getLogger(LazyDataObjectModification.class);
* which are directly accessed by user of data object modification.
*
*/
-@Deprecated
+@Deprecated(forRemoval = true)
class LazyDataTreeModification<T extends DataObject> implements DataTreeModification<T> {
private final DataTreeIdentifier<T> path;
import org.opendaylight.yangtools.yang.model.api.SchemaPath;
// FIXME: Should be this moved to binding-data-codec?
-@Deprecated
+@Deprecated(forRemoval = true)
class LazySerializedContainerNode implements ContainerNode, BindingDataAware {
private final NodeIdentifier identifier;
* of notification actually accessed data from notification.
*
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public final class LazySerializedDOMNotification implements DOMNotification {
private final BindingNormalizedNodeSerializer codec;
import org.opendaylight.yangtools.yang.model.api.RpcDefinition;
import org.opendaylight.yangtools.yang.model.api.SchemaPath;
-@Deprecated
+@Deprecated(forRemoval = true)
class RpcServiceAdapter implements InvocationHandler {
private final ImmutableMap<Method, RpcInvocationStrategy> rpcNames;
import java.util.Set;
import org.opendaylight.yangtools.concepts.Builder;
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class AdapterBuilder<T,D> implements Builder<T> {
private final ClassToInstanceMap<D> delegates = MutableClassToInstanceMap.create();
import org.opendaylight.controller.md.sal.dom.api.DOMDataBroker;
@Beta
-@Deprecated
+@Deprecated(forRemoval = true)
@NonNullByDefault
public interface AdapterFactory {
/**
import org.eclipse.jdt.annotation.Nullable;
import org.gaul.modernizer_maven_annotations.SuppressModernizer;
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class AdapterLoader<T, D> extends CacheLoader<Class<? extends T>, Optional<T>> {
@Override
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
-@Deprecated
+@Deprecated(forRemoval = true)
public class RootBindingAwareBroker implements Mutable, Identifiable<String>, BindingAwareBroker, AutoCloseable,
RpcProviderRegistry {
*
* @deprecated Use config-it and/or mdsal-it instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public final class TestHelper {
public static final String CONTROLLER = "org.opendaylight.controller";
import org.opendaylight.yangtools.yang.binding.Notification;
import org.opendaylight.yangtools.yang.binding.RpcService;
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class AbstractBindingSalConsumerInstance<N extends NotificationService, R extends RpcConsumerRegistry>
implements RpcConsumerRegistry, NotificationService {
import org.opendaylight.yangtools.yang.binding.Notification;
import org.opendaylight.yangtools.yang.binding.RpcService;
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class AbstractBindingSalProviderInstance<N extends NotificationProviderService,
R extends RpcProviderRegistry>
extends AbstractBindingSalConsumerInstance<N, R>
import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
import org.opendaylight.yangtools.yang.binding.RpcService;
-@Deprecated
+@Deprecated(forRemoval = true)
public final class BindingContextUtils {
private BindingContextUtils() {
}
* @deprecated Use {@link org.opendaylight.controller.md.sal.binding.api.ReadTransaction#read(
* org.opendaylight.controller.md.sal.common.api.data.LogicalDatastoreType, InstanceIdentifier)} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public final class TypeSafeDataReader {
private final DataReader<InstanceIdentifier<? extends DataObject>, DataObject> delegate;
*
* @deprecated Use {@link AbstractNormalizedNodePruner} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class NormalizedNodePruner extends AbstractNormalizedNodePruner {
public static final URI BASE_NAMESPACE = URI.create("urn:ietf:params:xml:ns:netconf:base:1.0");
* @param <V> The result type returned by this Future's get method
* @param <X> The checked exception type
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public final class MappingCheckedFuture<V, X extends Exception> extends AbstractCheckedFuture<V, X> {
private final Function<Exception, X> mapper;
import java.util.EventListener;
import org.opendaylight.yangtools.concepts.Registration;
-@Deprecated
+@Deprecated(forRemoval = true)
public interface RegistrationListener<T extends Registration> extends EventListener {
void onRegister(T registration);
* @param <D>
* Type of data (payload), which represents data payload
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface AsyncConfigurationCommitCohort<P extends Path<P>, D> {
/**
* @param <D>
* Type of data (payload), which represents data payload
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface AsyncConfigurationCommitCoordinator<P extends Path<P>, D> {
/**
* Register configuration commit handler for particular subtree. Configuration commit handler is invoked for all
* @param <D>
* Type of data (payload), which represents data payload
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface AsyncConfigurationCommitHandler<P extends Path<P>, D> {
/**
* @param <D>
* Type of data (payload), which represents data payload
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface AsyncDataBroker<P extends Path<P>, D> extends AsyncDataTransactionFactory<P, D> {
@Override
* @param <D>
* Type of data (payload), which represents data payload
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface AsyncDataTransactionFactory<P extends Path<P>, D> {
/**
* @param <D>
* Type of data (payload), which represents data payload
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface AsyncReadOnlyTransaction<P extends Path<P>, D> extends AsyncReadTransaction<P, D>, AutoCloseable {
/**
* @param <D>
* Type of data (payload), which represents data payload
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface AsyncReadTransaction<P extends Path<P>, D> extends AsyncTransaction<P, D> {
}
* @param <D>
* Type of data (payload), which represents data payload
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface AsyncReadWriteTransaction<P extends Path<P>, D> extends AsyncReadTransaction<P, D>,
AsyncWriteTransaction<P, D> {
* @param <P> Type of path (subtree identifier), which represents location in tree
* @param <D> Type of data (payload), which represents data payload
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface AsyncTransaction<P extends Path<P>,D> extends //
Identifiable<Object> {
* @param <D>
* Type of data (payload), which represents data payload
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface AsyncWriteTransaction<P extends Path<P>, D> extends AsyncTransaction<P, D> {
/**
* Cancels the transaction.
* @param <D> Data Type
* @deprecated Replaced by org.opendaylight.controller.sal.core.spi.data.DOMStore contract.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DataReader<P extends Path<P>, D> {
/**
*
* @deprecated Use {@link org.opendaylight.mdsal.common.api.DataStoreUnavailableException} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class DataStoreUnavailableException extends Exception {
private static final long serialVersionUID = 1L;
*
* @deprecated Use {@link org.opendaylight.mdsal.common.api.DataValidationFailedException} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class DataValidationFailedException extends TransactionCommitFailedException {
private static final long serialVersionUID = 1L;
import org.eclipse.jdt.annotation.NonNullByDefault;
-@Deprecated
+@Deprecated(forRemoval = true)
@NonNullByDefault
public enum LogicalDatastoreType {
/**
*
* @deprecated Use {@link org.opendaylight.mdsal.common.api.OptimisticLockFailedException} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class OptimisticLockFailedException extends TransactionCommitFailedException {
private static final long serialVersionUID = 1L;
*
* @deprecated Use {@link org.opendaylight.mdsal.common.api.ReadFailedException} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class ReadFailedException extends OperationFailedException {
private static final long serialVersionUID = 1L;
* and leads to expected behavior: t2 will always see the data written in t1
* present.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface TransactionChain<P extends Path<P>, D> extends AutoCloseable, AsyncDataTransactionFactory<P, D> {
/**
/**
* Exception thrown when an attempt is made to open a new transaction in a closed chain.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public final class TransactionChainClosedException extends IllegalStateException {
private static final long serialVersionUID = 1L;
/**
* Interface for creating transaction chains.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface TransactionChainFactory<P extends Path<P>, D> {
/**
/**
* Listener for transaction chain events.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface TransactionChainListener extends EventListener {
/**
* Invoked if when a transaction in the chain fails. All other transactions are automatically cancelled by the time
*
* @deprecated Use {@link org.opendaylight.mdsal.common.api.TransactionCommitDeadlockException} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class TransactionCommitDeadlockException extends TransactionCommitFailedException {
private static final long serialVersionUID = 1L;
private static final String DEADLOCK_MESSAGE =
*
* @deprecated Use {@link org.opendaylight.mdsal.common.api.TransactionCommitFailedException} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class TransactionCommitFailedException extends OperationFailedException {
private static final long serialVersionUID = 1L;
*
* @param <N> the type of notifications
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface NotificationPublishService<N> {
/**
import java.util.EventListener;
import org.opendaylight.yangtools.concepts.ListenerRegistration;
-@Deprecated
+@Deprecated(forRemoval = true)
public interface NotificationSubscriptionService<T, N, L extends EventListener> {
ListenerRegistration<L> registerNotificationListener(T type, L listener);
* @param <C> Type, which is used to represent Routing context.
* @param <P> Type of data tree path, which is used to identify route.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface RouteChange<C, P> {
/**
* @param <C> Type, which is used to represent Routing context.
* @param <P> Type of data tree path, which is used to identify route.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface RouteChangeListener<C, P> extends EventListener {
/**
* @param <C> Type, which is used to represent Routing context.
* @param <P> Type of data tree path, which is used to identify route.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface RouteChangePublisher<C,P> {
<L extends RouteChangeListener<C,P>> ListenerRegistration<L> registerRouteChangeListener(L listener);
* @param <P> the path identifier type
* @param <S> the RPC implementation type
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface RoutedRegistration<C, P extends Path<P>, S> extends Registration {
/**
import java.util.Map;
import org.opendaylight.yangtools.concepts.Path;
-@Deprecated
+@Deprecated(forRemoval = true)
public interface RoutingTable<C, P extends Path<P>, T> {
C getIdentifier();
*/
package org.opendaylight.controller.md.sal.common.impl.util.compat;
-@Deprecated
+@Deprecated(forRemoval = true)
public class DataNormalizationException extends Exception {
private static final long serialVersionUID = 1L;
import org.opendaylight.yangtools.yang.model.api.SchemaNode;
import org.opendaylight.yangtools.yang.model.util.EffectiveAugmentationSchema;
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class DataNormalizationOperation<T extends PathArgument> implements Identifiable<T> {
private final T identifier;
* @deprecated This class provides compatibility between XML semantics
* and {@link org.opendaylight.yangtools.yang.data.util.DataSchemaContextTree}
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class DataNormalizer {
private final DataNormalizationOperation<?> operation;
import org.opendaylight.yangtools.yang.model.api.TypeDefinition;
import org.opendaylight.yangtools.yang.model.api.UsesNode;
-@Deprecated
+@Deprecated(forRemoval = true)
class DataSchemaContainerProxy implements DataNodeContainer {
private final Set<DataSchemaNode> realChildSchemas;
*
* @author Thomas Pantelis
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class LegacyDOMStoreAdapter extends ForwardingObject implements DOMStore, AutoCloseable {
private final DistributedDataStoreInterface delegate;
*
* @deprecated Use {@link org.opendaylight.controller.cluster.datastore.persisted.ShardManagerSnapshot} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public final class ShardManagerSnapshot implements Serializable {
private static final long serialVersionUID = 1L;
private final List<String> shardList;
* @author Thomas Pantelis
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.ClusteredDOMDataTreeChangeListener} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface ClusteredDOMDataTreeChangeListener extends DOMDataTreeChangeListener {
}
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMActionProviderService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
@SuppressFBWarnings(value = "NM_SAME_SIMPLE_NAME_AS_INTERFACE", justification = "Migration")
public interface DOMActionProviderService extends DOMService, org.opendaylight.mdsal.dom.api.DOMActionProviderService {
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMActionService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
@SuppressFBWarnings(value = "NM_SAME_SIMPLE_NAME_AS_INTERFACE", justification = "Migration")
public interface DOMActionService extends DOMService, org.opendaylight.mdsal.dom.api.DOMActionService {
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMDataBroker} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMDataBroker extends
AsyncDataBroker<YangInstanceIdentifier, NormalizedNode<?, ?>>,
TransactionChainFactory<YangInstanceIdentifier, NormalizedNode<?, ?>>,
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMDataBrokerExtension} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMDataBrokerExtension extends DOMServiceExtension<DOMDataBroker, DOMDataBrokerExtension> {
}
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMDataReadOnlyTransaction extends DOMDataReadTransaction,
AsyncReadOnlyTransaction<YangInstanceIdentifier, NormalizedNode<?, ?>> {
}
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMDataTreeReadTransaction} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMDataReadTransaction extends AsyncReadTransaction<YangInstanceIdentifier, NormalizedNode<?, ?>> {
/**
* Reads data from provided logical data store located at the provided path.
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMDataReadWriteTransaction extends DOMDataReadTransaction, DOMDataWriteTransaction,
AsyncReadWriteTransaction<YangInstanceIdentifier, NormalizedNode<?, ?>> {
}
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMDataTreeChangeListener} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMDataTreeChangeListener extends EventListener {
/**
* Invoked when there was data change for the supplied path, which was used
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMDataTreeChangeService} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMDataTreeChangeService extends DOMDataBrokerExtension {
/**
* Registers a {@link DOMDataTreeChangeListener} to receive
* @author Thomas Pantelis
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMDataTreeCommitCohortRegistry} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
@SuppressFBWarnings("NM_SAME_SIMPLE_NAME_AS_INTERFACE")
public interface DOMDataTreeCommitCohortRegistry extends DOMDataBrokerExtension,
org.opendaylight.mdsal.dom.api.DOMDataTreeCommitCohortRegistry {
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMDataTreeIdentifier} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public final class DOMDataTreeIdentifier implements Immutable,
Path<DOMDataTreeIdentifier>, Serializable, Comparable<DOMDataTreeIdentifier> {
private static final long serialVersionUID = 1L;
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMDataTreeWriteTransaction} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMDataWriteTransaction extends AsyncWriteTransaction<YangInstanceIdentifier, NormalizedNode<?, ?>> {
@Override
* Generic event interface.
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMEvent} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
@SuppressFBWarnings(value = "NM_SAME_SIMPLE_NAME_AS_INTERFACE", justification = "Migration")
public interface DOMEvent extends org.opendaylight.mdsal.dom.api.DOMEvent {
* @param <E> Extension type
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMExtensibleService} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
@Beta
public interface DOMExtensibleService<T extends DOMExtensibleService<T, E>,
E extends DOMServiceExtension<T, E>> extends DOMService {
import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier;
import org.opendaylight.yangtools.yang.model.api.SchemaContext;
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMMountPoint extends Identifiable<YangInstanceIdentifier> {
<T extends DOMService> Optional<T> getService(Class<T> cls);
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMMountPointService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMMountPointService extends DOMService {
Optional<DOMMountPoint> getMountPoint(YangInstanceIdentifier path);
* A single YANG notification.
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMNotification} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
@SuppressFBWarnings(value = "NM_SAME_SIMPLE_NAME_AS_INTERFACE", justification = "Migration")
public interface DOMNotification extends org.opendaylight.mdsal.dom.api.DOMNotification {
}
* Interface implemented by listeners interested in {@link DOMNotification}s.
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMNotificationListener} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMNotificationListener extends EventListener {
/**
* Invoked whenever a {@link DOMNotification} matching the subscription
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMNotificationPublishService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMNotificationPublishService extends DOMService {
/**
* Well-known value indicating that the implementation is currently not
* Expected use: {@link DOMNotificationPublishService}
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMNotificationRejectedException} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class DOMNotificationRejectedException extends Exception {
private static final long serialVersionUID = 1L;
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMNotificationService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMNotificationService extends DOMService {
/**
* Register a {@link DOMNotificationListener} to receive a set of notifications. As with
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMRpcAvailabilityListener} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMRpcAvailabilityListener extends EventListener {
/**
* Method invoked whenever an RPC type becomes available.
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMRpcException} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
@SuppressFBWarnings(value = "NM_SAME_SIMPLE_NAME_AS_SUPERCLASS", justification = "Migration")
public abstract class DOMRpcException extends org.opendaylight.mdsal.dom.api.DOMRpcException {
private static final long serialVersionUID = 1L;
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMRpcIdentifier} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class DOMRpcIdentifier {
private static final class Global extends DOMRpcIdentifier {
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMRpcImplementation} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMRpcImplementation {
/**
* Initiate invocation of the RPC. Implementations of this method are
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMRpcImplementationNotAvailableException} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class DOMRpcImplementationNotAvailableException extends DOMRpcException {
private static final long serialVersionUID = 1L;
* @param <T> RPC implementation type
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMRpcImplementationRegistration} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMRpcImplementationRegistration<T extends DOMRpcImplementation> extends ObjectRegistration<T> {
@Override
void close();
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMRpcProviderService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMRpcProviderService extends DOMService {
/**
* Register an {@link DOMRpcImplementation} object with this service.
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMRpcResult} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
@SuppressFBWarnings(value = "NM_SAME_SIMPLE_NAME_AS_INTERFACE", justification = "Migration")
public interface DOMRpcResult extends org.opendaylight.mdsal.dom.api.DOMRpcResult {
}
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMRpcService} instead
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMRpcService extends DOMService {
/**
* Initiate invocation of an RPC. This method is guaranteed to not block on any external
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMService} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
@SuppressFBWarnings(value = "NM_SAME_SIMPLE_NAME_AS_INTERFACE", justification = "Migration")
public interface DOMService extends org.opendaylight.mdsal.dom.api.DOMService {
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMServiceExtension} instead.
*/
@Beta
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMServiceExtension<T extends DOMExtensibleService<T, E>, E extends DOMServiceExtension<T, E>> {
}
*
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DOMTransactionChain} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public interface DOMTransactionChain extends TransactionChain<YangInstanceIdentifier, NormalizedNode<?, ?>> {
@Override
* @author Thomas Pantelis
* @deprecated Use {@link org.opendaylight.mdsal.dom.api.DefaultDOMRpcException} instead.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
public class DefaultDOMRpcException extends DOMRpcException {
private static final long serialVersionUID = 1L;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
-@Deprecated
+@Deprecated(forRemoval = true)
public abstract class AbstractDOMDataBroker extends AbstractDOMForwardedTransactionFactory<DOMStore>
implements DOMDataBroker {
private static final Logger LOG = LoggerFactory.getLogger(AbstractDOMDataBroker.class);
* @param <T>
* Subtransaction type
*/
-@Deprecated
+@Deprecated(forRemoval = true)
abstract class AbstractDOMForwardedCompositeTransaction<K, T extends DOMStoreTransaction> implements
AsyncTransaction<YangInstanceIdentifier, NormalizedNode<?, ?>> {
* @param <T>
* Type of {@link DOMStoreTransactionFactory} factory.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
abstract class AbstractDOMForwardedTransactionFactory<T extends DOMStoreTransactionFactory> implements AutoCloseable {
@SuppressWarnings("rawtypes")
private static final AtomicIntegerFieldUpdater<AbstractDOMForwardedTransactionFactory> UPDATER =
import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode;
import org.opendaylight.yangtools.yang.model.api.SchemaPath;
-@Deprecated
+@Deprecated(forRemoval = true)
abstract class AbstractDOMRpcRoutingTableEntry {
private final Map<YangInstanceIdentifier, List<DOMRpcImplementation>> implementations;
private final SchemaPath schemaPath;
* Implementation of blocking three-phase commit-coordination tasks without
* support of cancellation.
*/
-@Deprecated
+@Deprecated(forRemoval = true)
final class CommitCoordinationTask<T> implements Callable<T> {
private enum Phase {
canCommit,