Add ByteBufUtils
[bgpcep.git] / pcep / impl / src / main / java / org / opendaylight / protocol / pcep / impl / PCEPDispatcherImpl.java
index 941a3b4218e1450dad1ff4bb4ddada6cfea07a05..618608b54176dfcd940504a9f7c749eb1614c3f3 100644 (file)
  */
 package org.opendaylight.protocol.pcep.impl;
 
-import io.netty.bootstrap.Bootstrap;
+import static java.util.Objects.requireNonNull;
+
 import io.netty.bootstrap.ServerBootstrap;
+import io.netty.buffer.PooledByteBufAllocator;
 import io.netty.channel.ChannelFuture;
+import io.netty.channel.ChannelInitializer;
+import io.netty.channel.ChannelOption;
 import io.netty.channel.EventLoopGroup;
+import io.netty.channel.FixedRecvByteBufAllocator;
+import io.netty.channel.epoll.Epoll;
+import io.netty.channel.epoll.EpollChannelOption;
+import io.netty.channel.epoll.EpollEventLoopGroup;
+import io.netty.channel.epoll.EpollMode;
+import io.netty.channel.epoll.EpollServerSocketChannel;
 import io.netty.channel.socket.SocketChannel;
+import io.netty.channel.socket.nio.NioServerSocketChannel;
+import io.netty.util.concurrent.DefaultPromise;
+import io.netty.util.concurrent.EventExecutor;
+import io.netty.util.concurrent.GlobalEventExecutor;
 import io.netty.util.concurrent.Promise;
-
+import java.io.Closeable;
 import java.net.InetSocketAddress;
-
-import org.opendaylight.bgpcep.tcpmd5.KeyMapping;
-import org.opendaylight.bgpcep.tcpmd5.netty.MD5ChannelFactory;
-import org.opendaylight.bgpcep.tcpmd5.netty.MD5ChannelOption;
-import org.opendaylight.bgpcep.tcpmd5.netty.MD5ServerChannelFactory;
-import org.opendaylight.protocol.framework.AbstractDispatcher;
-import org.opendaylight.protocol.framework.SessionListenerFactory;
-import org.opendaylight.protocol.framework.SessionNegotiatorFactory;
+import java.util.concurrent.TimeUnit;
+import org.checkerframework.checker.lock.qual.GuardedBy;
+import org.eclipse.jdt.annotation.NonNull;
+import org.opendaylight.protocol.concepts.KeyMapping;
 import org.opendaylight.protocol.pcep.PCEPDispatcher;
-import org.opendaylight.protocol.pcep.PCEPSessionListener;
+import org.opendaylight.protocol.pcep.PCEPDispatcherDependencies;
+import org.opendaylight.protocol.pcep.PCEPSessionNegotiatorFactory;
 import org.opendaylight.protocol.pcep.spi.MessageRegistry;
-import org.opendaylight.yang.gen.v1.urn.opendaylight.params.xml.ns.yang.pcep.types.rev131005.Message;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-import com.google.common.base.Preconditions;
-
 /**
  * Implementation of PCEPDispatcher.
  */
