Remove AbstractNetconfTopology.createSalFacade()
[netconf.git] / netconf / netconf-topology / src / main / java / org / opendaylight / netconf / topology / spi / AbstractNetconfTopology.java
index fd31e9a7589a459f1043734af752c7f7da5ccd5f..ccd258ccf0aca0d9aab6a637f7e7f4d5362a18b1 100644 (file)
@@ -11,31 +11,26 @@ import static java.util.Objects.requireNonNull;
 
 import com.google.common.annotations.VisibleForTesting;
 import com.google.common.base.Preconditions;
-import com.google.common.base.Strings;
 import com.google.common.collect.Lists;
 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.ListeningExecutorService;
 import com.google.common.util.concurrent.MoreExecutors;
-import com.google.common.util.concurrent.Uninterruptibles;
 import io.netty.util.concurrent.EventExecutor;
-import java.io.File;
-import java.math.BigDecimal;
-import java.net.InetSocketAddress;
 import java.net.URL;
 import java.util.ArrayList;
 import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
 import java.util.Optional;
-import java.util.concurrent.TimeUnit;
+import java.util.concurrent.ExecutionException;
 import org.opendaylight.aaa.encrypt.AAAEncryptionService;
 import org.opendaylight.controller.config.threadpool.ScheduledThreadPool;
 import org.opendaylight.controller.config.threadpool.ThreadPool;
 import org.opendaylight.mdsal.binding.api.DataBroker;
+import org.opendaylight.mdsal.common.api.LogicalDatastoreType;
 import org.opendaylight.mdsal.dom.api.DOMMountPointService;
-import org.opendaylight.netconf.api.NetconfMessage;
 import org.opendaylight.netconf.client.NetconfClientDispatcher;
 import org.opendaylight.netconf.client.NetconfClientSessionListener;
 import org.opendaylight.netconf.client.conf.NetconfClientConfiguration;
@@ -48,25 +43,24 @@ import org.opendaylight.netconf.nettyutil.handler.ssh.authentication.LoginPasswo
 import org.opendaylight.netconf.sal.connect.api.DeviceActionFactory;
 import org.opendaylight.netconf.sal.connect.api.RemoteDevice;
 import org.opendaylight.netconf.sal.connect.api.RemoteDeviceHandler;
+import org.opendaylight.netconf.sal.connect.api.SchemaResourceManager;
 import org.opendaylight.netconf.sal.connect.netconf.LibraryModulesSchemas;
-import org.opendaylight.netconf.sal.connect.netconf.NetconfDevice;
+import org.opendaylight.netconf.sal.connect.netconf.NetconfDevice.SchemaResourcesDTO;
 import org.opendaylight.netconf.sal.connect.netconf.NetconfDeviceBuilder;
-import org.opendaylight.netconf.sal.connect.netconf.NetconfStateSchemasResolverImpl;
 import org.opendaylight.netconf.sal.connect.netconf.SchemalessNetconfDevice;
 import org.opendaylight.netconf.sal.connect.netconf.auth.DatastoreBackedPublicKeyAuth;
-import org.opendaylight.netconf.sal.connect.netconf.listener.NetconfDeviceCapabilities;
 import org.opendaylight.netconf.sal.connect.netconf.listener.NetconfDeviceCommunicator;
 import org.opendaylight.netconf.sal.connect.netconf.listener.NetconfSessionPreferences;
 import org.opendaylight.netconf.sal.connect.netconf.listener.UserPreferences;
 import org.opendaylight.netconf.sal.connect.netconf.sal.KeepaliveSalFacade;
+import org.opendaylight.netconf.sal.connect.netconf.sal.NetconfDeviceSalFacade;
 import org.opendaylight.netconf.sal.connect.netconf.sal.NetconfKeystoreAdapter;
 import org.opendaylight.netconf.sal.connect.netconf.schema.YangLibrarySchemaYangSourceProvider;
+import org.opendaylight.netconf.sal.connect.netconf.schema.mapping.BaseNetconfSchemas;
 import org.opendaylight.netconf.sal.connect.util.RemoteDeviceId;
 import org.opendaylight.netconf.sal.connect.util.SslHandlerFactoryImpl;
 import org.opendaylight.netconf.topology.api.NetconfTopology;
-import org.opendaylight.netconf.topology.api.SchemaRepositoryProvider;
-import org.opendaylight.yang.gen.v1.urn.ietf.params.xml.ns.yang.ietf.inet.types.rev130715.Host;
-import org.opendaylight.yang.gen.v1.urn.ietf.params.xml.ns.yang.ietf.inet.types.rev130715.IpAddress;
+import org.opendaylight.yang.gen.v1.urn.ietf.params.xml.ns.yang.ietf.inet.types.rev130715.Uri;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.optional.rev190614.NetconfNodeAugmentedOptional;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.topology.rev150114.NetconfNode;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.topology.rev150114.netconf.node.connection.parameters.Protocol;
@@ -79,136 +73,39 @@ import org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.topology.rev15
 import org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.topology.rev150114.netconf.node.credentials.credentials.key.auth.KeyBased;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.topology.rev150114.netconf.node.credentials.credentials.login.pw.LoginPassword;
 import org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.topology.rev150114.netconf.node.credentials.credentials.login.pw.unencrypted.LoginPasswordUnencrypted;
