Magnesium platform upgrade
[lispflowmapping.git] / mappingservice / southbound / src / main / java / org / opendaylight / lispflowmapping / southbound / LispSouthboundPlugin.java
index 356dc5b88263c5237b82e45034963818ad4ef1ea..6bc70e716799155b0cab62e0cdde2e3880974fc7 100644 (file)
@@ -1,5 +1,5 @@
 /*
- * Copyright (c) 2013 Contextream, Inc. and others.  All rights reserved.
+ * Copyright (c) 2014 Contextream, Inc. and others.  All rights reserved.
  *
  * This program and the accompanying materials are made available under the
  * terms of the Eclipse Public License v1.0 which accompanies this distribution,
 
 package org.opendaylight.lispflowmapping.southbound;
 
-import java.io.IOException;
-import java.net.DatagramPacket;
-import java.net.DatagramSocket;
+import static io.netty.buffer.Unpooled.wrappedBuffer;
+
+import com.google.common.base.Preconditions;
+import com.google.common.util.concurrent.Futures;
+import com.google.common.util.concurrent.ListenableFuture;
+import io.netty.bootstrap.Bootstrap;
+import io.netty.buffer.ByteBuf;
+import io.netty.buffer.ByteBufUtil;
+import io.netty.buffer.PooledByteBufAllocator;
+import io.netty.channel.Channel;
+import io.netty.channel.ChannelOption;
+import io.netty.channel.EventLoopGroup;
+import io.netty.channel.epoll.Epoll;
+import io.netty.channel.epoll.EpollChannelOption;
+import io.netty.channel.epoll.EpollDatagramChannel;
+import io.netty.channel.epoll.EpollEventLoopGroup;
+import io.netty.channel.nio.NioEventLoopGroup;
+import io.netty.channel.socket.DatagramPacket;
+import io.netty.channel.socket.nio.NioDatagramChannel;
+import io.netty.util.concurrent.DefaultThreadFactory;
 import java.net.InetAddress;
 import java.net.InetSocketAddress;
-import java.net.SocketException;
-import java.net.SocketTimeoutException;
+import java.net.UnknownHostException;
 import java.nio.ByteBuffer;
-import java.util.concurrent.Future;
-
-import org.eclipse.osgi.framework.console.CommandProvider;
-import org.opendaylight.controller.sal.binding.api.AbstractBindingAwareProvider;
-import org.opendaylight.controller.sal.binding.api.BindingAwareBroker.ProviderContext;
-import org.opendaylight.controller.sal.binding.api.NotificationProviderService;
-import org.opendaylight.lispflowmapping.implementation.serializer.LispMessage;
-import org.opendaylight.lispflowmapping.implementation.serializer.MapNotifySerializer;
-import org.opendaylight.lispflowmapping.implementation.serializer.MapReplySerializer;
-import org.opendaylight.lispflowmapping.southbound.lisp.LispSouthboundService;
-import org.opendaylight.lispflowmapping.type.lisp.MapNotify;
-import org.opendaylight.lispflowmapping.type.lisp.MapReply;
-import org.opendaylight.lispflowmapping.type.sbplugin.ILispSouthboundPlugin;
-import org.opendaylight.yangtools.yang.common.RpcResult;
-import org.osgi.framework.BundleContext;
-import org.osgi.framework.FrameworkUtil;
+import java.util.List;
+import java.util.concurrent.ThreadFactory;
+import org.opendaylight.lispflowmapping.dsbackend.DataStoreBackEnd;
+import org.opendaylight.lispflowmapping.inmemorydb.HashMapDb;
+import org.opendaylight.lispflowmapping.lisp.type.LispMessage;
+import org.opendaylight.lispflowmapping.lisp.util.LispAddressStringifier;
+import org.opendaylight.lispflowmapping.mapcache.AuthKeyDb;
+import org.opendaylight.lispflowmapping.southbound.lisp.AuthenticationKeyDataListener;
+import org.opendaylight.lispflowmapping.southbound.lisp.LispSouthboundHandler;
+import org.opendaylight.lispflowmapping.southbound.lisp.LispXtrSouthboundHandler;
+import org.opendaylight.lispflowmapping.southbound.lisp.cache.MapRegisterCache;
+import org.opendaylight.lispflowmapping.type.sbplugin.IConfigLispSouthboundPlugin;
+import org.opendaylight.mdsal.binding.api.DataBroker;
+import org.opendaylight.mdsal.binding.api.NotificationPublishService;
+import org.opendaylight.mdsal.singleton.common.api.ClusterSingletonService;
+import org.opendaylight.mdsal.singleton.common.api.ClusterSingletonServiceProvider;
+import org.opendaylight.mdsal.singleton.common.api.ServiceGroupIdentifier;
+import org.opendaylight.yang.gen.v1.urn.opendaylight.lfm.inet.binary.types.rev160303.IpAddressBinary;
+import org.opendaylight.yang.gen.v1.urn.opendaylight.lfm.lisp.proto.rev151105.MessageType;
+import org.opendaylight.yang.gen.v1.urn.opendaylight.lfm.lisp.proto.rev151105.eid.container.Eid;
+import org.opendaylight.yang.gen.v1.urn.opendaylight.lfm.lisp.proto.rev151105.mapping.authkey.container.MappingAuthkey;
+import org.opendaylight.yang.gen.v1.urn.opendaylight.lfm.lisp.proto.rev151105.transport.address.TransportAddress;
+import org.opendaylight.yang.gen.v1.urn.opendaylight.lfm.mappingservice.rev150906.db.instance.AuthenticationKey;
+import org.opendaylight.yangtools.yang.binding.Notification;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class LispSouthboundPlugin extends AbstractBindingAwareProvider implements ILispSouthboundPlugin, CommandProvider {
-    protected static final Logger logger = LoggerFactory.getLogger(LispSouthboundPlugin.class);
+public class LispSouthboundPlugin implements IConfigLispSouthboundPlugin, AutoCloseable, ClusterSingletonService {
+    protected static final Logger LOG = LoggerFactory.getLogger(LispSouthboundPlugin.class);
+    public static final String LISPFLOWMAPPING_ENTITY_NAME = "lispflowmapping";
+    public static final ServiceGroupIdentifier SERVICE_GROUP_IDENTIFIER = ServiceGroupIdentifier.create(
+            LISPFLOWMAPPING_ENTITY_NAME);
 
-    private LispIoThread thread;
-    private LispSouthboundService lispSouthboundService;
-    private volatile DatagramSocket socket = null;
-    private final String MAP_NOTIFY = "MapNotify";
-    private final String MAP_REPlY = "MapReply";
+    private volatile boolean isMaster = false;
+    private volatile String bindingAddress;
+    private AuthKeyDb akdb;
+    private final MapRegisterCache mapRegisterCache = new MapRegisterCache();
+    private boolean mapRegisterCacheEnabled;
+    private long mapRegisterCacheTimeout;
 
-    private void registerWithOSGIConsole() {
-        BundleContext bundleContext = FrameworkUtil.getBundle(this.getClass()).getBundleContext();
-        bundleContext.registerService(CommandProvider.class.getName(), this, null);
-    }
+    private static Object startLock = new Object();
+    private final ClusterSingletonServiceProvider clusterSingletonService;
+    private LispSouthboundHandler lispSouthboundHandler;
+    private LispXtrSouthboundHandler lispXtrSouthboundHandler;
+    private final NotificationPublishService notificationPublishService;
+    private int numChannels = 1;
+    private final Channel[] channel;
+    private Channel xtrChannel;
+    private Class channelType;
+    private volatile int xtrPort = LispMessage.XTR_PORT_NUM;
+    private volatile boolean listenOnXtrPort = false;
+    private final ConcurrentLispSouthboundStats statistics = new ConcurrentLispSouthboundStats();
+    private final Bootstrap bootstrap = new Bootstrap();
+    private final Bootstrap xtrBootstrap = new Bootstrap();
+    private final ThreadFactory threadFactory = new DefaultThreadFactory("lisp-sb");
+    private EventLoopGroup eventLoopGroup;
+    private final DataBroker dataBroker;
+    private AuthenticationKeyDataListener authenticationKeyDataListener;
+    private DataStoreBackEnd dsbe;
 
-    protected void stopImpl(BundleContext context) {
-        unloadActions();
+    public LispSouthboundPlugin(final DataBroker dataBroker,
+            final NotificationPublishService notificationPublishService,
+            final ClusterSingletonServiceProvider clusterSingletonService) {
+        this.dataBroker = dataBroker;
+        this.notificationPublishService = notificationPublishService;
+        this.clusterSingletonService = clusterSingletonService;
+        if (Epoll.isAvailable()) {
+            // When lispflowmapping is under heavy load, there are usually two threads nearing 100% CPU core
+            // utilization. In order to have some headroom, we reserve 3 cores for "other" tasks, and allow the
+            // rest to be used for southbound packet processing, which is the most CPU intensive work done in lfm
+            numChannels = Math.max(1, Runtime.getRuntime().availableProcessors() - 3);
+        }
+        channel = new Channel[numChannels];
     }
 
-    private void unloadActions() {
-        if (thread != null) {
-            thread.stopRunning();
+    public void init() {
+        LOG.info("LISP (RFC6830) Southbound Plugin is initializing...");
+        synchronized (startLock) {
+            this.akdb = new AuthKeyDb(new HashMapDb());
+            this.authenticationKeyDataListener = new AuthenticationKeyDataListener(dataBroker, akdb);
+            this.dsbe = new DataStoreBackEnd(dataBroker);
+            restoreDaoFromDatastore();
+
+            LispSouthboundHandler lsbh = new LispSouthboundHandler(this);
+            this.lispSouthboundHandler = lsbh;
+
+            LispXtrSouthboundHandler lxsbh = new LispXtrSouthboundHandler(this);
+            this.lispXtrSouthboundHandler = lxsbh;
+
+            if (Epoll.isAvailable()) {
+                eventLoopGroup = new EpollEventLoopGroup(numChannels, threadFactory);
+                channelType = EpollDatagramChannel.class;
+                bootstrap.option(ChannelOption.ALLOCATOR, PooledByteBufAllocator.DEFAULT);
+                bootstrap.option(EpollChannelOption.SO_REUSEPORT, true);
+                LOG.debug("Using Netty Epoll for UDP sockets");
+            } else {
+                eventLoopGroup = new NioEventLoopGroup(0, threadFactory);
+                channelType = NioDatagramChannel.class;
+                LOG.debug("Using Netty I/O (non-Epoll) for UDP sockets");
+            }
+
+            bootstrap.group(eventLoopGroup);
+            bootstrap.channel(channelType);
+            bootstrap.handler(lsbh);
+
+            xtrBootstrap.group(eventLoopGroup);
+            xtrBootstrap.channel(channelType);
+            xtrBootstrap.handler(lxsbh);
+
+            start();
+            startXtr();
+
+            clusterSingletonService.registerClusterSingletonService(this);
+            LOG.info("LISP (RFC6830) Southbound Plugin is up!");
         }
-        logger.info("LISP (RFC6830) Mapping Service is down!");
+    }
+
+    @SuppressWarnings("checkstyle:IllegalCatch")
+    private void start() {
         try {
-            Thread.sleep(1100);
-        } catch (InterruptedException e) {
+            for (int i = 0; i < numChannels; ++i) {
+                channel[i] = bootstrap.bind(bindingAddress, LispMessage.PORT_NUM).sync().channel();
+            }
+            LOG.debug("Binding LISP UDP listening socket to {}:{}", bindingAddress, LispMessage.PORT_NUM);
+        } catch (Exception e) {
+            LOG.error("Failed to open main socket ", e);
         }
-        lispSouthboundService = null;
-        thread = null;
     }
 
-    public void destroy() {
-        unloadActions();
+    @SuppressWarnings("checkstyle:IllegalCatch")
+    private void startXtr() {
+        if (listenOnXtrPort) {
+            try {
+                xtrChannel = xtrBootstrap.bind(bindingAddress, xtrPort).sync().channel();
+                LOG.debug("Binding LISP xTR UDP listening socket to {}:{}", bindingAddress, xtrPort);
+            } catch (Exception e) {
+                LOG.error("Failed to open xTR socket ", e);
+            }
+        }
     }
 
-    private class LispIoThread extends Thread {
-        private volatile boolean running;
-
-        public LispIoThread() {
-            super("Lisp Thread");
-            running = true;
+    @SuppressWarnings("checkstyle:IllegalCatch")
+    private void stop() {
+        try {
+            for (int i = 0; i < numChannels; ++i) {
+                channel[i].close().sync();
+                channel[i] = null;
+            }
+        } catch (Exception e) {
+            LOG.error("Failed to close main socket ", e);
         }
+    }
 
-        @Override
-        public void run() {
-            String lispBindAddress = "0.0.0.0";
-            String lispIp = System.getProperty("lispip");
-            if (lispIp != null) {
-                lispBindAddress = lispIp;
+    @SuppressWarnings("checkstyle:IllegalCatch")
+    private void stopXtr() {
+        if (listenOnXtrPort) {
+            try {
+                xtrChannel.close().sync();
+                xtrChannel = null;
+            } catch (Exception e) {
+                LOG.error("Failed to close xTR socket ", e);
             }
+        }
+    }
 
-            int lispPortNumber = LispMessage.PORT_NUM;
-            int lispReceiveTimeout = 1000;
+    private void restart() {
+        LOG.info("Reloading");
+        stop();
+        start();
+    }
 
-            logger.info("LISP (RFC6830) Mapping Service is running and listening on " + lispBindAddress);
-            try {
-                socket = new DatagramSocket(new InetSocketAddress(lispBindAddress, lispPortNumber));
-                socket.setSoTimeout(lispReceiveTimeout);
-            } catch (SocketException e) {
-                logger.warn("Cannot open socket on UDP port " + lispPortNumber, e);
-                return;
+    private void restartXtr() {
+        LOG.info("Reloading xTR");
+        stopXtr();
+        startXtr();
+    }
+
+    private void unloadActions() {
+        lispSouthboundHandler = null;
+        lispXtrSouthboundHandler = null;
+
+        stop();
+        stopXtr();
+
+        LOG.info("LISP (RFC6830) Southbound Plugin is down!");
+    }
+
+    /**
+     * Restore all keys from MDSAL datastore.
+     */
+    public void restoreDaoFromDatastore() {
+        final List<AuthenticationKey> authKeys = dsbe.getAllAuthenticationKeys();
+        LOG.info("Restoring {} keys from datastore into southbound DAO", authKeys.size());
+
+        for (AuthenticationKey authKey : authKeys) {
+            final Eid key = authKey.getEid();
+            final MappingAuthkey mappingAuthkey = authKey.getMappingAuthkey();
+            LOG.debug("Adding authentication key '{}' with key-ID {} for {}", mappingAuthkey.getKeyString(),
+                    mappingAuthkey.getKeyType(),
+                    LispAddressStringifier.getString(key));
+            akdb.addAuthenticationKey(key, mappingAuthkey);
+        }
+    }
+
+    public void handleSerializedLispBuffer(TransportAddress address, ByteBuffer outBuffer,
+                                           final MessageType packetType) {
+        InetAddress ip = getInetAddress(address);
+        handleSerializedLispBuffer(ip, outBuffer, packetType, address.getPort().getValue().toJava(), null);
+    }
+
+    public void handleSerializedLispBuffer(InetAddress address, ByteBuffer outBuffer,
+            final MessageType packetType, final int portNumber, Channel senderChannel) {
+        if (senderChannel == null) {
+            senderChannel = this.channel[0];
+        }
+        InetSocketAddress recipient = new InetSocketAddress(address, portNumber);
+        outBuffer.position(0);
+        ByteBuf data = wrappedBuffer(outBuffer);
+        DatagramPacket packet = new DatagramPacket(data, recipient);
+        LOG.debug("Sending {} on port {} to address: {}", packetType, portNumber, address);
+        if (LOG.isTraceEnabled()) {
+            LOG.trace("Buffer:\n{}", ByteBufUtil.prettyHexDump(data));
+        }
+        senderChannel.write(packet).addListener(future -> {
+            if (future.isSuccess()) {
+                LOG.trace("Success");
+                statistics.incrementTx(packetType.getIntValue());
+            } else {
+                LOG.warn("Failed to send packet");
+                statistics.incrementTxErrors();
             }
+        });
+        senderChannel.flush();
+    }
 
