Do not use NetconfServerFactory in NetconfDeviceSimulator
[netconf.git] / netconf / tools / netconf-testtool / src / main / java / org / opendaylight / netconf / test / tool / NetconfDeviceSimulator.java
index 3ade59f8a5822b4aa209ec2cc8c0ea8d1f5192c3..0aecf91aec7bf9b36109e86d9bd5bf48182b0e7f 100644 (file)
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
  * and is available at http://www.eclipse.org/legal/epl-v10.html
  */
-
 package org.opendaylight.netconf.test.tool;
 
-import com.google.common.base.Function;
-import com.google.common.base.MoreObjects;
-import com.google.common.base.Optional;
+import static java.util.Objects.requireNonNullElseGet;
+
 import com.google.common.collect.Collections2;
-import com.google.common.collect.Lists;
-import com.google.common.collect.Sets;
-import com.google.common.util.concurrent.CheckedFuture;
+import com.google.common.collect.ImmutableList;
 import com.google.common.util.concurrent.Futures;
-import com.google.common.util.concurrent.ThreadFactoryBuilder;
-import io.netty.channel.Channel;
-import io.netty.channel.ChannelFuture;
-import io.netty.channel.local.LocalAddress;
-import io.netty.channel.nio.NioEventLoopGroup;
 import io.netty.util.HashedWheelTimer;
 import java.io.Closeable;
 import java.io.IOException;
-import java.io.InputStream;
-import java.net.BindException;
-import java.net.Inet4Address;
-import java.net.InetSocketAddress;
+import java.net.InetAddress;
+import java.net.ServerSocket;
 import java.net.UnknownHostException;
-import java.nio.file.Files;
-import java.nio.file.Path;
+import java.util.ArrayList;
+import java.util.HashSet;
 import java.util.List;
+import java.util.Optional;
 import java.util.Set;
 import java.util.concurrent.ExecutionException;
-import java.util.concurrent.ExecutorService;
-import java.util.concurrent.Executors;
-import java.util.concurrent.ScheduledExecutorService;
-import org.apache.sshd.common.util.ThreadUtils;
-import org.apache.sshd.server.keyprovider.PEMGeneratorHostKeyProvider;
-import org.opendaylight.controller.config.util.capability.BasicCapability;
-import org.opendaylight.controller.config.util.capability.Capability;
-import org.opendaylight.controller.config.util.capability.YangModuleCapability;
-import org.opendaylight.netconf.api.monitoring.NetconfMonitoringService;
-import org.opendaylight.netconf.api.xml.XmlNetconfConstants;
-import org.opendaylight.netconf.auth.AuthProvider;
-import org.opendaylight.netconf.impl.NetconfServerDispatcherImpl;
-import org.opendaylight.netconf.impl.NetconfServerSessionNegotiatorFactory;
-import org.opendaylight.netconf.impl.SessionIdProvider;
-import org.opendaylight.netconf.impl.osgi.AggregatedNetconfOperationServiceFactory;
-import org.opendaylight.netconf.mapping.api.NetconfOperationServiceFactory;
-import org.opendaylight.netconf.monitoring.osgi.NetconfMonitoringActivator;
-import org.opendaylight.netconf.monitoring.osgi.NetconfMonitoringOperationService;
-import org.opendaylight.netconf.ssh.SshProxyServer;
-import org.opendaylight.netconf.ssh.SshProxyServerConfiguration;
-import org.opendaylight.netconf.ssh.SshProxyServerConfigurationBuilder;
+import java.util.stream.IntStream;
+import org.opendaylight.netconf.api.CapabilityURN;
+import org.opendaylight.netconf.api.TransportConstants;
+import org.opendaylight.netconf.server.ServerChannelInitializer;
+import org.opendaylight.netconf.server.ServerTransportInitializer;
+import org.opendaylight.netconf.server.api.SessionIdProvider;
+import org.opendaylight.netconf.server.api.monitoring.BasicCapability;
+import org.opendaylight.netconf.server.api.monitoring.Capability;
+import org.opendaylight.netconf.server.api.monitoring.NetconfMonitoringService;
+import org.opendaylight.netconf.server.api.monitoring.YangModuleCapability;
+import org.opendaylight.netconf.server.api.operations.NetconfOperationServiceFactory;
+import org.opendaylight.netconf.server.impl.DefaultSessionIdProvider;
+import org.opendaylight.netconf.server.osgi.AggregatedNetconfOperationServiceFactory;
+import org.opendaylight.netconf.shaded.sshd.server.auth.UserAuthFactory;
+import org.opendaylight.netconf.shaded.sshd.server.auth.password.UserAuthPasswordFactory;
+import org.opendaylight.netconf.shaded.sshd.server.auth.pubkey.UserAuthPublicKeyFactory;
+import org.opendaylight.netconf.test.tool.config.Configuration;
 import org.opendaylight.netconf.test.tool.customrpc.SettableOperationProvider;