-public class PCEPDispatcherImpl extends AbstractDispatcher<PCEPSessionImpl, PCEPSessionListener> implements PCEPDispatcher, AutoCloseable {
-       private static final Logger LOG = LoggerFactory.getLogger(PCEPDispatcherImpl.class);
-       private final SessionNegotiatorFactory<Message, PCEPSessionImpl, PCEPSessionListener> snf;
-       private final MD5ServerChannelFactory<?> scf;
-       private final MD5ChannelFactory<?> cf;
-       private final PCEPHandlerFactory hf;
-       private KeyMapping keys;
-
-       /**
-        * Creates an instance of PCEPDispatcherImpl, gets the default selector and opens it.
-        */
-       public PCEPDispatcherImpl(final MessageRegistry registry,
-                       final SessionNegotiatorFactory<Message, PCEPSessionImpl, PCEPSessionListener> negotiatorFactory, final EventLoopGroup bossGroup,
-                       final EventLoopGroup workerGroup) {
-               this(registry, negotiatorFactory, bossGroup, workerGroup, null, null);
-       }
-
-       /**
-        * Creates an instance of PCEPDispatcherImpl, gets the default selector and opens it.
-        */
-       public PCEPDispatcherImpl(final MessageRegistry registry,
-                       final SessionNegotiatorFactory<Message, PCEPSessionImpl, PCEPSessionListener> negotiatorFactory, final EventLoopGroup bossGroup,
-                       final EventLoopGroup workerGroup, final MD5ChannelFactory<?> cf, final MD5ServerChannelFactory<?> scf) {
-               super(bossGroup, workerGroup);
-               this.cf = cf;
-               this.scf = scf;
-               this.snf = Preconditions.checkNotNull(negotiatorFactory);
-               this.hf = new PCEPHandlerFactory(registry);
-       }
-
-       @Override
-       public synchronized ChannelFuture createServer(final InetSocketAddress address, final SessionListenerFactory<PCEPSessionListener> listenerFactory) {
-               return createServer(address, null, listenerFactory);
-       }
-
-       @Override
-       public void close() {
-       }
-
-       @Override
-       protected void customizeBootstrap(final Bootstrap b) {
-               if (keys != null && !keys.isEmpty()) {
-                       if (cf == null) {
-                               throw new UnsupportedOperationException("No key access instance available, cannot use key mapping");
-                       }
-
-                       LOG.debug("Adding MD5 keys {} to boostrap {}", keys, b);
-                       b.channelFactory(cf);
-                       b.option(MD5ChannelOption.TCP_MD5SIG, keys);
-               }
-       }
-
-       @Override
-       protected void customizeBootstrap(final ServerBootstrap b) {
-               if (keys != null && !keys.isEmpty()) {
-                       if (scf == null) {
-                               throw new UnsupportedOperationException("No key access instance available, cannot use key mapping");
-                       }
-
-                       LOG.debug("Adding MD5 keys {} to boostrap {}", keys, b);
-                       b.channelFactory(scf);
-                       b.option(MD5ChannelOption.TCP_MD5SIG, keys);
-               }
-       }
-
-       @Override
-       public synchronized ChannelFuture createServer(final InetSocketAddress address, final KeyMapping keys,
-                       final SessionListenerFactory<PCEPSessionListener> listenerFactory) {
-               this.keys = keys;
-               ChannelFuture ret = super.createServer(address, new PipelineInitializer<PCEPSessionImpl>() {
-                       @Override
-                       public void initializeChannel(final SocketChannel ch, final Promise<PCEPSessionImpl> promise) {
-                               ch.pipeline().addLast(PCEPDispatcherImpl.this.hf.getDecoders());
-                               ch.pipeline().addLast("negotiator", PCEPDispatcherImpl.this.snf.getSessionNegotiator(listenerFactory, ch, promise));
-                               ch.pipeline().addLast(PCEPDispatcherImpl.this.hf.getEncoders());
-                       }
-               });
-
-               this.keys = null;
-               return ret;
-       }
+public class PCEPDispatcherImpl implements PCEPDispatcher, Closeable {
+    private static final Logger LOG = LoggerFactory.getLogger(PCEPDispatcherImpl.class);
+    private static final Integer SOCKET_BACKLOG_SIZE = 128;
+    private static final long TIMEOUT = 10;
+    private final PCEPSessionNegotiatorFactory<PCEPSessionImpl> snf;
+    private final PCEPHandlerFactory hf;
+    private final EventLoopGroup bossGroup;
+    private final EventLoopGroup workerGroup;
+    private final EventExecutor executor;
+    @GuardedBy("this")
+    private KeyMapping keys;
+
+    /**
+     * Creates an instance of PCEPDispatcherImpl, gets the default selector and opens it.
+     *
+     * @param registry          a message registry
+     * @param negotiatorFactory a negotiation factory
+     * @param bossGroup         accepts an incoming connection
+     * @param workerGroup       handles the traffic of accepted connection
+     */
+    public PCEPDispatcherImpl(final @NonNull MessageRegistry registry,
+            final @NonNull PCEPSessionNegotiatorFactory<PCEPSessionImpl> negotiatorFactory,
+            final @NonNull EventLoopGroup bossGroup, final @NonNull EventLoopGroup workerGroup) {
+        this.snf = requireNonNull(negotiatorFactory);
+        this.hf = new PCEPHandlerFactory(registry);
+        if (Epoll.isAvailable()) {
+            this.bossGroup = new EpollEventLoopGroup();
+            this.workerGroup = new EpollEventLoopGroup();
+        } else {
+            this.bossGroup = requireNonNull(bossGroup);
+            this.workerGroup = requireNonNull(workerGroup);
+        }
+        this.executor = requireNonNull(GlobalEventExecutor.INSTANCE);
+    }
+
+    @Override
+    public final synchronized ChannelFuture createServer(final PCEPDispatcherDependencies dispatcherDependencies) {
+        this.keys = dispatcherDependencies.getKeys();
+
+        final ChannelPipelineInitializer initializer = (ch, promise) -> {
+            ch.pipeline().addLast(this.hf.getDecoders());
+            ch.pipeline().addLast("negotiator", this.snf
+                    .getSessionNegotiator(dispatcherDependencies, ch, promise));
+            ch.pipeline().addLast(this.hf.getEncoders());
+        };
+
+        final ServerBootstrap b = createServerBootstrap(initializer);
+        final InetSocketAddress address = dispatcherDependencies.getAddress();
+        final ChannelFuture f = b.bind(address);
+        LOG.debug("Initiated server {} at {}.", f, address);
+
+        this.keys = KeyMapping.getKeyMapping();
+        return f;
+    }
+
+    synchronized ServerBootstrap createServerBootstrap(final ChannelPipelineInitializer initializer) {
+        final ServerBootstrap b = new ServerBootstrap();
+        b.childHandler(new ChannelInitializer<SocketChannel>() {
+            @Override
+            protected void initChannel(final SocketChannel ch) {
+                initializer.initializeChannel(ch, new DefaultPromise<>(PCEPDispatcherImpl.this.executor));
+            }
+        });
+        b.option(ChannelOption.SO_BACKLOG, SOCKET_BACKLOG_SIZE);
+
+        b.childOption(ChannelOption.ALLOCATOR, PooledByteBufAllocator.DEFAULT);
+
+        if (Epoll.isAvailable()) {
+            b.channel(EpollServerSocketChannel.class);
+            b.childOption(EpollChannelOption.EPOLL_MODE, EpollMode.LEVEL_TRIGGERED);
+        } else {
+            b.channel(NioServerSocketChannel.class);
+        }
+        if (!this.keys.isEmpty()) {
+            if (Epoll.isAvailable()) {
+                b.option(EpollChannelOption.TCP_MD5SIG, this.keys);
+            } else {
+                throw new UnsupportedOperationException(Epoll.unavailabilityCause().getCause());
+            }
+        }
+
+        // Make sure we are doing round-robin processing
+        b.childOption(ChannelOption.RCVBUF_ALLOCATOR, new FixedRecvByteBufAllocator(1));
+
+        if (b.config().group() == null) {
+            b.group(this.bossGroup, this.workerGroup);
+        }
+
+        return b;
+    }
+
+    @Override
+    public final void close() {
+        if (Epoll.isAvailable()) {
+            this.workerGroup.shutdownGracefully(0, TIMEOUT, TimeUnit.SECONDS);
+            this.bossGroup.shutdownGracefully(0, TIMEOUT, TimeUnit.SECONDS);
+        }
+    }
+
+    @Override
+    public final PCEPSessionNegotiatorFactory<PCEPSessionImpl> getPCEPSessionNegotiatorFactory() {
+        return this.snf;
+    }
+
+    protected interface ChannelPipelineInitializer {
+        void initializeChannel(SocketChannel socketChannel, Promise<PCEPSessionImpl> promise);
+    }
 }