All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.apache.hadoop.mapred.LexicographicalComparerHolder Maven / Gradle / Ivy

/**
 * 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.mapred;

import java.lang.reflect.Field;
import java.nio.ByteOrder;
import java.security.AccessController;
import java.security.PrivilegedAction;

import org.apache.commons.logging.Log;
import org.apache.commons.logging.LogFactory;

import sun.misc.Unsafe;

/**
 * this is borrowed from
 * http://guava-libraries.googlecode.com/svn/trunk/guava/src
 * /com/google/common/primitives/UnsignedBytes.java 
 * and
 * http://svn.apache.org/viewvc
 * /hbase/trunk/src/main/java/org/apache/hadoop/hbase
 * /util/Bytes.java?view=markup
 * 
 */
public class LexicographicalComparerHolder {

  private static final Log LOG = LogFactory
      .getLog(LexicographicalComparerHolder.class.getName());
  
  public static int compareBytes(byte[] kvbuffer, int offset1, int keyLen1,
      int offset2, int keyLen2) {
    return LexicographicalComparerHolder.BEST_COMPARER.compareTo(kvbuffer,
        offset1, keyLen1, kvbuffer, offset2, keyLen2);
  }
  
  /**
   * The number of bytes required to represent a primitive {@code long} value.
   */
  public static final int LONG_BYTES = Long.SIZE / Byte.SIZE;

  interface Comparer {
    abstract public int compareTo(T buffer1, int offset1, int length1,
        T buffer2, int offset2, int length2);
  }

  static Comparer lexicographicalComparerJavaImpl() {
    return LexicographicalComparerHolder.PureJavaComparer.INSTANCE;
  }

  static final String UNSAFE_COMPARER_NAME = LexicographicalComparerHolder.class
      .getName()
      + "$UnsafeComparer";

  static final Comparer BEST_COMPARER = getBestComparer();

  /**
   * Returns the Unsafe-using Comparer, or falls back to the pure-Java
   * implementation if unable to do so.
   */
  static Comparer getBestComparer() {
    try {
      Class theClass = Class.forName(UNSAFE_COMPARER_NAME);

      // yes, UnsafeComparer does implement Comparer
      @SuppressWarnings("unchecked")
      Comparer comparer = (Comparer) theClass
          .getEnumConstants()[0];
      return comparer;
    } catch (Throwable t) { // ensure we really catch *everything*
      LOG.error("Loading lexicographicalComparerJavaImpl...");
      return lexicographicalComparerJavaImpl();
    }
  }
  
  enum UnsafeComparer implements Comparer {
    INSTANCE;

    static final Unsafe theUnsafe;

    /** The offset to the first element in a byte array. */
    static final int BYTE_ARRAY_BASE_OFFSET;

    static {
      theUnsafe = (Unsafe) AccessController
          .doPrivileged(new PrivilegedAction() {
            @Override
            public Object run() {
              try {
                Field f = Unsafe.class.getDeclaredField("theUnsafe");
                f.setAccessible(true);
                return f.get(null);
              } catch (NoSuchFieldException e) {
                // It doesn't matter what we throw;
                // it's swallowed in getBestComparer().
                throw new Error();
              } catch (IllegalAccessException e) {
                throw new Error();
              }
            }
          });

      BYTE_ARRAY_BASE_OFFSET = theUnsafe.arrayBaseOffset(byte[].class);

      // sanity check - this should never fail
      if (theUnsafe.arrayIndexScale(byte[].class) != 1) {
        throw new AssertionError();
      }
    }

    static final boolean littleEndian = ByteOrder.nativeOrder().equals(
        ByteOrder.LITTLE_ENDIAN);

    /**
     * Returns true if x1 is less than x2, when both values are treated as
     * unsigned.
     */
    static boolean lessThanUnsigned(long x1, long x2) {
      return (x1 + Long.MIN_VALUE) < (x2 + Long.MIN_VALUE);
    }

    /**
     * Lexicographically compare two arrays.
     * 
     * @param buffer1
     *          left operand
     * @param buffer2
     *          right operand
     * @param offset1
     *          Where to start comparing in the left buffer
     * @param offset2
     *          Where to start comparing in the right buffer
     * @param length1
     *          How much to compare from the left buffer
     * @param length2
     *          How much to compare from the right buffer
     * @return 0 if equal, < 0 if left is less than right, etc.
     */
    @Override
    public int compareTo(byte[] buffer1, int offset1, int length1,
        byte[] buffer2, int offset2, int length2) {
      // Short circuit equal case
      if (buffer1 == buffer2 && offset1 == offset2 && length1 == length2) {
        return 0;
      }
      int minLength = Math.min(length1, length2);
      int minWords = minLength / LONG_BYTES;
      int offset1Adj = offset1 + BYTE_ARRAY_BASE_OFFSET;
      int offset2Adj = offset2 + BYTE_ARRAY_BASE_OFFSET;

      /*
       * Compare 8 bytes at a time. Benchmarking shows comparing 8 bytes at a
       * time is no slower than comparing 4 bytes at a time even on 32-bit. On
       * the other hand, it is substantially faster on 64-bit.
       */
      for (int i = 0; i < minWords * LONG_BYTES; i += LONG_BYTES) {
        long lw = theUnsafe.getLong(buffer1, offset1Adj + (long) i);
        long rw = theUnsafe.getLong(buffer2, offset2Adj + (long) i);
        long diff = lw ^ rw;

        if (diff != 0) {
          if (!littleEndian) {
            return lessThanUnsigned(lw, rw) ? -1 : 1;
          }

          // Use binary search
          int n = 0;
          int y;
          int x = (int) diff;
          if (x == 0) {
            x = (int) (diff >>> 32);
            n = 32;
          }

          y = x << 16;
          if (y == 0) {
            n += 16;
          } else {
            x = y;
          }

          y = x << 8;
          if (y == 0) {
            n += 8;
          }
          return (int) (((lw >>> n) & 0xFFL) - ((rw >>> n) & 0xFFL));
        }
      }

      // The epilogue to cover the last (minLength % 8) elements.
      for (int i = minWords * LONG_BYTES; i < minLength; i++) {
        int a = (buffer1[offset1 + i] & 0xff);
        int b = (buffer2[offset2 + i] & 0xff);
        if (a != b) {
          return a - b;
        }
      }
      return length1 - length2;
    }
  }

  enum PureJavaComparer implements Comparer {
    INSTANCE;

    @Override
    public int compareTo(byte[] buffer1, int offset1, int length1,
        byte[] buffer2, int offset2, int length2) {
      // Short circuit equal case
      if (buffer1 == buffer2 && offset1 == offset2 && length1 == length2) {
        return 0;
      }
      // Bring WritableComparator code local
      int end1 = offset1 + length1;
      int end2 = offset2 + length2;
      for (int i = offset1, j = offset2; i < end1 && j < end2; i++, j++) {
        int a = (buffer1[i] & 0xff);
        int b = (buffer2[j] & 0xff);
        if (a != b) {
          return a - b;
        }
      }
      return length1 - length2;
    }
  }

}