-import org.opendaylight.yangtools.yang.common.SimpleDateFormatUtil;
+import org.opendaylight.netconf.test.tool.monitoring.NetconfMonitoringOperationServiceFactory;
+import org.opendaylight.netconf.test.tool.operations.DefaultOperationsCreator;
+import org.opendaylight.netconf.test.tool.operations.OperationsProvider;
+import org.opendaylight.netconf.test.tool.rpchandler.SettableOperationRpcProvider;
+import org.opendaylight.netconf.test.tool.schemacache.SchemaSourceCache;
+import org.opendaylight.netconf.transport.api.TransportStack;
+import org.opendaylight.netconf.transport.api.UnsupportedConfigurationException;
+import org.opendaylight.netconf.transport.ssh.SSHTransportStackFactory;
+import org.opendaylight.netconf.transport.ssh.ServerFactoryManagerConfigurator;
+import org.opendaylight.netconf.transport.tcp.TCPServer;
+import org.opendaylight.yang.gen.v1.urn.ietf.params.xml.ns.yang.ietf.inet.types.rev130715.IetfInetUtil;
+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.PortNumber;
+import org.opendaylight.yang.gen.v1.urn.ietf.params.xml.ns.yang.ietf.netconf.server.rev230417.netconf.server.listen.stack.grouping.transport.ssh.ssh.TcpServerParametersBuilder;
+import org.opendaylight.yang.gen.v1.urn.ietf.params.xml.ns.yang.ietf.tcp.server.rev230417.TcpServerGrouping;
+import org.opendaylight.yangtools.yang.common.Revision;
+import org.opendaylight.yangtools.yang.common.Uint16;
+import org.opendaylight.yangtools.yang.model.api.EffectiveModelContext;
 import org.opendaylight.yangtools.yang.model.api.Module;
-import org.opendaylight.yangtools.yang.model.api.SchemaContext;
-import org.opendaylight.yangtools.yang.model.repo.api.RevisionSourceIdentifier;
-import org.opendaylight.yangtools.yang.model.repo.api.SchemaResolutionException;
-import org.opendaylight.yangtools.yang.model.repo.api.SchemaSourceException;
-import org.opendaylight.yangtools.yang.model.repo.api.SchemaSourceFilter;
+import org.opendaylight.yangtools.yang.model.api.ModuleLike;
+import org.opendaylight.yangtools.yang.model.api.Submodule;
 import org.opendaylight.yangtools.yang.model.repo.api.SchemaSourceRepresentation;
 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.fs.FilesystemSchemaSourceCache;
 import org.opendaylight.yangtools.yang.model.repo.spi.PotentialSchemaSource;
 import org.opendaylight.yangtools.yang.model.repo.spi.SchemaSourceListener;
 import org.opendaylight.yangtools.yang.model.repo.spi.SchemaSourceProvider;
-import org.opendaylight.yangtools.yang.model.repo.util.FilesystemSchemaSourceCache;
 import org.opendaylight.yangtools.yang.parser.repo.SharedSchemaRepository;
