org.apache.hadoop.ipc.CallQueueManager.java Source code

Java tutorial

Introduction

Here is the source code for org.apache.hadoop.ipc.CallQueueManager.java

Source

/**
 * Licensed to the Apache Software Foundation (ASF) under one
 * or more contributor license agreements.  See the NOTICE file
 * distributed with this work for additional information
 * regarding copyright ownership.  The ASF licenses this file
 * to you 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 org.apache.hadoop.ipc;

import java.lang.reflect.Constructor;
import java.lang.reflect.InvocationTargetException;
import java.util.concurrent.BlockingQueue;
import java.util.concurrent.TimeUnit;
import java.util.concurrent.atomic.AtomicReference;

import org.apache.commons.logging.Log;
import org.apache.commons.logging.LogFactory;
import org.apache.hadoop.conf.Configuration;
import org.apache.hadoop.fs.CommonConfigurationKeys;

/**
 * Abstracts queue operations for different blocking queues.
 */
public class CallQueueManager<E> {
    public static final Log LOG = LogFactory.getLog(CallQueueManager.class);
    // Number of checkpoints for empty queue.
    private static final int CHECKPOINT_NUM = 20;
    // Interval to check empty queue.
    private static final long CHECKPOINT_INTERVAL_MS = 10;

    @SuppressWarnings("unchecked")
    static <E> Class<? extends BlockingQueue<E>> convertQueueClass(Class<?> queueClass, Class<E> elementClass) {
        return (Class<? extends BlockingQueue<E>>) queueClass;
    }

    @SuppressWarnings("unchecked")
    static Class<? extends RpcScheduler> convertSchedulerClass(Class<?> schedulerClass) {
        return (Class<? extends RpcScheduler>) schedulerClass;
    }

    private final boolean clientBackOffEnabled;

    // Atomic refs point to active callQueue
    // We have two so we can better control swapping
    private final AtomicReference<BlockingQueue<E>> putRef;
    private final AtomicReference<BlockingQueue<E>> takeRef;

    private RpcScheduler scheduler;

    public CallQueueManager(Class<? extends BlockingQueue<E>> backingClass,
            Class<? extends RpcScheduler> schedulerClass, boolean clientBackOffEnabled, int maxQueueSize,
            String namespace, Configuration conf) {
        int priorityLevels = parseNumLevels(namespace, conf);
        this.scheduler = createScheduler(schedulerClass, priorityLevels, namespace, conf);
        BlockingQueue<E> bq = createCallQueueInstance(backingClass, priorityLevels, maxQueueSize, namespace, conf);
        this.clientBackOffEnabled = clientBackOffEnabled;
        this.putRef = new AtomicReference<BlockingQueue<E>>(bq);
        this.takeRef = new AtomicReference<BlockingQueue<E>>(bq);
        LOG.info("Using callQueue: " + backingClass + " queueCapacity: " + maxQueueSize + " scheduler: "
                + schedulerClass);
    }

    private static <T extends RpcScheduler> T createScheduler(Class<T> theClass, int priorityLevels, String ns,
            Configuration conf) {
        // Used for custom, configurable scheduler
        try {
            Constructor<T> ctor = theClass.getDeclaredConstructor(int.class, String.class, Configuration.class);
            return ctor.newInstance(priorityLevels, ns, conf);
        } catch (RuntimeException e) {
            throw e;
        } catch (InvocationTargetException e) {
            throw new RuntimeException(theClass.getName() + " could not be constructed.", e.getCause());
        } catch (Exception e) {
        }

        try {
            Constructor<T> ctor = theClass.getDeclaredConstructor(int.class);
            return ctor.newInstance(priorityLevels);
        } catch (RuntimeException e) {
            throw e;
        } catch (InvocationTargetException e) {
            throw new RuntimeException(theClass.getName() + " could not be constructed.", e.getCause());
        } catch (Exception e) {
        }

        // Last attempt
        try {
            Constructor<T> ctor = theClass.getDeclaredConstructor();
            return ctor.newInstance();
        } catch (RuntimeException e) {
            throw e;
        } catch (InvocationTargetException e) {
            throw new RuntimeException(theClass.getName() + " could not be constructed.", e.getCause());
        } catch (Exception e) {
        }

        // Nothing worked
        throw new RuntimeException(theClass.getName() + " could not be constructed.");
    }

    private <T extends BlockingQueue<E>> T createCallQueueInstance(Class<T> theClass, int priorityLevels,
            int maxLen, String ns, Configuration conf) {

        // Used for custom, configurable callqueues
        try {
            Constructor<T> ctor = theClass.getDeclaredConstructor(int.class, int.class, String.class,
                    Configuration.class);
            return ctor.newInstance(priorityLevels, maxLen, ns, conf);
        } catch (RuntimeException e) {
            throw e;
        } catch (InvocationTargetException e) {
            throw new RuntimeException(theClass.getName() + " could not be constructed.", e.getCause());
        } catch (Exception e) {
        }

        // Used for LinkedBlockingQueue, ArrayBlockingQueue, etc
        try {
            Constructor<T> ctor = theClass.getDeclaredConstructor(int.class);
            return ctor.newInstance(maxLen);
        } catch (RuntimeException e) {
            throw e;
        } catch (InvocationTargetException e) {
            throw new RuntimeException(theClass.getName() + " could not be constructed.", e.getCause());
        } catch (Exception e) {
        }

        // Last attempt
        try {
            Constructor<T> ctor = theClass.getDeclaredConstructor();
            return ctor.newInstance();
        } catch (RuntimeException e) {
            throw e;
        } catch (InvocationTargetException e) {
            throw new RuntimeException(theClass.getName() + " could not be constructed.", e.getCause());
        } catch (Exception e) {
        }

        // Nothing worked
        throw new RuntimeException(theClass.getName() + " could not be constructed.");
    }