-            while (running) {
-                byte[] buffer = new byte[4096];
-                DatagramPacket packet = new DatagramPacket(buffer, buffer.length);
-                try {
-                    socket.receive(packet);
-                    logger.debug("Received a packet!");
-                } catch (SocketTimeoutException ste) {
-                    continue;
-                } catch (IOException e) {
-                    logger.error("IO Exception while trying to recieve packet", e);
-                }
-                logger.debug("Handling packet from {}:{} (len={})", packet.getAddress().getHostAddress(), packet.getPort(), packet.getLength());
+    private InetAddress getInetAddress(TransportAddress address) {
+        Preconditions.checkNotNull(address, "TransportAddress must not be null");
+        IpAddressBinary ip = address.getIpAddress();
+        try {
+            if (ip.getIpv4AddressBinary() != null) {
+                return InetAddress.getByAddress(ip.getIpv4AddressBinary().getValue());
+            } else if (ip.getIpv6AddressBinary() != null) {
+                return InetAddress.getByAddress(ip.getIpv6AddressBinary().getValue());
+            }
+        } catch (UnknownHostException e) {
+            LOG.debug("Could not convert TransportAddress {} to InetAddress", address, e);
+        }
+        return null;
+    }
 
-                try {
-                    lispSouthboundService.handlePacket(packet);
-                } catch (Throwable t) {
-                    logger.error("Error while handling packet", t);
+    @Override
+    @SuppressWarnings("checkstyle:IllegalCatch")
+    public void setLispAddress(String address) {
+        synchronized (startLock) {
+            if (bindingAddress.equals(address)) {
+                LOG.debug("Configured LISP binding address didn't change.");
+            } else {
+                LOG.debug("Setting LISP binding address to {}", address);
+                bindingAddress = address;
+                if (channel != null) {
+                    try {
+                        restart();
+                        restartXtr();
+                    } catch (Exception e) {
+                        LOG.error("Failed to set LISP binding address: ", e);
+                    }
                 }
             }
+        }
+    }
+
+    @Override
+    public void shouldListenOnXtrPort(boolean shouldListenOnXtrPort) {
+        listenOnXtrPort = shouldListenOnXtrPort;
+        if (listenOnXtrPort) {
+            restartXtr();
+        } else {
+            LOG.info("Shutting down xTR");
+            stopXtr();
+        }
+    }
 
-            socket.close();
-            logger.info("Socket closed");
+    @Override
+    public void setXtrPort(int port) {
+        this.xtrPort = port;
+        if (listenOnXtrPort) {
+            restartXtr();
         }
+    }
 
-        public void stopRunning() {
-            running = false;
+    public void setMapRegisterCacheEnabled(final boolean mapRegisterCacheEnabled) {
+        this.mapRegisterCacheEnabled = mapRegisterCacheEnabled;
+        if (mapRegisterCacheEnabled) {
+            LOG.info("Enabling Map-Register cache");
+        } else {
+            LOG.info("Disabling Map-Register cache");
         }
     }
 
-    public static String intToIpv4(int address) {
-        return ((address >> 24) & 0xff) + "." + //
-                ((address >> 16) & 0xff) + "." + //
-                ((address >> 8) & 0xff) + "." + //
-                ((address >> 0) & 0xff);
+    public void setMapRegisterCacheTimeout(long mapRegisterCacheTimeout) {
+        this.mapRegisterCacheTimeout = mapRegisterCacheTimeout;
     }
 
-    public String getHelp() {
-        StringBuffer help = new StringBuffer();
-        help.append("---LISP Southbound Plugin---\n");
-        return help.toString();
+    public void setBindingAddress(String bindingAddress) {
+        this.bindingAddress = bindingAddress;
     }
 
-    public void onSessionInitiated(ProviderContext session) {
-        lispSouthboundService = new LispSouthboundService();
-        thread = new LispIoThread();
-        logger.info("LISP (RFC6830) Mapping Service is up!");
-        thread.start();
+    @Override
+    public void close() throws Exception {
+        eventLoopGroup.shutdownGracefully();
+        lispSouthboundHandler.close();
+        unloadActions();
+        clusterSingletonService.close();
+        dsbe.closeTransactionChain();
+    }
 
-        // OSGI console
-        registerWithOSGIConsole();
+    @Override
+    public void instantiateServiceInstance() {
+        this.isMaster = true;
+    }
 
-        logger.debug("Provider Session initialized");
+    @Override
+    public ListenableFuture<Void> closeServiceInstance() {
+        this.isMaster = false;
+        return Futures.<Void>immediateFuture(null);
+    }
 
-        lispSouthboundService.setNotificationProvider(session.getSALService(NotificationProviderService.class));
-        session.addRpcImplementation(ILispSouthboundPlugin.class, this);
+    @Override
+    public ServiceGroupIdentifier getIdentifier() {
+        return SERVICE_GROUP_IDENTIFIER;
     }
 
-    public Future<RpcResult<Void>> handleMapNotify(MapNotify mapNotify, InetAddress address) {
-        logger.trace("handleMapNotify called!!");
-        if (mapNotify != null) {
-            ByteBuffer outBuffer = MapNotifySerializer.getInstance().serialize(mapNotify);
-            handleSerializedLispBuffer(address, outBuffer, MAP_NOTIFY);
-        } else {
-            logger.debug("MapNotify was null");
+    public synchronized void sendNotificationIfPossible(final Notification notification) throws InterruptedException {
+        if (isMaster && notificationPublishService != null) {
+            notificationPublishService.putNotification(notification);
+            LOG.trace("Publishing notification: {}", notification);
+        } else if (notificationPublishService == null) {
+            LOG.warn("Can't publish notification because no reference to publication service exists!");
         }
-        return null;
     }
 
-    private void handleSerializedLispBuffer(InetAddress address, ByteBuffer outBuffer, String packetType) {
-        DatagramPacket packet = new DatagramPacket(outBuffer.array(), outBuffer.limit());
-        packet.setPort(LispMessage.PORT_NUM);
-        packet.setAddress(address);
-        try {
-            if (logger.isDebugEnabled()) {
-                logger.debug("Sending " + packetType + " on port " + LispMessage.PORT_NUM + " to address: " + address);
-            }
-            socket.send(packet);
-        } catch (IOException e) {
-            logger.error("Failed to send " + packetType, e);
-        }
+    public AuthKeyDb getAkdb() {
+        return akdb;
     }
 
-    public Future<RpcResult<Void>> handleMapReply(MapReply mapReply, InetAddress address) {
-        logger.trace("handleMapReply called!!");
-        if (mapReply != null) {
-            ByteBuffer outBuffer = MapReplySerializer.getInstance().serialize(mapReply);
-            handleSerializedLispBuffer(address, outBuffer, MAP_REPlY);
-        } else {
-            logger.debug("MapReply was null");
-        }
-        return null;
+    public ConcurrentLispSouthboundStats getStats() {
+        return statistics;
+    }
+
+    public DataBroker getDataBroker() {
+        return dataBroker;
+    }
+
+    public AuthenticationKeyDataListener getAuthenticationKeyDataListener() {
+        return authenticationKeyDataListener;
+    }
+
+    public MapRegisterCache getMapRegisterCache() {
+        return mapRegisterCache;
+    }
+
+    public boolean isMapRegisterCacheEnabled() {
+        return mapRegisterCacheEnabled;
+    }
+
+    public long getMapRegisterCacheTimeout() {
+        return mapRegisterCacheTimeout;
     }
 }