Package voldemort.server.niosocket

Source Code of voldemort.server.niosocket.NioSelectorManager

/*
* Copyright 2009 Mustard Grain, Inc., 2009-2010 LinkedIn, Inc.
*
* Licensed under the Apache License, Version 2.0 (the "License"); you may not
* use this file except in compliance with the License. You may obtain a copy of
* the License at
*
* http://www.apache.org/licenses/LICENSE-2.0
*
* Unless required by applicable law or agreed to in writing, software
* distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
* WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the
* License for the specific language governing permissions and limitations under
* the License.
*/

package voldemort.server.niosocket;

import java.net.InetSocketAddress;
import java.nio.channels.ClosedSelectorException;
import java.nio.channels.SelectionKey;
import java.nio.channels.SocketChannel;
import java.util.Queue;
import java.util.concurrent.ConcurrentLinkedQueue;

import org.apache.log4j.Level;

import voldemort.common.nio.CommBufferSizeStats;
import voldemort.common.nio.SelectorManager;
import voldemort.server.protocol.RequestHandlerFactory;
import voldemort.store.stats.Histogram;

/**
* SelectorManager handles the non-blocking polling of IO events using the
* Selector/SelectionKey APIs from NIO.
* <p/>
* This is probably not the way to write NIO code, but it's much faster than the
* documented way. All the documentation on NIO suggested that a single Selector
* be used for all open sockets and then individual IO requests for selected
* keys be stuck in a thread pool and executed asynchronously. This seems
* logical and works fine. However, it was very slow, for two reasons.
* <p>
* First, the thread processing the event calls interestOps() on the
* SelectionKey to update what types of events it's interested in. In fact, it
* does this twice - first before any processing occurs it disables all events
* (so that the same channel isn't selected concurrently (similar to disabling
* interrupts)) and secondly after processing is completed to re-enable interest
* in events. Understandably, interestOps() has some internal state that it
* needs to update, and so the thread must grab a lock on the Selector to do
* internal interest state modifications. With hundreds/thousands of threads,
* this lock is very heavily contended as backed up by profiling and empirical
* testing.
* <p/>
* The second reason the thread pool approach was slow was that after calling
* interestOps() to re-enable events, the threads in the thread pool had to
* invoke the Selector API's wakeup() method or else the state change would go
* unnoticed (it's similar to notifyAll for basic thread synchronization). This
* causes the select() method to return immediately and process whatever
* requests are immediately available. However, with so many threads in play,
* this lead to a near constant spinning of the select()/wakeup() cycling.
* <p>
* Astonishingly it was found to be about 25% faster to simply execute all IO
* synchronously/serially as it eliminated the context switching, lock
* contention, etc. However, we actually have N simultaneous SelectorManager
* instances in play, which are round-robin-ed by the caller (NioSocketService).
* <p>
* In terms of the number of SelectorManager instances to use in parallel, the
* configuration defaults to the number of active CPUs (multi-cores count). This
* helps to balance out the load a little and help with the serial nature of
* processing.
* <p>
* Of course, potential problems exist.
* <p>
* First of all, I still can't believe my eyes that processing these serially is
* faster than in parallel. There may be something about my environment that is
* causing inaccurate reporting. At some point, with enough requests I would
* imagine this will start to slow down.
* <p/>
* Another potential problem is that a given SelectorManager could become
* overloaded. As new socket channels are established, they're distributed to a
* SelectorManager in a round-robin fashion. However, there's no re-balancing
* logic in case a disproportionate number of clients on one SelectorManager
* disconnect.
* <p/>
* For instance, let's say we have two SelectorManager instances and four
* connections. Connection 1 goes to SelectorManager A, connection 2 to
* SelectorManager B, 3 to A, and 4 to B. However, later on let's say that both
* connections 1 and 3 disconnect. This leaves SelectorManager B with two
* connections and SelectorManager A with none. There's no provision to
* re-balance the remaining requests evenly.
*
*/

public class NioSelectorManager extends SelectorManager {

    private final InetSocketAddress endpoint;

    private final Queue<SocketChannel> socketChannelQueue;