    boolean isClientBackoffEnabled() {
        return clientBackOffEnabled;
    }

    // Based on policy to determine back off current call
    boolean shouldBackOff(Schedulable e) {
        return scheduler.shouldBackOff(e);
    }

    void addResponseTime(String name, int priorityLevel, int queueTime, int processingTime) {
        scheduler.addResponseTime(name, priorityLevel, queueTime, processingTime);
    }

    // This should be only called once per call and cached in the call object
    // each getPriorityLevel call will increment the counter for the caller
    int getPriorityLevel(Schedulable e) {
        return scheduler.getPriorityLevel(e);
    }

    /**
     * Insert e into the backing queue or block until we can.
     * If we block and the queue changes on us, we will insert while the
     * queue is drained.
     */
    public void put(E e) throws InterruptedException {
        putRef.get().put(e);
    }

    /**
     * Insert e into the backing queue.
     * Return true if e is queued.
     * Return false if the queue is full.
     */
    public boolean offer(E e) throws InterruptedException {
        return putRef.get().offer(e);
    }

    /**
     * Retrieve an E from the backing queue or block until we can.
     * Guaranteed to return an element from the current queue.
     */
    public E take() throws InterruptedException {
        E e = null;

        while (e == null) {
            e = takeRef.get().poll(1000L, TimeUnit.MILLISECONDS);
        }

        return e;
    }

    public int size() {
        return takeRef.get().size();
    }

    /**
     * Read the number of levels from the configuration.
     * This will affect the FairCallQueue's overall capacity.
     * @throws IllegalArgumentException on invalid queue count
     */
    @SuppressWarnings("deprecation")
    private static int parseNumLevels(String ns, Configuration conf) {
        // Fair call queue levels (IPC_CALLQUEUE_PRIORITY_LEVELS_KEY)
        // takes priority over the scheduler level key
        // (IPC_SCHEDULER_PRIORITY_LEVELS_KEY)
        int retval = conf.getInt(ns + "." + FairCallQueue.IPC_CALLQUEUE_PRIORITY_LEVELS_KEY, 0);
        if (retval == 0) { // No FCQ priority level configured
            retval = conf.getInt(ns + "." + CommonConfigurationKeys.IPC_SCHEDULER_PRIORITY_LEVELS_KEY,
                    CommonConfigurationKeys.IPC_SCHEDULER_PRIORITY_LEVELS_DEFAULT_KEY);
        } else {
            LOG.warn(ns + "." + FairCallQueue.IPC_CALLQUEUE_PRIORITY_LEVELS_KEY + " is deprecated. Please use " + ns
                    + "." + CommonConfigurationKeys.IPC_SCHEDULER_PRIORITY_LEVELS_KEY + ".");
        }
        if (retval < 1) {
            throw new IllegalArgumentException("numLevels must be at least 1");
        }
        return retval;
    }

    /**
     * Replaces active queue with the newly requested one and transfers
     * all calls to the newQ before returning.
     */
    public synchronized void swapQueue(Class<? extends RpcScheduler> schedulerClass,
            Class<? extends BlockingQueue<E>> queueClassToUse, int maxSize, String ns, Configuration conf) {
        int priorityLevels = parseNumLevels(ns, conf);
        this.scheduler.stop();
        RpcScheduler newScheduler = createScheduler(schedulerClass, priorityLevels, ns, conf);
        BlockingQueue<E> newQ = createCallQueueInstance(queueClassToUse, priorityLevels, maxSize, ns, conf);

        // Our current queue becomes the old queue
        BlockingQueue<E> oldQ = putRef.get();

        // Swap putRef first: allow blocked puts() to be unblocked
        putRef.set(newQ);

        // Wait for handlers to drain the oldQ
        while (!queueIsReallyEmpty(oldQ)) {
        }

        // Swap takeRef to handle new calls
        takeRef.set(newQ);

        this.scheduler = newScheduler;

        LOG.info("Old Queue: " + stringRepr(oldQ) + ", " + "Replacement: " + stringRepr(newQ));
    }

    /**
     * Checks if queue is empty by checking at CHECKPOINT_NUM points with
     * CHECKPOINT_INTERVAL_MS interval.
     * This doesn't mean the queue might not fill up at some point later, but
     * it should decrease the probability that we lose a call this way.
     */
    private boolean queueIsReallyEmpty(BlockingQueue<?> q) {
        for (int i = 0; i < CHECKPOINT_NUM; i++) {
            try {
                Thread.sleep(CHECKPOINT_INTERVAL_MS);
            } catch (InterruptedException ie) {
                return false;
            }
            if (!q.isEmpty()) {
                return false;
            }
        }
        return true;
    }

    private String stringRepr(Object o) {
        return o.getClass().getName() + '@' + Integer.toHexString(o.hashCode());
    }
}