-import org.opendaylight.yangtools.yang.parser.util.TextToASTTransformer;
+import org.opendaylight.yangtools.yang.parser.rfc7950.repo.TextToIRTransformer;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 public class NetconfDeviceSimulator implements Closeable {
-
     private static final Logger LOG = LoggerFactory.getLogger(NetconfDeviceSimulator.class);
 
-    private final NioEventLoopGroup nettyThreadgroup;
-    private final HashedWheelTimer hashedWheelTimer;
-    private final List<Channel> devicesChannels = Lists.newArrayList();
-    private final List<SshProxyServer> sshWrappers = Lists.newArrayList();
-    private final ScheduledExecutorService minaTimerExecutor;
-    private final ExecutorService nioExecutor;
-    private SchemaContext schemaContext;
+    private final HashedWheelTimer hashedWheelTimer = new HashedWheelTimer();
+    private final Configuration configuration;
+    private final List<TransportStack> servers;
+    private final SSHTransportStackFactory sshStackFactory;
+    private EffectiveModelContext schemaContext;
 
     private boolean sendFakeSchema = false;
 
-    public NetconfDeviceSimulator(final int ThreadPoolSize) {
-        this(new NioEventLoopGroup(), new HashedWheelTimer(),
-                Executors.newScheduledThreadPool(ThreadPoolSize, new ThreadFactoryBuilder().setNameFormat("netconf-ssh-server-mina-timers-%d").build()),
-                ThreadUtils.newFixedThreadPool("netconf-ssh-server-nio-group", ThreadPoolSize));
-    }
-
-    private NetconfDeviceSimulator(final NioEventLoopGroup eventExecutors, final HashedWheelTimer hashedWheelTimer, final ScheduledExecutorService minaTimerExecutor, final ExecutorService nioExecutor) {
-        this.nettyThreadgroup = eventExecutors;
-        this.hashedWheelTimer = hashedWheelTimer;
-        this.minaTimerExecutor = minaTimerExecutor;
-        this.nioExecutor = nioExecutor;
+    public NetconfDeviceSimulator(final Configuration configuration) {
+        this.configuration = configuration;
+        servers = new ArrayList<>(configuration.getDeviceCount());
+        sshStackFactory = new SSHTransportStackFactory("netconf-device-simulator-threads",
+            configuration.getThreadPoolSize());
     }
 
-    private NetconfServerDispatcherImpl createDispatcher(final Set<Capability> capabilities,
-                                                         final SchemaSourceProvider<YangTextSchemaSource> sourceProvider,
-                                                         final TesttoolParameters params) {
-
-        final Set<Capability> transformedCapabilities = Sets.newHashSet(Collections2.transform(capabilities, new Function<Capability, Capability>() {
-            @Override
-            public Capability apply(final Capability input) {
-                if (sendFakeSchema) {
-                    sendFakeSchema = false;
-                    return new FakeCapability((YangModuleCapability) input);
-                } else {
-                    return input;
-                }
+    private ServerTransportInitializer createTransportInitializer(final Set<Capability> capabilities,
+            final SchemaSourceProvider<YangTextSchemaSource> sourceProvider) {
+        final var transformedCapabilities = new HashSet<>(Collections2.transform(capabilities, input -> {
+            if (sendFakeSchema) {
+                sendFakeSchema = false;
+                return new FakeCapability((YangModuleCapability) input);
+            } else {
+                return input;
             }
         }));
-        transformedCapabilities.add(new BasicCapability("urn:ietf:params:netconf:capability:candidate:1.0"));
-        final NetconfMonitoringService monitoringService1 = new DummyMonitoringService(transformedCapabilities);
-        final SessionIdProvider idProvider = new SessionIdProvider();
-
-        final NetconfOperationServiceFactory aggregatedNetconfOperationServiceFactory = createOperationServiceFactory(sourceProvider, params, transformedCapabilities, monitoringService1, idProvider);
+        transformedCapabilities.add(new BasicCapability(CapabilityURN.CANDIDATE));
+        final var monitoringService1 = new DummyMonitoringService(transformedCapabilities);
+        final var idProvider = new DefaultSessionIdProvider();
 
-        final Set<String> serverCapabilities = params.exi
-                ? NetconfServerSessionNegotiatorFactory.DEFAULT_BASE_CAPABILITIES
-                : Sets.newHashSet(XmlNetconfConstants.URN_IETF_PARAMS_NETCONF_BASE_1_0, XmlNetconfConstants.URN_IETF_PARAMS_NETCONF_BASE_1_1);
+        final var aggregatedNetconfOperationServiceFactory = createOperationServiceFactory(
+            sourceProvider, transformedCapabilities, monitoringService1, idProvider);
 
-        final NetconfServerSessionNegotiatorFactory serverNegotiatorFactory = new TesttoolNegotiationFactory(
-                hashedWheelTimer, aggregatedNetconfOperationServiceFactory, idProvider, params.generateConfigsTimeout, monitoringService1, serverCapabilities);
-
-        final NetconfServerDispatcherImpl.ServerChannelInitializer serverChannelInitializer = new NetconfServerDispatcherImpl.ServerChannelInitializer(
-                serverNegotiatorFactory);
-        return new NetconfServerDispatcherImpl(serverChannelInitializer, nettyThreadgroup, nettyThreadgroup);
+        return new ServerTransportInitializer(new ServerChannelInitializer(new TesttoolNegotiationFactory(
+            hashedWheelTimer, aggregatedNetconfOperationServiceFactory, idProvider,
+            configuration.getGenerateConfigsTimeout(), monitoringService1, configuration.getCapabilities())));
     }
 
-    private NetconfOperationServiceFactory createOperationServiceFactory(final SchemaSourceProvider<YangTextSchemaSource> sourceProvider,
-                                                                         final TesttoolParameters params,
-                                                                         final Set<Capability> transformedCapabilities,
-                                                                         final NetconfMonitoringService monitoringService1,
-                                                                         final SessionIdProvider idProvider) {
-        final AggregatedNetconfOperationServiceFactory aggregatedNetconfOperationServiceFactory = new AggregatedNetconfOperationServiceFactory();
+    private NetconfOperationServiceFactory createOperationServiceFactory(
+            final SchemaSourceProvider<YangTextSchemaSource> sourceProvider,
+            final Set<Capability> transformedCapabilities, final NetconfMonitoringService monitoringService1,
+            final SessionIdProvider idProvider) {
+        final AggregatedNetconfOperationServiceFactory aggregatedNetconfOperationServiceFactory =
+            new AggregatedNetconfOperationServiceFactory();
 
         final NetconfOperationServiceFactory operationProvider;
-        if (params.mdSal) {
-            operationProvider = new MdsalOperationProvider(idProvider, transformedCapabilities, schemaContext, sourceProvider);
+        if (configuration.isMdSal()) {
+            LOG.info("using MdsalOperationProvider.");
+            operationProvider = new MdsalOperationProvider(
+                idProvider, transformedCapabilities, schemaContext, sourceProvider);
+        } else if (configuration.isXmlConfigurationProvided()) {
+            LOG.info("using SimulatedOperationProvider.");
+            operationProvider = new SimulatedOperationProvider(transformedCapabilities,
+                    Optional.ofNullable(configuration.getNotificationFile()),
+                    Optional.ofNullable(configuration.getInitialConfigXMLFile()));
+        } else if (configuration.isNotificationsSupported()) {
+            LOG.info("using SimulatedOperationProvider.");
+            operationProvider = new SimulatedOperationProvider(transformedCapabilities,
+                    Optional.ofNullable(configuration.getNotificationFile()),
+                    Optional.empty());
         } else {
-            operationProvider = new SimulatedOperationProvider(idProvider, transformedCapabilities,
-                    Optional.fromNullable(params.notificationFile),
-                    Optional.fromNullable(params.initialConfigXMLFile));
+            LOG.info("using OperationsProvider.");
+            operationProvider = new OperationsProvider(transformedCapabilities,
+                requireNonNullElseGet(configuration.getOperationsCreator(), DefaultOperationsCreator::new));
         }
 
-
-        final NetconfMonitoringActivator.NetconfMonitoringOperationServiceFactory monitoringService =
-                new NetconfMonitoringActivator.NetconfMonitoringOperationServiceFactory(
-                        new NetconfMonitoringOperationService(monitoringService1));
+        final NetconfMonitoringOperationServiceFactory monitoringService =
+                new NetconfMonitoringOperationServiceFactory(monitoringService1);
         aggregatedNetconfOperationServiceFactory.onAddNetconfOperationServiceFactory(operationProvider);
         aggregatedNetconfOperationServiceFactory.onAddNetconfOperationServiceFactory(monitoringService);
-        if (params.rpcConfig != null) {
-            final SettableOperationProvider settableService = new SettableOperationProvider(params.rpcConfig);
+        if (configuration.getRpcConfigFile() != null) {
+            final SettableOperationProvider settableService =
+                    new SettableOperationProvider(configuration.getRpcConfigFile());
+            aggregatedNetconfOperationServiceFactory.onAddNetconfOperationServiceFactory(settableService);
+        } else {
+            final SettableOperationRpcProvider settableService =
+                    new SettableOperationRpcProvider(configuration.getRpcHandler());
             aggregatedNetconfOperationServiceFactory.onAddNetconfOperationServiceFactory(settableService);
         }
         return aggregatedNetconfOperationServiceFactory;
     }
 
-    public List<Integer> start(final TesttoolParameters params) {
-        LOG.info("Starting {}, {} simulated devices starting on port {}", params.deviceCount, params.ssh ? "SSH" : "TCP", params.startingPort);
-
-        final SharedSchemaRepository schemaRepo = new SharedSchemaRepository("netconf-simulator");
-        final Set<Capability> capabilities = parseSchemasToModuleCapabilities(params, schemaRepo);
-
-        final NetconfServerDispatcherImpl dispatcher = createDispatcher(capabilities,
-                new SchemaSourceProvider<YangTextSchemaSource>() {
-                    @Override
-                    public CheckedFuture<? extends YangTextSchemaSource, SchemaSourceException> getSource(final SourceIdentifier sourceIdentifier) {
-                        return schemaRepo.getSchemaSource(sourceIdentifier, YangTextSchemaSource.class);
-                    }
-                }, params);
-
-        int currentPort = params.startingPort;
-
-        final List<Integer> openDevices = Lists.newArrayList();
-
-        // Generate key to temp folder
-        final PEMGeneratorHostKeyProvider keyPairProvider = getPemGeneratorHostKeyProvider();
-
-        for (int i = 0; i < params.deviceCount; i++) {
-            if (currentPort > 65535) {
-                LOG.warn("Port cannot be greater than 65535, stopping further attempts.");
+    public List<Integer> start() {
+        final var proto = configuration.isSsh() ? "SSH" : "TCP";
+        LOG.info("Starting {}, {} simulated devices starting on port {}",
+            configuration.getDeviceCount(), proto, configuration.getStartingPort());
+
+        final var schemaRepo = new SharedSchemaRepository("netconf-simulator");
+        final var capabilities = parseSchemasToModuleCapabilities(schemaRepo);
+        final var transportInitializer = createTransportInitializer(capabilities,
+            sourceIdentifier -> schemaRepo.getSchemaSource(sourceIdentifier, YangTextSchemaSource.class));
+
+        final var ipAddress = getIpAddress(configuration);
+        final var startingPort = getStartingPort(configuration);
+        final var deviceCount = configuration.getDeviceCount();
+        final var ports = IntStream.range(startingPort, Math.min(startingPort + deviceCount, 65536))
+            .mapToObj(Integer::new).toList();
+
+        final var openDevices = new ArrayList<Integer>(ports.size());
+        final var configurator = configuration.isSsh() ? createServerFactoryManagerConfigurator(configuration) : null;
+
+        LOG.debug("Ports: {}", ports);
+
+        for (final int port : ports) {
+            try {
+                final var connectParams = connectionParams(ipAddress, port);
+                final var serverFuture = configuration.isSsh()
+                    ? sshStackFactory.listenServer(TransportConstants.SSH_SUBSYSTEM, transportInitializer,
+                        connectParams, null, configurator)
+                        : TCPServer.listen(transportInitializer, sshStackFactory.newServerBootstrap(), connectParams);
+                servers.add(serverFuture.get());
+                openDevices.add(port);
+            } catch (UnsupportedConfigurationException | InterruptedException | ExecutionException e) {
+                LOG.error("Could not start {} simulated device on port {}", proto, port, e);
                 break;
             }
-            final InetSocketAddress address = getAddress(params.ip, currentPort);
-
-            final ChannelFuture server;
-            if(params.ssh) {
-                final InetSocketAddress bindingAddress = InetSocketAddress.createUnresolved("0.0.0.0", currentPort);
-                final LocalAddress tcpLocalAddress = new LocalAddress(address.toString());
-
-                server = dispatcher.createLocalServer(tcpLocalAddress);
-                try {
-                    final SshProxyServer sshServer = new SshProxyServer(minaTimerExecutor, nettyThreadgroup, nioExecutor);
-                    sshServer.bind(getSshConfiguration(bindingAddress, tcpLocalAddress, keyPairProvider));
-                    sshWrappers.add(sshServer);
-                } catch (final BindException e) {
-                    LOG.warn("Cannot start simulated device on {}, port already in use. Skipping.", address);
-                    // Close local server and continue
-                    server.cancel(true);
-                    if(server.isDone()) {
-                        server.channel().close();
-                    }
-                    continue;
-                } catch (final IOException e) {
-                    LOG.warn("Cannot start simulated device on {} due to IOException.", address, e);
-                    break;
-                } finally {
-                    currentPort++;
-                }
-
-                try {
-                    server.get();
-                } catch (final InterruptedException e) {
-                    throw new RuntimeException(e);
-                } catch (final ExecutionException e) {
-                    LOG.warn("Cannot start ssh simulated device on {}, skipping", address, e);
-                    continue;
-                }
-
-                LOG.debug("Simulated SSH device started on {}", address);
-
-            } else {
-                server = dispatcher.createServer(address);
-                currentPort++;
-
-                try {
-                    server.get();
-                } catch (final InterruptedException e) {
-                    throw new RuntimeException(e);
-                } catch (final ExecutionException e) {
-                    LOG.warn("Cannot start tcp simulated device on {}, skipping", address, e);
-                    continue;
-                }
-
-                LOG.debug("Simulated TCP device started on {}", address);
-            }
-
-            devicesChannels.add(server.channel());
-            openDevices.add(currentPort - 1);
         }
 
-        if(openDevices.size() == params.deviceCount) {
-            LOG.info("All simulated devices started successfully from port {} to {}", params.startingPort, currentPort - 1);
-        } else if (openDevices.size() == 0) {
+        final var first = openDevices.get(0);
+        final var last = openDevices.isEmpty() ? null : openDevices.get(openDevices.size() - 1);
+        if (openDevices.size() == configuration.getDeviceCount()) {
+            LOG.info("All simulated devices started successfully from port {} to {}", first, last);
+        } else if (openDevices.isEmpty()) {
             LOG.warn("No simulated devices started.");
         } else {
-            LOG.warn("Not all simulated devices started successfully. Started devices ar on ports {}", openDevices);
+            LOG.warn("Not all simulated devices started successfully. Started devices are on ports {} to {}",
+                first, last);
         }
-
         return openDevices;
     }
 
-    private SshProxyServerConfiguration getSshConfiguration(final InetSocketAddress bindingAddress, final LocalAddress tcpLocalAddress, final PEMGeneratorHostKeyProvider keyPairProvider) throws IOException {
-        return new SshProxyServerConfigurationBuilder()
-                .setBindingAddress(bindingAddress)
-                .setLocalAddress(tcpLocalAddress)
-                .setAuthenticator(new AuthProvider() {
-                    @Override
-                    public boolean authenticated(final String username, final String password) {
-                        return true;
-                    }
-                })
-                .setKeyPairProvider(keyPairProvider)
-                .setIdleTimeout(Integer.MAX_VALUE)
-                .createSshProxyServerConfiguration();
-    }
-
-    private PEMGeneratorHostKeyProvider getPemGeneratorHostKeyProvider() {
-        try {
-            final Path tempFile = Files.createTempFile("tempKeyNetconfTest", "suffix");
-            return new PEMGeneratorHostKeyProvider(tempFile.toAbsolutePath().toString());
-        } catch (final IOException e) {
-            LOG.error("Unable to generate PEM key", e);
-            throw new RuntimeException(e);
-        }
+    private static ServerFactoryManagerConfigurator createServerFactoryManagerConfigurator(
+            final Configuration configuration) {
+        final var authProvider = configuration.getAuthProvider();
+        final var publicKeyAuthenticator = configuration.getPublickeyAuthenticator();
+        return factoryManager -> {
+            final var authFactoriesListBuilder = ImmutableList.<UserAuthFactory>builder();
+            authFactoriesListBuilder.add(new UserAuthPasswordFactory());
+            factoryManager.setPasswordAuthenticator(
+                (usr, pass, session) -> authProvider.authenticated(usr, pass));
+            if (publicKeyAuthenticator != null) {
+                final var factory = new UserAuthPublicKeyFactory();
+                factory.setSignatureFactories(factoryManager.getSignatureFactories());
+                authFactoriesListBuilder.add(factory);
+                factoryManager.setPublickeyAuthenticator(publicKeyAuthenticator);
+            }
+            factoryManager.setUserAuthFactories(authFactoriesListBuilder.build());
+            factoryManager.setKeyPairProvider(new VirtualKeyPairProvider());
+        };
     }
 
-    private Set<Capability> parseSchemasToModuleCapabilities(final TesttoolParameters params, final SharedSchemaRepository consumer) {
-        final Set<SourceIdentifier> loadedSources = Sets.newHashSet();
-
-        consumer.registerSchemaSourceListener(TextToASTTransformer.create(consumer, consumer));
-
+    private Set<Capability> parseSchemasToModuleCapabilities(final SharedSchemaRepository consumer) {
+        final Set<SourceIdentifier> loadedSources = new HashSet<>();
+        consumer.registerSchemaSourceListener(TextToIRTransformer.create(consumer, consumer));
         consumer.registerSchemaSourceListener(new SchemaSourceListener() {
             @Override
-            public void schemaSourceEncountered(final SchemaSourceRepresentation schemaSourceRepresentation) {}
+            public void schemaSourceEncountered(final SchemaSourceRepresentation schemaSourceRepresentation) {
+
+            }
 
             @Override
             public void schemaSourceRegistered(final Iterable<PotentialSchemaSource<?>> potentialSchemaSources) {
@@ -301,29 +245,42 @@ public class NetconfDeviceSimulator implements Closeable {
             }
 
             @Override
-            public void schemaSourceUnregistered(final PotentialSchemaSource<?> potentialSchemaSource) {}
+            public void schemaSourceUnregistered(final PotentialSchemaSource<?> potentialSchemaSource) {
+
+            }
         });
 
-        if(params.schemasDir != null) {
-            final FilesystemSchemaSourceCache<YangTextSchemaSource> cache = new FilesystemSchemaSourceCache<>(consumer, YangTextSchemaSource.class, params.schemasDir);
+        if (configuration.getSchemasDir() != null) {
+            LOG.info("Loading models from directory.");
+            final FilesystemSchemaSourceCache<YangTextSchemaSource> cache = new FilesystemSchemaSourceCache<>(
+                consumer, YangTextSchemaSource.class, configuration.getSchemasDir());
+            consumer.registerSchemaSourceListener(cache);
+        } else if (configuration.getModels() != null) {
+            LOG.info("Loading models from classpath.");
+            final SchemaSourceCache<YangTextSchemaSource> cache = new SchemaSourceCache<>(
+                    consumer, YangTextSchemaSource.class, configuration.getModels());
             consumer.registerSchemaSourceListener(cache);
+        } else {
+            LOG.info("Custom module loading skipped.");
         }
 
-        addDefaultSchemas(consumer);
+        configuration.getDefaultYangResources().forEach(r -> {
+            registerSource(consumer, r.resourcePath(), new SourceIdentifier(r.moduleName(), r.revision()));
+        });
 
         try {
             //necessary for creating mdsal data stores and operations
-            this.schemaContext = consumer.createSchemaContextFactory(
-                SchemaSourceFilter.ALWAYS_ACCEPT)
-                .createSchemaContext(loadedSources).checkedGet();
-        } catch (final SchemaResolutionException e) {
-            throw new RuntimeException("Cannot parse schema context", e);
+            schemaContext = consumer.createEffectiveModelContextFactory()
+                    .createEffectiveModelContext(loadedSources).get();
+        } catch (final InterruptedException | ExecutionException e) {
+            throw new IllegalStateException(
+                "Cannot parse schema context. Please read stack trace and check YANG files in schema directory.", e);
         }
 
-        final Set<Capability> capabilities = Sets.newHashSet();
+        final Set<Capability> capabilities = new HashSet<>();
 
         for (final Module module : schemaContext.getModules()) {
-            for (final Module subModule : module.getSubmodules()) {
+            for (final Submodule subModule : module.getSubmodules()) {
                 addModuleCapability(consumer, capabilities, subModule);
             }
             addModuleCapability(consumer, capabilities, module);
@@ -331,72 +288,70 @@ public class NetconfDeviceSimulator implements Closeable {
         return capabilities;
     }
 
-    private void addModuleCapability(final SharedSchemaRepository consumer, final Set<Capability> capabilities, final Module module) {
-        final SourceIdentifier moduleSourceIdentifier = SourceIdentifier.create(module.getName(),
-                (SimpleDateFormatUtil.DEFAULT_DATE_REV == module.getRevision() ? Optional.<String>absent() :
-                        Optional.of(SimpleDateFormatUtil.getRevisionFormat().format(module.getRevision()))));
+    private static void addModuleCapability(final SharedSchemaRepository consumer, final Set<Capability> capabilities,
+                                            final ModuleLike module) {
+        final var moduleNamespace = module.getNamespace().toString();
+        final var moduleName = module.getName();
+        final var revision = module.getRevision().map(Revision::toString).orElse(null);
+        final var sourceId = new SourceIdentifier(moduleName, revision);
+
+        final String moduleContent;
         try {
-            final String moduleContent = new String(consumer.getSchemaSource(moduleSourceIdentifier, YangTextSchemaSource.class)
-                    .checkedGet().read());
-            capabilities.add(new YangModuleCapability(module, moduleContent));
-            //IOException would be thrown in creating SchemaContext already
-        } catch (SchemaSourceException |IOException e) {
-            throw new RuntimeException("Cannot retrieve schema source for module " + moduleSourceIdentifier.toString() + " from schema repository", e);
+            moduleContent = consumer.getSchemaSource(sourceId, YangTextSchemaSource.class).get().read();
+        } catch (ExecutionException | InterruptedException | IOException e) {
+            throw new IllegalStateException(
+                "Cannot retrieve schema source for module " + sourceId + " from schema repository", e);
         }
-    }
-
-    private void addDefaultSchemas(final SharedSchemaRepository consumer) {
-        SourceIdentifier sId = RevisionSourceIdentifier.create("ietf-netconf-monitoring", "2010-10-04");
-        registerSource(consumer, "/META-INF/yang/ietf-netconf-monitoring.yang", sId);
-
-        sId = RevisionSourceIdentifier.create("ietf-netconf-monitoring-extension", "2013-12-10");
-        registerSource(consumer, "/META-INF/yang/ietf-netconf-monitoring-extension.yang", sId);
-
-        sId = RevisionSourceIdentifier.create("ietf-yang-types", "2013-07-15");
-        registerSource(consumer, "/META-INF/yang/ietf-yang-types@2013-07-15.yang", sId);
 
-        sId = RevisionSourceIdentifier.create("ietf-inet-types", "2013-07-15");
-        registerSource(consumer, "/META-INF/yang/ietf-inet-types@2013-07-15.yang", sId);
+        capabilities.add(new YangModuleCapability(moduleNamespace, moduleName, revision, moduleContent));
     }
 
-    private void registerSource(final SharedSchemaRepository consumer, final String resource, final SourceIdentifier sourceId) {
-        consumer.registerSchemaSource(new SchemaSourceProvider<SchemaSourceRepresentation>() {
-            @Override
-            public CheckedFuture<? extends SchemaSourceRepresentation, SchemaSourceException> getSource(final SourceIdentifier sourceIdentifier) {
-                return Futures.immediateCheckedFuture(new YangTextSchemaSource(sourceId) {
-                    @Override
-                    protected MoreObjects.ToStringHelper addToStringAttributes(final MoreObjects.ToStringHelper toStringHelper) {
-                        return toStringHelper;
-                    }
-
-                    @Override
-                    public InputStream openStream() throws IOException {
-                        return getClass().getResourceAsStream(resource);
-                    }
-                });
-            }
-        }, PotentialSchemaSource.create(sourceId, YangTextSchemaSource.class, PotentialSchemaSource.Costs.IMMEDIATE.getValue()));
+    private static void registerSource(final SharedSchemaRepository consumer, final String resource,
+            final SourceIdentifier sourceId) {
+        consumer.registerSchemaSource(sourceIdentifier -> Futures.immediateFuture(
+            YangTextSchemaSource.forResource(NetconfDeviceSimulator.class, resource)),
+            PotentialSchemaSource.create(sourceId, YangTextSchemaSource.class,
+                PotentialSchemaSource.Costs.IMMEDIATE.getValue()));
     }
 
-    private static InetSocketAddress getAddress(final String ip, final int port) {
+    private static IpAddress getIpAddress(final Configuration configuration) {
         try {
-            return new InetSocketAddress(Inet4Address.getByName(ip), port);
+            return IetfInetUtil.ipAddressFor(InetAddress.getByName(configuration.getIp()));
         } catch (final UnknownHostException e) {
-            throw new RuntimeException(e);
+            throw new IllegalArgumentException("Cannot resolve address " + configuration.getIp(), e);
         }
     }
 
+    private static int getStartingPort(final Configuration configuration) {
+        final int startingPort = configuration.getStartingPort();
+        if (startingPort > 0 && startingPort < 65536) {
+            return startingPort;
+        }
+        // find available port
+        try {
+            final var socket = new ServerSocket(0);
+            final int port = socket.getLocalPort();
+            socket.close();
+            return port;
+        } catch (IOException e) {
+            throw new IllegalStateException("Cannot find available port", e);
+        }
+    }
+
+    private static TcpServerGrouping connectionParams(final IpAddress address, final int port) {
+        return new TcpServerParametersBuilder().setLocalAddress(address)
+            .setLocalPort(new PortNumber(Uint16.valueOf(port))).build();
+    }
+
     @Override
     public void close() {
-        for (final SshProxyServer sshWrapper : sshWrappers) {
-            sshWrapper.close();
-        }
-        for (final Channel deviceCh : devicesChannels) {
-            deviceCh.close();
+        for (final var server : servers) {
+            try {
+                server.shutdown().get();
+            } catch (InterruptedException | ExecutionException e) {
+                LOG.debug("Exception on simulated device shutdown", e);
+            }
         }
-        nettyThreadgroup.shutdownGracefully();
-        minaTimerExecutor.shutdownNow();
-        nioExecutor.shutdownNow();
-        // close Everything
+        sshStackFactory.close();
     }
 }