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=451fb057c467850637732598e7def7a56ee9d4f5;hb=33d6351332b51e2cfd454daf673c7663b03f096c;hp=45e67e363140a6778bf789e754397e232f961a24;hpb=50351b4cb37a1998cfaef53ff584aeb767c25f50;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 45e67e3631..451fb057c4 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,32 +7,38 @@ */ package org.opendaylight.netconf.sal.connect.netconf; -import com.google.common.base.Function; -import com.google.common.base.Optional; +import static java.util.Objects.requireNonNull; + import com.google.common.base.Preconditions; 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.FluentFuture; 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 io.netty.util.concurrent.EventExecutor; +import java.util.ArrayList; 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 java.util.concurrent.ExecutionException; +import java.util.concurrent.TimeUnit; import java.util.stream.Collectors; -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 javax.annotation.Nonnull; +import javax.annotation.concurrent.GuardedBy; +import org.opendaylight.mdsal.dom.api.DOMNotification; +import org.opendaylight.mdsal.dom.api.DOMRpcResult; +import org.opendaylight.mdsal.dom.api.DOMRpcService; import org.opendaylight.netconf.api.NetconfMessage; +import org.opendaylight.netconf.sal.connect.api.DeviceActionFactory; import org.opendaylight.netconf.sal.connect.api.MessageTransformer; import org.opendaylight.netconf.sal.connect.api.NetconfDeviceSchemas; import org.opendaylight.netconf.sal.connect.api.NetconfDeviceSchemasResolver; @@ -50,6 +56,8 @@ import org.opendaylight.netconf.sal.connect.netconf.schema.mapping.NetconfMessag 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.yang.common.QName; @@ -59,7 +67,6 @@ 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.SchemaSourceException; 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; @@ -67,7 +74,6 @@ 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.opendaylight.yangtools.yang.parser.util.ASTSchemaSource; import org.slf4j.Logger; import org.slf4j.LoggerFactory; @@ -79,22 +85,26 @@ public class NetconfDevice private static final Logger LOG = LoggerFactory.getLogger(NetconfDevice.class); - public static final Function QNAME_TO_SOURCE_ID_FUNCTION = - input -> RevisionSourceIdentifier.create(input.getLocalName(), - Optional.fromNullable(input.getFormattedRevision())); - protected final RemoteDeviceId id; - private final boolean reconnectOnSchemasChange; - protected final SchemaContextFactory schemaContextFactory; - private final RemoteDeviceHandler salFacade; - private final ListeningExecutorService processingExecutor; protected final SchemaSourceRegistry schemaRegistry; protected final SchemaRepository schemaRepository; + + protected final List> sourceRegistrations = + new ArrayList<>(); + + private final RemoteDeviceHandler salFacade; + private final ListeningExecutorService processingExecutor; + private final DeviceActionFactory deviceActionFactory; private final NetconfDeviceSchemasResolver stateSchemasResolver; private final NotificationHandler notificationHandler; - protected final List> sourceRegistrations = - Lists.newArrayList(); + private final boolean reconnectOnSchemasChange; + 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; @@ -115,15 +125,29 @@ public class NetconfDevice public NetconfDevice(final SchemaResourcesDTO schemaResourcesDTO, final RemoteDeviceId id, final RemoteDeviceHandler salFacade, - final ExecutorService globalProcessingExecutor, final boolean reconnectOnSchemasChange) { + final ListeningExecutorService globalProcessingExecutor, + final boolean reconnectOnSchemasChange) { + this(schemaResourcesDTO, id, salFacade, globalProcessingExecutor, reconnectOnSchemasChange, null, null, null, + null); + } + + public NetconfDevice(final SchemaResourcesDTO schemaResourcesDTO, 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.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); } @@ -135,6 +159,7 @@ public class NetconfDevice // Yang models are being downloaded in this method and it would cause a // deadlock if we used the netty thread // http://netty.io/wiki/thread-model.html + setConnected(true); LOG.debug("{}: Session to remote device established with {}", id, remoteSessionCapabilities); final NetconfDeviceRpc initRpc = @@ -149,7 +174,7 @@ public class NetconfDevice final FutureCallback resolvedSourceCallback = new FutureCallback() { @Override - public void onSuccess(final DeviceSources result) { + public void onSuccess(@Nonnull final DeviceSources result) { addProvidedSourcesToSchemaRegistry(result); setUpSchema(result); } @@ -160,22 +185,22 @@ public class NetconfDevice @Override public void onFailure(final Throwable throwable) { - LOG.warn("{}: Unexpected error resolving device sources: {}", id, throwable); + LOG.warn("{}: Unexpected error resolving device sources", id, throwable); handleSalInitializationFailure(throwable, listener); } }; - Futures.addCallback(sourceResolverFuture, resolvedSourceCallback); + Futures.addCallback(sourceResolverFuture, resolvedSourceCallback, MoreExecutors.directExecutor()); } private void registerToBaseNetconfStream(final NetconfDeviceRpc deviceRpc, final NetconfDeviceCommunicator listener) { - // TODO check whether the model describing create subscription is present in schema + // 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 FluentFuture rpcResultListenableFuture = deviceRpc.invokeRpc( + NetconfMessageTransformUtil.toPath(NetconfMessageTransformUtil.CREATE_SUBSCRIPTION_RPC_QNAME), + NetconfMessageTransformUtil.CREATE_SUBSCRIPTION_RPC_CONTENT); final NotificationHandler.NotificationFilter filter = new NotificationHandler.NotificationFilter() { @Override @@ -185,7 +210,7 @@ public class NetconfDevice // Only disconnect is enough, // the reconnecting nature of the connector will take care of reconnecting listener.disconnect(); - return Optional.absent(); + return Optional.empty(); } return Optional.of(notification); } @@ -206,31 +231,40 @@ public class NetconfDevice 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; } - void handleSalInitializationSuccess(final SchemaContext result, + private synchronized void handleSalInitializationSuccess(final SchemaContext result, final NetconfSessionPreferences remoteSessionCapabilities, - final DOMRpcService deviceRpc) { - final BaseSchema baseSchema = + 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) { + final 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); + this.messageTransformer = new NetconfMessageTransformer(result, true, baseSchema); + + updateTransformer(this.messageTransformer); + // 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)); + this.notificationHandler.onRemoteSchemaUp(this.messageTransformer); + + LOG.info("{}: Netconf connector initialized successfully", id); + } else { + LOG.warn("{}: Device communicator was closed before schema setup finished.", id); + } } - void handleSalInitializationFailure(final Throwable throwable, - final RemoteDeviceCommunicator listener) { + private void handleSalInitializationFailure(final Throwable throwable, + final RemoteDeviceCommunicator listener) { LOG.error("{}: Initialization in sal failed, disconnecting from device", id, throwable); listener.close(); onRemoteSessionDown(); @@ -244,10 +278,14 @@ public class NetconfDevice updateTransformer(null); } - private void updateTransformer(final MessageTransformer transformer) { + private synchronized void updateTransformer(final MessageTransformer transformer) { messageTransformer = transformer; } + private synchronized void setConnected(final boolean connected) { + this.connected = connected; + } + private void addProvidedSourcesToSchemaRegistry(final DeviceSources deviceSources) { final SchemaSourceProvider yangProvider = deviceSources.getSourceProvider(); for (final SourceIdentifier sourceId : deviceSources.getProvidedSources()) { @@ -259,6 +297,7 @@ public class NetconfDevice @Override public void onRemoteSessionDown() { + setConnected(false); notificationHandler.onRemoteSchemaDown(); salFacade.onDeviceDisconnected(); @@ -271,6 +310,7 @@ public class NetconfDevice @Override public void onRemoteSessionFailed(final Throwable throwable) { + setConnected(false); salFacade.onDeviceFailed(throwable); } @@ -341,7 +381,7 @@ public class NetconfDevice } @Override - public DeviceSources call() throws Exception { + public DeviceSources call() { final NetconfDeviceSchemas availableSchemas = stateSchemasResolver.resolve(deviceRpc, remoteSessionCapabilities, id); LOG.debug("{}: Schemas exposed by ietf-netconf-monitoring: {}", id, @@ -407,16 +447,20 @@ public class NetconfDevice } public Collection getRequiredSources() { - return Collections2.transform(requiredSources, QNAME_TO_SOURCE_ID_FUNCTION); + return Collections2.transform(requiredSources, DeviceSources::toSourceId); } public Collection getProvidedSources() { - return Collections2.transform(providedSources, QNAME_TO_SOURCE_ID_FUNCTION); + return Collections2.transform(providedSources, DeviceSources::toSourceId); } public SchemaSourceProvider getSourceProvider() { return sourceProvider; } + + private static SourceIdentifier toSourceId(final QName input) { + return RevisionSourceIdentifier.create(input.getLocalName(), input.getRevision()); + } } /** @@ -450,29 +494,29 @@ public class NetconfDevice } private Collection filterMissingSources(final Collection requiredSources) { - return requiredSources.parallelStream().filter(sourceIdentifier -> { - boolean remove = false; try { - schemaRepository.getSchemaSource(sourceIdentifier, ASTSchemaSource.class).checkedGet(); - } catch (SchemaSourceException e) { - remove = true; + schemaRepository.getSchemaSource(sourceIdentifier, YangTextSchemaSource.class).get(); + return false; + } catch (InterruptedException | ExecutionException e) { + return true; } - return remove; }).collect(Collectors.toList()); } /** * Build schema context, in case of success or final failure notify device. + * + * @param requiredSources required sources */ @SuppressWarnings("checkstyle:IllegalCatch") private void setUpSchema(Collection requiredSources) { while (!requiredSources.isEmpty()) { LOG.trace("{}: Trying to build schema context from {}", id, requiredSources); try { - final CheckedFuture schemaBuilderFuture = - schemaContextFactory.createSchemaContext(requiredSources); - final SchemaContext result = schemaBuilderFuture.checkedGet(); + final ListenableFuture schemaBuilderFuture = schemaContextFactory + .createSchemaContext(requiredSources); + final SchemaContext result = schemaBuilderFuture.get(); LOG.debug("{}: Schema context built successfully from {}", id, requiredSources); final Collection filteredQNames = Sets.difference(deviceSources.getRequiredSourcesQName(), capabilities.getUnresolvedCapabilites().keySet()); @@ -483,50 +527,64 @@ public class NetconfDevice capabilities.addNonModuleBasedCapabilities(remoteSessionCapabilities .getNonModuleCaps().stream().map(entry -> new AvailableCapabilityBuilder() - .setCapability(entry).setCapabilityOrigin( + .setCapability(entry).setCapabilityOrigin( remoteSessionCapabilities.getNonModuleBasedCapsOrigin().get(entry)).build()) .collect(Collectors.toList())); - handleSalInitializationSuccess(result, remoteSessionCapabilities, getDeviceSpecificRpc(result)); + handleSalInitializationSuccess(result, remoteSessionCapabilities, getDeviceSpecificRpc(result), + listener); return; - } catch (final 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); + } catch (final ExecutionException e) { + // 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. + final Throwable cause = e.getCause(); + + if (cause instanceof MissingSchemaSourceException) { + requiredSources = handleMissingSchemaSourceException( + requiredSources, (MissingSchemaSourceException) cause); + continue; + } + if (cause instanceof SchemaResolutionException) { + requiredSources = handleSchemaResolutionException(requiredSources, + (SchemaResolutionException) cause); } else { - // unknown error, fail - handleSalInitializationFailure(t, listener); + handleSalInitializationFailure(e, listener); return; } + } catch (final Exception e) { + // unknown error, fail + handleSalInitializationFailure(e, listener); + return; } } - // No more sources, fail - final IllegalStateException cause = new IllegalStateException(id + ": No more sources for schema context"); - handleSalInitializationFailure(cause, listener); - salFacade.onDeviceFailed(cause); + // No more sources, fail or try to reconnect + if (nodeOptional != null && nodeOptional.getIgnoreMissingSchemaSources().isAllowed()) { + 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(), TimeUnit.MILLISECONDS); + } else { + final IllegalStateException cause = + new IllegalStateException(id + ": No more sources for schema context"); + handleSalInitializationFailure(cause, listener); + salFacade.onDeviceFailed(cause); + } } private Collection handleMissingSchemaSourceException( final Collection requiredSources, final MissingSchemaSourceException exception) { // In case source missing, try without it final SourceIdentifier missingSource = exception.getSourceId(); - LOG.warn("{}: Unable to build schema context, missing source {}, will reattempt without it", id, - missingSource); + 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", - exception); + id, missingSource, exception); final Collection qNameOfMissingSource = - getQNameFromSourceIdentifiers(Sets.newHashSet(missingSource)); + getQNameFromSourceIdentifiers(Sets.newHashSet(missingSource)); if (!qNameOfMissingSource.isEmpty()) { capabilities.addUnresolvedCapabilities( qNameOfMissingSource, UnavailableCapability.FailureReason.MissingSource); @@ -543,21 +601,22 @@ public class NetconfDevice // 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); + id, failedSourceId); LOG.warn("{}: Unable to build schema context, failed to resolve source {}, will reattempt without it", - id, resolutionException); - capabilities.addUnresolvedCapabilities(getQNameFromSourceIdentifiers( - Collections.singleton(failedSourceId)), UnavailableCapability.FailureReason.UnableToResolve); + id, failedSourceId, resolutionException); + capabilities.addUnresolvedCapabilities( + getQNameFromSourceIdentifiers(Collections.singleton(failedSourceId)), + UnavailableCapability.FailureReason.UnableToResolve); return stripUnavailableSource(requiredSources, resolutionException.getFailedSource()); } // unsatisfied imports final Set unresolvedSources = resolutionException.getUnsatisfiedImports().keySet(); - capabilities.addUnresolvedCapabilities( - getQNameFromSourceIdentifiers(unresolvedSources), UnavailableCapability.FailureReason.UnableToResolve); + capabilities.addUnresolvedCapabilities(getQNameFromSourceIdentifiers(unresolvedSources), + UnavailableCapability.FailureReason.UnableToResolve); LOG.warn("{}: Unable to build schema context, unsatisfied imports {}, will reattempt with resolved only", - id, resolutionException.getUnsatisfiedImports()); + id, resolutionException.getUnsatisfiedImports()); LOG.debug("{}: Unable to build schema context, unsatisfied imports {}, will reattempt with resolved only", - resolutionException); + id, resolutionException.getUnsatisfiedImports(), resolutionException); return resolutionException.getResolvedSources(); } @@ -591,12 +650,7 @@ public class NetconfDevice continue; } - final String rev = getNullableRev(identifier); - if (rev == null) { - if (qname.getRevision() == null) { - return qname; - } - } else if (qname.getFormattedRevision().equals(rev)) { + if (identifier.getRevision().equals(qname.getRevision())) { return qname; } } @@ -606,10 +660,5 @@ public class NetconfDevice // this capability will be removed from required sources and not reported as unresolved-capability return null; } - - private String getNullableRev(final SourceIdentifier identifier) { - final String rev = identifier.getRevision(); - return rev == null || SourceIdentifier.NOT_PRESENT_FORMATTED_REVISION.equals(rev) ? null : rev; - } } }