    private final RequestHandlerFactory requestHandlerFactory;

    private final int socketBufferSize;

    private final NioSelectorManagerStats stats;

    public NioSelectorManager(InetSocketAddress endpoint,
                              RequestHandlerFactory requestHandlerFactory,
                              int socketBufferSize) {
        this.endpoint = endpoint;
        this.socketChannelQueue = new ConcurrentLinkedQueue<SocketChannel>();
        this.requestHandlerFactory = requestHandlerFactory;
        this.socketBufferSize = socketBufferSize;
        this.stats = new NioSelectorManagerStats();
    }

    public void accept(SocketChannel socketChannel) {
        if(isClosed.get())
            throw new IllegalStateException("Cannot accept more channels, selector manager closed");

        socketChannelQueue.add(socketChannel);
        selector.wakeup();
    }

    @Override
    protected void processEvents() {
        try {
            // update stats
            stats.updateSelectStats(selectCount, selectTimeMs, processingTimeMs);

            SocketChannel socketChannel = null;

            while((socketChannel = socketChannelQueue.poll()) != null) {
                if(isClosed.get()) {
                    if(logger.isInfoEnabled())
                        logger.debug("Closed, exiting for " + endpoint);

                    break;
                }

                try {
                    if(logger.isDebugEnabled())
                        logger.debug("Registering connection from "
                                     + socketChannel.socket().getPort());

                    socketChannel.socket().setTcpNoDelay(true);
                    socketChannel.socket().setReuseAddress(true);
                    socketChannel.socket().setSendBufferSize(socketBufferSize);

                    if(socketChannel.socket().getReceiveBufferSize() != this.socketBufferSize)
                        if(logger.isDebugEnabled())
                            logger.debug("Requested socket receive buffer size was "
                                         + this.socketBufferSize + " bytes but actual size is "
                                         + socketChannel.socket().getReceiveBufferSize()
                                         + " bytes.");

                    if(socketChannel.socket().getSendBufferSize() != this.socketBufferSize)
                        if(logger.isDebugEnabled())
                            logger.debug("Requested socket send buffer size was "
                                         + this.socketBufferSize + " bytes but actual size is "
                                         + socketChannel.socket().getSendBufferSize() + " bytes.");

                    socketChannel.configureBlocking(false);
                    AsyncRequestHandler attachment = new AsyncRequestHandler(selector,
                                                                             socketChannel,
                                                                             requestHandlerFactory,
                                                                             socketBufferSize,
                                                                             stats);

                    if(!isClosed.get()) {
                        socketChannel.register(selector, SelectionKey.OP_READ, attachment);
                        stats.addConnection();
                    }
                } catch(ClosedSelectorException e) {
                    if(logger.isDebugEnabled())
                        logger.debug("Selector is closed, exiting");

                    close();

                    break;
                } catch(Exception e) {
                    if(logger.isEnabledFor(Level.ERROR))
                        logger.error(e.getMessage(), e);
                }
            }
        } catch(Exception e) {
            if(logger.isEnabledFor(Level.ERROR))
                logger.error(e.getMessage(), e);
        }
    }

    /**
     * Returns the number of active connections for this selector manager
     *
     * @return number of active connections
     */
    public Integer getNumActiveConnections() {
        return stats.getNumActiveConnections();
    }

    /**
     * Returns the number of connections queued for registration
     *
     * @return number of connections queued for registration
     */
    public Integer getNumQueuedConnections() {
        return socketChannelQueue.size();
    }

    public Histogram getSelectTimeMsHistogram() {
        return stats.getSelectTimeMsHistogram();
    }

    public Histogram getSelectCountHistogram() {
        return stats.getSelectCountHistogram();
    }

    public Histogram getProcessingTimeMsHistogram() {
        return stats.getProcessingTimeMsHistogram();
    }

    public CommBufferSizeStats getCommBufferSizeStats() {
        return stats.getServerCommBufferStats();
    }
}
TOP

Related Classes of voldemort.server.niosocket.NioSelectorManager

TOP
Copyright © 2018 www.massapi.com. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.