+import org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.topology.rev150114.netconf.schema.storage.YangLibrary;
+import org.opendaylight.yang.gen.v1.urn.tbd.params.xml.ns.yang.network.topology.rev131021.NetworkTopology;
 import org.opendaylight.yang.gen.v1.urn.tbd.params.xml.ns.yang.network.topology.rev131021.NodeId;
+import org.opendaylight.yang.gen.v1.urn.tbd.params.xml.ns.yang.network.topology.rev131021.TopologyId;
+import org.opendaylight.yang.gen.v1.urn.tbd.params.xml.ns.yang.network.topology.rev131021.network.topology.Topology;
+import org.opendaylight.yang.gen.v1.urn.tbd.params.xml.ns.yang.network.topology.rev131021.network.topology.TopologyBuilder;
+import org.opendaylight.yang.gen.v1.urn.tbd.params.xml.ns.yang.network.topology.rev131021.network.topology.TopologyKey;
 import org.opendaylight.yang.gen.v1.urn.tbd.params.xml.ns.yang.network.topology.rev131021.network.topology.topology.Node;
-import org.opendaylight.yangtools.yang.model.repo.api.EffectiveModelContextFactory;
-import org.opendaylight.yangtools.yang.model.repo.api.SchemaContextFactory;
-import org.opendaylight.yangtools.yang.model.repo.api.SchemaContextFactoryConfiguration;
-import org.opendaylight.yangtools.yang.model.repo.api.SchemaRepository;
+import org.opendaylight.yangtools.yang.binding.InstanceIdentifier;
+import org.opendaylight.yangtools.yang.common.Empty;
 import org.opendaylight.yangtools.yang.model.repo.api.SourceIdentifier;
 import org.opendaylight.yangtools.yang.model.repo.api.YangTextSchemaSource;
 import org.opendaylight.yangtools.yang.model.repo.spi.PotentialSchemaSource;
 import org.opendaylight.yangtools.yang.model.repo.spi.SchemaSourceRegistration;
 import org.opendaylight.yangtools.yang.model.repo.spi.SchemaSourceRegistry;
