X-Git-Url: https://git.opendaylight.org/gerrit/gitweb?a=blobdiff_plain;f=netconf%2Fsal-netconf-connector%2Fsrc%2Fmain%2Fjava%2Forg%2Fopendaylight%2Fnetconf%2Fsal%2Fconnect%2Fnetconf%2FNetconfDevice.java;h=42ce7987f2b9fef0f37f4da3fa135b64381009d5;hb=3b5e41839346a83c1d8d54b3d869e19d9e417063;hp=4070c96750519ba3ae9f71bd7a720c5653db3861;hpb=79951c770e34cea96fca471c9c2bd465190991f6;p=netconf.git diff --git a/netconf/sal-netconf-connector/src/main/java/org/opendaylight/netconf/sal/connect/netconf/NetconfDevice.java b/netconf/sal-netconf-connector/src/main/java/org/opendaylight/netconf/sal/connect/netconf/NetconfDevice.java index 4070c96750..42ce7987f2 100644 --- a/netconf/sal-netconf-connector/src/main/java/org/opendaylight/netconf/sal/connect/netconf/NetconfDevice.java +++ b/netconf/sal-netconf-connector/src/main/java/org/opendaylight/netconf/sal/connect/netconf/NetconfDevice.java @@ -7,31 +7,40 @@ */ package org.opendaylight.netconf.sal.connect.netconf; -import com.google.common.base.Function; -import com.google.common.base.Optional; -import com.google.common.base.Preconditions; +import static com.google.common.base.Preconditions.checkState; +import static java.util.Objects.requireNonNull; +import static org.opendaylight.netconf.sal.connect.netconf.util.NetconfMessageTransformUtil.NETCONF_GET_NODEID; + import com.google.common.base.Predicates; 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.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.SettableFuture; +import edu.umd.cs.findbugs.annotations.SuppressFBWarnings; +import io.netty.util.concurrent.EventExecutor; +import java.util.ArrayList; +import java.util.Arrays; import java.util.Collection; +import java.util.Collections; import java.util.LinkedList; import java.util.List; +import java.util.Optional; import java.util.Set; -import java.util.concurrent.Callable; -import java.util.concurrent.ExecutorService; -import org.opendaylight.controller.md.sal.dom.api.DOMNotification; -import org.opendaylight.controller.md.sal.dom.api.DOMRpcException; -import org.opendaylight.controller.md.sal.dom.api.DOMRpcResult; -import org.opendaylight.controller.md.sal.dom.api.DOMRpcService; +import java.util.concurrent.ExecutionException; +import java.util.concurrent.TimeUnit; +import java.util.stream.Collectors; +import org.checkerframework.checker.lock.qual.GuardedBy; +import org.opendaylight.mdsal.dom.api.DOMRpcResult; +import org.opendaylight.mdsal.dom.api.DOMRpcService; import org.opendaylight.netconf.api.NetconfMessage; +import org.opendaylight.netconf.api.xml.XmlNetconfConstants; +import org.opendaylight.netconf.sal.connect.api.DeviceActionFactory; import org.opendaylight.netconf.sal.connect.api.MessageTransformer; +import org.opendaylight.netconf.sal.connect.api.NetconfDeviceSchemasResolver; import org.opendaylight.netconf.sal.connect.api.RemoteDevice; import org.opendaylight.netconf.sal.connect.api.RemoteDeviceCommunicator; import org.opendaylight.netconf.sal.connect.api.RemoteDeviceHandler; @@ -39,77 +48,104 @@ import org.opendaylight.netconf.sal.connect.netconf.listener.NetconfDeviceCapabi 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.sal.NetconfDeviceRpc; -import org.opendaylight.netconf.sal.connect.netconf.schema.NetconfRemoteSchemaYangSourceProvider; +import org.opendaylight.netconf.sal.connect.netconf.schema.mapping.BaseNetconfSchemas; import org.opendaylight.netconf.sal.connect.netconf.schema.mapping.BaseSchema; import org.opendaylight.netconf.sal.connect.netconf.schema.mapping.NetconfMessageTransformer; import org.opendaylight.netconf.sal.connect.netconf.util.NetconfMessageTransformUtil; import org.opendaylight.netconf.sal.connect.util.RemoteDeviceId; import org.opendaylight.yang.gen.v1.urn.ietf.params.xml.ns.yang.ietf.netconf.notifications.rev120206.NetconfCapabilityChange; +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.status.available.capabilities.AvailableCapabilityBuilder; import org.opendaylight.yang.gen.v1.urn.opendaylight.netconf.node.topology.rev150114.netconf.node.connection.status.unavailable.capabilities.UnavailableCapability; +import org.opendaylight.yangtools.rcf8528.data.util.EmptyMountPointContext; +import org.opendaylight.yangtools.rfc8528.data.api.MountPointContext; +import org.opendaylight.yangtools.rfc8528.model.api.SchemaMountConstants; import org.opendaylight.yangtools.yang.common.QName; -import org.opendaylight.yangtools.yang.model.api.SchemaContext; +import org.opendaylight.yangtools.yang.common.RpcError; +import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier; +import org.opendaylight.yangtools.yang.data.api.YangInstanceIdentifier.NodeIdentifier; +import org.opendaylight.yangtools.yang.data.api.schema.ContainerNode; +import org.opendaylight.yangtools.yang.data.api.schema.NormalizedNode; +import org.opendaylight.yangtools.yang.data.impl.schema.Builders; +import org.opendaylight.yangtools.yang.model.api.EffectiveModelContext; +import org.opendaylight.yangtools.yang.model.repo.api.EffectiveModelContextFactory; import org.opendaylight.yangtools.yang.model.repo.api.MissingSchemaSourceException; -import org.opendaylight.yangtools.yang.model.repo.api.RevisionSourceIdentifier; -import org.opendaylight.yangtools.yang.model.repo.api.SchemaContextFactory; +import org.opendaylight.yangtools.yang.model.repo.api.SchemaRepository; import org.opendaylight.yangtools.yang.model.repo.api.SchemaResolutionException; -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.spi.PotentialSchemaSource; +import org.opendaylight.yangtools.yang.model.repo.spi.SchemaSourceProvider; import org.opendaylight.yangtools.yang.model.repo.spi.SchemaSourceRegistration; import org.opendaylight.yangtools.yang.model.repo.spi.SchemaSourceRegistry; import org.slf4j.Logger; import org.slf4j.LoggerFactory; /** - * This is a mediator between NetconfDeviceCommunicator and NetconfDeviceSalFacade + * This is a mediator between NetconfDeviceCommunicator and NetconfDeviceSalFacade. */ -public class NetconfDevice implements RemoteDevice { +public class NetconfDevice + implements RemoteDevice { - private static final Logger LOG = LoggerFactory.getLogger(NetconfDevice.class); + @SuppressFBWarnings(value = "SLF4J_LOGGER_SHOULD_BE_PRIVATE", + justification = "Needed for common logging of related classes") + static final Logger LOG = LoggerFactory.getLogger(NetconfDevice.class); - public static final Function QNAME_TO_SOURCE_ID_FUNCTION = new Function() { - @Override - public SourceIdentifier apply(final QName input) { - return RevisionSourceIdentifier - .create(input.getLocalName(), Optional.fromNullable(input.getFormattedRevision())); - } - }; + private static final QName RFC8528_SCHEMA_MOUNTS_QNAME = QName.create( + SchemaMountConstants.RFC8528_MODULE, "schema-mounts").intern(); + private static final YangInstanceIdentifier RFC8528_SCHEMA_MOUNTS = YangInstanceIdentifier.create( + NodeIdentifier.create(RFC8528_SCHEMA_MOUNTS_QNAME)); protected final RemoteDeviceId id; - private final boolean reconnectOnSchemasChange; + protected final EffectiveModelContextFactory schemaContextFactory; + protected final SchemaSourceRegistry schemaRegistry; + protected final SchemaRepository schemaRepository; + + protected final List> sourceRegistrations = new ArrayList<>(); - protected final SchemaContextFactory schemaContextFactory; private final RemoteDeviceHandler salFacade; private final ListeningExecutorService processingExecutor; - protected final SchemaSourceRegistry schemaRegistry; - private final NetconfStateSchemas.NetconfStateSchemasResolver stateSchemasResolver; + private final DeviceActionFactory deviceActionFactory; + private final NetconfDeviceSchemasResolver stateSchemasResolver; private final NotificationHandler notificationHandler; - protected final List> sourceRegistrations = Lists.newArrayList(); + private final boolean reconnectOnSchemasChange; + private final BaseNetconfSchemas baseSchemas; + private final NetconfNode node; + private final EventExecutor eventExecutor; + private final NetconfNodeAugmentedOptional nodeOptional; + + @GuardedBy("this") + private boolean connected = false; // Message transformer is constructed once the schemas are available private MessageTransformer messageTransformer; - /** - * Create rpc implementation capable of handling RPC for monitoring and notifications even before the schemas of remote device are downloaded - */ - static NetconfDeviceRpc getRpcForInitialization(final NetconfDeviceCommunicator listener, final boolean notificationSupport) { - BaseSchema baseSchema = notificationSupport ? - BaseSchema.BASE_NETCONF_CTX_WITH_NOTIFICATIONS : - BaseSchema.BASE_NETCONF_CTX; - - return new NetconfDeviceRpc(baseSchema.getSchemaContext(), listener, new NetconfMessageTransformer(baseSchema.getSchemaContext(), false, baseSchema)); + public NetconfDevice(final SchemaResourcesDTO schemaResourcesDTO, final BaseNetconfSchemas baseSchemas, + final RemoteDeviceId id, final RemoteDeviceHandler salFacade, + final ListeningExecutorService globalProcessingExecutor, final boolean reconnectOnSchemasChange) { + this(schemaResourcesDTO, baseSchemas, id, salFacade, globalProcessingExecutor, reconnectOnSchemasChange, null, + null, null, null); } - protected NetconfDevice(final SchemaResourcesDTO schemaResourcesDTO, final RemoteDeviceId id, final RemoteDeviceHandler salFacade, - final ExecutorService globalProcessingExecutor, final boolean reconnectOnSchemasChange) { + public NetconfDevice(final SchemaResourcesDTO schemaResourcesDTO, final BaseNetconfSchemas baseSchemas, + final RemoteDeviceId id, final RemoteDeviceHandler salFacade, + final ListeningExecutorService globalProcessingExecutor, final boolean reconnectOnSchemasChange, + final DeviceActionFactory deviceActionFactory, final NetconfNode node, final EventExecutor eventExecutor, + final NetconfNodeAugmentedOptional nodeOptional) { + this.baseSchemas = requireNonNull(baseSchemas); this.id = id; this.reconnectOnSchemasChange = reconnectOnSchemasChange; + this.deviceActionFactory = deviceActionFactory; + this.node = node; + this.eventExecutor = eventExecutor; + this.nodeOptional = nodeOptional; this.schemaRegistry = schemaResourcesDTO.getSchemaRegistry(); + this.schemaRepository = schemaResourcesDTO.getSchemaRepository(); this.schemaContextFactory = schemaResourcesDTO.getSchemaContextFactory(); this.salFacade = salFacade; this.stateSchemasResolver = schemaResourcesDTO.getStateSchemasResolver(); - this.processingExecutor = MoreExecutors.listeningDecorator(globalProcessingExecutor); + this.processingExecutor = requireNonNull(globalProcessingExecutor); this.notificationHandler = new NotificationHandler(salFacade, id); } @@ -121,131 +157,209 @@ public class NetconfDevice implements RemoteDevice sourceResolverFuture = processingExecutor.submit(task); + final BaseSchema baseSchema = resolveBaseSchema(remoteSessionCapabilities.isNotificationsSupported()); + final NetconfDeviceRpc initRpc = new NetconfDeviceRpc(baseSchema.getEffectiveModelContext(), listener, + new NetconfMessageTransformer(baseSchema.getMountPointContext(), false, baseSchema)); + final ListenableFuture sourceResolverFuture = processingExecutor.submit( + new DeviceSourcesResolver(id, baseSchema, initRpc, remoteSessionCapabilities, stateSchemasResolver)); if (shouldListenOnSchemaChange(remoteSessionCapabilities)) { registerToBaseNetconfStream(initRpc, listener); } - final FutureCallback resolvedSourceCallback = new FutureCallback() { - @Override - public void onSuccess(final DeviceSources result) { - addProvidedSourcesToSchemaRegistry(initRpc, result); - setUpSchema(result); - } + // Set up the SchemaContext for the device + final ListenableFuture futureSchema = Futures.transformAsync(sourceResolverFuture, + deviceSources -> assembleSchemaContext(deviceSources, remoteSessionCapabilities), processingExecutor); - private void setUpSchema(final DeviceSources result) { - processingExecutor.submit(new SchemaSetup(result, remoteSessionCapabilities, listener)); - } + // Potentially acquire mount point list and interpret it + final ListenableFuture futureContext = Futures.transformAsync(futureSchema, + schemaContext -> createMountPointContext(schemaContext, baseSchema, listener), processingExecutor); + Futures.addCallback(futureContext, new FutureCallback() { @Override - public void onFailure(final Throwable t) { - LOG.warn("{}: Unexpected error resolving device sources: {}", id, t); - handleSalInitializationFailure(t, listener); + public void onSuccess(final MountPointContext result) { + handleSalInitializationSuccess(result, remoteSessionCapabilities, + getDeviceSpecificRpc(result, listener), listener); } - }; - - Futures.addCallback(sourceResolverFuture, resolvedSourceCallback); - } - private void registerToBaseNetconfStream(final NetconfDeviceRpc deviceRpc, final NetconfDeviceCommunicator listener) { - // TODO check whether the model describing create subscription is present in schema - // Perhaps add a default schema context to support create-subscription if the model was not provided (same as what we do for base netconf operations in transformer) - final CheckedFuture rpcResultListenableFuture = - deviceRpc.invokeRpc(NetconfMessageTransformUtil.toPath(NetconfMessageTransformUtil.CREATE_SUBSCRIPTION_RPC_QNAME), NetconfMessageTransformUtil.CREATE_SUBSCRIPTION_RPC_CONTENT); - - final NotificationHandler.NotificationFilter filter = new NotificationHandler.NotificationFilter() { @Override - public Optional filterNotification(final DOMNotification notification) { - if (isCapabilityChanged(notification)) { - LOG.info("{}: Schemas change detected, reconnecting", id); - // Only disconnect is enough, the reconnecting nature of the connector will take care of reconnecting - listener.disconnect(); - return Optional.absent(); + public void onFailure(final Throwable cause) { + LOG.warn("{}: Unexpected error resolving device sources", id, cause); + + // No more sources, fail or try to reconnect + if (cause instanceof EmptySchemaContextException) { + if (nodeOptional != null && nodeOptional.getIgnoreMissingSchemaSources().getAllowed()) { + eventExecutor.schedule(() -> { + LOG.warn("Reconnection is allowed! This can lead to unexpected errors at runtime."); + LOG.warn("{} : No more sources for schema context.", id); + LOG.info("{} : Try to remount device.", id); + onRemoteSessionDown(); + salFacade.onDeviceReconnected(remoteSessionCapabilities, node); + }, nodeOptional.getIgnoreMissingSchemaSources().getReconnectTime().toJava(), + TimeUnit.MILLISECONDS); + return; + } } - return Optional.of(notification); - } - private boolean isCapabilityChanged(final DOMNotification notification) { - return notification.getBody().getNodeType().equals(NetconfCapabilityChange.QNAME); + handleSalInitializationFailure(cause, listener); + salFacade.onDeviceFailed(cause); } - }; + }, MoreExecutors.directExecutor()); + } + + private void registerToBaseNetconfStream(final NetconfDeviceRpc deviceRpc, + final NetconfDeviceCommunicator listener) { + // TODO check whether the model describing create subscription is present in schema + // Perhaps add a default schema context to support create-subscription if the model was not provided + // (same as what we do for base netconf operations in transformer) + final ListenableFuture rpcResultListenableFuture = deviceRpc.invokeRpc( + NetconfMessageTransformUtil.CREATE_SUBSCRIPTION_RPC_QNAME, + NetconfMessageTransformUtil.CREATE_SUBSCRIPTION_RPC_CONTENT); Futures.addCallback(rpcResultListenableFuture, new FutureCallback() { @Override public void onSuccess(final DOMRpcResult domRpcResult) { - notificationHandler.addNotificationFilter(filter); + notificationHandler.addNotificationFilter(notification -> { + if (NetconfCapabilityChange.QNAME.equals(notification.getBody().getNodeType())) { + LOG.info("{}: Schemas change detected, reconnecting", id); + // Only disconnect is enough, + // the reconnecting nature of the connector will take care of reconnecting + listener.disconnect(); + return Optional.empty(); + } + return Optional.of(notification); + }); } @Override - public void onFailure(final Throwable t) { - LOG.warn("Unable to subscribe to base notification stream. Schemas will not be reloaded on the fly", t); + public void onFailure(final Throwable throwable) { + LOG.warn("Unable to subscribe to base notification stream. Schemas will not be reloaded on the fly", + throwable); } - }); + }, MoreExecutors.directExecutor()); } private boolean shouldListenOnSchemaChange(final NetconfSessionPreferences remoteSessionCapabilities) { return remoteSessionCapabilities.isNotificationsSupported() && reconnectOnSchemasChange; } - protected void handleSalInitializationSuccess(final SchemaContext result, final NetconfSessionPreferences remoteSessionCapabilities, final DOMRpcService deviceRpc) { - BaseSchema baseSchema = - remoteSessionCapabilities.isNotificationsSupported() ? - BaseSchema.BASE_NETCONF_CTX_WITH_NOTIFICATIONS : - BaseSchema.BASE_NETCONF_CTX; - messageTransformer = new NetconfMessageTransformer(result, true, baseSchema); - - updateTransformer(messageTransformer); - // salFacade.onDeviceConnected has to be called before the notification handler is initialized - salFacade.onDeviceConnected(result, remoteSessionCapabilities, deviceRpc); - notificationHandler.onRemoteSchemaUp(messageTransformer); - - LOG.info("{}: Netconf connector initialized successfully", id); + @SuppressFBWarnings(value = "UPM_UNCALLED_PRIVATE_METHOD", + justification = "https://github.com/spotbugs/spotbugs/issues/811") + private synchronized void handleSalInitializationSuccess(final MountPointContext result, + final NetconfSessionPreferences remoteSessionCapabilities, + final DOMRpcService deviceRpc, + final RemoteDeviceCommunicator listener) { + //NetconfDevice.SchemaSetup can complete after NetconfDeviceCommunicator was closed. In that case do nothing, + //since salFacade.onDeviceDisconnected was already called. + if (connected) { + this.messageTransformer = new NetconfMessageTransformer(result, true, + resolveBaseSchema(remoteSessionCapabilities.isNotificationsSupported())); + + // salFacade.onDeviceConnected has to be called before the notification handler is initialized + this.salFacade.onDeviceConnected(result, remoteSessionCapabilities, deviceRpc, + this.deviceActionFactory == null ? null : this.deviceActionFactory.createDeviceAction( + this.messageTransformer, listener, result.getEffectiveModelContext())); + this.notificationHandler.onRemoteSchemaUp(this.messageTransformer); + + LOG.info("{}: Netconf connector initialized successfully", id); + } else { + LOG.warn("{}: Device communicator was closed before schema setup finished.", id); + } } - protected void handleSalInitializationFailure(final Throwable t, final RemoteDeviceCommunicator listener) { - LOG.error("{}: Initialization in sal failed, disconnecting from device", id, t); + @SuppressFBWarnings(value = "UPM_UNCALLED_PRIVATE_METHOD", + justification = "https://github.com/spotbugs/spotbugs/issues/811") + private void handleSalInitializationFailure(final Throwable throwable, + final RemoteDeviceCommunicator listener) { + LOG.error("{}: Initialization in sal failed, disconnecting from device", id, throwable); listener.close(); onRemoteSessionDown(); resetMessageTransformer(); } /** - * Set the transformer to null as is in initial state + * Set the transformer to null as is in initial state. */ private void resetMessageTransformer() { updateTransformer(null); } - private void updateTransformer(final MessageTransformer transformer) { + private synchronized void updateTransformer(final MessageTransformer transformer) { messageTransformer = transformer; } - private void addProvidedSourcesToSchemaRegistry(final NetconfDeviceRpc deviceRpc, final DeviceSources deviceSources) { - final NetconfRemoteSchemaYangSourceProvider yangProvider = new NetconfRemoteSchemaYangSourceProvider(id, deviceRpc); + private synchronized void setConnected(final boolean connected) { + this.connected = connected; + } + + @SuppressFBWarnings(value = "UPM_UNCALLED_PRIVATE_METHOD", + justification = "https://github.com/spotbugs/spotbugs/issues/811") + private ListenableFuture assembleSchemaContext(final DeviceSources deviceSources, + final NetconfSessionPreferences remoteSessionCapabilities) { + LOG.debug("{}: Resolved device sources to {}", id, deviceSources); + final SchemaSourceProvider yangProvider = deviceSources.getSourceProvider(); for (final SourceIdentifier sourceId : deviceSources.getProvidedSources()) { sourceRegistrations.add(schemaRegistry.registerSchemaSource(yangProvider, - PotentialSchemaSource.create(sourceId, YangTextSchemaSource.class, PotentialSchemaSource.Costs.REMOTE_IO.getValue()))); + PotentialSchemaSource.create(sourceId, YangTextSchemaSource.class, + PotentialSchemaSource.Costs.REMOTE_IO.getValue()))); } + + return new SchemaSetup(deviceSources, remoteSessionCapabilities).startResolution(); + } + + private ListenableFuture createMountPointContext(final EffectiveModelContext schemaContext, + final BaseSchema baseSchema, final NetconfDeviceCommunicator listener) { + final MountPointContext emptyContext = new EmptyMountPointContext(schemaContext); + if (!schemaContext.findModule(SchemaMountConstants.RFC8528_MODULE).isPresent()) { + return Futures.immediateFuture(emptyContext); + } + + // Create a temporary RPC invoker and acquire the mount point tree + LOG.debug("{}: Acquiring available mount points", id); + final NetconfDeviceRpc deviceRpc = new NetconfDeviceRpc(schemaContext, listener, + new NetconfMessageTransformer(emptyContext, false, baseSchema)); + + return Futures.transform(deviceRpc.invokeRpc(NetconfMessageTransformUtil.NETCONF_GET_QNAME, + Builders.containerBuilder().withNodeIdentifier(NETCONF_GET_NODEID) + .withChild(NetconfMessageTransformUtil.toFilterStructure(RFC8528_SCHEMA_MOUNTS, schemaContext)) + .build()), rpcResult -> processSchemaMounts(rpcResult, emptyContext), MoreExecutors.directExecutor()); + } + + private MountPointContext processSchemaMounts(final DOMRpcResult rpcResult, final MountPointContext emptyContext) { + final Collection errors = rpcResult.getErrors(); + if (!errors.isEmpty()) { + LOG.warn("{}: Schema-mounts acquisition resulted in errors {}", id, errors); + } + final NormalizedNode schemaMounts = rpcResult.getResult(); + if (schemaMounts == null) { + LOG.debug("{}: device does not define any schema mounts", id); + return emptyContext; + } + if (!(schemaMounts instanceof ContainerNode)) { + LOG.warn("{}: ignoring non-container schema mounts {}", id, schemaMounts); + return emptyContext; + } + + return DeviceMountPointContext.create(emptyContext, (ContainerNode) schemaMounts); } @Override public void onRemoteSessionDown() { + setConnected(false); notificationHandler.onRemoteSchemaDown(); salFacade.onDeviceDisconnected(); - for (final SchemaSourceRegistration sourceRegistration : sourceRegistrations) { - sourceRegistration.close(); - } + sourceRegistrations.forEach(SchemaSourceRegistration::close); + sourceRegistrations.clear(); resetMessageTransformer(); } @Override public void onRemoteSessionFailed(final Throwable throwable) { + setConnected(false); salFacade.onDeviceFailed(throwable); } @@ -254,220 +368,228 @@ public class NetconfDevice implements RemoteDevice listener) { + return new NetconfDeviceRpc(result.getEffectiveModelContext(), listener, + new NetconfMessageTransformer(result, true, baseSchemas.getBaseSchema())); + } + /** * Just a transfer object containing schema related dependencies. Injected in constructor. */ public static class SchemaResourcesDTO { private final SchemaSourceRegistry schemaRegistry; - private final SchemaContextFactory schemaContextFactory; - private final NetconfStateSchemas.NetconfStateSchemasResolver stateSchemasResolver; - - public SchemaResourcesDTO(final SchemaSourceRegistry schemaRegistry, final SchemaContextFactory schemaContextFactory, final NetconfStateSchemas.NetconfStateSchemasResolver stateSchemasResolver) { - this.schemaRegistry = Preconditions.checkNotNull(schemaRegistry); - this.schemaContextFactory = Preconditions.checkNotNull(schemaContextFactory); - this.stateSchemasResolver = Preconditions.checkNotNull(stateSchemasResolver); + private final SchemaRepository schemaRepository; + private final EffectiveModelContextFactory schemaContextFactory; + private final NetconfDeviceSchemasResolver stateSchemasResolver; + + public SchemaResourcesDTO(final SchemaSourceRegistry schemaRegistry, + final SchemaRepository schemaRepository, + final EffectiveModelContextFactory schemaContextFactory, + final NetconfDeviceSchemasResolver deviceSchemasResolver) { + this.schemaRegistry = requireNonNull(schemaRegistry); + this.schemaRepository = requireNonNull(schemaRepository); + this.schemaContextFactory = requireNonNull(schemaContextFactory); + this.stateSchemasResolver = requireNonNull(deviceSchemasResolver); } public SchemaSourceRegistry getSchemaRegistry() { return schemaRegistry; } - public SchemaContextFactory getSchemaContextFactory() { - return schemaContextFactory; - } - - public NetconfStateSchemas.NetconfStateSchemasResolver getStateSchemasResolver() { - return stateSchemasResolver; - } - } - - /** - * Schema building callable. - */ - private static class DeviceSourcesResolver implements Callable { - - private final NetconfDeviceRpc deviceRpc; - private final NetconfSessionPreferences remoteSessionCapabilities; - private final RemoteDeviceId id; - private final NetconfStateSchemas.NetconfStateSchemasResolver stateSchemasResolver; - - DeviceSourcesResolver(final NetconfDeviceRpc deviceRpc, final NetconfSessionPreferences remoteSessionCapabilities, - final RemoteDeviceId id, final NetconfStateSchemas.NetconfStateSchemasResolver stateSchemasResolver) { - this.deviceRpc = deviceRpc; - this.remoteSessionCapabilities = remoteSessionCapabilities; - this.id = id; - this.stateSchemasResolver = stateSchemasResolver; + public SchemaRepository getSchemaRepository() { + return schemaRepository; } - public DeviceSourcesResolver(final NetconfSessionPreferences remoteSessionCapabilities, final RemoteDeviceId id, final NetconfStateSchemas.NetconfStateSchemasResolver stateSchemasResolver, final NetconfDeviceRpc rpcForMonitoring) { - this(rpcForMonitoring, remoteSessionCapabilities, id, stateSchemasResolver); + public EffectiveModelContextFactory getSchemaContextFactory() { + return schemaContextFactory; } - @Override - public DeviceSources call() throws Exception { - final NetconfStateSchemas availableSchemas = stateSchemasResolver.resolve(deviceRpc, remoteSessionCapabilities, id); - LOG.debug("{}: Schemas exposed by ietf-netconf-monitoring: {}", id, availableSchemas.getAvailableYangSchemasQNames()); - - final Set requiredSources = Sets.newHashSet(remoteSessionCapabilities.getModuleBasedCaps()); - final Set providedSources = availableSchemas.getAvailableYangSchemasQNames(); - - final Set requiredSourcesNotProvided = Sets.difference(requiredSources, providedSources); - if (!requiredSourcesNotProvided.isEmpty()) { - LOG.warn("{}: Netconf device does not provide all yang models reported in hello message capabilities, required but not provided: {}", - id, requiredSourcesNotProvided); - LOG.warn("{}: Attempting to build schema context from required sources", id); - } - - // Here all the sources reported in netconf monitoring are merged with those reported in hello. - // It is necessary to perform this since submodules are not mentioned in hello but still required. - // This clashes with the option of a user to specify supported yang models manually in configuration for netconf-connector - // and as a result one is not able to fully override yang models of a device. It is only possible to add additional models. - final Set providedSourcesNotRequired = Sets.difference(providedSources, requiredSources); - if (!providedSourcesNotRequired.isEmpty()) { - LOG.warn("{}: Netconf device provides additional yang models not reported in hello message capabilities: {}", - id, providedSourcesNotRequired); - LOG.warn("{}: Adding provided but not required sources as required to prevent failures", id); - LOG.debug("{}: Netconf device reported in hello: {}", id, requiredSources); - requiredSources.addAll(providedSourcesNotRequired); - } - - return new DeviceSources(requiredSources, providedSources); + public NetconfDeviceSchemasResolver getStateSchemasResolver() { + return stateSchemasResolver; } } /** - * Contains RequiredSources - sources from capabilities. + * A dedicated exception to indicate when we fail to setup a SchemaContext. + * + * @author Robert Varga */ - private static final class DeviceSources { - private final Set requiredSources; - private final Set providedSources; - - public DeviceSources(final Set requiredSources, final Set providedSources) { - this.requiredSources = requiredSources; - this.providedSources = providedSources; - } - - public Set getRequiredSourcesQName() { - return requiredSources; - } + private static final class EmptySchemaContextException extends Exception { + private static final long serialVersionUID = 1L; - public Set getProvidedSourcesQName() { - return providedSources; + EmptySchemaContextException(final String message) { + super(message); } - - public Collection getRequiredSources() { - return Collections2.transform(requiredSources, QNAME_TO_SOURCE_ID_FUNCTION); - } - - public Collection getProvidedSources() { - return Collections2.transform(providedSources, QNAME_TO_SOURCE_ID_FUNCTION); - } - } /** * Schema builder that tries to build schema context from provided sources or biggest subset of it. */ - private final class SchemaSetup implements Runnable { + private final class SchemaSetup implements FutureCallback { + private final SettableFuture resultFuture = SettableFuture.create(); + private final DeviceSources deviceSources; private final NetconfSessionPreferences remoteSessionCapabilities; - private final RemoteDeviceCommunicator listener; private final NetconfDeviceCapabilities capabilities; - public SchemaSetup(final DeviceSources deviceSources, final NetconfSessionPreferences remoteSessionCapabilities, final RemoteDeviceCommunicator listener) { + private Collection requiredSources; + + SchemaSetup(final DeviceSources deviceSources, final NetconfSessionPreferences remoteSessionCapabilities) { this.deviceSources = deviceSources; this.remoteSessionCapabilities = remoteSessionCapabilities; - this.listener = listener; this.capabilities = remoteSessionCapabilities.getNetconfDeviceCapabilities(); + + // If device supports notifications and does not contain necessary modules, add them automatically + if (remoteSessionCapabilities.containsNonModuleCapability( + XmlNetconfConstants.URN_IETF_PARAMS_NETCONF_CAPABILITY_NOTIFICATION_1_0)) { + deviceSources.getRequiredSourcesQName().addAll( + Arrays.asList( + org.opendaylight.yang.gen.v1.urn.ietf.params.xml.ns.netconf.notification._1._0.rev080714 + .$YangModuleInfoImpl.getInstance().getName(), + org.opendaylight.yang.gen.v1.urn.ietf.params.xml.ns.yang.ietf.yang.types.rev130715 + .$YangModuleInfoImpl.getInstance().getName() + ) + ); + } + + requiredSources = deviceSources.getRequiredSources(); + final Collection missingSources = filterMissingSources(requiredSources); + + capabilities.addUnresolvedCapabilities(getQNameFromSourceIdentifiers(missingSources), + UnavailableCapability.FailureReason.MissingSource); + requiredSources.removeAll(missingSources); + } + + ListenableFuture startResolution() { + trySetupSchema(); + return resultFuture; } @Override - public void run() { - setUpSchema(deviceSources.getRequiredSources()); + public void onSuccess(final EffectiveModelContext result) { + LOG.debug("{}: Schema context built successfully from {}", id, requiredSources); + + final Collection filteredQNames = Sets.difference(deviceSources.getRequiredSourcesQName(), + capabilities.getUnresolvedCapabilites().keySet()); + capabilities.addCapabilities(filteredQNames.stream().map(entry -> new AvailableCapabilityBuilder() + .setCapability(entry.toString()).setCapabilityOrigin( + remoteSessionCapabilities.getModuleBasedCapsOrigin().get(entry)).build()) + .collect(Collectors.toList())); + + capabilities.addNonModuleBasedCapabilities(remoteSessionCapabilities + .getNonModuleCaps().stream().map(entry -> new AvailableCapabilityBuilder() + .setCapability(entry).setCapabilityOrigin( + remoteSessionCapabilities.getNonModuleBasedCapsOrigin().get(entry)).build()) + .collect(Collectors.toList())); + + resultFuture.set(result); } - /** - * Build schema context, in case of success or final failure notify device - */ - private void setUpSchema(Collection requiredSources) { - while (!requiredSources.isEmpty()) { + @Override + public void onFailure(final Throwable cause) { + // schemaBuilderFuture.checkedGet() throws only SchemaResolutionException + // that might be wrapping a MissingSchemaSourceException so we need to look + // at the cause of the exception to make sure we don't misinterpret it. + if (cause instanceof MissingSchemaSourceException) { + requiredSources = handleMissingSchemaSourceException((MissingSchemaSourceException) cause); + } else if (cause instanceof SchemaResolutionException) { + requiredSources = handleSchemaResolutionException((SchemaResolutionException) cause); + } else { + LOG.debug("Unhandled failure", cause); + resultFuture.setException(cause); + // No more trying... + return; + } + + trySetupSchema(); + } + + private void trySetupSchema() { + if (!requiredSources.isEmpty()) { + // Initiate async resolution, drive it back based on the result LOG.trace("{}: Trying to build schema context from {}", id, requiredSources); + Futures.addCallback(schemaContextFactory.createEffectiveModelContext(requiredSources), this, + MoreExecutors.directExecutor()); + } else { + LOG.debug("{}: no more sources for schema context", id); + resultFuture.setException(new EmptySchemaContextException(id + ": No more sources for schema context")); + } + } + + private Collection filterMissingSources(final Collection origSources) { + return origSources.parallelStream().filter(sourceIdentifier -> { try { - final CheckedFuture schemaBuilderFuture = schemaContextFactory.createSchemaContext(requiredSources); - final SchemaContext result = schemaBuilderFuture.checkedGet(); - LOG.debug("{}: Schema context built successfully from {}", id, requiredSources); - final Collection filteredQNames = Sets.difference(deviceSources.getRequiredSourcesQName(), capabilities.getUnresolvedCapabilites().keySet()); - capabilities.addCapabilities(filteredQNames); - capabilities.addNonModuleBasedCapabilities(remoteSessionCapabilities.getNonModuleCaps()); - handleSalInitializationSuccess(result, remoteSessionCapabilities, getDeviceSpecificRpc(result)); - return; - } catch (Throwable t) { - if (t instanceof MissingSchemaSourceException){ - requiredSources = handleMissingSchemaSourceException(requiredSources, (MissingSchemaSourceException) t); - } else if (t instanceof SchemaResolutionException) { - // schemaBuilderFuture.checkedGet() throws only SchemaResolutionException - // that might be wrapping a MissingSchemaSourceException so we need to look - // at the cause of the exception to make sure we don't misinterpret it. - if (t.getCause() instanceof MissingSchemaSourceException) { - requiredSources = handleMissingSchemaSourceException(requiredSources, (MissingSchemaSourceException) t.getCause()); - continue; - } - requiredSources = handleSchemaResolutionException(requiredSources, (SchemaResolutionException) t); - } else { - // unknown error, fail - handleSalInitializationFailure(t, listener); - return; - } + schemaRepository.getSchemaSource(sourceIdentifier, YangTextSchemaSource.class).get(); + return false; + } catch (InterruptedException | ExecutionException e) { + return true; } - } - // No more sources, fail - final IllegalStateException cause = new IllegalStateException(id + ": No more sources for schema context"); - handleSalInitializationFailure(cause, listener); - salFacade.onDeviceFailed(cause); + }).collect(Collectors.toList()); } - private Collection handleMissingSchemaSourceException(Collection requiredSources, final MissingSchemaSourceException t) { + private Collection handleMissingSchemaSourceException( + final MissingSchemaSourceException exception) { // In case source missing, try without it - final SourceIdentifier missingSource = t.getSourceId(); - LOG.warn("{}: Unable to build schema context, missing source {}, will reattempt without it", id, missingSource); - LOG.debug("{}: Unable to build schema context, missing source {}, will reattempt without it", t); - final Collection qNameOfMissingSource = getQNameFromSourceIdentifiers(Sets.newHashSet(missingSource)); + final SourceIdentifier missingSource = exception.getSourceId(); + LOG.warn("{}: Unable to build schema context, missing source {}, will reattempt without it", + id, missingSource); + LOG.debug("{}: Unable to build schema context, missing source {}, will reattempt without it", + id, missingSource, exception); + final Collection qNameOfMissingSource = + getQNameFromSourceIdentifiers(Sets.newHashSet(missingSource)); if (!qNameOfMissingSource.isEmpty()) { - capabilities.addUnresolvedCapabilities(qNameOfMissingSource, UnavailableCapability.FailureReason.MissingSource); + capabilities.addUnresolvedCapabilities( + qNameOfMissingSource, UnavailableCapability.FailureReason.MissingSource); } - return stripMissingSource(requiredSources, missingSource); + return stripUnavailableSource(missingSource); } - private Collection handleSchemaResolutionException(Collection requiredSources, final SchemaResolutionException resolutionException) { + private Collection handleSchemaResolutionException( + final SchemaResolutionException resolutionException) { // In case resolution error, try only with resolved sources + // There are two options why schema resolution exception occurred : unsatisfied imports or flawed model + // FIXME Do we really have assurance that these two cases cannot happen at once? + if (resolutionException.getFailedSource() != null) { + // flawed model - exclude it + final SourceIdentifier failedSourceId = resolutionException.getFailedSource(); + LOG.warn("{}: Unable to build schema context, failed to resolve source {}, will reattempt without it", + id, failedSourceId); + LOG.warn("{}: Unable to build schema context, failed to resolve source {}, will reattempt without it", + id, failedSourceId, resolutionException); + capabilities.addUnresolvedCapabilities( + getQNameFromSourceIdentifiers(Collections.singleton(failedSourceId)), + UnavailableCapability.FailureReason.UnableToResolve); + return stripUnavailableSource(resolutionException.getFailedSource()); + } + // unsatisfied imports final Set unresolvedSources = resolutionException.getUnsatisfiedImports().keySet(); - capabilities.addUnresolvedCapabilities(getQNameFromSourceIdentifiers(unresolvedSources), UnavailableCapability.FailureReason.UnableToResolve); - LOG.warn("{}: Unable to build schema context, unsatisfied imports {}, will reattempt with resolved only", id, resolutionException.getUnsatisfiedImports()); - LOG.debug("{}: Unable to build schema context, unsatisfied imports {}, will reattempt with resolved only", resolutionException); + capabilities.addUnresolvedCapabilities(getQNameFromSourceIdentifiers(unresolvedSources), + UnavailableCapability.FailureReason.UnableToResolve); + LOG.warn("{}: Unable to build schema context, unsatisfied imports {}, will reattempt with resolved only", + id, resolutionException.getUnsatisfiedImports()); + LOG.debug("{}: Unable to build schema context, unsatisfied imports {}, will reattempt with resolved only", + id, resolutionException.getUnsatisfiedImports(), resolutionException); return resolutionException.getResolvedSources(); } - protected NetconfDeviceRpc getDeviceSpecificRpc(final SchemaContext result) { - return new NetconfDeviceRpc(result, listener, new NetconfMessageTransformer(result, true)); - } - - private Collection stripMissingSource(final Collection requiredSources, final SourceIdentifier sIdToRemove) { - final LinkedList sourceIdentifiers = Lists.newLinkedList(requiredSources); - final boolean removed = sourceIdentifiers.remove(sIdToRemove); - Preconditions.checkState(removed, "{}: Trying to remove {} from {} failed", id, sIdToRemove, requiredSources); + private Collection stripUnavailableSource(final SourceIdentifier sourceIdToRemove) { + final LinkedList sourceIdentifiers = new LinkedList<>(requiredSources); + checkState(sourceIdentifiers.remove(sourceIdToRemove), + "%s: Trying to remove %s from %s failed", id, sourceIdToRemove, requiredSources); return sourceIdentifiers; } private Collection getQNameFromSourceIdentifiers(final Collection identifiers) { - final Collection qNames = Collections2.transform(identifiers, new Function() { - @Override - public QName apply(final SourceIdentifier sourceIdentifier) { - return getQNameFromSourceIdentifier(sourceIdentifier); - } - }); + final Collection qNames = Collections2.transform(identifiers, this::getQNameFromSourceIdentifier); if (qNames.isEmpty()) { - LOG.debug("{}: Unable to map any source identifiers to a capability reported by device : {}", id, identifiers); + LOG.debug("{}: Unable to map any source identifiers to a capability reported by device : {}", id, + identifiers); } return Collections2.filter(qNames, Predicates.notNull()); } @@ -475,21 +597,18 @@ public class NetconfDevice implements RemoteDevice