-import org.opendaylight.yangtools.yang.model.repo.util.FilesystemSchemaSourceCache;
-import org.opendaylight.yangtools.yang.model.repo.util.InMemorySchemaSourceCache;
-import org.opendaylight.yangtools.yang.parser.repo.SharedSchemaRepository;
-import org.opendaylight.yangtools.yang.parser.rfc7950.repo.ASTSchemaSource;
-import org.opendaylight.yangtools.yang.parser.rfc7950.repo.TextToASTTransformer;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 public abstract class AbstractNetconfTopology implements NetconfTopology {
-
     private static final Logger LOG = LoggerFactory.getLogger(AbstractNetconfTopology.class);
 
-    protected static final long DEFAULT_REQUEST_TIMEOUT_MILLIS = 60000L;
-    protected static final int DEFAULT_KEEPALIVE_DELAY = 0;
-    protected static final boolean DEFAULT_RECONNECT_ON_CHANGED_SCHEMA = false;
-    protected static final int DEFAULT_CONCURRENT_RPC_LIMIT = 0;
-    private static final boolean DEFAULT_IS_TCP_ONLY = false;
-    private static final int DEFAULT_MAX_CONNECTION_ATTEMPTS = 0;
-    private static final int DEFAULT_BETWEEN_ATTEMPTS_TIMEOUT_MILLIS = 2000;
-    private static final long DEFAULT_CONNECTION_TIMEOUT_MILLIS = 20000L;
-    private static final BigDecimal DEFAULT_SLEEP_FACTOR = new BigDecimal(1.5);
-
-    // constants related to Schema Cache(s)
-    /**
-     * Filesystem based caches are stored relative to the cache directory.
-     */
-    private static final String CACHE_DIRECTORY = "cache";
-
-    /**
-     * The default cache directory relative to <code>CACHE_DIRECTORY</code>.
-     */
-    private static final String DEFAULT_CACHE_DIRECTORY = "schema";
-
-    /**
-     * The qualified schema cache directory <code>cache/schema</code>.
-     */
-    private static final String QUALIFIED_DEFAULT_CACHE_DIRECTORY =
-            CACHE_DIRECTORY + File.separator + DEFAULT_CACHE_DIRECTORY;
-
-    /**
-     * The name for the default schema repository.
-     */
-    private static final String DEFAULT_SCHEMA_REPOSITORY_NAME = "sal-netconf-connector";
-
-    /**
-     * The default schema repository in the case that one is not specified.
-     */
-    private static final SharedSchemaRepository DEFAULT_SCHEMA_REPOSITORY =
-            new SharedSchemaRepository(DEFAULT_SCHEMA_REPOSITORY_NAME);
-
-    public static final InMemorySchemaSourceCache<ASTSchemaSource> DEFAULT_AST_CACHE =
-            InMemorySchemaSourceCache.createSoftCache(DEFAULT_SCHEMA_REPOSITORY, ASTSchemaSource.class);
-
-    /**
-     * The default factory for creating <code>SchemaContext</code> instances.
-     */
-    private static final EffectiveModelContextFactory DEFAULT_SCHEMA_CONTEXT_FACTORY =
-            DEFAULT_SCHEMA_REPOSITORY.createEffectiveModelContextFactory(
-                SchemaContextFactoryConfiguration.getDefault());
-
-    /**
-     * Keeps track of initialized Schema resources.  A Map is maintained in which the key represents the name
-     * of the schema cache directory, and the value is a corresponding <code>SchemaResourcesDTO</code>.  The
-     * <code>SchemaResourcesDTO</code> is essentially a container that allows for the extraction of the
-     * <code>SchemaRegistry</code> and <code>SchemaContextFactory</code> which should be used for a particular
-     * Netconf mount.  Access to <code>SCHEMA_RESOURCES_DTO_MAP</code> should be surrounded by appropriate
-     * synchronization locks.
-     */
-    private static final Map<String, NetconfDevice.SchemaResourcesDTO> SCHEMA_RESOURCES_DTO_MAP = new HashMap<>();
-
-    // Initializes default constant instances for the case when the default schema repository
-    // directory cache/schema is used.
-    static {
-        SCHEMA_RESOURCES_DTO_MAP.put(DEFAULT_CACHE_DIRECTORY,
-                new NetconfDevice.SchemaResourcesDTO(DEFAULT_SCHEMA_REPOSITORY, DEFAULT_SCHEMA_REPOSITORY,
-                        DEFAULT_SCHEMA_CONTEXT_FACTORY,
-                        new NetconfStateSchemasResolverImpl()));
-        DEFAULT_SCHEMA_REPOSITORY.registerSchemaSourceListener(DEFAULT_AST_CACHE);
-        DEFAULT_SCHEMA_REPOSITORY.registerSchemaSourceListener(
-                TextToASTTransformer.create(DEFAULT_SCHEMA_REPOSITORY, DEFAULT_SCHEMA_REPOSITORY));
-
-        /*
-         * Create the default <code>FilesystemSchemaSourceCache</code>, which stores cached files
-         * in <code>cache/schema</code>. Try up to 3 times - we've seen intermittent failures on jenkins where
-         * FilesystemSchemaSourceCache throws an IAE due to mkdirs failure. The theory is that there's a race
-         * creating the dir and it already exists when mkdirs is called (mkdirs returns false in this case). In this
-         * scenario, a retry should succeed.
-         */
-        int tries = 1;
-        while (true) {
-            try {
-                FilesystemSchemaSourceCache<YangTextSchemaSource> defaultCache =
-                        new FilesystemSchemaSourceCache<>(DEFAULT_SCHEMA_REPOSITORY, YangTextSchemaSource.class,
-                                new File(QUALIFIED_DEFAULT_CACHE_DIRECTORY));
-                DEFAULT_SCHEMA_REPOSITORY.registerSchemaSourceListener(defaultCache);
-                break;
-            } catch (IllegalArgumentException e) {
-                if (tries++ >= 3) {
-                    LOG.error("Error creating default schema cache", e);
-                    break;
-                }
-                Uninterruptibles.sleepUninterruptibly(100, TimeUnit.MILLISECONDS);
-            }
-        }
-    }
-
     private final NetconfClientDispatcher clientDispatcher;
     private final EventExecutor eventExecutor;
     private final DeviceActionFactory deviceActionFactory;
     private final NetconfKeystoreAdapter keystoreAdapter;
+    private final SchemaResourceManager schemaManager;
+    private final BaseNetconfSchemas baseSchemas;
+
     protected final ScheduledThreadPool keepaliveExecutor;
     protected final ListeningExecutorService processingExecutor;
-    protected final SharedSchemaRepository sharedSchemaRepository;
     protected final DataBroker dataBroker;
     protected final DOMMountPointService mountPointService;
     protected final String topologyId;
-    protected SchemaSourceRegistry schemaRegistry = DEFAULT_SCHEMA_REPOSITORY;
-    protected SchemaRepository schemaRepository = DEFAULT_SCHEMA_REPOSITORY;
-    protected SchemaContextFactory schemaContextFactory = DEFAULT_SCHEMA_CONTEXT_FACTORY;
     protected String privateKeyPath;
     protected String privateKeyPassphrase;
     protected final AAAEncryptionService encryptionService;
@@ -216,35 +113,44 @@ public abstract class AbstractNetconfTopology implements NetconfTopology {
 
     protected AbstractNetconfTopology(final String topologyId, final NetconfClientDispatcher clientDispatcher,
                                       final EventExecutor eventExecutor, final ScheduledThreadPool keepaliveExecutor,
-                                      final ThreadPool processingExecutor,
-                                      final SchemaRepositoryProvider schemaRepositoryProvider,
+                                      final ThreadPool processingExecutor, final SchemaResourceManager schemaManager,
                                       final DataBroker dataBroker, final DOMMountPointService mountPointService,
                                       final AAAEncryptionService encryptionService,
-                                      final DeviceActionFactory deviceActionFactory) {
-        this.topologyId = topologyId;
+                                      final DeviceActionFactory deviceActionFactory,
+                                      final BaseNetconfSchemas baseSchemas) {
+        this.topologyId = requireNonNull(topologyId);
         this.clientDispatcher = clientDispatcher;
         this.eventExecutor = eventExecutor;
         this.keepaliveExecutor = keepaliveExecutor;
         this.processingExecutor = MoreExecutors.listeningDecorator(processingExecutor.getExecutor());
+        this.schemaManager = requireNonNull(schemaManager);
         this.deviceActionFactory = deviceActionFactory;
-        this.sharedSchemaRepository = schemaRepositoryProvider.getSharedSchemaRepository();
-        this.dataBroker = dataBroker;
+        this.dataBroker = requireNonNull(dataBroker);
         this.mountPointService = mountPointService;
         this.encryptionService = encryptionService;
+        this.baseSchemas = requireNonNull(baseSchemas);
+
+        keystoreAdapter = new NetconfKeystoreAdapter(dataBroker);
+
+        // FIXME: this should be a put(), as we are initializing and will be re-populating the datastore with all the
+        //        devices. Whatever has been there before should be nuked to properly re-align lifecycle.
+        final var wtx = dataBroker.newWriteOnlyTransaction();
+        wtx.merge(LogicalDatastoreType.OPERATIONAL, InstanceIdentifier.builder(NetworkTopology.class)
+            .child(Topology.class, new TopologyKey(new TopologyId(topologyId)))
+            .build(), new TopologyBuilder().setTopologyId(new TopologyId(topologyId)).build());
+        final var future = wtx.commit();
+        try {
+            future.get();
+        } catch (InterruptedException | ExecutionException e) {
+            LOG.error("Unable to initialize topology {}", topologyId, e);
+            throw new IllegalStateException(e);
+        }
 
-        this.keystoreAdapter = new NetconfKeystoreAdapter(dataBroker);
-    }
-
-    public void setSchemaRegistry(final SchemaSourceRegistry schemaRegistry) {
-        this.schemaRegistry = schemaRegistry;
-    }
-
-    public void setSchemaContextFactory(final SchemaContextFactory schemaContextFactory) {
-        this.schemaContextFactory = schemaContextFactory;
+        LOG.debug("Topology {} initialized", topologyId);
     }
 
     @Override
-    public ListenableFuture<NetconfDeviceCapabilities> connectNode(final NodeId nodeId, final Node configNode) {
+    public ListenableFuture<Empty> connectNode(final NodeId nodeId, final Node configNode) {
         LOG.info("Connecting RemoteDevice{{}} , with config {}", nodeId, hideCredentials(configNode));
         return setupConnection(nodeId, configNode);
     }
@@ -264,22 +170,21 @@ public abstract class AbstractNetconfTopology implements NetconfTopology {
     }
 
     @Override
-    public ListenableFuture<Void> disconnectNode(final NodeId nodeId) {
-        LOG.debug("Disconnecting RemoteDevice{{}}", nodeId.getValue());
-        if (!activeConnectors.containsKey(nodeId)) {
+    public ListenableFuture<Empty> disconnectNode(final NodeId nodeId) {
+        final var nodeName = nodeId.getValue();
+        LOG.debug("Disconnecting RemoteDevice{{}}", nodeName);
+
+        final NetconfConnectorDTO connectorDTO = activeConnectors.remove(nodeId);
+        if (connectorDTO == null) {
             return Futures.immediateFailedFuture(
-                    new IllegalStateException("Unable to disconnect device that is not connected"));
+                new IllegalStateException("Cannot disconnect " + nodeName + " as it is not connected"));
         }
 
-        // retrieve connection, and disconnect it
-        final NetconfConnectorDTO connectorDTO = activeConnectors.remove(nodeId);
-        connectorDTO.getCommunicator().close();
-        connectorDTO.getFacade().close();
-        return Futures.immediateFuture(null);
+        connectorDTO.close();
+        return Futures.immediateFuture(Empty.value());
     }
 
-    protected ListenableFuture<NetconfDeviceCapabilities> setupConnection(final NodeId nodeId,
-                                                                          final Node configNode) {
+    protected ListenableFuture<Empty> setupConnection(final NodeId nodeId, final Node configNode) {
         final NetconfNode netconfNode = configNode.augmentation(NetconfNode.class);
         final NetconfNodeAugmentedOptional nodeOptional = configNode.augmentation(NetconfNodeAugmentedOptional.class);
 
@@ -290,15 +195,15 @@ public abstract class AbstractNetconfTopology implements NetconfTopology {
         final NetconfDeviceCommunicator deviceCommunicator = deviceCommunicatorDTO.getCommunicator();
         final NetconfClientSessionListener netconfClientSessionListener = deviceCommunicatorDTO.getSessionListener();
         final NetconfReconnectingClientConfiguration clientConfig =
-                getClientConfig(netconfClientSessionListener, netconfNode);
-        final ListenableFuture<NetconfDeviceCapabilities> future =
+                getClientConfig(netconfClientSessionListener, netconfNode, nodeId);
+        final ListenableFuture<Empty> future =
                 deviceCommunicator.initializeRemoteConnection(clientDispatcher, clientConfig);
 
         activeConnectors.put(nodeId, deviceCommunicatorDTO);
 
-        Futures.addCallback(future, new FutureCallback<NetconfDeviceCapabilities>() {
+        Futures.addCallback(future, new FutureCallback<>() {
             @Override
-            public void onSuccess(final NetconfDeviceCapabilities result) {
+            public void onSuccess(final Empty result) {
                 LOG.debug("Connector for {} started succesfully", nodeId.getValue());
             }
 
@@ -318,166 +223,95 @@ public abstract class AbstractNetconfTopology implements NetconfTopology {
 
     protected NetconfConnectorDTO createDeviceCommunicator(final NodeId nodeId, final NetconfNode node,
             final NetconfNodeAugmentedOptional nodeOptional) {
-        //setup default values since default value is not supported in mdsal
-        final long defaultRequestTimeoutMillis = node.getDefaultRequestTimeoutMillis() == null
-                ? DEFAULT_REQUEST_TIMEOUT_MILLIS : node.getDefaultRequestTimeoutMillis().toJava();
-        final long keepaliveDelay = node.getKeepaliveDelay() == null
-                ? DEFAULT_KEEPALIVE_DELAY : node.getKeepaliveDelay().toJava();
-        final boolean reconnectOnChangedSchema = node.isReconnectOnChangedSchema() == null
-                ? DEFAULT_RECONNECT_ON_CHANGED_SCHEMA : node.isReconnectOnChangedSchema();
-
-        final IpAddress ipAddress = node.getHost().getIpAddress();
-        final InetSocketAddress address = new InetSocketAddress(ipAddress.getIpv4Address() != null
-                ? ipAddress.getIpv4Address().getValue() : ipAddress.getIpv6Address().getValue(),
-                node.getPort().getValue().toJava());
-        final RemoteDeviceId remoteDeviceId = new RemoteDeviceId(nodeId.getValue(), address);
-
-        RemoteDeviceHandler<NetconfSessionPreferences> salFacade =
-                createSalFacade(remoteDeviceId);
+        final var deviceId = NetconfNodeUtils.toRemoteDeviceId(nodeId, node);
+        final long keepaliveDelay = node.requireKeepaliveDelay().toJava();
 
+        final var deviceSalFacade = new NetconfDeviceSalFacade(deviceId, mountPointService, dataBroker, topologyId);
+        // The facade we are going it present to NetconfDevice
+        RemoteDeviceHandler salFacade;
+        final KeepaliveSalFacade keepAliveFacade;
         if (keepaliveDelay > 0) {
-            LOG.warn("Adding keepalive facade, for device {}", nodeId);
-            salFacade = new KeepaliveSalFacade(remoteDeviceId, salFacade, this.keepaliveExecutor.getExecutor(),
-                    keepaliveDelay, defaultRequestTimeoutMillis);
-        }
-
-        // pre register yang library sources as fallback schemas to schema registry
-        final List<SchemaSourceRegistration<YangTextSchemaSource>> registeredYangLibSources = Lists.newArrayList();
-        if (node.getYangLibrary() != null) {
-            final String yangLibURL = node.getYangLibrary().getYangLibraryUrl().getValue();
-            final String yangLibUsername = node.getYangLibrary().getUsername();
-            final String yangLigPassword = node.getYangLibrary().getPassword();
-
-            final LibraryModulesSchemas libraryModulesSchemas;
-            if (yangLibURL != null) {
-                if (yangLibUsername != null && yangLigPassword != null) {
-                    libraryModulesSchemas = LibraryModulesSchemas.create(yangLibURL, yangLibUsername, yangLigPassword);
-                } else {
-                    libraryModulesSchemas = LibraryModulesSchemas.create(yangLibURL);
-                }
-
-                for (final Map.Entry<SourceIdentifier, URL> sourceIdentifierURLEntry
-                        : libraryModulesSchemas.getAvailableModels().entrySet()) {
-                    registeredYangLibSources
-                        .add(schemaRegistry.registerSchemaSource(
-                                new YangLibrarySchemaYangSourceProvider(remoteDeviceId,
-                                        libraryModulesSchemas.getAvailableModels()),
-                                PotentialSchemaSource.create(sourceIdentifierURLEntry.getKey(),
-                                        YangTextSchemaSource.class, PotentialSchemaSource.Costs.REMOTE_IO.getValue())));
-                }
-            }
+            LOG.info("Adding keepalive facade, for device {}", nodeId);
+            salFacade = keepAliveFacade = new KeepaliveSalFacade(deviceId, deviceSalFacade,
+                keepaliveExecutor.getExecutor(), keepaliveDelay, node.requireDefaultRequestTimeoutMillis().toJava());
+        } else {
+            salFacade = deviceSalFacade;
+            keepAliveFacade = null;
         }
 
-        final NetconfDevice.SchemaResourcesDTO schemaResourcesDTO = setupSchemaCacheDTO(nodeId, node);
-        final RemoteDevice<NetconfSessionPreferences, NetconfMessage, NetconfDeviceCommunicator> device;
-        if (node.isSchemaless()) {
-            device = new SchemalessNetconfDevice(remoteDeviceId, salFacade);
+        final RemoteDevice<NetconfDeviceCommunicator> device;
+        final List<SchemaSourceRegistration<?>> yanglibRegistrations;
+        if (node.requireSchemaless()) {
+            device = new SchemalessNetconfDevice(baseSchemas, deviceId, salFacade);
+            yanglibRegistrations = List.of();
         } else {
-            NetconfDeviceBuilder netconfDeviceBuilder = new NetconfDeviceBuilder()
-                    .setReconnectOnSchemasChange(reconnectOnChangedSchema)
-                    .setSchemaResourcesDTO(schemaResourcesDTO)
-                    .setGlobalProcessingExecutor(this.processingExecutor)
-                    .setId(remoteDeviceId)
-                    .setSalFacade(salFacade)
-                    .setNode(node)
-                    .setEventExecutor(eventExecutor)
-                    .setNodeOptional(nodeOptional)
-                    .setDeviceActionFactory(deviceActionFactory);
-            device = netconfDeviceBuilder.build();
+            final boolean reconnectOnChangedSchema = node.requireReconnectOnChangedSchema();
+            final SchemaResourcesDTO resources = schemaManager.getSchemaResources(node.getSchemaCacheDirectory(),
+                nodeId.getValue());
+            device = new NetconfDeviceBuilder()
+                .setReconnectOnSchemasChange(reconnectOnChangedSchema)
+                .setSchemaResourcesDTO(resources)
+                .setGlobalProcessingExecutor(processingExecutor)
+                .setId(deviceId)
+                .setSalFacade(salFacade)
+                .setNode(node)
+                .setEventExecutor(eventExecutor)
+                .setNodeOptional(nodeOptional)
+                .setDeviceActionFactory(deviceActionFactory)
+                .setBaseSchemas(baseSchemas)
+                .build();
+            yanglibRegistrations = registerDeviceSchemaSources(deviceId, node, resources);
         }
 
         final Optional<UserPreferences> userCapabilities = getUserCapabilities(node);
-        final int rpcMessageLimit = node.getConcurrentRpcLimit() == null ? DEFAULT_CONCURRENT_RPC_LIMIT
-            : node.getConcurrentRpcLimit().toJava();
-
+        final int rpcMessageLimit = node.requireConcurrentRpcLimit().toJava();
         if (rpcMessageLimit < 1) {
-            LOG.info("Concurrent rpc limit is smaller than 1, no limit will be enforced for device {}", remoteDeviceId);
+            LOG.info("Concurrent rpc limit is smaller than 1, no limit will be enforced for device {}", deviceId);
         }
 
-        NetconfDeviceCommunicator netconfDeviceCommunicator =
-             userCapabilities.isPresent() ? new NetconfDeviceCommunicator(remoteDeviceId, device,
+        final NetconfDeviceCommunicator netconfDeviceCommunicator =
+             userCapabilities.isPresent() ? new NetconfDeviceCommunicator(deviceId, device,
                      userCapabilities.get(), rpcMessageLimit)
-            : new NetconfDeviceCommunicator(remoteDeviceId, device, rpcMessageLimit);
+            : new NetconfDeviceCommunicator(deviceId, device, rpcMessageLimit);
 
-        if (salFacade instanceof KeepaliveSalFacade) {
-            ((KeepaliveSalFacade)salFacade).setListener(netconfDeviceCommunicator);
+        if (keepAliveFacade != null) {
+            keepAliveFacade.setListener(netconfDeviceCommunicator);
         }
-        return new NetconfConnectorDTO(netconfDeviceCommunicator, salFacade);
+
+        return new NetconfConnectorDTO(netconfDeviceCommunicator, salFacade, yanglibRegistrations);
     }
 
-    protected NetconfDevice.SchemaResourcesDTO setupSchemaCacheDTO(final NodeId nodeId, final NetconfNode node) {
-        // Setup information related to the SchemaRegistry, SchemaResourceFactory, etc.
-        NetconfDevice.SchemaResourcesDTO schemaResourcesDTO = null;
-        final String moduleSchemaCacheDirectory = node.getSchemaCacheDirectory();
-        // Only checks to ensure the String is not empty or null; further checks related to directory
-        // accessibility and file permissionsare handled during the FilesystemSchemaSourceCache initialization.
-        if (!Strings.isNullOrEmpty(moduleSchemaCacheDirectory)) {
-            // If a custom schema cache directory is specified, create the backing DTO; otherwise,
-            // the SchemaRegistry and SchemaContextFactory remain the default values.
-            if (!moduleSchemaCacheDirectory.equals(DEFAULT_CACHE_DIRECTORY)) {
-                // Multiple modules may be created at once;
-                // synchronize to avoid issues with data consistency among threads.
-                synchronized (SCHEMA_RESOURCES_DTO_MAP) {
-                    // Look for the cached DTO to reuse SchemaRegistry and SchemaContextFactory variables
-                    // if they already exist
-                    schemaResourcesDTO = SCHEMA_RESOURCES_DTO_MAP.get(moduleSchemaCacheDirectory);
-                    if (schemaResourcesDTO == null) {
-                        schemaResourcesDTO = createSchemaResourcesDTO(moduleSchemaCacheDirectory);
-                        schemaResourcesDTO.getSchemaRegistry().registerSchemaSourceListener(
-                                TextToASTTransformer.create((SchemaRepository) schemaResourcesDTO.getSchemaRegistry(),
-                                        schemaResourcesDTO.getSchemaRegistry())
-                        );
-                        SCHEMA_RESOURCES_DTO_MAP.put(moduleSchemaCacheDirectory, schemaResourcesDTO);
-                    }
+    private static List<SchemaSourceRegistration<?>> registerDeviceSchemaSources(final RemoteDeviceId remoteDeviceId,
+            final NetconfNode node, final SchemaResourcesDTO resources) {
+        final YangLibrary yangLibrary = node.getYangLibrary();
+        if (yangLibrary != null) {
+            final Uri uri = yangLibrary.getYangLibraryUrl();
+            if (uri != null) {
+                final List<SchemaSourceRegistration<?>> registrations = new ArrayList<>();
+                final String yangLibURL = uri.getValue();
+                final SchemaSourceRegistry schemaRegistry = resources.getSchemaRegistry();
+
+                // pre register yang library sources as fallback schemas to schema registry
+                final LibraryModulesSchemas schemas;
+                final String yangLibUsername = yangLibrary.getUsername();
+                final String yangLigPassword = yangLibrary.getPassword();
+                if (yangLibUsername != null && yangLigPassword != null) {
+                    schemas = LibraryModulesSchemas.create(yangLibURL, yangLibUsername, yangLigPassword);
+                } else {
+                    schemas = LibraryModulesSchemas.create(yangLibURL);
                 }
-                LOG.info("Netconf connector for device {} will use schema cache directory {} instead of {}",
-                        nodeId.getValue(), moduleSchemaCacheDirectory, DEFAULT_CACHE_DIRECTORY);
-            }
-        } else {
-            LOG.warn("schema-cache-directory for {} is null or empty;  using the default {}",
-                    nodeId.getValue(), QUALIFIED_DEFAULT_CACHE_DIRECTORY);
-        }
 
-        if (schemaResourcesDTO == null) {
-            schemaResourcesDTO = new NetconfDevice.SchemaResourcesDTO(schemaRegistry, schemaRepository,
-                    schemaContextFactory, new NetconfStateSchemasResolverImpl());
+                for (final Map.Entry<SourceIdentifier, URL> entry : schemas.getAvailableModels().entrySet()) {
+                    registrations.add(schemaRegistry.registerSchemaSource(new YangLibrarySchemaYangSourceProvider(
+                        remoteDeviceId, schemas.getAvailableModels()),
+                        PotentialSchemaSource.create(entry.getKey(), YangTextSchemaSource.class,
+                            PotentialSchemaSource.Costs.REMOTE_IO.getValue())));
+                }
+                return List.copyOf(registrations);
+            }
         }
 
-        return schemaResourcesDTO;
-    }
-
-    /**
-     * Creates the backing Schema classes for a particular directory.
-     *
-     * @param moduleSchemaCacheDirectory The string directory relative to "cache"
-     * @return A DTO containing the Schema classes for the Netconf mount.
-     */
-    private NetconfDevice.SchemaResourcesDTO createSchemaResourcesDTO(final String moduleSchemaCacheDirectory) {
-        final SharedSchemaRepository repository = new SharedSchemaRepository(moduleSchemaCacheDirectory);
-        final EffectiveModelContextFactory contextFactory
-                = repository.createEffectiveModelContextFactory(SchemaContextFactoryConfiguration.getDefault());
-        setSchemaRegistry(repository);
-        setSchemaContextFactory(contextFactory);
-        final FilesystemSchemaSourceCache<YangTextSchemaSource> deviceCache =
-                createDeviceFilesystemCache(moduleSchemaCacheDirectory);
-        repository.registerSchemaSourceListener(deviceCache);
-        repository.registerSchemaSourceListener(
-            InMemorySchemaSourceCache.createSoftCache(repository, ASTSchemaSource.class));
-        return new NetconfDevice.SchemaResourcesDTO(repository, repository, contextFactory,
-                new NetconfStateSchemasResolverImpl());
-    }
-
-    /**
-     * Creates a <code>FilesystemSchemaSourceCache</code> for the custom schema cache directory.
-     *
-     * @param schemaCacheDirectory The custom cache directory relative to "cache"
-     * @return A <code>FilesystemSchemaSourceCache</code> for the custom schema cache directory
-     */
-    private FilesystemSchemaSourceCache<YangTextSchemaSource> createDeviceFilesystemCache(
-            final String schemaCacheDirectory) {
-        final String relativeSchemaCacheDirectory = CACHE_DIRECTORY + File.separator + schemaCacheDirectory;
-        return new FilesystemSchemaSourceCache<>(schemaRegistry, YangTextSchemaSource.class,
-                new File(relativeSchemaCacheDirectory));
+        return List.of();
     }
 
     /**
@@ -495,26 +329,13 @@ public abstract class AbstractNetconfTopology implements NetconfTopology {
     }
 
     public NetconfReconnectingClientConfiguration getClientConfig(final NetconfClientSessionListener listener,
-                                                                  final NetconfNode node) {
-
-        //setup default values since default value is not supported in mdsal
-        final long clientConnectionTimeoutMillis = node.getConnectionTimeoutMillis() == null
-                ? DEFAULT_CONNECTION_TIMEOUT_MILLIS : node.getConnectionTimeoutMillis().toJava();
-        final long maxConnectionAttempts = node.getMaxConnectionAttempts() == null
-                ? DEFAULT_MAX_CONNECTION_ATTEMPTS : node.getMaxConnectionAttempts().toJava();
-        final int betweenAttemptsTimeoutMillis = node.getBetweenAttemptsTimeoutMillis() == null
-                ? DEFAULT_BETWEEN_ATTEMPTS_TIMEOUT_MILLIS : node.getBetweenAttemptsTimeoutMillis().toJava();
-        final boolean useTcp = node.isTcpOnly() == null ? DEFAULT_IS_TCP_ONLY : node.isTcpOnly();
-        final BigDecimal sleepFactor = node.getSleepFactor() == null ? DEFAULT_SLEEP_FACTOR : node.getSleepFactor();
-
-        final InetSocketAddress socketAddress = getSocketAddress(node.getHost(), node.getPort().getValue().toJava());
-
+                                                                  final NetconfNode node, final NodeId nodeId) {
         final ReconnectStrategyFactory sf = new TimedReconnectStrategyFactory(eventExecutor,
-                maxConnectionAttempts, betweenAttemptsTimeoutMillis, sleepFactor);
-
+                node.requireMaxConnectionAttempts().toJava(), node.requireBetweenAttemptsTimeoutMillis().toJava(),
+                node.requireSleepFactor().decimalValue());
         final NetconfReconnectingClientConfigurationBuilder reconnectingClientConfigurationBuilder;
         final Protocol protocol = node.getProtocol();
-        if (useTcp) {
+        if (node.requireTcpOnly()) {
             reconnectingClientConfigurationBuilder = NetconfReconnectingClientConfigurationBuilder.create()
                     .withProtocol(NetconfClientConfiguration.NetconfClientProtocol.TCP)
                     .withAuthHandler(getHandlerFromCredentials(node.getCredentials()));
@@ -531,13 +352,14 @@ public abstract class AbstractNetconfTopology implements NetconfTopology {
         }
 
         if (node.getOdlHelloMessageCapabilities() != null) {
-            reconnectingClientConfigurationBuilder
-                    .withOdlHelloCapabilities(node.getOdlHelloMessageCapabilities().getCapability());
+            reconnectingClientConfigurationBuilder.withOdlHelloCapabilities(
+                    Lists.newArrayList(node.getOdlHelloMessageCapabilities().getCapability()));
         }
 
         return reconnectingClientConfigurationBuilder
-                .withAddress(socketAddress)
-                .withConnectionTimeoutMillis(clientConnectionTimeoutMillis)
+                .withName(nodeId.getValue())
+                .withAddress(NetconfNodeUtils.toInetSocketAddress(node))
+                .withConnectionTimeoutMillis(node.requireConnectionTimeoutMillis().toJava())
                 .withReconnectStrategy(sf.createReconnectStrategy())
                 .withConnectStrategyFactory(sf)
                 .withSessionListener(listener)
@@ -545,12 +367,9 @@ public abstract class AbstractNetconfTopology implements NetconfTopology {
     }
 
     private AuthenticationHandler getHandlerFromCredentials(final Credentials credentials) {
-        if (credentials instanceof org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.topology
-                .rev150114.netconf.node.credentials.credentials.LoginPassword) {
-            final org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.topology
-                    .rev150114.netconf.node.credentials.credentials.LoginPassword loginPassword
-                    = (org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.topology
-                    .rev150114.netconf.node.credentials.credentials.LoginPassword) credentials;
+        if (credentials
+                instanceof org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.topology
+                    .rev150114.netconf.node.credentials.credentials.LoginPassword loginPassword) {
             return new LoginPasswordHandler(loginPassword.getUsername(), loginPassword.getPassword());
         }
         if (credentials instanceof LoginPwUnencrypted) {
@@ -571,19 +390,6 @@ public abstract class AbstractNetconfTopology implements NetconfTopology {
         throw new IllegalStateException("Unsupported credential type: " + credentials.getClass());
     }
 
-    protected abstract RemoteDeviceHandler<NetconfSessionPreferences> createSalFacade(RemoteDeviceId id);
-
-    private static InetSocketAddress getSocketAddress(final Host host, final int port) {
-        if (host.getDomainName() != null) {
-            return new InetSocketAddress(host.getDomainName().getValue(), port);
-        }
-
-        final IpAddress ipAddress = host.getIpAddress();
-        final String ip = ipAddress.getIpv4Address() != null ? ipAddress.getIpv4Address().getValue()
-                : ipAddress.getIpv6Address().getValue();
-        return new InetSocketAddress(ip, port);
-    }
-
     private static Optional<UserPreferences> getUserCapabilities(final NetconfNode node) {
         // if none of yang-module-capabilities or non-module-capabilities is specified
         // just return absent
@@ -596,7 +402,7 @@ public abstract class AbstractNetconfTopology implements NetconfTopology {
         boolean overrideYangModuleCaps = false;
         if (node.getYangModuleCapabilities() != null) {
             capabilities.addAll(node.getYangModuleCapabilities().getCapability());
-            overrideYangModuleCaps = node.getYangModuleCapabilities().isOverride();
+            overrideYangModuleCaps = node.getYangModuleCapabilities().getOverride();
         }
 
         //non-module capabilities should not exist in yang module capabilities
@@ -608,40 +414,10 @@ public abstract class AbstractNetconfTopology implements NetconfTopology {
         boolean overrideNonModuleCaps = false;
         if (node.getNonModuleCapabilities() != null) {
             capabilities.addAll(node.getNonModuleCapabilities().getCapability());
-            overrideNonModuleCaps = node.getNonModuleCapabilities().isOverride();
+            overrideNonModuleCaps = node.getNonModuleCapabilities().getOverride();
         }
 
         return Optional.of(new UserPreferences(NetconfSessionPreferences
             .fromStrings(capabilities, CapabilityOrigin.UserDefined), overrideYangModuleCaps, overrideNonModuleCaps));
     }
-
-    protected static class NetconfConnectorDTO implements AutoCloseable {
-
-        private final NetconfDeviceCommunicator communicator;
-        private final RemoteDeviceHandler<NetconfSessionPreferences> facade;
-
-        public NetconfConnectorDTO(final NetconfDeviceCommunicator communicator,
-                                   final RemoteDeviceHandler<NetconfSessionPreferences> facade) {
-            this.communicator = communicator;
-            this.facade = facade;
-        }
-
-        public NetconfDeviceCommunicator getCommunicator() {
-            return communicator;
-        }
-
-        public RemoteDeviceHandler<NetconfSessionPreferences> getFacade() {
-            return facade;
-        }
-
-        public NetconfClientSessionListener getSessionListener() {
-            return communicator;
-        }
-
-        @Override
-        public void close() {
-            communicator.close();
-            facade.close();
-        }
-    }
 }