You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pirk.apache.org by ea...@apache.org on 2016/07/31 23:06:27 UTC

[1/9] incubator-pirk git commit: [PIRK-37]: Rename package for test classes to be org.apache.pirk.* -- closes apache/incubator-pirk#39

Repository: incubator-pirk
Updated Branches:
  refs/heads/master 9d7b46d66 -> 0912bb658


http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/test/general/PaillierTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/test/general/PaillierTest.java b/src/test/java/test/general/PaillierTest.java
deleted file mode 100644
index 833798a..0000000
--- a/src/test/java/test/general/PaillierTest.java
+++ /dev/null
@@ -1,292 +0,0 @@
-/*
- * 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 test.general;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.fail;
-
-import java.math.BigInteger;
-import java.util.Random;
-
-import org.apache.pirk.encryption.Paillier;
-import org.apache.pirk.utils.PIRException;
-import org.apache.pirk.utils.SystemConfiguration;
-import org.junit.BeforeClass;
-import org.junit.Test;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * Basic test functionality for Paillier library
- * 
- */
-public class PaillierTest
-{
-  private static final Logger logger = LoggerFactory.getLogger(PaillierTest.class);
-
-  private static BigInteger p = null; // large prime
-  private static BigInteger q = null; // large prime
-  private static BigInteger N = null; // N=pq, RSA modulus
-  private static BigInteger NSquared = null; // N^2
-  private static BigInteger lambdaN = null; // lambda(N) = lcm(p-1,q-1)
-
-  private static int bitLength = 0; // bit length of the modulus N
-  private static int certainty = 64; // prob that new BigInteger values represents primes will exceed (1 - (1/2)^certainty)
-
-  private static BigInteger r1 = null; // random number in (Z/NZ)*
-  private static BigInteger r2 = null; // random number in (Z/NZ)*
-
-  private static BigInteger m1 = null; // message to encrypt
-  private static BigInteger m2 = null; // message to encrypt
-
-  @BeforeClass
-  public static void setup()
-  {
-    p = BigInteger.valueOf(7);
-    q = BigInteger.valueOf(17);
-    N = p.multiply(q);
-    NSquared = N.multiply(N);
-
-    lambdaN = BigInteger.valueOf(48);
-
-    r1 = BigInteger.valueOf(3);
-    r2 = BigInteger.valueOf(4);
-
-    m1 = BigInteger.valueOf(5);
-    m2 = BigInteger.valueOf(2);
-
-    bitLength = 201;// bitLength = 384;
-    certainty = 128;
-
-    logger.info("p = " + p.intValue() + " q = " + q.intValue() + " N = " + N.intValue() + " bitLength = " + N.bitLength() + " lambdaN = " + lambdaN + " m1 = "
-        + m1.intValue() + " m2 = " + m2.intValue() + " r1 = " + r1.intValue() + " r2 = " + r2.intValue());
-  }
-
-  @Test
-  @SuppressWarnings("unused")
-  public void testPIRExceptions()
-  {
-    try
-    {
-      Paillier paillier = new Paillier(BigInteger.valueOf(2), BigInteger.valueOf(2), 128);
-      fail("Paillier constructor did not throw PIRException for p,q < 3");
-    } catch (PIRException ignore)
-    {}
-
-    try
-    {
-      Paillier paillier = new Paillier(BigInteger.valueOf(2), BigInteger.valueOf(3), 128);
-      fail("Paillier constructor did not throw PIRException for p < 3");
-    } catch (PIRException ignore)
-    {}
-
-    try
-    {
-      Paillier paillier = new Paillier(BigInteger.valueOf(3), BigInteger.valueOf(2), 128);
-      fail("Paillier constructor did not throw PIRException for q < 3");
-    } catch (PIRException ignore)
-    {}
-
-    try
-    {
-      Paillier paillier = new Paillier(BigInteger.valueOf(7), BigInteger.valueOf(7), 128);
-      fail("Paillier constructor did not throw PIRException for p = q");
-    } catch (PIRException ignore)
-    {}
-
-    try
-    {
-      Paillier paillier = new Paillier(BigInteger.valueOf(8), BigInteger.valueOf(7), 128);
-      fail("Paillier constructor did not throw PIRException for p not prime");
-    } catch (PIRException ignore)
-    {}
-
-    try
-    {
-      Paillier paillier = new Paillier(BigInteger.valueOf(7), BigInteger.valueOf(10), 128);
-      fail("Paillier constructor did not throw PIRException for q not prime");
-    } catch (PIRException ignore)
-    {}
-
-    try
-    {
-      int systemPrimeCertainty = Integer.parseInt(SystemConfiguration.getProperty("pir.primeCertainty", "128"));
-      Paillier paillier = new Paillier(3072, systemPrimeCertainty - 10);
-      fail("Paillier constructor did not throw PIRException for certainty less than system default of " + systemPrimeCertainty);
-    } catch (PIRException ignore)
-    {}
-
-    try
-    {
-      Paillier pailler = new Paillier(p, q, bitLength);
-      BigInteger encM1 = pailler.encrypt(N);
-      fail("Paillier encryption did not throw PIRException for message m = N");
-    } catch (PIRException ignore)
-    {}
-
-    try
-    {
-      Paillier pailler = new Paillier(p, q, bitLength);
-      BigInteger encM1 = pailler.encrypt(N.add(BigInteger.TEN));
-      fail("Paillier encryption did not throw PIRException for message m > N");
-    } catch (PIRException ignore)
-    {}
-
-    try
-    {
-      Paillier pailler = new Paillier(bitLength, 128, bitLength);
-      fail("Paillier constructor did not throw PIRException for ensureBitSet = bitLength");
-    } catch (PIRException ignore)
-    {}
-
-    try
-    {
-      Paillier pailler = new Paillier(bitLength, 128, bitLength + 1);
-      fail("Paillier constructor did not throw PIRException for ensureBitSet > bitLength");
-    } catch (PIRException ignore)
-    {}
-  }
-
-  @Test
-  public void testPaillierGivenAllParameters() throws Exception
-  {
-    logger.info("Starting testPaillierGivenAllParameters: ");
-
-    Paillier pailler = new Paillier(p, q, bitLength);
-
-    assertEquals(pailler.getN(), N);
-    assertEquals(pailler.getLambdaN(), lambdaN);
-
-    // Check encryption
-    BigInteger encM1 = pailler.encrypt(m1, r1);
-    BigInteger encM2 = pailler.encrypt(m2, r2);
-    logger.info("encM1 = " + encM1.intValue() + " encM2 = " + encM2.intValue());
-
-    assertEquals(encM1, BigInteger.valueOf(14019));
-    assertEquals(encM2, BigInteger.valueOf(8836));
-
-    // Check decryption
-    BigInteger decM1 = pailler.decrypt(encM1);
-    BigInteger decM2 = pailler.decrypt(encM2);
-    logger.info("decM1 = " + decM1.intValue() + " decM2 = " + decM2.intValue());
-
-    assertEquals(decM1, m1);
-    assertEquals(decM2, m2);
-
-    // Check homomorphic property: E_r1(m1)*E_r2(m2) mod N^2 = E_r1r2((m1+m2) mod N) mod N^2
-    BigInteger encM1_times_encM2 = (encM1.multiply(encM2)).mod(NSquared);
-    BigInteger encM1plusM2 = pailler.encrypt((m1.add(m2)).mod(N), r1.multiply(r2));
-    logger.info("encM1_times_encM2 = " + encM1_times_encM2.intValue() + " encM1plusM2 = " + encM1plusM2.intValue());
-
-    assertEquals(encM1_times_encM2, BigInteger.valueOf(5617));
-    assertEquals(encM1plusM2, BigInteger.valueOf(5617));
-
-    logger.info("Successfully completed testPaillierGivenAllParameters: ");
-  }
-
-  @Test
-  public void testPaillierWithKeyGeneration() throws Exception
-  {
-    logger.info("Starting testPaillierWithKeyGeneration: ");
-
-    // Test with and without gmp optimization for modPow
-    SystemConfiguration.setProperty("pallier.FIPSPrimeGenerationChecks", "true");
-    SystemConfiguration.setProperty("paillier.useGMPForModPow", "true");
-    SystemConfiguration.setProperty("paillier.GMPConstantTimeMode", "true");
-    testPaillerWithKeyGenerationGeneral();
-
-    SystemConfiguration.setProperty("pallier.FIPSPrimeGenerationChecks", "false");
-
-    SystemConfiguration.setProperty("paillier.useGMPForModPow", "true");
-    SystemConfiguration.setProperty("paillier.GMPConstantTimeMode", "true");
-    testPaillerWithKeyGenerationGeneral();
-
-    SystemConfiguration.setProperty("paillier.useGMPForModPow", "true");
-    SystemConfiguration.setProperty("paillier.GMPConstantTimeMode", "false");
-    testPaillerWithKeyGenerationGeneral();
-
-    SystemConfiguration.setProperty("paillier.useGMPForModPow", "false");
-    SystemConfiguration.setProperty("paillier.GMPConstantTimeMode", "false");
-    testPaillerWithKeyGenerationGeneral();
-
-    // Reset the properties
-    SystemConfiguration.resetProperties();
-
-    logger.info("Ending testPaillierWithKeyGeneration: ");
-  }
-
-  public void testPaillerWithKeyGenerationGeneral() throws Exception
-  {
-    // Test without requiring highest bit to be set
-    logger.info("Starting testPaillierWithKeyGenerationBitSetOption with ensureHighBitSet = false");
-    testPaillierWithKeyGenerationBitSetOption(-1);
-
-    // Test requiring highest bit to be set
-    logger.info("Starting testPaillierWithKeyGenerationBitSetOption with ensureHighBitSet = true");
-    testPaillierWithKeyGenerationBitSetOption(5);
-  }
-
-  public void testPaillierWithKeyGenerationBitSetOption(int ensureBitSet) throws Exception
-  {
-    Random r = new Random();
-    int lowBitLength = 3073; // inclusive
-    int highBitLength = 7001; // exclusive
-
-    int loopVal = 1; // int loopVal = 1000; //change this and re-test for high loop testing
-    for (int i = 0; i < loopVal; ++i)
-    {
-      logger.info("i = " + i);
-
-      basicTestPaillierWithKeyGeneration(bitLength, certainty, ensureBitSet);
-      basicTestPaillierWithKeyGeneration(3072, certainty, ensureBitSet);
-
-      // Test with random bit length between 3073 and 7000
-      int randomLargeBitLength = r.nextInt(highBitLength - lowBitLength) + lowBitLength;
-      basicTestPaillierWithKeyGeneration(randomLargeBitLength, certainty, ensureBitSet);
-    }
-  }
-
-  private void basicTestPaillierWithKeyGeneration(int bitLengthInput, int certaintyInput, int ensureBitSet) throws Exception
-  {
-    Paillier pailler = new Paillier(bitLengthInput, certaintyInput, ensureBitSet);
-    BigInteger generatedN = pailler.getN();
-    BigInteger geneartedNsquared = generatedN.multiply(generatedN);
-
-    // Check the decrypting the encryption yields the message
-    BigInteger encM1 = pailler.encrypt(m1);
-    BigInteger encM2 = pailler.encrypt(m2);
-    logger.info("encM1 = " + encM1.intValue() + " encM2 = " + encM2.intValue());
-
-    BigInteger decM1 = pailler.decrypt(encM1);
-    BigInteger decM2 = pailler.decrypt(encM2);
-    logger.info("decM1 = " + decM1.intValue() + " decM2 = " + decM2.intValue());
-
-    assertEquals(decM1, m1);
-    assertEquals(decM2, m2);
-
-    // Check homomorphic property: E_r1(m1)*E_r2(m2) mod N^2 = E_r1r2((m1+m2) mod N) mod N^2
-    BigInteger encM1_times_encM2 = (encM1.multiply(encM2)).mod(geneartedNsquared);
-    BigInteger multDecrypt = pailler.decrypt(encM1_times_encM2);
-    BigInteger m1_plus_m2 = (m1.add(m2)).mod(N);
-
-    logger.info("encM1_times_encM2 = " + encM1_times_encM2.intValue() + " multDecrypt = " + multDecrypt.intValue() + " m1_plus_m2 = " + m1_plus_m2.intValue());
-
-    assertEquals(multDecrypt, m1_plus_m2);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/test/general/PartitionUtilsTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/test/general/PartitionUtilsTest.java b/src/test/java/test/general/PartitionUtilsTest.java
deleted file mode 100644
index 2c85406..0000000
--- a/src/test/java/test/general/PartitionUtilsTest.java
+++ /dev/null
@@ -1,233 +0,0 @@
-/*
- * 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 test.general;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.fail;
-
-import java.math.BigInteger;
-import java.util.ArrayList;
-
-import org.apache.pirk.schema.data.partitioner.IPDataPartitioner;
-import org.apache.pirk.schema.data.partitioner.ISO8601DatePartitioner;
-import org.apache.pirk.schema.data.partitioner.PrimitiveTypePartitioner;
-import org.apache.pirk.utils.SystemConfiguration;
-import org.junit.Test;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * Class to functionally test the bit conversion utils
- */
-public class PartitionUtilsTest
-{
-  private static final Logger logger = LoggerFactory.getLogger(PartitionUtilsTest.class);
-
-  @Test
-  public void testMask()
-  {
-    logger.info("Starting testMask: ");
-
-    BigInteger mask = PrimitiveTypePartitioner.formBitMask(4); // 1111
-
-    assertEquals(mask.intValue(), 15);
-
-    logger.info("Successfully completed testMask");
-  }
-
-  @Test
-  public void testPartitionBits()
-  {
-    logger.info("Starting testPartitionBits: ");
-
-    BigInteger value = new BigInteger("245"); // 11110101
-    BigInteger value2 = new BigInteger("983"); // 1111010111
-
-    BigInteger mask4 = PrimitiveTypePartitioner.formBitMask(4); // 1111
-    BigInteger mask8 = PrimitiveTypePartitioner.formBitMask(8); // 11111111
-
-    try
-    {
-      ArrayList<BigInteger> partitions = PrimitiveTypePartitioner.partitionBits(value, 4, mask4);
-
-      assertEquals(2, partitions.size());
-      assertEquals(partitions.get(0).intValue(), 15); // 1111
-      assertEquals(partitions.get(1).intValue(), 5); // 0101
-
-    } catch (Exception e)
-    {
-      fail(e.toString());
-    }
-
-    try
-    {
-      ArrayList<BigInteger> partitions = PrimitiveTypePartitioner.partitionBits(value2, 4, mask4);
-
-      assertEquals(3, partitions.size());
-      assertEquals(partitions.get(0).intValue(), 15); // 1111
-      assertEquals(partitions.get(1).intValue(), 5); // 0101
-      assertEquals(partitions.get(2).intValue(), 3); // 11
-
-    } catch (Exception e)
-    {
-      fail(e.toString());
-    }
-    try
-    {
-      ArrayList<BigInteger> partitions = PrimitiveTypePartitioner.partitionBits(value, 8, mask8);
-
-      assertEquals(1, partitions.size());
-      assertEquals(partitions.get(0).intValue(), 245);
-
-    } catch (Exception e)
-    {
-      fail(e.toString());
-    }
-
-    try
-    {
-      ArrayList<BigInteger> partitions = PrimitiveTypePartitioner.partitionBits(value, 4, mask8);
-
-      fail("BitConversionUtils.partitionBits did not throw error for mismatched partitionSize and mask size");
-
-    } catch (Exception ignore)
-    {}
-
-    logger.info("Successfully completed testPartitionBits");
-  }
-
-  @Test
-  public void testPartitions() throws Exception
-  {
-    logger.info("Starting testToPartitions:");
-
-    PrimitiveTypePartitioner primitivePartitioner = new PrimitiveTypePartitioner();
-    IPDataPartitioner ipPartitioner = new IPDataPartitioner();
-    ISO8601DatePartitioner datePartitioner = new ISO8601DatePartitioner();
-
-    // Test IP
-    String ipTest = "127.0.0.1";
-    ArrayList<BigInteger> partsIP = ipPartitioner.toPartitions(ipTest, PrimitiveTypePartitioner.STRING);
-    assertEquals(4, partsIP.size());
-    assertEquals(ipTest, ipPartitioner.fromPartitions(partsIP, 0, PrimitiveTypePartitioner.STRING));
-
-    // Test Date
-    String dateTest = "2016-02-20T23:29:05.000Z";
-    ArrayList<BigInteger> partsDate = datePartitioner.toPartitions(dateTest, null);
-    assertEquals(8, partsDate.size());
-    assertEquals(dateTest, datePartitioner.fromPartitions(partsDate, 0, null));
-
-    // Test byte
-    byte bTest = Byte.parseByte("10");
-    ArrayList<BigInteger> partsByte = primitivePartitioner.toPartitions(bTest, PrimitiveTypePartitioner.BYTE);
-    assertEquals(1, partsByte.size());
-    assertEquals(bTest, primitivePartitioner.fromPartitions(partsByte, 0, PrimitiveTypePartitioner.BYTE));
-
-    ArrayList<BigInteger> partsByteMax = primitivePartitioner.toPartitions(Byte.MAX_VALUE, PrimitiveTypePartitioner.BYTE);
-    assertEquals(1, partsByteMax.size());
-    assertEquals(Byte.MAX_VALUE, primitivePartitioner.fromPartitions(partsByteMax, 0, PrimitiveTypePartitioner.BYTE));
-
-    // Test string
-    String stringBits = SystemConfiguration.getProperty("pir.stringBits");
-    SystemConfiguration.setProperty("pir.stringBits", "64");
-    testString("testString"); // over the allowed bit size
-    testString("t"); // under the allowed bit size
-    SystemConfiguration.setProperty("pir.stringBits", stringBits);
-
-    // Test short
-    short shortTest = new Short("2456");
-    ArrayList<BigInteger> partsShort = primitivePartitioner.toPartitions(shortTest, PrimitiveTypePartitioner.SHORT);
-    assertEquals(2, partsShort.size());
-    assertEquals(shortTest, primitivePartitioner.fromPartitions(partsShort, 0, PrimitiveTypePartitioner.SHORT));
-
-    ArrayList<BigInteger> partsShortMax = primitivePartitioner.toPartitions(Short.MAX_VALUE, PrimitiveTypePartitioner.SHORT);
-    assertEquals(2, partsShortMax.size());
-    assertEquals(Short.MAX_VALUE, primitivePartitioner.fromPartitions(partsShortMax, 0, PrimitiveTypePartitioner.SHORT));
-
-    // Test int
-    int intTest = Integer.parseInt("-5789");
-    ArrayList<BigInteger> partsInt = primitivePartitioner.toPartitions(intTest, PrimitiveTypePartitioner.INT);
-    assertEquals(4, partsInt.size());
-    assertEquals(intTest, primitivePartitioner.fromPartitions(partsInt, 0, PrimitiveTypePartitioner.INT));
-
-    ArrayList<BigInteger> partsIntMax = primitivePartitioner.toPartitions(Integer.MAX_VALUE, PrimitiveTypePartitioner.INT);
-    assertEquals(4, partsIntMax.size());
-    assertEquals(Integer.MAX_VALUE, primitivePartitioner.fromPartitions(partsIntMax, 0, PrimitiveTypePartitioner.INT));
-
-    // Test long
-    long longTest = Long.parseLong("56789");
-    ArrayList<BigInteger> partsLong = primitivePartitioner.toPartitions(longTest, PrimitiveTypePartitioner.LONG);
-    assertEquals(8, partsLong.size());
-    assertEquals(longTest, primitivePartitioner.fromPartitions(partsLong, 0, PrimitiveTypePartitioner.LONG));
-
-    ArrayList<BigInteger> partsLongMax = primitivePartitioner.toPartitions(Long.MAX_VALUE, PrimitiveTypePartitioner.LONG);
-    assertEquals(8, partsLongMax.size());
-    assertEquals(Long.MAX_VALUE, primitivePartitioner.fromPartitions(partsLongMax, 0, PrimitiveTypePartitioner.LONG));
-
-    // Test float
-    float floatTest = Float.parseFloat("567.77");
-    ArrayList<BigInteger> partsFloat = primitivePartitioner.toPartitions(floatTest, PrimitiveTypePartitioner.FLOAT);
-    assertEquals(4, partsFloat.size());
-    assertEquals(floatTest, primitivePartitioner.fromPartitions(partsFloat, 0, PrimitiveTypePartitioner.FLOAT));
-
-    ArrayList<BigInteger> partsFloatMax = primitivePartitioner.toPartitions(Float.MAX_VALUE, PrimitiveTypePartitioner.FLOAT);
-    assertEquals(4, partsFloatMax.size());
-    assertEquals(Float.MAX_VALUE, primitivePartitioner.fromPartitions(partsFloatMax, 0, PrimitiveTypePartitioner.FLOAT));
-
-    // Test double
-    double doubleTest = Double.parseDouble("567.77");
-    ArrayList<BigInteger> partsDouble = primitivePartitioner.toPartitions(doubleTest, PrimitiveTypePartitioner.DOUBLE);
-    assertEquals(8, partsDouble.size());
-    assertEquals(doubleTest, primitivePartitioner.fromPartitions(partsDouble, 0, PrimitiveTypePartitioner.DOUBLE));
-
-    ArrayList<BigInteger> partsDoubleMax = primitivePartitioner.toPartitions(Double.MAX_VALUE, PrimitiveTypePartitioner.DOUBLE);
-    assertEquals(8, partsDoubleMax.size());
-    assertEquals(Double.MAX_VALUE, primitivePartitioner.fromPartitions(partsDoubleMax, 0, PrimitiveTypePartitioner.DOUBLE));
-
-    // Test char
-    char charTest = 'b';
-    ArrayList<BigInteger> partsChar = primitivePartitioner.toPartitions(charTest, PrimitiveTypePartitioner.CHAR);
-    assertEquals(2, partsChar.size());
-    assertEquals(charTest, primitivePartitioner.fromPartitions(partsChar, 0, PrimitiveTypePartitioner.CHAR));
-
-    ArrayList<BigInteger> partsCharMax = primitivePartitioner.toPartitions(Character.MAX_VALUE, PrimitiveTypePartitioner.CHAR);
-    assertEquals(2, partsCharMax.size());
-    assertEquals(Character.MAX_VALUE, primitivePartitioner.fromPartitions(partsCharMax, 0, PrimitiveTypePartitioner.CHAR));
-
-    logger.info("Sucessfully completed testToPartitions:");
-  }
-
-  private void testString(String testString) throws Exception
-  {
-    PrimitiveTypePartitioner ptp = new PrimitiveTypePartitioner();
-
-    ArrayList<BigInteger> partsString = ptp.toPartitions(testString, PrimitiveTypePartitioner.STRING);
-    int numParts = Integer.parseInt(SystemConfiguration.getProperty("pir.stringBits")) / 8;
-    assertEquals(numParts, partsString.size());
-
-    logger.info("testString.getBytes().length = " + testString.getBytes().length);
-    int offset = numParts;
-    if (testString.getBytes().length < numParts)
-    {
-      offset = testString.getBytes().length;
-    }
-    String element = new String(testString.getBytes(), 0, offset);
-    assertEquals(element, ptp.fromPartitions(partsString, 0, PrimitiveTypePartitioner.STRING));
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/test/general/QueryParserUtilsTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/test/general/QueryParserUtilsTest.java b/src/test/java/test/general/QueryParserUtilsTest.java
deleted file mode 100644
index 669a347..0000000
--- a/src/test/java/test/general/QueryParserUtilsTest.java
+++ /dev/null
@@ -1,421 +0,0 @@
-/*
- * 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 test.general;
-
-import static org.junit.Assert.assertFalse;
-import static org.junit.Assert.assertTrue;
-
-import java.util.ArrayList;
-import java.util.Map;
-
-import org.apache.hadoop.io.MapWritable;
-import org.apache.pirk.schema.data.DataSchema;
-import org.apache.pirk.schema.data.DataSchemaRegistry;
-import org.apache.pirk.schema.query.QuerySchemaRegistry;
-import org.apache.pirk.test.utils.Inputs;
-import org.apache.pirk.utils.QueryParserUtils;
-import org.apache.pirk.utils.StringUtils;
-import org.apache.pirk.utils.SystemConfiguration;
-import org.json.simple.JSONObject;
-import org.junit.AfterClass;
-import org.junit.BeforeClass;
-import org.junit.Test;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * Class for testing the QueryParser methods
- */
-public class QueryParserUtilsTest
-{
-  private static final Logger logger = LoggerFactory.getLogger(QueryParserUtilsTest.class);
-
-  private static MapWritable doc = null; // MapWritable with arrays in json string representation
-  private static MapWritable docWAW = null; // MapWritable with arrays as WritableArrayWritable objects
-  private static Map<String,Object> docMap = null; // arrays as ArrayList<String>
-
-  private static DataSchema dSchema = null;
-
-  @BeforeClass
-  public static void setup() throws Exception
-  {
-    ArrayList<JSONObject> dataElementsJSON = Inputs.createJSONDataElements();
-
-    // Reset the schema properties and registries
-    DataSchemaRegistry.clearRegistry();
-    QuerySchemaRegistry.clearRegistry();
-    SystemConfiguration.setProperty("data.schemas", "none");
-    SystemConfiguration.setProperty("query.schemas", "none");
-
-    Inputs.createSchemaFiles(null, false, null);
-
-    dSchema = DataSchemaRegistry.get(Inputs.TEST_DATA_SCHEMA_NAME);
-
-    // ProcessBuilder pAdd1 = new ProcessBuilder("curl", "-XPUT", indexTypeNum1, "-d",
-    // "{\"qname\":\"a.b.c.com\",\"date\":\"2016-02-20T23:29:05.000Z\",\"qtype\":[\"1\"]"
-    // + ",\"rcode\":\"0\",\"src_ip\":\"55.55.55.55\",\"dest_ip\":\"1.2.3.6\"" + ",\"ip\":[\"10.20.30.40\",\"10.20.30.60\"]}");
-    //
-    doc = StringUtils.jsonStringToMapWritableWithArrayWritable(dataElementsJSON.get(0).toJSONString(), dSchema);
-    docWAW = StringUtils.jsonStringToMapWritableWithWritableArrayWritable(dataElementsJSON.get(0).toJSONString(), dSchema);
-    docMap = StringUtils.jsonStringToMap(dataElementsJSON.get(0).toJSONString(), dSchema);
-  }
-
-  @AfterClass
-  public static void teardown()
-  {
-    // Reset the schema properties and registries
-    DataSchemaRegistry.clearRegistry();
-    QuerySchemaRegistry.clearRegistry();
-    SystemConfiguration.setProperty("data.schemas", "none");
-    SystemConfiguration.setProperty("query.schemas", "none");
-  }
-
-  @Test
-  public void testSingleQuery()
-  {
-    String query1 = "?q=src_ip:55.55.55.55";
-    assertTrue(QueryParserUtils.checkRecord(query1, doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable(query1, docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecord(query1, docMap, dSchema));
-
-    String query2 = "?q=qname:a.b.c.com";
-    assertTrue(QueryParserUtils.checkRecord(query2, doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable(query2, docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecord(query2, docMap, dSchema));
-
-    String query3 = "?q=qname:d.b.c.com";
-    assertFalse(QueryParserUtils.checkRecord(query3, doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable(query3, docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecord(query3, docMap, dSchema));
-  }
-
-  @Test
-  public void testQueryFieldDoesNotExist()
-  {
-    logger.info("running testQueryFieldDoesNotExist");
-
-    // Field does not exist, this should not be found
-    String query = "?q=nonexistent-field:*check*";
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable(query, docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecord(query, doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecord(query, docMap, dSchema));
-
-    // First field does not exist, but second should be found
-    String query2 = "?q=nonexistent-field:*check*+OR+qname:*a.b.c.com*";
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable(query2, docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecord(query2, doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord(query2, docMap, dSchema));
-
-    // First field does not exist, second field does, but AND operator makes query false
-    String query3 = "?q=nonexistent-field:*check*+AND+qname:*a.b.c.com*";
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable(query3, docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecord(query3, doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecord(query3, docMap, dSchema));
-
-    logger.info("completed testQueryFieldDoesNotExist");
-  }
-
-  @Test
-  public void testIgnoreCase()
-  {
-    logger.info("running testIgnoreCase");
-
-    // with case sensitivity, should NOT be found
-    String query = "?q=qname:*A.b.c.com*";
-    assertFalse(QueryParserUtils.checkRecord(query, doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable(query, docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecord(query, docMap, dSchema));
-
-    // with case sensitivity, should be found
-    String query2 = "?q=qname:*a.b.c.com*";
-    assertTrue(QueryParserUtils.checkRecord(query2, doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable(query2, docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecord(query2, docMap, dSchema));
-
-    // adds @ flag = case insensitivity, thus should be found
-    String query3 = "?q=qname@:*A.b.c.com*";
-    assertTrue(QueryParserUtils.checkRecord(query3, doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable(query3, docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecord(query3, docMap, dSchema));
-
-    logger.info("completed testIgnoreCase");
-  }
-
-  @Test
-  public void testSingleValueRangeQuery()
-  {
-    testSingleValueRangeQueryMapWritable();
-    testSingleValueRangeQueryMap();
-    testSingleValueRangeQueryMapWritableWAW();
-  }
-
-  private void testSingleValueRangeQueryMapWritable()
-  {
-    assertTrue(QueryParserUtils.checkRecord("?q=rcode:[0+TO+2]", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=rcode:{-1+TO+2}", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=rcode:[-1+TO+0]", doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=rcode:{0+TO+3}", doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=rcode:[3+TO+10]", doc, dSchema));
-  }
-
-  private void testSingleValueRangeQueryMap()
-  {
-    assertTrue(QueryParserUtils.checkRecord("?q=rcode:[0+TO+2]", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=rcode:{-1+TO+2}", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=rcode:[-1+TO+0]", docMap, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=rcode:{0+TO+3}", docMap, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=rcode:[3+TO+10]", docMap, dSchema));
-  }
-
-  private void testSingleValueRangeQueryMapWritableWAW()
-  {
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=rcode:[0+TO+2]", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=rcode:{-1+TO+2}", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=rcode:[-1+TO+0]", docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=rcode:{0+TO+3}", docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=rcode:[3+TO+10]", docWAW, dSchema));
-  }
-
-  @Test
-  public void testIPRangeQuery()
-  {
-    testIPRangeQueryMapWritable();
-    testIPRangeQueryMap();
-    testIPRangeQueryMapWritableWAW();
-  }
-
-  public void testIPRangeQueryMapWritable()
-  {
-    // src_ip: 55.55.55.55
-    // ip: 10.20.30.40,10.20.30.60
-    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:[55.55.55.0+TO+173.248.255.255]", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:[55.55.55.0+TO+55.55.55.100]", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:[55.55.55.2+TO+55.55.55.55]", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:{55.55.55.2+TO+55.55.55.57}", doc, dSchema));
-
-    assertFalse(QueryParserUtils.checkRecord("?q=src_ip:{173.248.188.0+TO+173.248.188.10}", doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=src_ip:{55.55.55.2+TO+55.55.55.55}", doc, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecord("?q=ip:[10.20.30.50+TO+10.20.30.69]", doc, dSchema));
-  }
-
-  public void testIPRangeQueryMapWritableWAW()
-  {
-    // src_ip: 55.55.55.55
-    // ip: 10.20.30.40,10.20.30.60
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=src_ip:[55.55.55.0+TO+173.248.255.255]", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=src_ip:[55.55.55.0+TO+55.55.55.100]", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=src_ip:[55.55.55.2+TO+55.55.55.55]", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=src_ip:{55.55.55.2+TO+55.55.55.57}", docWAW, dSchema));
-
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=src_ip:{173.248.188.0+TO+173.248.188.10}", docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=src_ip:{55.55.55.2+TO+55.55.55.55}", docWAW, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=ip:[10.20.30.50+TO+10.20.30.69]", docWAW, dSchema));
-  }
-
-  public void testIPRangeQueryMap()
-  {
-    // src_ip: 55.55.55.55
-    // ip: 10.20.30.40,10.20.30.60
-    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:[55.55.55.0+TO+173.248.255.255]", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:[55.55.55.0+TO+55.55.55.100]", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:[55.55.55.2+TO+55.55.55.55]", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:{55.55.55.2+TO+55.55.55.57}", docMap, dSchema));
-
-    assertFalse(QueryParserUtils.checkRecord("?q=src_ip:{173.248.188.0+TO+173.248.188.10}", docMap, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=src_ip:{55.55.55.2+TO+55.55.55.55}", docMap, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecord("?q=ip:[10.20.30.50+TO+10.20.30.69]", docMap, dSchema));
-  }
-
-  @Test
-  public void testDateRangeQuery()
-  {
-    testDateRangeQueryMapWritable();
-    testDateRangeQueryMapWritableWAW();
-    testDateRangeQueryMap();
-  }
-
-  private void testDateRangeQueryMapWritable()
-  {
-    // date: 2016-02-20T23:29:05.000Z
-
-    assertTrue(QueryParserUtils.checkRecord("?q=date:[2014-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=date:[2015-05-05T20:33:07.000Z+TO+2016-04-20T23:29:05.000Z]", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=date:[2016-02-20T23:29:05.000Z+TO+2017-02-20T23:29:05.000Z]", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=date:{2015-06-05T20:33:07.000Z+TO+2016-02-20T23:30:05.000Z}", doc, dSchema));
-
-    assertFalse(QueryParserUtils.checkRecord("?q=date:[2013-05-05T20:33:07.000Z+TO+2014-07-05T20:33:07.000Z]", doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=date:{2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z}", doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=date:{2015-06-05T20:33:07.000Z+TO+2015-07-05T20:33:07.000Z}", doc, dSchema));
-  }
-
-  private void testDateRangeQueryMap()
-  {
-    // date: 2016-02-20T23:29:05.000Z
-
-    assertTrue(QueryParserUtils.checkRecord("?q=date:[2014-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=date:[2015-05-05T20:33:07.000Z+TO+2016-04-20T23:29:05.000Z]", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=date:[2016-02-20T23:29:05.000Z+TO+2017-02-20T23:29:05.000Z]", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=date:{2015-06-05T20:33:07.000Z+TO+2016-02-20T23:30:05.000Z}", docMap, dSchema));
-
-    assertFalse(QueryParserUtils.checkRecord("?q=date:[2013-05-05T20:33:07.000Z+TO+2014-07-05T20:33:07.000Z]", docMap, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=date:{2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z}", docMap, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=date:{2015-06-05T20:33:07.000Z+TO+2015-07-05T20:33:07.000Z}", docMap, dSchema));
-  }
-
-  private void testDateRangeQueryMapWritableWAW()
-  {
-    // date: 2016-02-20T23:29:05.000Z
-
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:[2014-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:[2015-05-05T20:33:07.000Z+TO+2016-04-20T23:29:05.000Z]", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:[2016-02-20T23:29:05.000Z+TO+2017-02-20T23:29:05.000Z]", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:{2015-06-05T20:33:07.000Z+TO+2016-02-20T23:30:05.000Z}", docWAW, dSchema));
-
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:[2013-05-05T20:33:07.000Z+TO+2014-07-05T20:33:07.000Z]", docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:{2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z}", docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:{2015-06-05T20:33:07.000Z+TO+2015-07-05T20:33:07.000Z}", docWAW, dSchema));
-  }
-
-  @Test
-  public void testBooleanQuery()
-  {
-    testBooleanQueryMapWritable();
-    testBooleanQueryMapMapWritableWAW();
-    testBooleanQueryMap();
-  }
-
-  private void testBooleanQueryMapWritable()
-  {
-    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=qtype:5+OR+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", doc, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+rcode:0+AND+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", doc, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+rcode:0+OR+date:[2013-05-05T20:33:07.000Z+TO+2014-07-05T20:33:07.000Z]", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+rcode:1+OR+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", doc, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecord("?q=qtype:5+OR+qtype:2+OR+rcode:0", doc, dSchema));
-  }
-
-  private void testBooleanQueryMap()
-  {
-    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=qtype:5+OR+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docMap, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+rcode:0+AND+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docMap, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+rcode:0+OR+date:[2013-05-05T20:33:07.000Z+TO+2014-07-05T20:33:07.000Z]", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+rcode:1+OR+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docMap, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecord("?q=qtype:5+OR+qtype:2+OR+rcode:0", docMap, dSchema));
-  }
-
-  private void testBooleanQueryMapMapWritableWAW()
-  {
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qtype:1+AND+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qtype:5+OR+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docWAW, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qtype:1+AND+rcode:0+AND+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]",
-        docWAW, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qtype:1+AND+rcode:0+OR+date:[2013-05-05T20:33:07.000Z+TO+2014-07-05T20:33:07.000Z]",
-        docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qtype:1+AND+rcode:1+OR+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]",
-        docWAW, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qtype:5+OR+qtype:2+OR+rcode:0", docWAW, dSchema));
-  }
-
-  @Test
-  public void testAllQuery()
-  {
-    assertTrue(QueryParserUtils.checkRecord("?q=*", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=*", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=*", docWAW, dSchema));
-  }
-
-  @Test
-  public void testWildcardQuery()
-  {
-    testWildcardQueryMapWritable();
-    testWildcardQueryMap();
-    testWildcardQueryMapWritableWAW();
-  }
-
-  private void testWildcardQueryMapWritable()
-  {
-    assertTrue(QueryParserUtils.checkRecord("?q=qname:*.com", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b.c.c*m", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b*", doc, dSchema));
-
-    assertFalse(QueryParserUtils.checkRecord("?q=qname:*.org", doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=qname:mrtf*", doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=qname:nedeljnik*.uk", doc, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b.c.c?m", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b.?.com", doc, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=qname:?.b.c.com", doc, dSchema));
-
-    assertFalse(QueryParserUtils.checkRecord("?q=qname:medelj?ikafera.com", doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=qname:nedeljntkafer?.com", doc, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=qname:?edeljnikrfera.com", doc, dSchema));
-  }
-
-  private void testWildcardQueryMap()
-  {
-    assertTrue(QueryParserUtils.checkRecord("?q=qname:*.com", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b.c.c*m", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b*", docMap, dSchema));
-
-    assertFalse(QueryParserUtils.checkRecord("?q=qname:*.org", docMap, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=qname:mrtf*", docMap, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=qname:nedeljnik*.uk", docMap, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b.c.c?m", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b.?.com", docMap, dSchema));
-    assertTrue(QueryParserUtils.checkRecord("?q=qname:?.b.c.com", docMap, dSchema));
-
-    assertFalse(QueryParserUtils.checkRecord("?q=qname:medelj?ikafera.com", docMap, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=qname:nedeljntkafer?.com", docMap, dSchema));
-    assertFalse(QueryParserUtils.checkRecord("?q=qname:?edeljnikrfera.com", docMap, dSchema));
-  }
-
-  private void testWildcardQueryMapWritableWAW()
-  {
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:*.com", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:a.b.c.c*m", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:a.b*", docWAW, dSchema));
-
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:*.org", docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:mrtf*", docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:nedeljnik*.uk", docWAW, dSchema));
-
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:a.b.c.c?m", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:a.b.?.com", docWAW, dSchema));
-    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:?.b.c.com", docWAW, dSchema));
-
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:medelj?ikafera.com", docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:nedeljntkafer?.com", docWAW, dSchema));
-    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:?edeljnikrfera.com", docWAW, dSchema));
-
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/test/schema/data/LoadDataSchemaTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/test/schema/data/LoadDataSchemaTest.java b/src/test/java/test/schema/data/LoadDataSchemaTest.java
deleted file mode 100644
index b1b8ec4..0000000
--- a/src/test/java/test/schema/data/LoadDataSchemaTest.java
+++ /dev/null
@@ -1,327 +0,0 @@
-/*
- * 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 test.schema.data;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertTrue;
-import static org.junit.Assert.fail;
-
-import java.io.File;
-import java.io.IOException;
-
-import javax.xml.parsers.DocumentBuilder;
-import javax.xml.parsers.DocumentBuilderFactory;
-import javax.xml.transform.Transformer;
-import javax.xml.transform.TransformerFactory;
-import javax.xml.transform.dom.DOMSource;
-import javax.xml.transform.stream.StreamResult;
-
-import org.apache.pirk.schema.data.DataSchema;
-import org.apache.pirk.schema.data.DataSchemaLoader;
-import org.apache.pirk.schema.data.DataSchemaRegistry;
-import org.apache.pirk.schema.data.partitioner.IPDataPartitioner;
-import org.apache.pirk.schema.data.partitioner.PrimitiveTypePartitioner;
-import org.apache.pirk.test.utils.TestUtils;
-import org.apache.pirk.utils.SystemConfiguration;
-import org.junit.Test;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.w3c.dom.Document;
-import org.w3c.dom.Element;
-
-/**
- * Test suite for LoadDataSchema and DataSchema
- */
-public class LoadDataSchemaTest
-{
-  private static final Logger logger = LoggerFactory.getLogger(LoadDataSchemaTest.class);
-
-  private String dataSchemaName = "fakeDataSchema";
-
-  private String element1 = "elementName1";
-  private String element2 = "elementName2";
-  private String element3 = "elementName3";
-
-  @Test
-  public void testGeneralSchemaLoad() throws Exception
-  {
-    // Pull off the property and reset upon completion
-    String schemasProp = SystemConfiguration.getProperty("data.schemas", "none");
-
-    // Write the schema file
-    try
-    {
-      createDataSchema("schemaFile");
-    } catch (IOException e)
-    {
-      e.printStackTrace();
-      fail(e.toString());
-    }
-
-    // Force the schema to load
-    DataSchemaLoader.initialize();
-
-    // Check the entries
-    DataSchema dSchema = DataSchemaRegistry.get(dataSchemaName);
-
-    assertEquals(dataSchemaName, dSchema.getSchemaName());
-
-    assertEquals(3, dSchema.getElementNames().size());
-
-    // TODO: check Hadoop text names
-
-    assertEquals(PrimitiveTypePartitioner.STRING, dSchema.getElementType(element1));
-    assertEquals(PrimitiveTypePartitioner.INT, dSchema.getElementType(element2));
-    assertEquals(PrimitiveTypePartitioner.STRING, dSchema.getElementType(element3));
-
-    assertEquals(PrimitiveTypePartitioner.class.getName(), dSchema.getPartitionerTypeName(element1));
-    if (!(dSchema.getPartitionerForElement(element1) instanceof PrimitiveTypePartitioner))
-    {
-      fail("Partitioner instance for element1 must be PrimitiveTypePartitioner");
-    }
-    assertEquals(IPDataPartitioner.class.getName(), dSchema.getPartitionerTypeName(element3));
-    if (!(dSchema.getPartitionerForElement(element3) instanceof IPDataPartitioner))
-    {
-      fail("Partitioner instance for element3 must be IPDataPartitioner");
-    }
-
-    assertEquals(2, dSchema.getArrayElements().size());
-    assertTrue(dSchema.getArrayElements().contains(element2));
-    assertTrue(dSchema.getArrayElements().contains(element3));
-
-    assertEquals(1, dSchema.getNonArrayElements().size());
-    assertTrue(dSchema.getNonArrayElements().contains(element1));
-
-    // Reset original data.schemas property
-    SystemConfiguration.setProperty("data.schemas", schemasProp);
-
-    // Force the schema to load
-    if (!schemasProp.equals("none"))
-    {
-      DataSchemaLoader.initialize();
-    }
-  }
-
-  @Test
-  public void testIncorrectJavaType() throws Exception
-  {
-    // Pull off the property and reset upon completion
-    String schemasProp = SystemConfiguration.getProperty("data.schemas");
-
-    // Write the schema file
-    try
-    {
-      createDataSchemaIncorrectJavaType("wrongJavaType");
-    } catch (IOException e)
-    {
-      e.printStackTrace();
-      fail(e.toString());
-    }
-
-    try
-    {
-      // Force the schema to load
-      DataSchemaLoader.initialize();
-      fail("DataSchemaLoader did not throw exception for incorrect javaType");
-    } catch (Exception ignore)
-    {}
-
-    // Reset original data.schemas property
-    SystemConfiguration.setProperty("data.schemas", schemasProp);
-
-    // Force the schema to load
-    DataSchemaLoader.initialize();
-  }
-
-  @Test
-  public void testUnknownPartitioner() throws Exception
-  {
-    // Pull off the property and reset upon completion
-    String schemasProp = SystemConfiguration.getProperty("data.schemas");
-
-    // Write the schema file
-    try
-    {
-      createDataSchemaUnknownPartitioner("unknownPartitioner");
-    } catch (IOException e)
-    {
-      e.printStackTrace();
-      fail(e.toString());
-    }
-
-    try
-    {
-      // Force the schema to load
-      DataSchemaLoader.initialize();
-      fail("DataSchemaLoader did not throw exception for unknown partitioner");
-    } catch (Exception ignore)
-    {}
-
-    // Reset original data.schemas property
-    SystemConfiguration.setProperty("data.schemas", schemasProp);
-
-    // Force the schema to load
-    DataSchemaLoader.initialize();
-  }
-
-  // Create the file that contains an unknown partitioner
-  private void createDataSchemaUnknownPartitioner(String schemaFile) throws IOException
-  {
-    // Create a temporary file for the test schema, set in the properties
-    File file = File.createTempFile(schemaFile, ".xml");
-    file.deleteOnExit();
-    logger.info("file = " + file.toString());
-    SystemConfiguration.setProperty("data.schemas", file.toString());
-
-    // Write to the file
-    try
-    {
-      DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();
-      DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();
-      Document doc = dBuilder.newDocument();
-
-      // root element
-      Element rootElement = doc.createElement("schema");
-      doc.appendChild(rootElement);
-
-      // Add the schemaName
-      Element schemaNameElement = doc.createElement("schemaName");
-      schemaNameElement.appendChild(doc.createTextNode(dataSchemaName));
-      rootElement.appendChild(schemaNameElement);
-
-      // Add the element - unknown partitioner
-      TestUtils.addElement(doc, rootElement, element1, PrimitiveTypePartitioner.INT, "false", "fakePartitioner");
-
-      // Write to a xml file
-      TransformerFactory transformerFactory = TransformerFactory.newInstance();
-      Transformer transformer = transformerFactory.newTransformer();
-      DOMSource source = new DOMSource(doc);
-      StreamResult result = new StreamResult(file);
-      transformer.transform(source, result);
-
-      // Output for testing
-      StreamResult consoleResult = new StreamResult(System.out);
-      transformer.transform(source, consoleResult);
-      System.out.println();
-    } catch (Exception e)
-    {
-      e.printStackTrace();
-    }
-  }
-
-  // Create the test data schema file
-  private void createDataSchema(String schemaFile) throws IOException
-  {
-    // Create a temporary file for the test schema, set in the properties
-    File file = File.createTempFile(schemaFile, ".xml");
-    file.deleteOnExit();
-    logger.info("file = " + file.toString());
-    SystemConfiguration.setProperty("data.schemas", file.toString());
-
-    // Write to the file
-    try
-    {
-      DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();
-      DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();
-      Document doc = dBuilder.newDocument();
-
-      // root element
-      Element rootElement = doc.createElement("schema");
-      doc.appendChild(rootElement);
-
-      // Add the schemaName
-      Element schemaNameElement = doc.createElement("schemaName");
-      schemaNameElement.appendChild(doc.createTextNode(dataSchemaName));
-      rootElement.appendChild(schemaNameElement);
-
-      // Add the elements
-      // element1 -- single String
-      // TestUtils.addElement(doc, rootElement, element1, PrimitiveTypePartitioner.STRING, "false", PrimitiveTypePartitioner.class.getName());
-      TestUtils.addElement(doc, rootElement, element1, PrimitiveTypePartitioner.STRING, "false", null);
-
-      // element2 - -- array of Integers
-      TestUtils.addElement(doc, rootElement, element2, PrimitiveTypePartitioner.INT, "true", PrimitiveTypePartitioner.class.getName());
-
-      // element3 -- array of IP addresses
-      TestUtils.addElement(doc, rootElement, element3, PrimitiveTypePartitioner.STRING, "true", IPDataPartitioner.class.getName());
-
-      // Write to a xml file
-      TransformerFactory transformerFactory = TransformerFactory.newInstance();
-      Transformer transformer = transformerFactory.newTransformer();
-      DOMSource source = new DOMSource(doc);
-      StreamResult result = new StreamResult(file);
-      transformer.transform(source, result);
-
-      // Output for testing
-      StreamResult consoleResult = new StreamResult(System.out);
-      transformer.transform(source, consoleResult);
-      System.out.println();
-
-    } catch (Exception e)
-    {
-      e.printStackTrace();
-    }
-  }
-
-  // Create the test schema file
-  private void createDataSchemaIncorrectJavaType(String schemaFile) throws IOException
-  {
-    // Create a temporary file for the test schema, set in the properties
-    File file = File.createTempFile(schemaFile, ".xml");
-    file.deleteOnExit();
-    logger.info("file = " + file.toString());
-    SystemConfiguration.setProperty("data.schemas", file.toString());
-
-    // Write to the file
-    try
-    {
-      DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();
-      DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();
-      Document doc = dBuilder.newDocument();
-
-      // root element
-      Element rootElement = doc.createElement("schema");
-      doc.appendChild(rootElement);
-
-      // Add the schemaName
-      Element schemaNameElement = doc.createElement("schemaName");
-      schemaNameElement.appendChild(doc.createTextNode(dataSchemaName));
-      rootElement.appendChild(schemaNameElement);
-
-      // Add the element - unknown Java type
-      TestUtils.addElement(doc, rootElement, element1, "bogus", "false", PrimitiveTypePartitioner.class.getName());
-
-      // Write to a xml file
-      TransformerFactory transformerFactory = TransformerFactory.newInstance();
-      Transformer transformer = transformerFactory.newTransformer();
-      DOMSource source = new DOMSource(doc);
-      StreamResult result = new StreamResult(file);
-      transformer.transform(source, result);
-
-      // Output for testing
-      StreamResult consoleResult = new StreamResult(System.out);
-      transformer.transform(source, consoleResult);
-      System.out.println();
-
-    } catch (Exception e)
-    {
-      e.printStackTrace();
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/test/schema/query/LoadQuerySchemaTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/test/schema/query/LoadQuerySchemaTest.java b/src/test/java/test/schema/query/LoadQuerySchemaTest.java
deleted file mode 100644
index 0a9ad1c..0000000
--- a/src/test/java/test/schema/query/LoadQuerySchemaTest.java
+++ /dev/null
@@ -1,373 +0,0 @@
-/*
- * 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 test.schema.query;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.fail;
-
-import java.io.File;
-import java.io.IOException;
-import java.util.Arrays;
-import java.util.Collections;
-import java.util.List;
-
-import javax.xml.parsers.DocumentBuilder;
-import javax.xml.parsers.DocumentBuilderFactory;
-import javax.xml.transform.Transformer;
-import javax.xml.transform.TransformerFactory;
-import javax.xml.transform.dom.DOMSource;
-import javax.xml.transform.stream.StreamResult;
-
-import org.apache.pirk.schema.data.DataSchemaLoader;
-import org.apache.pirk.schema.data.partitioner.IPDataPartitioner;
-import org.apache.pirk.schema.data.partitioner.PrimitiveTypePartitioner;
-import org.apache.pirk.schema.query.QuerySchema;
-import org.apache.pirk.schema.query.QuerySchemaLoader;
-import org.apache.pirk.schema.query.QuerySchemaRegistry;
-import org.apache.pirk.schema.query.filter.StopListFilter;
-import org.apache.pirk.test.utils.Inputs;
-import org.apache.pirk.test.utils.TestUtils;
-import org.apache.pirk.utils.PIRException;
-import org.apache.pirk.utils.SystemConfiguration;
-import org.junit.Test;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-import org.w3c.dom.Document;
-import org.w3c.dom.Element;
-
-import test.schema.data.LoadDataSchemaTest;
-
-/**
- * Test suite for LoadQuerySchema and QuerySchema
- */
-public class LoadQuerySchemaTest
-{
-  private static final Logger logger = LoggerFactory.getLogger(LoadDataSchemaTest.class);
-
-  private String querySchemaFile = "querySchemaFile";
-  private String dataSchemaName = "fakeDataSchema";
-  private String querySchemaName = "fakeQuerySchema";
-
-  private String element1 = "elementName1";
-  private String element2 = "elementName2";
-  private String element3 = "elementName3";
-  private String element4 = "elementName4";
-
-  private List<String> queryElements = Arrays.asList(element1, element2, element3);
-  private List<String> filterElements = Collections.singletonList(element2);
-
-  @Test
-  public void testGeneralSchemaLoad() throws Exception
-  {
-    logger.info("Starting testGeneralSchemaLoad: ");
-
-    // Pull off the properties and reset upon completion
-    String dataSchemasProp = SystemConfiguration.getProperty("data.schemas", "none");
-    String querySchemasProp = SystemConfiguration.getProperty("query.schemas", "none");
-    String stopListFileProp = SystemConfiguration.getProperty("pir.stopListFile");
-
-    // Create the stoplist file
-    createStopListFile();
-
-    // Create the data schema used and force it to load
-    try
-    {
-      createDataSchema("dataSchemaFile");
-    } catch (Exception e)
-    {
-      e.printStackTrace();
-      fail(e.toString());
-    }
-    DataSchemaLoader.initialize();
-
-    // Create the query schema used and force it to load
-    try
-    {
-      TestUtils.createQuerySchema(querySchemaFile, querySchemaName, dataSchemaName, element4, queryElements, filterElements, StopListFilter.class.getName());
-
-    } catch (IOException e)
-    {
-      e.printStackTrace();
-      fail(e.toString());
-    }
-    QuerySchemaLoader.initialize();
-
-    // Check the entries
-    QuerySchema qSchema = QuerySchemaRegistry.get(querySchemaName);
-
-    assertEquals(querySchemaName, qSchema.getSchemaName());
-    assertEquals(dataSchemaName, qSchema.getDataSchemaName());
-    assertEquals(element4, qSchema.getSelectorName());
-
-    assertEquals(StopListFilter.class.getName(), qSchema.getFilterTypeName());
-    if (!(qSchema.getFilter() instanceof StopListFilter))
-    {
-      fail("Filter class instance must be StopListFilter");
-    }
-
-    assertEquals(3, qSchema.getElementNames().size());
-    for (String item : qSchema.getElementNames())
-    {
-      if (!(item.equals(element1) || item.equals(element2) || item.equals(element3)))
-      {
-        fail("elementNames: item = " + item + " must equal one of: " + element1 + ", " + element2 + ", or " + element3);
-      }
-    }
-    assertEquals(1, qSchema.getFilteredElementNames().size());
-    for (String item : qSchema.getFilteredElementNames())
-    {
-      if (!item.equals(element2))
-      {
-        fail("filterElementNames: item = " + item + " must equal " + element2);
-      }
-    }
-
-    // one string, array IPs, array integers
-    int stringSize = Integer.parseInt(SystemConfiguration.getProperty("pir.stringBits"));
-    int arrayMult = Integer.parseInt(SystemConfiguration.getProperty("pir.numReturnArrayElements"));
-    int dataElementSize = stringSize + 32 * arrayMult + 32 * arrayMult;
-    assertEquals(dataElementSize, qSchema.getDataElementSize());
-
-    // Reset original query and data schema properties
-    SystemConfiguration.setProperty("data.schemas", dataSchemasProp);
-    SystemConfiguration.setProperty("query.schemas", querySchemasProp);
-    SystemConfiguration.setProperty("pir.stopListFile", stopListFileProp);
-
-    // Force the query and data schemas to load their original values
-    if (!dataSchemasProp.equals("none"))
-    {
-      DataSchemaLoader.initialize();
-    }
-
-    if (!querySchemasProp.equals("none"))
-    {
-      QuerySchemaLoader.initialize();
-    }
-
-    logger.info("Finished testGeneralSchemaLoad: ");
-  }
-
-  @Test
-  public void testUnknownFilterClass() throws Exception
-  {
-    // Pull off the properties and reset upon completion
-    String dataSchemasProp = SystemConfiguration.getProperty("data.schemas", "none");
-    String querySchemasProp = SystemConfiguration.getProperty("query.schemas", "none");
-
-    // Create the data schema used and force it to load
-    try
-    {
-      createDataSchema("dataSchemaFile");
-    } catch (Exception e)
-    {
-      e.printStackTrace();
-      fail(e.toString());
-    }
-    DataSchemaLoader.initialize();
-
-    // Create the query schema used and force it to load
-    try
-    {
-      TestUtils.createQuerySchema(querySchemaFile, querySchemaName, dataSchemaName, "nonExistentElement", queryElements, filterElements, "bogusFilterClass");
-
-    } catch (IOException e)
-    {
-      e.printStackTrace();
-      fail(e.toString());
-    }
-    try
-    {
-      QuerySchemaLoader.initialize();
-      fail("QuerySchemaLoader did not throw exception for bogus filter class");
-    } catch (Exception ignore)
-    {}
-
-    // Reset original query and data schema properties
-    SystemConfiguration.setProperty("data.schemas", dataSchemasProp);
-    SystemConfiguration.setProperty("query.schemas", querySchemasProp);
-
-    // Force the query and data schemas to load their original values
-    if (!dataSchemasProp.equals("none"))
-    {
-      DataSchemaLoader.initialize();
-    }
-
-    if (!querySchemasProp.equals("none"))
-    {
-      QuerySchemaLoader.initialize();
-    }
-
-    logger.info("Finished testFunkyFilterScenarios");
-  }
-
-  @Test
-  public void testDataSchemaDoesNotExist() throws Exception
-  {
-    logger.info("Starting testDataSchemaDoesNotExist: ");
-
-    // Pull off the properties and reset upon completion
-    String querySchemasProp = SystemConfiguration.getProperty("query.schemas", "none");
-
-    // Create the query schema used and force it to load
-    try
-    {
-      TestUtils.createQuerySchema(querySchemaFile, querySchemaName, dataSchemaName, element4, queryElements, filterElements, null);
-
-    } catch (IOException e)
-    {
-      e.printStackTrace();
-      fail(e.toString());
-    }
-    try
-    {
-      QuerySchemaLoader.initialize();
-      fail("QuerySchemaLoader did not throw exception for non-existent DataSchema");
-    } catch (Exception ignore)
-    {}
-
-    // Reset original query properties and force to load
-    SystemConfiguration.setProperty("query.schemas", querySchemasProp);
-    if (!querySchemasProp.equals("none"))
-    {
-      QuerySchemaLoader.initialize();
-    }
-
-    logger.info("Finished testDataSchemaDoesNotExist ");
-  }
-
-  @Test
-  public void testSelectorDoesNotExistInDataSchema() throws Exception
-  {
-    logger.info("Starting testSelectorDoesNotExistInDataSchema: ");
-
-    // Pull off the properties and reset upon completion
-    String dataSchemasProp = SystemConfiguration.getProperty("data.schemas", "none");
-    String querySchemasProp = SystemConfiguration.getProperty("query.schemas", "none");
-
-    // Create the data schema used and force it to load
-    try
-    {
-      createDataSchema("dataSchemaFile");
-    } catch (Exception e)
-    {
-      e.printStackTrace();
-      fail(e.toString());
-    }
-    DataSchemaLoader.initialize();
-
-    // Create the query schema used and force it to load
-    try
-    {
-      TestUtils.createQuerySchema(querySchemaFile, querySchemaName, dataSchemaName, "nonExistentElement", queryElements, filterElements,
-          StopListFilter.class.getName());
-
-    } catch (IOException e)
-    {
-      e.printStackTrace();
-      fail(e.toString());
-    }
-    try
-    {
-      QuerySchemaLoader.initialize();
-      fail("QuerySchemaLoader did not throw exception for non-existent selectorName");
-    } catch (Exception ignore)
-    {}
-
-    // Reset original query and data schema properties
-    SystemConfiguration.setProperty("data.schemas", dataSchemasProp);
-    SystemConfiguration.setProperty("query.schemas", querySchemasProp);
-
-    // Force the query and data schemas to load their original values
-    if (!dataSchemasProp.equals("none"))
-    {
-      DataSchemaLoader.initialize();
-    }
-
-    if (!querySchemasProp.equals("none"))
-    {
-      QuerySchemaLoader.initialize();
-    }
-
-    logger.info("Finished testSelectorDoesNotExistInDataSchema ");
-  }
-
-  // Create the stoplist file and alter the properties accordingly
-  private void createStopListFile() throws IOException, PIRException
-  {
-    SystemConfiguration.setProperty("pir.stopListFile", "testStopListFile");
-    String newSLFile = Inputs.createPIRStopList(null, false);
-    SystemConfiguration.setProperty("pir.stopListFile", newSLFile);
-  }
-
-  // Create the test data schema file
-  private void createDataSchema(String schemaFile) throws IOException
-  {
-    // Create a temporary file for the test schema, set in the properties
-    File file = File.createTempFile(schemaFile, ".xml");
-    file.deleteOnExit();
-    logger.info("file = " + file.toString());
-    SystemConfiguration.setProperty("data.schemas", file.toString());
-
-    // Write to the file
-    try
-    {
-      DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();
-      DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();
-      Document doc = dBuilder.newDocument();
-
-      // root element
-      Element rootElement = doc.createElement("schema");
-      doc.appendChild(rootElement);
-
-      // Add the schemaName
-      Element schemaNameElement = doc.createElement("schemaName");
-      schemaNameElement.appendChild(doc.createTextNode(dataSchemaName));
-      rootElement.appendChild(schemaNameElement);
-
-      // Add the elements
-      // element1 -- single String
-      TestUtils.addElement(doc, rootElement, element1, PrimitiveTypePartitioner.STRING, "false", PrimitiveTypePartitioner.class.getName());
-
-      // element2 - -- array of Integers
-      TestUtils.addElement(doc, rootElement, element2, PrimitiveTypePartitioner.INT, "true", PrimitiveTypePartitioner.class.getName());
-
-      // element3 -- array of IP addresses
-      TestUtils.addElement(doc, rootElement, element3, PrimitiveTypePartitioner.STRING, "true", IPDataPartitioner.class.getName());
-
-      // element4 -- single byte type
-      TestUtils.addElement(doc, rootElement, element4, PrimitiveTypePartitioner.BYTE, "false", PrimitiveTypePartitioner.class.getName());
-
-      // Write to a xml file
-      TransformerFactory transformerFactory = TransformerFactory.newInstance();
-      Transformer transformer = transformerFactory.newTransformer();
-      DOMSource source = new DOMSource(doc);
-      StreamResult result = new StreamResult(file);
-      transformer.transform(source, result);
-
-      // Output for testing
-      StreamResult consoleResult = new StreamResult(System.out);
-      transformer.transform(source, consoleResult);
-      System.out.println();
-
-    } catch (Exception e)
-    {
-      e.printStackTrace();
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/test/wideskies/standalone/StandaloneTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/test/wideskies/standalone/StandaloneTest.java b/src/test/java/test/wideskies/standalone/StandaloneTest.java
deleted file mode 100644
index b4fd255..0000000
--- a/src/test/java/test/wideskies/standalone/StandaloneTest.java
+++ /dev/null
@@ -1,128 +0,0 @@
-/*
- * 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 test.wideskies.standalone;
-
-import java.util.ArrayList;
-
-import org.apache.pirk.schema.data.DataSchemaRegistry;
-import org.apache.pirk.schema.query.QuerySchemaRegistry;
-import org.apache.pirk.schema.query.filter.StopListFilter;
-import org.apache.pirk.test.utils.BaseTests;
-import org.apache.pirk.test.utils.Inputs;
-import org.apache.pirk.utils.SystemConfiguration;
-import org.json.simple.JSONObject;
-import org.junit.AfterClass;
-import org.junit.BeforeClass;
-import org.junit.Test;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * Functional test suite for stand alone testing - non Spark applications
- * <p>
- * Tests low side module and basic encryption, decryption mechanisms
- * <p>
- * Using a fixed 8-bit data partition size (consistent with the currently codebase)
- * <p>
- * Runs with useExpLookupTable = false as generating the lookup table takes too long for normal in-memory builds
- * 
- */
-public class StandaloneTest
-{
-  private static final Logger logger = LoggerFactory.getLogger(StandaloneTest.class);
-
-  private static final String STOPLIST_FILE = "testStopListFile";
-
-  private static String stopListFileProp = null;
-
-  @BeforeClass
-  public static void setup() throws Exception
-  {
-    // Reset the schema properties and registries
-    DataSchemaRegistry.clearRegistry();
-    QuerySchemaRegistry.clearRegistry();
-    SystemConfiguration.setProperty("data.schemas", "none");
-    SystemConfiguration.setProperty("query.schemas", "none");
-
-    // Create the stoplist file
-    stopListFileProp = SystemConfiguration.getProperty("pir.stopListFile");
-    SystemConfiguration.setProperty("pir.stopListFile", STOPLIST_FILE);
-    String newSLFile = Inputs.createPIRStopList(null, false);
-    SystemConfiguration.setProperty("pir.stopListFile", newSLFile);
-    logger.info("stopListFileProp = " + stopListFileProp + " new prop = " + SystemConfiguration.getProperty("pir.stopListFile"));
-
-    // Create data and query schemas
-    Inputs.createSchemaFiles(StopListFilter.class.getName());
-  }
-
-  @AfterClass
-  public static void teardown()
-  {
-    // Reset the schema properties and registries
-    DataSchemaRegistry.clearRegistry();
-    QuerySchemaRegistry.clearRegistry();
-    SystemConfiguration.setProperty("data.schemas", "none");
-    SystemConfiguration.setProperty("query.schemas", "none");
-  }
-
-  @Test
-  public void runTests() throws Exception
-  {
-    ArrayList<JSONObject> dataElements = Inputs.createJSONDataElements();
-    ArrayList<JSONObject> dataElementsRcode3 = Inputs.getRcode3JSONDataElements();
-
-    SystemConfiguration.setProperty("pir.allowAdHocQuerySchemas", "false");
-    SystemConfiguration.setProperty("pir.embedQuerySchema", "false");
-
-    // Run tests and use the embedded selector
-    SystemConfiguration.setProperty("pirTest.embedSelector", "true");
-    BaseTests.testDNSHostnameQuery(dataElements, 1, false);
-    BaseTests.testSRCIPQuery(dataElements, 2);
-    BaseTests.testDNSIPQuery(dataElements, 3); // numThreads % num elements to encrypt != 0
-    BaseTests.testDNSNXDOMAINQuery(dataElementsRcode3, 4); // numThreads % num elements to encrypt = 0
-
-    // Test embedded QuerySchema
-    SystemConfiguration.setProperty("pir.allowAdHocQuerySchemas", "true");
-    SystemConfiguration.setProperty("pir.embedQuerySchema", "false");
-    BaseTests.testDNSHostnameQuery(dataElements, 1, false);
-
-    SystemConfiguration.setProperty("pir.allowAdHocQuerySchemas", "true");
-    SystemConfiguration.setProperty("pir.embedQuerySchema", "true");
-    BaseTests.testDNSHostnameQuery(dataElements, 1, false);
-
-    SystemConfiguration.setProperty("pir.allowAdHocQuerySchemas", "false");
-    SystemConfiguration.setProperty("pir.embedQuerySchema", "true");
-    BaseTests.testDNSHostnameQuery(dataElements, 1, false);
-    SystemConfiguration.setProperty("pir.embedQuerySchema", "false");
-
-    // Run tests without using the embedded selector
-    SystemConfiguration.setProperty("pirTest.embedSelector", "false");
-    BaseTests.testDNSHostnameQuery(dataElements, 1, false);
-    BaseTests.testSRCIPQuery(dataElements, 2);
-    BaseTests.testDNSIPQuery(dataElements, 3);
-    BaseTests.testDNSNXDOMAINQuery(dataElementsRcode3, 4);
-
-    // Run using a false positive
-    SystemConfiguration.setProperty("pirTest.embedSelector", "true");
-    BaseTests.testDNSHostnameQuery(dataElements, 1, true);
-
-    // Reset the stoplist file property
-    SystemConfiguration.setProperty("pir.stopListFile", stopListFileProp);
-  }
-}


[9/9] incubator-pirk git commit: [PIRK-37]: Rename package for test classes to be org.apache.pirk.* -- closes apache/incubator-pirk#39

Posted by ea...@apache.org.
[PIRK-37]: Rename package for test classes to be org.apache.pirk.*  -- closes apache/incubator-pirk#39


Project: http://git-wip-us.apache.org/repos/asf/incubator-pirk/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-pirk/commit/0912bb65
Tree: http://git-wip-us.apache.org/repos/asf/incubator-pirk/tree/0912bb65
Diff: http://git-wip-us.apache.org/repos/asf/incubator-pirk/diff/0912bb65

Branch: refs/heads/master
Commit: 0912bb658f758dcf041bc35231b39747e43ae63b
Parents: 9d7b46d
Author: smarthi <sm...@apache.org>
Authored: Sun Jul 31 19:06:10 2016 -0400
Committer: eawilliams <ea...@apache.org>
Committed: Sun Jul 31 19:06:10 2016 -0400

----------------------------------------------------------------------
 docs/allclasses-frame.html                      |  20 +-
 docs/allclasses-noframe.html                    |  20 +-
 docs/constant-values.html                       |   4 +-
 docs/deprecated-list.html                       |   4 +-
 docs/help-doc.html                              |   4 +-
 docs/index-files/index-1.html                   |   4 +-
 docs/index-files/index-10.html                  |   4 +-
 docs/index-files/index-11.html                  |   8 +-
 docs/index-files/index-12.html                  |  12 +-
 docs/index-files/index-13.html                  |   4 +-
 docs/index-files/index-14.html                  |   4 +-
 docs/index-files/index-15.html                  |   8 +-
 docs/index-files/index-16.html                  |  12 +-
 docs/index-files/index-17.html                  |   8 +-
 docs/index-files/index-18.html                  |   6 +-
 docs/index-files/index-19.html                  |  14 +-
 docs/index-files/index-2.html                   |   4 +-
 docs/index-files/index-20.html                  |  76 ++--
 docs/index-files/index-21.html                  |   4 +-
 docs/index-files/index-22.html                  |   4 +-
 docs/index-files/index-23.html                  |   4 +-
 docs/index-files/index-3.html                   |  12 +-
 docs/index-files/index-4.html                   |   4 +-
 docs/index-files/index-5.html                   |   4 +-
 docs/index-files/index-6.html                   |   4 +-
 docs/index-files/index-7.html                   |   4 +-
 docs/index-files/index-8.html                   |   4 +-
 docs/index-files/index-9.html                   |   8 +-
 docs/index.html                                 |   2 +-
 .../apache/pirk/benchmark/BenchmarkDriver.html  |   4 +-
 ...aillierBenchmark.PaillierBenchmarkState.html |   4 +-
 .../pirk/benchmark/PaillierBenchmark.html       |   4 +-
 .../benchmark/class-use/BenchmarkDriver.html    |   4 +-
 ...aillierBenchmark.PaillierBenchmarkState.html |   4 +-
 .../benchmark/class-use/PaillierBenchmark.html  |   4 +-
 .../apache/pirk/benchmark/package-frame.html    |   4 +-
 .../apache/pirk/benchmark/package-summary.html  |   4 +-
 .../org/apache/pirk/benchmark/package-tree.html |   4 +-
 docs/org/apache/pirk/benchmark/package-use.html |   4 +-
 .../pirk/encryption/ModPowAbstraction.html      |   4 +-
 docs/org/apache/pirk/encryption/Paillier.html   |   4 +-
 .../apache/pirk/encryption/PrimeGenerator.html  |   4 +-
 .../encryption/class-use/ModPowAbstraction.html |   4 +-
 .../pirk/encryption/class-use/Paillier.html     |   4 +-
 .../encryption/class-use/PrimeGenerator.html    |   4 +-
 .../apache/pirk/encryption/package-frame.html   |   4 +-
 .../apache/pirk/encryption/package-summary.html |   8 +-
 .../apache/pirk/encryption/package-tree.html    |   8 +-
 .../org/apache/pirk/encryption/package-use.html |   4 +-
 .../pirk/general/ISO8601DateParserTest.html     | 260 +++++++++++
 docs/org/apache/pirk/general/KeyedHashTest.html | 270 ++++++++++++
 docs/org/apache/pirk/general/PaillierTest.html  | 334 +++++++++++++++
 .../apache/pirk/general/PartitionUtilsTest.html | 286 +++++++++++++
 .../pirk/general/QueryParserUtilsTest.html      | 429 +++++++++++++++++++
 .../class-use/ISO8601DateParserTest.html        | 115 +++++
 .../pirk/general/class-use/KeyedHashTest.html   | 115 +++++
 .../pirk/general/class-use/PaillierTest.html    | 115 +++++
 .../general/class-use/PartitionUtilsTest.html   | 115 +++++
 .../general/class-use/QueryParserUtilsTest.html | 115 +++++
 docs/org/apache/pirk/general/package-frame.html |  23 +
 .../apache/pirk/general/package-summary.html    | 159 +++++++
 docs/org/apache/pirk/general/package-tree.html  | 132 ++++++
 docs/org/apache/pirk/general/package-use.html   | 115 +++++
 .../inputformat/hadoop/BaseInputFormat.html     |   4 +-
 .../inputformat/hadoop/BytesArrayWritable.html  |   4 +-
 .../inputformat/hadoop/InputFormatConst.html    |   4 +-
 .../inputformat/hadoop/TextArrayWritable.html   |   4 +-
 .../hadoop/class-use/BaseInputFormat.html       |   4 +-
 .../hadoop/class-use/BytesArrayWritable.html    |   4 +-
 .../hadoop/class-use/InputFormatConst.html      |   4 +-
 .../hadoop/class-use/TextArrayWritable.html     |   4 +-
 .../hadoop/json/JSONInputFormat.html            |   4 +-
 .../hadoop/json/JSONInputFormatBase.html        |   4 +-
 .../hadoop/json/JSONRecordReader.html           |   4 +-
 .../hadoop/json/class-use/JSONInputFormat.html  |   4 +-
 .../json/class-use/JSONInputFormatBase.html     |   4 +-
 .../hadoop/json/class-use/JSONRecordReader.html |   4 +-
 .../inputformat/hadoop/json/package-frame.html  |   4 +-
 .../hadoop/json/package-summary.html            |   4 +-
 .../inputformat/hadoop/json/package-tree.html   |   4 +-
 .../inputformat/hadoop/json/package-use.html    |   4 +-
 .../pirk/inputformat/hadoop/package-frame.html  |   4 +-
 .../inputformat/hadoop/package-summary.html     |   8 +-
 .../pirk/inputformat/hadoop/package-tree.html   |   8 +-
 .../pirk/inputformat/hadoop/package-use.html    |   4 +-
 .../apache/pirk/querier/wideskies/Querier.html  |   4 +-
 .../pirk/querier/wideskies/QuerierConst.html    |   4 +-
 .../pirk/querier/wideskies/QuerierDriver.html   |   4 +-
 .../querier/wideskies/QuerierDriverCLI.html     |   4 +-
 .../pirk/querier/wideskies/QuerierProps.html    |   4 +-
 .../querier/wideskies/class-use/Querier.html    |   4 +-
 .../wideskies/class-use/QuerierConst.html       |   4 +-
 .../wideskies/class-use/QuerierDriver.html      |   4 +-
 .../wideskies/class-use/QuerierDriverCLI.html   |   4 +-
 .../wideskies/class-use/QuerierProps.html       |   4 +-
 .../wideskies/decrypt/DecryptResponse.html      |   4 +-
 .../decrypt/DecryptResponseRunnable.html        |   4 +-
 .../decrypt/class-use/DecryptResponse.html      |   4 +-
 .../class-use/DecryptResponseRunnable.html      |   4 +-
 .../wideskies/decrypt/package-frame.html        |   4 +-
 .../wideskies/decrypt/package-summary.html      |   4 +-
 .../querier/wideskies/decrypt/package-tree.html |   4 +-
 .../querier/wideskies/decrypt/package-use.html  |   4 +-
 .../querier/wideskies/encrypt/EncryptQuery.html |   4 +-
 .../wideskies/encrypt/EncryptQueryRunnable.html |   4 +-
 .../wideskies/encrypt/ExpTableRunnable.html     |   4 +-
 .../encrypt/class-use/EncryptQuery.html         |   4 +-
 .../encrypt/class-use/EncryptQueryRunnable.html |   4 +-
 .../encrypt/class-use/ExpTableRunnable.html     |   4 +-
 .../wideskies/encrypt/package-frame.html        |   4 +-
 .../wideskies/encrypt/package-summary.html      |   4 +-
 .../querier/wideskies/encrypt/package-tree.html |   4 +-
 .../querier/wideskies/encrypt/package-use.html  |   4 +-
 .../pirk/querier/wideskies/package-frame.html   |   4 +-
 .../pirk/querier/wideskies/package-summary.html |   4 +-
 .../pirk/querier/wideskies/package-tree.html    |   4 +-
 .../pirk/querier/wideskies/package-use.html     |   4 +-
 docs/org/apache/pirk/query/wideskies/Query.html |   4 +-
 .../apache/pirk/query/wideskies/QueryInfo.html  |   4 +-
 .../apache/pirk/query/wideskies/QueryUtils.html |   4 +-
 .../pirk/query/wideskies/class-use/Query.html   |   4 +-
 .../query/wideskies/class-use/QueryInfo.html    |   4 +-
 .../query/wideskies/class-use/QueryUtils.html   |   4 +-
 .../pirk/query/wideskies/package-frame.html     |   4 +-
 .../pirk/query/wideskies/package-summary.html   |   4 +-
 .../pirk/query/wideskies/package-tree.html      |   4 +-
 .../pirk/query/wideskies/package-use.html       |   4 +-
 .../pirk/responder/wideskies/ResponderCLI.html  |   4 +-
 .../responder/wideskies/ResponderDriver.html    |   4 +-
 .../responder/wideskies/ResponderProps.html     |   4 +-
 .../wideskies/class-use/ResponderCLI.html       |   4 +-
 .../wideskies/class-use/ResponderDriver.html    |   4 +-
 .../wideskies/class-use/ResponderProps.html     |   4 +-
 .../wideskies/common/ComputeEncryptedRow.html   |   4 +-
 .../common/HashSelectorAndPartitionData.html    |   4 +-
 .../common/class-use/ComputeEncryptedRow.html   |   4 +-
 .../class-use/HashSelectorAndPartitionData.html |   4 +-
 .../wideskies/common/package-frame.html         |   4 +-
 .../wideskies/common/package-summary.html       |   4 +-
 .../wideskies/common/package-tree.html          |   4 +-
 .../responder/wideskies/common/package-use.html |   4 +-
 .../wideskies/mapreduce/ColumnMultMapper.html   |   4 +-
 .../wideskies/mapreduce/ColumnMultReducer.html  |   4 +-
 .../mapreduce/ComputeResponseTool.html          |   4 +-
 .../wideskies/mapreduce/ExpTableMapper.html     |   4 +-
 .../wideskies/mapreduce/ExpTableReducer.html    |   4 +-
 .../mapreduce/FinalResponseReducer.html         |   4 +-
 .../HashSelectorsAndPartitionDataMapper.html    |   4 +-
 .../responder/wideskies/mapreduce/MRStats.html  |   4 +-
 .../wideskies/mapreduce/RowCalcReducer.html     |   4 +-
 .../mapreduce/class-use/ColumnMultMapper.html   |   4 +-
 .../mapreduce/class-use/ColumnMultReducer.html  |   4 +-
 .../class-use/ComputeResponseTool.html          |   4 +-
 .../mapreduce/class-use/ExpTableMapper.html     |   4 +-
 .../mapreduce/class-use/ExpTableReducer.html    |   4 +-
 .../class-use/FinalResponseReducer.html         |   4 +-
 .../HashSelectorsAndPartitionDataMapper.html    |   4 +-
 .../wideskies/mapreduce/class-use/MRStats.html  |   4 +-
 .../mapreduce/class-use/RowCalcReducer.html     |   4 +-
 .../wideskies/mapreduce/package-frame.html      |   4 +-
 .../wideskies/mapreduce/package-summary.html    |   4 +-
 .../wideskies/mapreduce/package-tree.html       |   4 +-
 .../wideskies/mapreduce/package-use.html        |   4 +-
 .../pirk/responder/wideskies/package-frame.html |   4 +-
 .../responder/wideskies/package-summary.html    |   4 +-
 .../pirk/responder/wideskies/package-tree.html  |   4 +-
 .../pirk/responder/wideskies/package-use.html   |   4 +-
 .../responder/wideskies/spark/Accumulators.html |   4 +-
 .../wideskies/spark/BroadcastVars.html          |   4 +-
 .../wideskies/spark/ComputeExpLookupTable.html  |   4 +-
 .../wideskies/spark/ComputeResponse.html        |   4 +-
 .../spark/EncColMultGroupedMapper.html          |   4 +-
 .../wideskies/spark/EncColMultReducer.html      |   4 +-
 .../responder/wideskies/spark/EncRowCalc.html   |   4 +-
 .../spark/EncRowCalcPrecomputedCache.html       |   4 +-
 .../wideskies/spark/ExpKeyFilenameMap.html      |   4 +-
 .../wideskies/spark/ExpTableGenerator.html      |   4 +-
 .../responder/wideskies/spark/FilterData.html   |   4 +-
 .../spark/HashSelectorsAndPartitionData.html    |   4 +-
 .../wideskies/spark/class-use/Accumulators.html |   4 +-
 .../spark/class-use/BroadcastVars.html          |   4 +-
 .../spark/class-use/ComputeExpLookupTable.html  |   4 +-
 .../spark/class-use/ComputeResponse.html        |   4 +-
 .../class-use/EncColMultGroupedMapper.html      |   4 +-
 .../spark/class-use/EncColMultReducer.html      |   4 +-
 .../wideskies/spark/class-use/EncRowCalc.html   |   4 +-
 .../class-use/EncRowCalcPrecomputedCache.html   |   4 +-
 .../spark/class-use/ExpKeyFilenameMap.html      |   4 +-
 .../spark/class-use/ExpTableGenerator.html      |   4 +-
 .../wideskies/spark/class-use/FilterData.html   |   4 +-
 .../HashSelectorsAndPartitionData.html          |   4 +-
 .../wideskies/spark/package-frame.html          |   4 +-
 .../wideskies/spark/package-summary.html        |   4 +-
 .../responder/wideskies/spark/package-tree.html |   4 +-
 .../responder/wideskies/spark/package-use.html  |   4 +-
 .../wideskies/standalone/Responder.html         |   4 +-
 .../standalone/class-use/Responder.html         |   4 +-
 .../wideskies/standalone/package-frame.html     |   4 +-
 .../wideskies/standalone/package-summary.html   |   4 +-
 .../wideskies/standalone/package-tree.html      |   4 +-
 .../wideskies/standalone/package-use.html       |   4 +-
 .../pirk/response/wideskies/Response.html       |   4 +-
 .../response/wideskies/class-use/Response.html  |   4 +-
 .../pirk/response/wideskies/package-frame.html  |   4 +-
 .../response/wideskies/package-summary.html     |   4 +-
 .../pirk/response/wideskies/package-tree.html   |   4 +-
 .../pirk/response/wideskies/package-use.html    |   4 +-
 .../org/apache/pirk/schema/data/DataSchema.html |   4 +-
 .../pirk/schema/data/DataSchemaLoader.html      |   4 +-
 .../pirk/schema/data/DataSchemaRegistry.html    |  30 +-
 .../pirk/schema/data/LoadDataSchemaTest.html    | 292 +++++++++++++
 .../pirk/schema/data/class-use/DataSchema.html  |   4 +-
 .../schema/data/class-use/DataSchemaLoader.html |   4 +-
 .../data/class-use/DataSchemaRegistry.html      |   4 +-
 .../data/class-use/LoadDataSchemaTest.html      | 115 +++++
 .../apache/pirk/schema/data/package-frame.html  |   5 +-
 .../pirk/schema/data/package-summary.html       |  10 +-
 .../apache/pirk/schema/data/package-tree.html   |   5 +-
 .../apache/pirk/schema/data/package-use.html    |   4 +-
 .../data/partitioner/DataPartitioner.html       |   4 +-
 .../data/partitioner/IPDataPartitioner.html     |   4 +-
 .../partitioner/ISO8601DatePartitioner.html     |   4 +-
 .../partitioner/PrimitiveTypePartitioner.html   |   4 +-
 .../partitioner/class-use/DataPartitioner.html  |   4 +-
 .../class-use/IPDataPartitioner.html            |   4 +-
 .../class-use/ISO8601DatePartitioner.html       |   4 +-
 .../class-use/PrimitiveTypePartitioner.html     |   4 +-
 .../schema/data/partitioner/package-frame.html  |   4 +-
 .../data/partitioner/package-summary.html       |   4 +-
 .../schema/data/partitioner/package-tree.html   |   4 +-
 .../schema/data/partitioner/package-use.html    |   4 +-
 .../pirk/schema/query/LoadQuerySchemaTest.html  | 308 +++++++++++++
 .../apache/pirk/schema/query/QuerySchema.html   |   8 +-
 .../pirk/schema/query/QuerySchemaLoader.html    |   4 +-
 .../pirk/schema/query/QuerySchemaRegistry.html  |  26 +-
 .../query/class-use/LoadQuerySchemaTest.html    | 115 +++++
 .../schema/query/class-use/QuerySchema.html     |   4 +-
 .../query/class-use/QuerySchemaLoader.html      |   4 +-
 .../query/class-use/QuerySchemaRegistry.html    |   4 +-
 .../pirk/schema/query/filter/DataFilter.html    |   4 +-
 .../pirk/schema/query/filter/FilterFactory.html |   4 +-
 .../schema/query/filter/StopListFilter.html     |   4 +-
 .../query/filter/class-use/DataFilter.html      |   4 +-
 .../query/filter/class-use/FilterFactory.html   |   4 +-
 .../query/filter/class-use/StopListFilter.html  |   4 +-
 .../pirk/schema/query/filter/package-frame.html |   4 +-
 .../schema/query/filter/package-summary.html    |   4 +-
 .../pirk/schema/query/filter/package-tree.html  |   4 +-
 .../pirk/schema/query/filter/package-use.html   |   4 +-
 .../apache/pirk/schema/query/package-frame.html |   5 +-
 .../pirk/schema/query/package-summary.html      |  14 +-
 .../apache/pirk/schema/query/package-tree.html  |   5 +-
 .../apache/pirk/schema/query/package-use.html   |   4 +-
 .../pirk/schema/response/QueryResponseJSON.html |   4 +-
 .../response/class-use/QueryResponseJSON.html   |   4 +-
 .../pirk/schema/response/package-frame.html     |   4 +-
 .../pirk/schema/response/package-summary.html   |   4 +-
 .../pirk/schema/response/package-tree.html      |   4 +-
 .../pirk/schema/response/package-use.html       |   4 +-
 .../serialization/HadoopFileSystemStore.html    |   4 +-
 .../pirk/serialization/JavaSerializer.html      |   4 +-
 .../pirk/serialization/JsonSerializer.html      |   4 +-
 .../serialization/LocalFileSystemStore.html     |   4 +-
 .../serialization/SerializationService.html     |   4 +-
 .../org/apache/pirk/serialization/Storable.html |   4 +-
 .../class-use/HadoopFileSystemStore.html        |   4 +-
 .../serialization/class-use/JavaSerializer.html |   4 +-
 .../serialization/class-use/JsonSerializer.html |   4 +-
 .../class-use/LocalFileSystemStore.html         |   4 +-
 .../class-use/SerializationService.html         |   4 +-
 .../pirk/serialization/class-use/Storable.html  |   4 +-
 .../pirk/serialization/package-frame.html       |   4 +-
 .../pirk/serialization/package-summary.html     |   4 +-
 .../apache/pirk/serialization/package-tree.html |   4 +-
 .../apache/pirk/serialization/package-use.html  |   4 +-
 .../test/distributed/DistributedTestCLI.html    |   4 +-
 .../test/distributed/DistributedTestDriver.html |   4 +-
 .../class-use/DistributedTestCLI.html           |   4 +-
 .../class-use/DistributedTestDriver.html        |   4 +-
 .../pirk/test/distributed/package-frame.html    |   4 +-
 .../pirk/test/distributed/package-summary.html  |   4 +-
 .../pirk/test/distributed/package-tree.html     |   4 +-
 .../pirk/test/distributed/package-use.html      |   4 +-
 .../distributed/testsuite/DistTestSuite.html    |   4 +-
 .../testsuite/class-use/DistTestSuite.html      |   4 +-
 .../distributed/testsuite/package-frame.html    |   4 +-
 .../distributed/testsuite/package-summary.html  |   4 +-
 .../distributed/testsuite/package-tree.html     |   4 +-
 .../test/distributed/testsuite/package-use.html |   4 +-
 docs/org/apache/pirk/test/utils/BaseTests.html  |   4 +-
 docs/org/apache/pirk/test/utils/Inputs.html     |   4 +-
 .../apache/pirk/test/utils/StandaloneQuery.html |   4 +-
 docs/org/apache/pirk/test/utils/TestUtils.html  |   4 +-
 .../pirk/test/utils/class-use/BaseTests.html    |   4 +-
 .../pirk/test/utils/class-use/Inputs.html       |   4 +-
 .../test/utils/class-use/StandaloneQuery.html   |   4 +-
 .../pirk/test/utils/class-use/TestUtils.html    |   4 +-
 .../apache/pirk/test/utils/package-frame.html   |   4 +-
 .../apache/pirk/test/utils/package-summary.html |   4 +-
 .../apache/pirk/test/utils/package-tree.html    |   4 +-
 .../org/apache/pirk/test/utils/package-use.html |   4 +-
 docs/org/apache/pirk/utils/CSVOutputUtils.html  |   4 +-
 docs/org/apache/pirk/utils/EpochDateParser.html |   4 +-
 docs/org/apache/pirk/utils/FileConst.html       |   4 +-
 .../apache/pirk/utils/FileIOUtils.Callable.html |   4 +-
 docs/org/apache/pirk/utils/FileIOUtils.html     |   4 +-
 docs/org/apache/pirk/utils/HDFS.html            |   4 +-
 .../apache/pirk/utils/ISO8601DateParser.html    |   4 +-
 docs/org/apache/pirk/utils/KeyedHash.html       |   4 +-
 docs/org/apache/pirk/utils/PIRException.html    |   4 +-
 .../org/apache/pirk/utils/QueryParserUtils.html |   4 +-
 docs/org/apache/pirk/utils/StopListUtils.html   |   4 +-
 docs/org/apache/pirk/utils/StringUtils.html     |   4 +-
 .../apache/pirk/utils/SystemConfiguration.html  |   4 +-
 .../pirk/utils/class-use/CSVOutputUtils.html    |   4 +-
 .../pirk/utils/class-use/EpochDateParser.html   |   4 +-
 .../apache/pirk/utils/class-use/FileConst.html  |   4 +-
 .../utils/class-use/FileIOUtils.Callable.html   |   4 +-
 .../pirk/utils/class-use/FileIOUtils.html       |   4 +-
 docs/org/apache/pirk/utils/class-use/HDFS.html  |   4 +-
 .../pirk/utils/class-use/ISO8601DateParser.html |   4 +-
 .../apache/pirk/utils/class-use/KeyedHash.html  |   4 +-
 .../pirk/utils/class-use/PIRException.html      |   4 +-
 .../pirk/utils/class-use/QueryParserUtils.html  |   4 +-
 .../pirk/utils/class-use/StopListUtils.html     |   4 +-
 .../pirk/utils/class-use/StringUtils.html       |   4 +-
 .../utils/class-use/SystemConfiguration.html    |   4 +-
 docs/org/apache/pirk/utils/package-frame.html   |   4 +-
 docs/org/apache/pirk/utils/package-summary.html |   8 +-
 docs/org/apache/pirk/utils/package-tree.html    |   8 +-
 docs/org/apache/pirk/utils/package-use.html     |   4 +-
 .../wideskies/standalone/StandaloneTest.html    | 295 +++++++++++++
 .../standalone/class-use/StandaloneTest.html    | 115 +++++
 .../wideskies/standalone/package-frame.html     |  19 +
 .../wideskies/standalone/package-summary.html   | 135 ++++++
 .../pirk/wideskies/standalone/package-tree.html | 128 ++++++
 .../pirk/wideskies/standalone/package-use.html  | 115 +++++
 docs/overview-frame.html                        |  10 +-
 docs/overview-summary.html                      |  60 ++-
 docs/overview-tree.html                         |  26 +-
 docs/package-list                               |   6 +-
 docs/serialized-form.html                       |   4 +-
 pom.xml                                         |  13 +-
 .../org/apache/pirk/utils/CSVOutputUtils.java   |   6 +-
 .../pirk/general/ISO8601DateParserTest.java     |  50 +++
 .../org/apache/pirk/general/KeyedHashTest.java  |  83 ++++
 .../org/apache/pirk/general/PaillierTest.java   | 292 +++++++++++++
 .../apache/pirk/general/PartitionUtilsTest.java | 233 ++++++++++
 .../pirk/general/QueryParserUtilsTest.java      | 421 ++++++++++++++++++
 .../pirk/schema/data/LoadDataSchemaTest.java    | 324 ++++++++++++++
 .../pirk/schema/query/LoadQuerySchemaTest.java  | 368 ++++++++++++++++
 .../wideskies/standalone/StandaloneTest.java    | 128 ++++++
 .../test/general/ISO8601DateParserTest.java     |  50 ---
 src/test/java/test/general/KeyedHashTest.java   |  83 ----
 src/test/java/test/general/PaillierTest.java    | 292 -------------
 .../java/test/general/PartitionUtilsTest.java   | 233 ----------
 .../java/test/general/QueryParserUtilsTest.java | 421 ------------------
 .../test/schema/data/LoadDataSchemaTest.java    | 327 --------------
 .../test/schema/query/LoadQuerySchemaTest.java  | 373 ----------------
 .../wideskies/standalone/StandaloneTest.java    | 128 ------
 360 files changed, 6961 insertions(+), 2692 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/allclasses-frame.html
----------------------------------------------------------------------
diff --git a/docs/allclasses-frame.html b/docs/allclasses-frame.html
index 45e95b1..96daddb 100644
--- a/docs/allclasses-frame.html
+++ b/docs/allclasses-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>All Classes</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>
@@ -61,7 +61,7 @@
 <li><a href="org/apache/pirk/test/utils/Inputs.html" title="class in org.apache.pirk.test.utils" target="classFrame">Inputs</a></li>
 <li><a href="org/apache/pirk/schema/data/partitioner/IPDataPartitioner.html" title="class in org.apache.pirk.schema.data.partitioner" target="classFrame">IPDataPartitioner</a></li>
 <li><a href="org/apache/pirk/utils/ISO8601DateParser.html" title="class in org.apache.pirk.utils" target="classFrame">ISO8601DateParser</a></li>
-<li><a href="test/general/ISO8601DateParserTest.html" title="class in test.general" target="classFrame">ISO8601DateParserTest</a></li>
+<li><a href="org/apache/pirk/general/ISO8601DateParserTest.html" title="class in org.apache.pirk.general" target="classFrame">ISO8601DateParserTest</a></li>
 <li><a href="org/apache/pirk/schema/data/partitioner/ISO8601DatePartitioner.html" title="class in org.apache.pirk.schema.data.partitioner" target="classFrame">ISO8601DatePartitioner</a></li>
 <li><a href="org/apache/pirk/serialization/JavaSerializer.html" title="class in org.apache.pirk.serialization" target="classFrame">JavaSerializer</a></li>
 <li><a href="org/apache/pirk/inputformat/hadoop/json/JSONInputFormat.html" title="class in org.apache.pirk.inputformat.hadoop.json" target="classFrame">JSONInputFormat</a></li>
@@ -69,17 +69,17 @@
 <li><a href="org/apache/pirk/inputformat/hadoop/json/JSONRecordReader.html" title="class in org.apache.pirk.inputformat.hadoop.json" target="classFrame">JSONRecordReader</a></li>
 <li><a href="org/apache/pirk/serialization/JsonSerializer.html" title="class in org.apache.pirk.serialization" target="classFrame">JsonSerializer</a></li>
 <li><a href="org/apache/pirk/utils/KeyedHash.html" title="class in org.apache.pirk.utils" target="classFrame">KeyedHash</a></li>
-<li><a href="test/general/KeyedHashTest.html" title="class in test.general" target="classFrame">KeyedHashTest</a></li>
-<li><a href="test/schema/data/LoadDataSchemaTest.html" title="class in test.schema.data" target="classFrame">LoadDataSchemaTest</a></li>
-<li><a href="test/schema/query/LoadQuerySchemaTest.html" title="class in test.schema.query" target="classFrame">LoadQuerySchemaTest</a></li>
+<li><a href="org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general" target="classFrame">KeyedHashTest</a></li>
+<li><a href="org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data" target="classFrame">LoadDataSchemaTest</a></li>
+<li><a href="org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query" target="classFrame">LoadQuerySchemaTest</a></li>
 <li><a href="org/apache/pirk/serialization/LocalFileSystemStore.html" title="class in org.apache.pirk.serialization" target="classFrame">LocalFileSystemStore</a></li>
 <li><a href="org/apache/pirk/encryption/ModPowAbstraction.html" title="class in org.apache.pirk.encryption" target="classFrame">ModPowAbstraction</a></li>
 <li><a href="org/apache/pirk/responder/wideskies/mapreduce/MRStats.html" title="enum in org.apache.pirk.responder.wideskies.mapreduce" target="classFrame">MRStats</a></li>
 <li><a href="org/apache/pirk/encryption/Paillier.html" title="class in org.apache.pirk.encryption" target="classFrame">Paillier</a></li>
 <li><a href="org/apache/pirk/benchmark/PaillierBenchmark.html" title="class in org.apache.pirk.benchmark" target="classFrame">PaillierBenchmark</a></li>
 <li><a href="org/apache/pirk/benchmark/PaillierBenchmark.PaillierBenchmarkState.html" title="class in org.apache.pirk.benchmark" target="classFrame">PaillierBenchmark.PaillierBenchmarkState</a></li>
-<li><a href="test/general/PaillierTest.html" title="class in test.general" target="classFrame">PaillierTest</a></li>
-<li><a href="test/general/PartitionUtilsTest.html" title="class in test.general" target="classFrame">PartitionUtilsTest</a></li>
+<li><a href="org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general" target="classFrame">PaillierTest</a></li>
+<li><a href="org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general" target="classFrame">PartitionUtilsTest</a></li>
 <li><a href="org/apache/pirk/utils/PIRException.html" title="class in org.apache.pirk.utils" target="classFrame">PIRException</a></li>
 <li><a href="org/apache/pirk/encryption/PrimeGenerator.html" title="class in org.apache.pirk.encryption" target="classFrame">PrimeGenerator</a></li>
 <li><a href="org/apache/pirk/schema/data/partitioner/PrimitiveTypePartitioner.html" title="class in org.apache.pirk.schema.data.partitioner" target="classFrame">PrimitiveTypePartitioner</a></li>
@@ -91,7 +91,7 @@
 <li><a href="org/apache/pirk/query/wideskies/Query.html" title="class in org.apache.pirk.query.wideskies" target="classFrame">Query</a></li>
 <li><a href="org/apache/pirk/query/wideskies/QueryInfo.html" title="class in org.apache.pirk.query.wideskies" target="classFrame">QueryInfo</a></li>
 <li><a href="org/apache/pirk/utils/QueryParserUtils.html" title="class in org.apache.pirk.utils" target="classFrame">QueryParserUtils</a></li>
-<li><a href="test/general/QueryParserUtilsTest.html" title="class in test.general" target="classFrame">QueryParserUtilsTest</a></li>
+<li><a href="org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general" target="classFrame">QueryParserUtilsTest</a></li>
 <li><a href="org/apache/pirk/schema/response/QueryResponseJSON.html" title="class in org.apache.pirk.schema.response" target="classFrame">QueryResponseJSON</a></li>
 <li><a href="org/apache/pirk/schema/query/QuerySchema.html" title="class in org.apache.pirk.schema.query" target="classFrame">QuerySchema</a></li>
 <li><a href="org/apache/pirk/schema/query/QuerySchemaLoader.html" title="class in org.apache.pirk.schema.query" target="classFrame">QuerySchemaLoader</a></li>
@@ -105,7 +105,7 @@
 <li><a href="org/apache/pirk/responder/wideskies/mapreduce/RowCalcReducer.html" title="class in org.apache.pirk.responder.wideskies.mapreduce" target="classFrame">RowCalcReducer</a></li>
 <li><a href="org/apache/pirk/serialization/SerializationService.html" title="class in org.apache.pirk.serialization" target="classFrame">SerializationService</a></li>
 <li><a href="org/apache/pirk/test/utils/StandaloneQuery.html" title="class in org.apache.pirk.test.utils" target="classFrame">StandaloneQuery</a></li>
-<li><a href="test/wideskies/standalone/StandaloneTest.html" title="class in test.wideskies.standalone" target="classFrame">StandaloneTest</a></li>
+<li><a href="org/apache/pirk/wideskies/standalone/StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone" target="classFrame">StandaloneTest</a></li>
 <li><a href="org/apache/pirk/schema/query/filter/StopListFilter.html" title="class in org.apache.pirk.schema.query.filter" target="classFrame">StopListFilter</a></li>
 <li><a href="org/apache/pirk/utils/StopListUtils.html" title="class in org.apache.pirk.utils" target="classFrame">StopListUtils</a></li>
 <li><a href="org/apache/pirk/serialization/Storable.html" title="interface in org.apache.pirk.serialization" target="classFrame"><i>Storable</i></a></li>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/allclasses-noframe.html
----------------------------------------------------------------------
diff --git a/docs/allclasses-noframe.html b/docs/allclasses-noframe.html
index 11fa924..cd18be1 100644
--- a/docs/allclasses-noframe.html
+++ b/docs/allclasses-noframe.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>All Classes</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>
@@ -61,7 +61,7 @@
 <li><a href="org/apache/pirk/test/utils/Inputs.html" title="class in org.apache.pirk.test.utils">Inputs</a></li>
 <li><a href="org/apache/pirk/schema/data/partitioner/IPDataPartitioner.html" title="class in org.apache.pirk.schema.data.partitioner">IPDataPartitioner</a></li>
 <li><a href="org/apache/pirk/utils/ISO8601DateParser.html" title="class in org.apache.pirk.utils">ISO8601DateParser</a></li>
-<li><a href="test/general/ISO8601DateParserTest.html" title="class in test.general">ISO8601DateParserTest</a></li>
+<li><a href="org/apache/pirk/general/ISO8601DateParserTest.html" title="class in org.apache.pirk.general">ISO8601DateParserTest</a></li>
 <li><a href="org/apache/pirk/schema/data/partitioner/ISO8601DatePartitioner.html" title="class in org.apache.pirk.schema.data.partitioner">ISO8601DatePartitioner</a></li>
 <li><a href="org/apache/pirk/serialization/JavaSerializer.html" title="class in org.apache.pirk.serialization">JavaSerializer</a></li>
 <li><a href="org/apache/pirk/inputformat/hadoop/json/JSONInputFormat.html" title="class in org.apache.pirk.inputformat.hadoop.json">JSONInputFormat</a></li>
@@ -69,17 +69,17 @@
 <li><a href="org/apache/pirk/inputformat/hadoop/json/JSONRecordReader.html" title="class in org.apache.pirk.inputformat.hadoop.json">JSONRecordReader</a></li>
 <li><a href="org/apache/pirk/serialization/JsonSerializer.html" title="class in org.apache.pirk.serialization">JsonSerializer</a></li>
 <li><a href="org/apache/pirk/utils/KeyedHash.html" title="class in org.apache.pirk.utils">KeyedHash</a></li>
-<li><a href="test/general/KeyedHashTest.html" title="class in test.general">KeyedHashTest</a></li>
-<li><a href="test/schema/data/LoadDataSchemaTest.html" title="class in test.schema.data">LoadDataSchemaTest</a></li>
-<li><a href="test/schema/query/LoadQuerySchemaTest.html" title="class in test.schema.query">LoadQuerySchemaTest</a></li>
+<li><a href="org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general">KeyedHashTest</a></li>
+<li><a href="org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data">LoadDataSchemaTest</a></li>
+<li><a href="org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query">LoadQuerySchemaTest</a></li>
 <li><a href="org/apache/pirk/serialization/LocalFileSystemStore.html" title="class in org.apache.pirk.serialization">LocalFileSystemStore</a></li>
 <li><a href="org/apache/pirk/encryption/ModPowAbstraction.html" title="class in org.apache.pirk.encryption">ModPowAbstraction</a></li>
 <li><a href="org/apache/pirk/responder/wideskies/mapreduce/MRStats.html" title="enum in org.apache.pirk.responder.wideskies.mapreduce">MRStats</a></li>
 <li><a href="org/apache/pirk/encryption/Paillier.html" title="class in org.apache.pirk.encryption">Paillier</a></li>
 <li><a href="org/apache/pirk/benchmark/PaillierBenchmark.html" title="class in org.apache.pirk.benchmark">PaillierBenchmark</a></li>
 <li><a href="org/apache/pirk/benchmark/PaillierBenchmark.PaillierBenchmarkState.html" title="class in org.apache.pirk.benchmark">PaillierBenchmark.PaillierBenchmarkState</a></li>
-<li><a href="test/general/PaillierTest.html" title="class in test.general">PaillierTest</a></li>
-<li><a href="test/general/PartitionUtilsTest.html" title="class in test.general">PartitionUtilsTest</a></li>
+<li><a href="org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general">PaillierTest</a></li>
+<li><a href="org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general">PartitionUtilsTest</a></li>
 <li><a href="org/apache/pirk/utils/PIRException.html" title="class in org.apache.pirk.utils">PIRException</a></li>
 <li><a href="org/apache/pirk/encryption/PrimeGenerator.html" title="class in org.apache.pirk.encryption">PrimeGenerator</a></li>
 <li><a href="org/apache/pirk/schema/data/partitioner/PrimitiveTypePartitioner.html" title="class in org.apache.pirk.schema.data.partitioner">PrimitiveTypePartitioner</a></li>
@@ -91,7 +91,7 @@
 <li><a href="org/apache/pirk/query/wideskies/Query.html" title="class in org.apache.pirk.query.wideskies">Query</a></li>
 <li><a href="org/apache/pirk/query/wideskies/QueryInfo.html" title="class in org.apache.pirk.query.wideskies">QueryInfo</a></li>
 <li><a href="org/apache/pirk/utils/QueryParserUtils.html" title="class in org.apache.pirk.utils">QueryParserUtils</a></li>
-<li><a href="test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></li>
+<li><a href="org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></li>
 <li><a href="org/apache/pirk/schema/response/QueryResponseJSON.html" title="class in org.apache.pirk.schema.response">QueryResponseJSON</a></li>
 <li><a href="org/apache/pirk/schema/query/QuerySchema.html" title="class in org.apache.pirk.schema.query">QuerySchema</a></li>
 <li><a href="org/apache/pirk/schema/query/QuerySchemaLoader.html" title="class in org.apache.pirk.schema.query">QuerySchemaLoader</a></li>
@@ -105,7 +105,7 @@
 <li><a href="org/apache/pirk/responder/wideskies/mapreduce/RowCalcReducer.html" title="class in org.apache.pirk.responder.wideskies.mapreduce">RowCalcReducer</a></li>
 <li><a href="org/apache/pirk/serialization/SerializationService.html" title="class in org.apache.pirk.serialization">SerializationService</a></li>
 <li><a href="org/apache/pirk/test/utils/StandaloneQuery.html" title="class in org.apache.pirk.test.utils">StandaloneQuery</a></li>
-<li><a href="test/wideskies/standalone/StandaloneTest.html" title="class in test.wideskies.standalone">StandaloneTest</a></li>
+<li><a href="org/apache/pirk/wideskies/standalone/StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone">StandaloneTest</a></li>
 <li><a href="org/apache/pirk/schema/query/filter/StopListFilter.html" title="class in org.apache.pirk.schema.query.filter">StopListFilter</a></li>
 <li><a href="org/apache/pirk/utils/StopListUtils.html" title="class in org.apache.pirk.utils">StopListUtils</a></li>
 <li><a href="org/apache/pirk/serialization/Storable.html" title="interface in org.apache.pirk.serialization"><i>Storable</i></a></li>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/constant-values.html
----------------------------------------------------------------------
diff --git a/docs/constant-values.html b/docs/constant-values.html
index fd64d89..cb477bc 100644
--- a/docs/constant-values.html
+++ b/docs/constant-values.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Constant Field Values</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/deprecated-list.html
----------------------------------------------------------------------
diff --git a/docs/deprecated-list.html b/docs/deprecated-list.html
index 49fee2c..504e4f2 100644
--- a/docs/deprecated-list.html
+++ b/docs/deprecated-list.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Deprecated List</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/help-doc.html
----------------------------------------------------------------------
diff --git a/docs/help-doc.html b/docs/help-doc.html
index 0688997..36c9ff5 100644
--- a/docs/help-doc.html
+++ b/docs/help-doc.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>API Help</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-1.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-1.html b/docs/index-files/index-1.html
index a892e45..7ba5863 100644
--- a/docs/index-files/index-1.html
+++ b/docs/index-files/index-1.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>A-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-10.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-10.html b/docs/index-files/index-10.html
index 3008396..99b40ee 100644
--- a/docs/index-files/index-10.html
+++ b/docs/index-files/index-10.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>J-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-11.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-11.html b/docs/index-files/index-11.html
index 081621e..5ac51d4 100644
--- a/docs/index-files/index-11.html
+++ b/docs/index-files/index-11.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>K-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>
@@ -73,11 +73,11 @@
 </dd>
 <dt><span class="strong"><a href="../org/apache/pirk/utils/KeyedHash.html#KeyedHash()">KeyedHash()</a></span> - Constructor for class org.apache.pirk.utils.<a href="../org/apache/pirk/utils/KeyedHash.html" title="class in org.apache.pirk.utils">KeyedHash</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="../test/general/KeyedHashTest.html" title="class in test.general"><span class="strong">KeyedHashTest</span></a> - Class in <a href="../test/general/package-summary.html">test.general</a></dt>
+<dt><a href="../org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general"><span class="strong">KeyedHashTest</span></a> - Class in <a href="../org/apache/pirk/general/package-summary.html">org.apache.pirk.general</a></dt>
 <dd>
 <div class="block">Basic functional tests for KeyedHash</div>
 </dd>
-<dt><span class="strong"><a href="../test/general/KeyedHashTest.html#KeyedHashTest()">KeyedHashTest()</a></span> - Constructor for class test.general.<a href="../test/general/KeyedHashTest.html" title="class in test.general">KeyedHashTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/KeyedHashTest.html#KeyedHashTest()">KeyedHashTest()</a></span> - Constructor for class org.apache.pirk.general.<a href="../org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general">KeyedHashTest</a></dt>
 <dd>&nbsp;</dd>
 </dl>
 <a href="index-1.html">A</a>&nbsp;<a href="index-2.html">B</a>&nbsp;<a href="index-3.html">C</a>&nbsp;<a href="index-4.html">D</a>&nbsp;<a href="index-5.html">E</a>&nbsp;<a href="index-6.html">F</a>&nbsp;<a href="index-7.html">G</a>&nbsp;<a href="index-8.html">H</a>&nbsp;<a href="index-9.html">I</a>&nbsp;<a href="index-10.html">J</a>&nbsp;<a href="index-11.html">K</a>&nbsp;<a href="index-12.html">L</a>&nbsp;<a href="index-13.html">M</a>&nbsp;<a href="index-14.html">N</a>&nbsp;<a href="index-15.html">O</a>&nbsp;<a href="index-16.html">P</a>&nbsp;<a href="index-17.html">Q</a>&nbsp;<a href="index-18.html">R</a>&nbsp;<a href="index-19.html">S</a>&nbsp;<a href="index-20.html">T</a>&nbsp;<a href="index-21.html">U</a>&nbsp;<a href="index-22.html">V</a>&nbsp;<a href="index-23.html">W</a>&nbsp;</div>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-12.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-12.html b/docs/index-files/index-12.html
index dd27fe3..d363fe4 100644
--- a/docs/index-files/index-12.html
+++ b/docs/index-files/index-12.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>L-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>
@@ -73,11 +73,11 @@
 <dd>
 <div class="block">Populate the cache based on the pre-generated exp table in hdfs</div>
 </dd>
-<dt><a href="../test/schema/data/LoadDataSchemaTest.html" title="class in test.schema.data"><span class="strong">LoadDataSchemaTest</span></a> - Class in <a href="../test/schema/data/package-summary.html">test.schema.data</a></dt>
+<dt><a href="../org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data"><span class="strong">LoadDataSchemaTest</span></a> - Class in <a href="../org/apache/pirk/schema/data/package-summary.html">org.apache.pirk.schema.data</a></dt>
 <dd>
 <div class="block">Test suite for LoadDataSchema and DataSchema</div>
 </dd>
-<dt><span class="strong"><a href="../test/schema/data/LoadDataSchemaTest.html#LoadDataSchemaTest()">LoadDataSchemaTest()</a></span> - Constructor for class test.schema.data.<a href="../test/schema/data/LoadDataSchemaTest.html" title="class in test.schema.data">LoadDataSchemaTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/schema/data/LoadDataSchemaTest.html#LoadDataSchemaTest()">LoadDataSchemaTest()</a></span> - Constructor for class org.apache.pirk.schema.data.<a href="../org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data">LoadDataSchemaTest</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/utils/SystemConfiguration.html#loadPropsFromDir(java.lang.String)">loadPropsFromDir(String)</a></span> - Static method in class org.apache.pirk.utils.<a href="../org/apache/pirk/utils/SystemConfiguration.html" title="class in org.apache.pirk.utils">SystemConfiguration</a></dt>
 <dd>
@@ -91,11 +91,11 @@
 <dd>
 <div class="block">Loads the properties from the specified file on the classpath</div>
 </dd>
-<dt><a href="../test/schema/query/LoadQuerySchemaTest.html" title="class in test.schema.query"><span class="strong">LoadQuerySchemaTest</span></a> - Class in <a href="../test/schema/query/package-summary.html">test.schema.query</a></dt>
+<dt><a href="../org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query"><span class="strong">LoadQuerySchemaTest</span></a> - Class in <a href="../org/apache/pirk/schema/query/package-summary.html">org.apache.pirk.schema.query</a></dt>
 <dd>
 <div class="block">Test suite for LoadQuerySchema and QuerySchema</div>
 </dd>
-<dt><span class="strong"><a href="../test/schema/query/LoadQuerySchemaTest.html#LoadQuerySchemaTest()">LoadQuerySchemaTest()</a></span> - Constructor for class test.schema.query.<a href="../test/schema/query/LoadQuerySchemaTest.html" title="class in test.schema.query">LoadQuerySchemaTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/schema/query/LoadQuerySchemaTest.html#LoadQuerySchemaTest()">LoadQuerySchemaTest()</a></span> - Constructor for class org.apache.pirk.schema.query.<a href="../org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query">LoadQuerySchemaTest</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/schema/data/DataSchemaLoader.html#loadSchema(java.io.InputStream)">loadSchema(InputStream)</a></span> - Method in class org.apache.pirk.schema.data.<a href="../org/apache/pirk/schema/data/DataSchemaLoader.html" title="class in org.apache.pirk.schema.data">DataSchemaLoader</a></dt>
 <dd>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-13.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-13.html b/docs/index-files/index-13.html
index 47f68ef..5ec1aaf 100644
--- a/docs/index-files/index-13.html
+++ b/docs/index-files/index-13.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>M-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-14.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-14.html b/docs/index-files/index-14.html
index f2e33fe..20436e4 100644
--- a/docs/index-files/index-14.html
+++ b/docs/index-files/index-14.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>N-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-15.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-15.html b/docs/index-files/index-15.html
index 308f2bb..5483590 100644
--- a/docs/index-files/index-15.html
+++ b/docs/index-files/index-15.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>O-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>
@@ -71,6 +71,8 @@
 <dd>&nbsp;</dd>
 <dt><a href="../org/apache/pirk/encryption/package-summary.html">org.apache.pirk.encryption</a> - package org.apache.pirk.encryption</dt>
 <dd>&nbsp;</dd>
+<dt><a href="../org/apache/pirk/general/package-summary.html">org.apache.pirk.general</a> - package org.apache.pirk.general</dt>
+<dd>&nbsp;</dd>
 <dt><a href="../org/apache/pirk/inputformat/hadoop/package-summary.html">org.apache.pirk.inputformat.hadoop</a> - package org.apache.pirk.inputformat.hadoop</dt>
 <dd>&nbsp;</dd>
 <dt><a href="../org/apache/pirk/inputformat/hadoop/json/package-summary.html">org.apache.pirk.inputformat.hadoop.json</a> - package org.apache.pirk.inputformat.hadoop.json</dt>
@@ -115,6 +117,8 @@
 <dd>&nbsp;</dd>
 <dt><a href="../org/apache/pirk/utils/package-summary.html">org.apache.pirk.utils</a> - package org.apache.pirk.utils</dt>
 <dd>&nbsp;</dd>
+<dt><a href="../org/apache/pirk/wideskies/standalone/package-summary.html">org.apache.pirk.wideskies.standalone</a> - package org.apache.pirk.wideskies.standalone</dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/test/distributed/DistributedTestDriver.html#OUTPUT_DIRECTORY_PROPERTY">OUTPUT_DIRECTORY_PROPERTY</a></span> - Static variable in class org.apache.pirk.test.distributed.<a href="../org/apache/pirk/test/distributed/DistributedTestDriver.html" title="class in org.apache.pirk.test.distributed">DistributedTestDriver</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/querier/wideskies/QuerierProps.html#OUTPUTFILE">OUTPUTFILE</a></span> - Static variable in class org.apache.pirk.querier.wideskies.<a href="../org/apache/pirk/querier/wideskies/QuerierProps.html" title="class in org.apache.pirk.querier.wideskies">QuerierProps</a></dt>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-16.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-16.html b/docs/index-files/index-16.html
index 14b423d..9068690 100644
--- a/docs/index-files/index-16.html
+++ b/docs/index-files/index-16.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>P-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>
@@ -97,11 +97,11 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/test/utils/BaseTests.html#paillierBitSize">paillierBitSize</a></span> - Static variable in class org.apache.pirk.test.utils.<a href="../org/apache/pirk/test/utils/BaseTests.html" title="class in org.apache.pirk.test.utils">BaseTests</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="../test/general/PaillierTest.html" title="class in test.general"><span class="strong">PaillierTest</span></a> - Class in <a href="../test/general/package-summary.html">test.general</a></dt>
+<dt><a href="../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general"><span class="strong">PaillierTest</span></a> - Class in <a href="../org/apache/pirk/general/package-summary.html">org.apache.pirk.general</a></dt>
 <dd>
 <div class="block">Basic test functionality for Paillier library</div>
 </dd>
-<dt><span class="strong"><a href="../test/general/PaillierTest.html#PaillierTest()">PaillierTest()</a></span> - Constructor for class test.general.<a href="../test/general/PaillierTest.html" title="class in test.general">PaillierTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/PaillierTest.html#PaillierTest()">PaillierTest()</a></span> - Constructor for class org.apache.pirk.general.<a href="../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general">PaillierTest</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/utils/ISO8601DateParser.html#parseDate(java.lang.String)">parseDate(String)</a></span> - Static method in class org.apache.pirk.utils.<a href="../org/apache/pirk/utils/ISO8601DateParser.html" title="class in org.apache.pirk.utils">ISO8601DateParser</a></dt>
 <dd>&nbsp;</dd>
@@ -117,11 +117,11 @@
 <dd>
 <div class="block">Method to convert the given data element given by the MapWritable data element into the extracted BigInteger partitions based upon the given queryType</div>
 </dd>
-<dt><a href="../test/general/PartitionUtilsTest.html" title="class in test.general"><span class="strong">PartitionUtilsTest</span></a> - Class in <a href="../test/general/package-summary.html">test.general</a></dt>
+<dt><a href="../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general"><span class="strong">PartitionUtilsTest</span></a> - Class in <a href="../org/apache/pirk/general/package-summary.html">org.apache.pirk.general</a></dt>
 <dd>
 <div class="block">Class to functionally test the bit conversion utils</div>
 </dd>
-<dt><span class="strong"><a href="../test/general/PartitionUtilsTest.html#PartitionUtilsTest()">PartitionUtilsTest()</a></span> - Constructor for class test.general.<a href="../test/general/PartitionUtilsTest.html" title="class in test.general">PartitionUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/PartitionUtilsTest.html#PartitionUtilsTest()">PartitionUtilsTest()</a></span> - Constructor for class org.apache.pirk.general.<a href="../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general">PartitionUtilsTest</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/responder/wideskies/spark/ComputeResponse.html#performQuery()">performQuery()</a></span> - Method in class org.apache.pirk.responder.wideskies.spark.<a href="../org/apache/pirk/responder/wideskies/spark/ComputeResponse.html" title="class in org.apache.pirk.responder.wideskies.spark">ComputeResponse</a></dt>
 <dd>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-17.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-17.html b/docs/index-files/index-17.html
index 5bb67c4..420b680 100644
--- a/docs/index-files/index-17.html
+++ b/docs/index-files/index-17.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Q-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>
@@ -143,11 +143,11 @@
 </dd>
 <dt><span class="strong"><a href="../org/apache/pirk/utils/QueryParserUtils.html#QueryParserUtils()">QueryParserUtils()</a></span> - Constructor for class org.apache.pirk.utils.<a href="../org/apache/pirk/utils/QueryParserUtils.html" title="class in org.apache.pirk.utils">QueryParserUtils</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="../test/general/QueryParserUtilsTest.html" title="class in test.general"><span class="strong">QueryParserUtilsTest</span></a> - Class in <a href="../test/general/package-summary.html">test.general</a></dt>
+<dt><a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general"><span class="strong">QueryParserUtilsTest</span></a> - Class in <a href="../org/apache/pirk/general/package-summary.html">org.apache.pirk.general</a></dt>
 <dd>
 <div class="block">Class for testing the QueryParser methods</div>
 </dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#QueryParserUtilsTest()">QueryParserUtilsTest()</a></span> - Constructor for class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#QueryParserUtilsTest()">QueryParserUtilsTest()</a></span> - Constructor for class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="../org/apache/pirk/schema/response/QueryResponseJSON.html" title="class in org.apache.pirk.schema.response"><span class="strong">QueryResponseJSON</span></a> - Class in <a href="../org/apache/pirk/schema/response/package-summary.html">org.apache.pirk.schema.response</a></dt>
 <dd>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-18.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-18.html b/docs/index-files/index-18.html
index e3e65ea..fd8c317 100644
--- a/docs/index-files/index-18.html
+++ b/docs/index-files/index-18.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>R-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>
@@ -195,7 +195,7 @@
 <dd>
 <div class="block">Determine if the argument was provided for the selected option, which determines if a test should or should not be run</div>
 </dd>
-<dt><span class="strong"><a href="../test/wideskies/standalone/StandaloneTest.html#runTests()">runTests()</a></span> - Method in class test.wideskies.standalone.<a href="../test/wideskies/standalone/StandaloneTest.html" title="class in test.wideskies.standalone">StandaloneTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/wideskies/standalone/StandaloneTest.html#runTests()">runTests()</a></span> - Method in class org.apache.pirk.wideskies.standalone.<a href="../org/apache/pirk/wideskies/standalone/StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone">StandaloneTest</a></dt>
 <dd>&nbsp;</dd>
 </dl>
 <a href="index-1.html">A</a>&nbsp;<a href="index-2.html">B</a>&nbsp;<a href="index-3.html">C</a>&nbsp;<a href="index-4.html">D</a>&nbsp;<a href="index-5.html">E</a>&nbsp;<a href="index-6.html">F</a>&nbsp;<a href="index-7.html">G</a>&nbsp;<a href="index-8.html">H</a>&nbsp;<a href="index-9.html">I</a>&nbsp;<a href="index-10.html">J</a>&nbsp;<a href="index-11.html">K</a>&nbsp;<a href="index-12.html">L</a>&nbsp;<a href="index-13.html">M</a>&nbsp;<a href="index-14.html">N</a>&nbsp;<a href="index-15.html">O</a>&nbsp;<a href="index-16.html">P</a>&nbsp;<a href="index-17.html">Q</a>&nbsp;<a href="index-18.html">R</a>&nbsp;<a href="index-19.html">S</a>&nbsp;<a href="index-20.html">T</a>&nbsp;<a href="index-21.html">U</a>&nbsp;<a href="index-22.html">V</a>&nbsp;<a href="index-23.html">W</a>&nbsp;</div>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-19.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-19.html b/docs/index-files/index-19.html
index fc05181..d00e334 100644
--- a/docs/index-files/index-19.html
+++ b/docs/index-files/index-19.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>S-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>
@@ -138,6 +138,10 @@
 <dd>
 <div class="block">This sets up the state for the two separate benchmarks</div>
 </dd>
+<dt><span class="strong"><a href="../org/apache/pirk/general/PaillierTest.html#setup()">setup()</a></span> - Static method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general">PaillierTest</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#setup()">setup()</a></span> - Static method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/responder/wideskies/mapreduce/ColumnMultMapper.html#setup(org.apache.hadoop.mapreduce.Mapper.Context)">setup(Mapper&lt;LongWritable, Text, LongWritable, Text&gt;.Context)</a></span> - Method in class org.apache.pirk.responder.wideskies.mapreduce.<a href="../org/apache/pirk/responder/wideskies/mapreduce/ColumnMultMapper.html" title="class in org.apache.pirk.responder.wideskies.mapreduce">ColumnMultMapper</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/responder/wideskies/mapreduce/ColumnMultReducer.html#setup(org.apache.hadoop.mapreduce.Reducer.Context)">setup(Reducer&lt;LongWritable, Text, LongWritable, Text&gt;.Context)</a></span> - Method in class org.apache.pirk.responder.wideskies.mapreduce.<a href="../org/apache/pirk/responder/wideskies/mapreduce/ColumnMultReducer.html" title="class in org.apache.pirk.responder.wideskies.mapreduce">ColumnMultReducer</a></dt>
@@ -152,6 +156,8 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/responder/wideskies/mapreduce/RowCalcReducer.html#setup(org.apache.hadoop.mapreduce.Reducer.Context)">setup(Reducer&lt;IntWritable, BytesArrayWritable, LongWritable, Text&gt;.Context)</a></span> - Method in class org.apache.pirk.responder.wideskies.mapreduce.<a href="../org/apache/pirk/responder/wideskies/mapreduce/RowCalcReducer.html" title="class in org.apache.pirk.responder.wideskies.mapreduce">RowCalcReducer</a></dt>
 <dd>&nbsp;</dd>
+<dt><span class="strong"><a href="../org/apache/pirk/wideskies/standalone/StandaloneTest.html#setup()">setup()</a></span> - Static method in class org.apache.pirk.wideskies.standalone.<a href="../org/apache/pirk/wideskies/standalone/StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone">StandaloneTest</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/responder/wideskies/spark/BroadcastVars.html#setUseLocalCache(java.lang.String)">setUseLocalCache(String)</a></span> - Method in class org.apache.pirk.responder.wideskies.spark.<a href="../org/apache/pirk/responder/wideskies/spark/BroadcastVars.html" title="class in org.apache.pirk.responder.wideskies.spark">BroadcastVars</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/schema/data/partitioner/PrimitiveTypePartitioner.html#SHORT">SHORT</a></span> - Static variable in class org.apache.pirk.schema.data.partitioner.<a href="../org/apache/pirk/schema/data/partitioner/PrimitiveTypePartitioner.html" title="class in org.apache.pirk.schema.data.partitioner">PrimitiveTypePartitioner</a></dt>
@@ -174,11 +180,11 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/test/utils/StandaloneQuery.html#StandaloneQuery()">StandaloneQuery()</a></span> - Constructor for class org.apache.pirk.test.utils.<a href="../org/apache/pirk/test/utils/StandaloneQuery.html" title="class in org.apache.pirk.test.utils">StandaloneQuery</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="../test/wideskies/standalone/StandaloneTest.html" title="class in test.wideskies.standalone"><span class="strong">StandaloneTest</span></a> - Class in <a href="../test/wideskies/standalone/package-summary.html">test.wideskies.standalone</a></dt>
+<dt><a href="../org/apache/pirk/wideskies/standalone/StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone"><span class="strong">StandaloneTest</span></a> - Class in <a href="../org/apache/pirk/wideskies/standalone/package-summary.html">org.apache.pirk.wideskies.standalone</a></dt>
 <dd>
 <div class="block">Functional test suite for stand alone testing - non Spark applications</div>
 </dd>
-<dt><span class="strong"><a href="../test/wideskies/standalone/StandaloneTest.html#StandaloneTest()">StandaloneTest()</a></span> - Constructor for class test.wideskies.standalone.<a href="../test/wideskies/standalone/StandaloneTest.html" title="class in test.wideskies.standalone">StandaloneTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/wideskies/standalone/StandaloneTest.html#StandaloneTest()">StandaloneTest()</a></span> - Constructor for class org.apache.pirk.wideskies.standalone.<a href="../org/apache/pirk/wideskies/standalone/StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone">StandaloneTest</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/responder/wideskies/ResponderProps.html#STOPLISTFILE">STOPLISTFILE</a></span> - Static variable in class org.apache.pirk.responder.wideskies.<a href="../org/apache/pirk/responder/wideskies/ResponderProps.html" title="class in org.apache.pirk.responder.wideskies">ResponderProps</a></dt>
 <dd>&nbsp;</dd>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-2.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-2.html b/docs/index-files/index-2.html
index f8a8d9a..843db56 100644
--- a/docs/index-files/index-2.html
+++ b/docs/index-files/index-2.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>B-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>


[2/9] incubator-pirk git commit: [PIRK-37]: Rename package for test classes to be org.apache.pirk.* -- closes apache/incubator-pirk#39

Posted by ea...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/org/apache/pirk/general/KeyedHashTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/pirk/general/KeyedHashTest.java b/src/test/java/org/apache/pirk/general/KeyedHashTest.java
new file mode 100644
index 0000000..676609f
--- /dev/null
+++ b/src/test/java/org/apache/pirk/general/KeyedHashTest.java
@@ -0,0 +1,83 @@
+/*
+ * 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.pirk.general;
+
+import static org.junit.Assert.assertEquals;
+
+import org.apache.pirk.utils.KeyedHash;
+import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/**
+ * Basic functional tests for KeyedHash
+ * 
+ */
+public class KeyedHashTest
+{
+  private static final Logger logger = LoggerFactory.getLogger(KeyedHashTest.class);
+
+  @Test
+  public void testKeyedHash()
+  {
+    logger.info("Starting testKeyedHash: ");
+
+    int hash1 = KeyedHash.hash("someKey", 12, "someInput");
+    logger.info("hash1 = " + hash1 + " hash1 = " + Integer.toString(hash1, 2));
+
+    int hash2 = KeyedHash.hash("someKey", 32, "someInput");
+    logger.info("hash2 = " + hash2 + " hash2 = " + Integer.toString(hash2, 2));
+
+    int hash3 = KeyedHash.hash("someKey", 34, "someInput");
+    logger.info("hash3 = " + hash3 + " hash3 = " + Integer.toString(hash3, 2));
+
+    assertEquals(hash2, hash3);
+    assertEquals(hash1, hash2 & 0xFFF);
+
+    logger.info("Successfully completed testKeyedHash");
+  }
+
+  @Test
+  public void testKeyedHashWithType()
+  {
+    testKeyedHashType("MD5");
+    testKeyedHashType("SHA-1");
+    testKeyedHashType("SHA-256");
+    testKeyedHashType("FAKE-HASH-TYPE");
+  }
+
+  private void testKeyedHashType(String type)
+  {
+    logger.info("Starting testKeyedHashType with type: " + type);
+
+    int hash1 = KeyedHash.hash("someKey", 12, "someInput", type);
+    logger.info("hash1 = " + hash1 + " hash1 = " + Integer.toString(hash1, 2));
+
+    int hash2 = KeyedHash.hash("someKey", 32, "someInput", type);
+    logger.info("hash2 = " + hash2 + " hash2 = " + Integer.toString(hash2, 2));
+
+    int hash3 = KeyedHash.hash("someKey", 34, "someInput", type);
+    logger.info("hash3 = " + hash3 + " hash3 = " + Integer.toString(hash3, 2));
+
+    assertEquals(hash2, hash3);
+    assertEquals(hash1, hash2 & 0xFFF);
+
+    logger.info("Successfully completed testKeyedHashType with type: " + type);
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/org/apache/pirk/general/PaillierTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/pirk/general/PaillierTest.java b/src/test/java/org/apache/pirk/general/PaillierTest.java
new file mode 100644
index 0000000..5d1c6b2
--- /dev/null
+++ b/src/test/java/org/apache/pirk/general/PaillierTest.java
@@ -0,0 +1,292 @@
+/*
+ * 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.pirk.general;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.fail;
+
+import java.math.BigInteger;
+import java.util.Random;
+
+import org.apache.pirk.encryption.Paillier;
+import org.apache.pirk.utils.PIRException;
+import org.apache.pirk.utils.SystemConfiguration;
+import org.junit.BeforeClass;
+import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/**
+ * Basic test functionality for Paillier library
+ * 
+ */
+public class PaillierTest
+{
+  private static final Logger logger = LoggerFactory.getLogger(PaillierTest.class);
+
+  private static BigInteger p = null; // large prime
+  private static BigInteger q = null; // large prime
+  private static BigInteger N = null; // N=pq, RSA modulus
+  private static BigInteger NSquared = null; // N^2
+  private static BigInteger lambdaN = null; // lambda(N) = lcm(p-1,q-1)
+
+  private static int bitLength = 0; // bit length of the modulus N
+  private static int certainty = 64; // prob that new BigInteger values represents primes will exceed (1 - (1/2)^certainty)
+
+  private static BigInteger r1 = null; // random number in (Z/NZ)*
+  private static BigInteger r2 = null; // random number in (Z/NZ)*
+
+  private static BigInteger m1 = null; // message to encrypt
+  private static BigInteger m2 = null; // message to encrypt
+
+  @BeforeClass
+  public static void setup()
+  {
+    p = BigInteger.valueOf(7);
+    q = BigInteger.valueOf(17);
+    N = p.multiply(q);
+    NSquared = N.multiply(N);
+
+    lambdaN = BigInteger.valueOf(48);
+
+    r1 = BigInteger.valueOf(3);
+    r2 = BigInteger.valueOf(4);
+
+    m1 = BigInteger.valueOf(5);
+    m2 = BigInteger.valueOf(2);
+
+    bitLength = 201;// bitLength = 384;
+    certainty = 128;
+
+    logger.info("p = " + p.intValue() + " q = " + q.intValue() + " N = " + N.intValue() + " bitLength = " + N.bitLength() + " lambdaN = " + lambdaN + " m1 = "
+        + m1.intValue() + " m2 = " + m2.intValue() + " r1 = " + r1.intValue() + " r2 = " + r2.intValue());
+  }
+
+  @Test
+  @SuppressWarnings("unused")
+  public void testPIRExceptions()
+  {
+    try
+    {
+      Paillier paillier = new Paillier(BigInteger.valueOf(2), BigInteger.valueOf(2), 128);
+      fail("Paillier constructor did not throw PIRException for p,q < 3");
+    } catch (PIRException ignore)
+    {}
+
+    try
+    {
+      Paillier paillier = new Paillier(BigInteger.valueOf(2), BigInteger.valueOf(3), 128);
+      fail("Paillier constructor did not throw PIRException for p < 3");
+    } catch (PIRException ignore)
+    {}
+
+    try
+    {
+      Paillier paillier = new Paillier(BigInteger.valueOf(3), BigInteger.valueOf(2), 128);
+      fail("Paillier constructor did not throw PIRException for q < 3");
+    } catch (PIRException ignore)
+    {}
+
+    try
+    {
+      Paillier paillier = new Paillier(BigInteger.valueOf(7), BigInteger.valueOf(7), 128);
+      fail("Paillier constructor did not throw PIRException for p = q");
+    } catch (PIRException ignore)
+    {}
+
+    try
+    {
+      Paillier paillier = new Paillier(BigInteger.valueOf(8), BigInteger.valueOf(7), 128);
+      fail("Paillier constructor did not throw PIRException for p not prime");
+    } catch (PIRException ignore)
+    {}
+
+    try
+    {
+      Paillier paillier = new Paillier(BigInteger.valueOf(7), BigInteger.valueOf(10), 128);
+      fail("Paillier constructor did not throw PIRException for q not prime");
+    } catch (PIRException ignore)
+    {}
+
+    try
+    {
+      int systemPrimeCertainty = Integer.parseInt(SystemConfiguration.getProperty("pir.primeCertainty", "128"));
+      Paillier paillier = new Paillier(3072, systemPrimeCertainty - 10);
+      fail("Paillier constructor did not throw PIRException for certainty less than system default of " + systemPrimeCertainty);
+    } catch (PIRException ignore)
+    {}
+
+    try
+    {
+      Paillier pailler = new Paillier(p, q, bitLength);
+      BigInteger encM1 = pailler.encrypt(N);
+      fail("Paillier encryption did not throw PIRException for message m = N");
+    } catch (PIRException ignore)
+    {}
+
+    try
+    {
+      Paillier pailler = new Paillier(p, q, bitLength);
+      BigInteger encM1 = pailler.encrypt(N.add(BigInteger.TEN));
+      fail("Paillier encryption did not throw PIRException for message m > N");
+    } catch (PIRException ignore)
+    {}
+
+    try
+    {
+      Paillier pailler = new Paillier(bitLength, 128, bitLength);
+      fail("Paillier constructor did not throw PIRException for ensureBitSet = bitLength");
+    } catch (PIRException ignore)
+    {}
+
+    try
+    {
+      Paillier pailler = new Paillier(bitLength, 128, bitLength + 1);
+      fail("Paillier constructor did not throw PIRException for ensureBitSet > bitLength");
+    } catch (PIRException ignore)
+    {}
+  }
+
+  @Test
+  public void testPaillierGivenAllParameters() throws Exception
+  {
+    logger.info("Starting testPaillierGivenAllParameters: ");
+
+    Paillier pailler = new Paillier(p, q, bitLength);
+
+    assertEquals(pailler.getN(), N);
+    assertEquals(pailler.getLambdaN(), lambdaN);
+
+    // Check encryption
+    BigInteger encM1 = pailler.encrypt(m1, r1);
+    BigInteger encM2 = pailler.encrypt(m2, r2);
+    logger.info("encM1 = " + encM1.intValue() + " encM2 = " + encM2.intValue());
+
+    assertEquals(encM1, BigInteger.valueOf(14019));
+    assertEquals(encM2, BigInteger.valueOf(8836));
+
+    // Check decryption
+    BigInteger decM1 = pailler.decrypt(encM1);
+    BigInteger decM2 = pailler.decrypt(encM2);
+    logger.info("decM1 = " + decM1.intValue() + " decM2 = " + decM2.intValue());
+
+    assertEquals(decM1, m1);
+    assertEquals(decM2, m2);
+
+    // Check homomorphic property: E_r1(m1)*E_r2(m2) mod N^2 = E_r1r2((m1+m2) mod N) mod N^2
+    BigInteger encM1_times_encM2 = (encM1.multiply(encM2)).mod(NSquared);
+    BigInteger encM1plusM2 = pailler.encrypt((m1.add(m2)).mod(N), r1.multiply(r2));
+    logger.info("encM1_times_encM2 = " + encM1_times_encM2.intValue() + " encM1plusM2 = " + encM1plusM2.intValue());
+
+    assertEquals(encM1_times_encM2, BigInteger.valueOf(5617));
+    assertEquals(encM1plusM2, BigInteger.valueOf(5617));
+
+    logger.info("Successfully completed testPaillierGivenAllParameters: ");
+  }
+
+  @Test
+  public void testPaillierWithKeyGeneration() throws Exception
+  {
+    logger.info("Starting testPaillierWithKeyGeneration: ");
+
+    // Test with and without gmp optimization for modPow
+    SystemConfiguration.setProperty("pallier.FIPSPrimeGenerationChecks", "true");
+    SystemConfiguration.setProperty("paillier.useGMPForModPow", "true");
+    SystemConfiguration.setProperty("paillier.GMPConstantTimeMode", "true");
+    testPaillerWithKeyGenerationGeneral();
+
+    SystemConfiguration.setProperty("pallier.FIPSPrimeGenerationChecks", "false");
+
+    SystemConfiguration.setProperty("paillier.useGMPForModPow", "true");
+    SystemConfiguration.setProperty("paillier.GMPConstantTimeMode", "true");
+    testPaillerWithKeyGenerationGeneral();
+
+    SystemConfiguration.setProperty("paillier.useGMPForModPow", "true");
+    SystemConfiguration.setProperty("paillier.GMPConstantTimeMode", "false");
+    testPaillerWithKeyGenerationGeneral();
+
+    SystemConfiguration.setProperty("paillier.useGMPForModPow", "false");
+    SystemConfiguration.setProperty("paillier.GMPConstantTimeMode", "false");
+    testPaillerWithKeyGenerationGeneral();
+
+    // Reset the properties
+    SystemConfiguration.resetProperties();
+
+    logger.info("Ending testPaillierWithKeyGeneration: ");
+  }
+
+  public void testPaillerWithKeyGenerationGeneral() throws Exception
+  {
+    // Test without requiring highest bit to be set
+    logger.info("Starting testPaillierWithKeyGenerationBitSetOption with ensureHighBitSet = false");
+    testPaillierWithKeyGenerationBitSetOption(-1);
+
+    // Test requiring highest bit to be set
+    logger.info("Starting testPaillierWithKeyGenerationBitSetOption with ensureHighBitSet = true");
+    testPaillierWithKeyGenerationBitSetOption(5);
+  }
+
+  public void testPaillierWithKeyGenerationBitSetOption(int ensureBitSet) throws Exception
+  {
+    Random r = new Random();
+    int lowBitLength = 3073; // inclusive
+    int highBitLength = 7001; // exclusive
+
+    int loopVal = 1; // int loopVal = 1000; //change this and re-test for high loop testing
+    for (int i = 0; i < loopVal; ++i)
+    {
+      logger.info("i = " + i);
+
+      basicTestPaillierWithKeyGeneration(bitLength, certainty, ensureBitSet);
+      basicTestPaillierWithKeyGeneration(3072, certainty, ensureBitSet);
+
+      // Test with random bit length between 3073 and 7000
+      int randomLargeBitLength = r.nextInt(highBitLength - lowBitLength) + lowBitLength;
+      basicTestPaillierWithKeyGeneration(randomLargeBitLength, certainty, ensureBitSet);
+    }
+  }
+
+  private void basicTestPaillierWithKeyGeneration(int bitLengthInput, int certaintyInput, int ensureBitSet) throws Exception
+  {
+    Paillier pailler = new Paillier(bitLengthInput, certaintyInput, ensureBitSet);
+    BigInteger generatedN = pailler.getN();
+    BigInteger geneartedNsquared = generatedN.multiply(generatedN);
+
+    // Check the decrypting the encryption yields the message
+    BigInteger encM1 = pailler.encrypt(m1);
+    BigInteger encM2 = pailler.encrypt(m2);
+    logger.info("encM1 = " + encM1.intValue() + " encM2 = " + encM2.intValue());
+
+    BigInteger decM1 = pailler.decrypt(encM1);
+    BigInteger decM2 = pailler.decrypt(encM2);
+    logger.info("decM1 = " + decM1.intValue() + " decM2 = " + decM2.intValue());
+
+    assertEquals(decM1, m1);
+    assertEquals(decM2, m2);
+
+    // Check homomorphic property: E_r1(m1)*E_r2(m2) mod N^2 = E_r1r2((m1+m2) mod N) mod N^2
+    BigInteger encM1_times_encM2 = (encM1.multiply(encM2)).mod(geneartedNsquared);
+    BigInteger multDecrypt = pailler.decrypt(encM1_times_encM2);
+    BigInteger m1_plus_m2 = (m1.add(m2)).mod(N);
+
+    logger.info("encM1_times_encM2 = " + encM1_times_encM2.intValue() + " multDecrypt = " + multDecrypt.intValue() + " m1_plus_m2 = " + m1_plus_m2.intValue());
+
+    assertEquals(multDecrypt, m1_plus_m2);
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/org/apache/pirk/general/PartitionUtilsTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/pirk/general/PartitionUtilsTest.java b/src/test/java/org/apache/pirk/general/PartitionUtilsTest.java
new file mode 100644
index 0000000..e20215b
--- /dev/null
+++ b/src/test/java/org/apache/pirk/general/PartitionUtilsTest.java
@@ -0,0 +1,233 @@
+/*
+ * 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.pirk.general;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.fail;
+
+import java.math.BigInteger;
+import java.util.ArrayList;
+
+import org.apache.pirk.schema.data.partitioner.IPDataPartitioner;
+import org.apache.pirk.schema.data.partitioner.ISO8601DatePartitioner;
+import org.apache.pirk.schema.data.partitioner.PrimitiveTypePartitioner;
+import org.apache.pirk.utils.SystemConfiguration;
+import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/**
+ * Class to functionally test the bit conversion utils
+ */
+public class PartitionUtilsTest
+{
+  private static final Logger logger = LoggerFactory.getLogger(PartitionUtilsTest.class);
+
+  @Test
+  public void testMask()
+  {
+    logger.info("Starting testMask: ");
+
+    BigInteger mask = PrimitiveTypePartitioner.formBitMask(4); // 1111
+
+    assertEquals(mask.intValue(), 15);
+
+    logger.info("Successfully completed testMask");
+  }
+
+  @Test
+  public void testPartitionBits()
+  {
+    logger.info("Starting testPartitionBits: ");
+
+    BigInteger value = new BigInteger("245"); // 11110101
+    BigInteger value2 = new BigInteger("983"); // 1111010111
+
+    BigInteger mask4 = PrimitiveTypePartitioner.formBitMask(4); // 1111
+    BigInteger mask8 = PrimitiveTypePartitioner.formBitMask(8); // 11111111
+
+    try
+    {
+      ArrayList<BigInteger> partitions = PrimitiveTypePartitioner.partitionBits(value, 4, mask4);
+
+      assertEquals(2, partitions.size());
+      assertEquals(partitions.get(0).intValue(), 15); // 1111
+      assertEquals(partitions.get(1).intValue(), 5); // 0101
+
+    } catch (Exception e)
+    {
+      fail(e.toString());
+    }
+
+    try
+    {
+      ArrayList<BigInteger> partitions = PrimitiveTypePartitioner.partitionBits(value2, 4, mask4);
+
+      assertEquals(3, partitions.size());
+      assertEquals(partitions.get(0).intValue(), 15); // 1111
+      assertEquals(partitions.get(1).intValue(), 5); // 0101
+      assertEquals(partitions.get(2).intValue(), 3); // 11
+
+    } catch (Exception e)
+    {
+      fail(e.toString());
+    }
+    try
+    {
+      ArrayList<BigInteger> partitions = PrimitiveTypePartitioner.partitionBits(value, 8, mask8);
+
+      assertEquals(1, partitions.size());
+      assertEquals(partitions.get(0).intValue(), 245);
+
+    } catch (Exception e)
+    {
+      fail(e.toString());
+    }
+
+    try
+    {
+      ArrayList<BigInteger> partitions = PrimitiveTypePartitioner.partitionBits(value, 4, mask8);
+
+      fail("BitConversionUtils.partitionBits did not throw error for mismatched partitionSize and mask size");
+
+    } catch (Exception ignore)
+    {}
+
+    logger.info("Successfully completed testPartitionBits");
+  }
+
+  @Test
+  public void testPartitions() throws Exception
+  {
+    logger.info("Starting testToPartitions:");
+
+    PrimitiveTypePartitioner primitivePartitioner = new PrimitiveTypePartitioner();
+    IPDataPartitioner ipPartitioner = new IPDataPartitioner();
+    ISO8601DatePartitioner datePartitioner = new ISO8601DatePartitioner();
+
+    // Test IP
+    String ipTest = "127.0.0.1";
+    ArrayList<BigInteger> partsIP = ipPartitioner.toPartitions(ipTest, PrimitiveTypePartitioner.STRING);
+    assertEquals(4, partsIP.size());
+    assertEquals(ipTest, ipPartitioner.fromPartitions(partsIP, 0, PrimitiveTypePartitioner.STRING));
+
+    // Test Date
+    String dateTest = "2016-02-20T23:29:05.000Z";
+    ArrayList<BigInteger> partsDate = datePartitioner.toPartitions(dateTest, null);
+    assertEquals(8, partsDate.size());
+    assertEquals(dateTest, datePartitioner.fromPartitions(partsDate, 0, null));
+
+    // Test byte
+    byte bTest = Byte.parseByte("10");
+    ArrayList<BigInteger> partsByte = primitivePartitioner.toPartitions(bTest, PrimitiveTypePartitioner.BYTE);
+    assertEquals(1, partsByte.size());
+    assertEquals(bTest, primitivePartitioner.fromPartitions(partsByte, 0, PrimitiveTypePartitioner.BYTE));
+
+    ArrayList<BigInteger> partsByteMax = primitivePartitioner.toPartitions(Byte.MAX_VALUE, PrimitiveTypePartitioner.BYTE);
+    assertEquals(1, partsByteMax.size());
+    assertEquals(Byte.MAX_VALUE, primitivePartitioner.fromPartitions(partsByteMax, 0, PrimitiveTypePartitioner.BYTE));
+
+    // Test string
+    String stringBits = SystemConfiguration.getProperty("pir.stringBits");
+    SystemConfiguration.setProperty("pir.stringBits", "64");
+    testString("testString"); // over the allowed bit size
+    testString("t"); // under the allowed bit size
+    SystemConfiguration.setProperty("pir.stringBits", stringBits);
+
+    // Test short
+    short shortTest = new Short("2456");
+    ArrayList<BigInteger> partsShort = primitivePartitioner.toPartitions(shortTest, PrimitiveTypePartitioner.SHORT);
+    assertEquals(2, partsShort.size());
+    assertEquals(shortTest, primitivePartitioner.fromPartitions(partsShort, 0, PrimitiveTypePartitioner.SHORT));
+
+    ArrayList<BigInteger> partsShortMax = primitivePartitioner.toPartitions(Short.MAX_VALUE, PrimitiveTypePartitioner.SHORT);
+    assertEquals(2, partsShortMax.size());
+    assertEquals(Short.MAX_VALUE, primitivePartitioner.fromPartitions(partsShortMax, 0, PrimitiveTypePartitioner.SHORT));
+
+    // Test int
+    int intTest = Integer.parseInt("-5789");
+    ArrayList<BigInteger> partsInt = primitivePartitioner.toPartitions(intTest, PrimitiveTypePartitioner.INT);
+    assertEquals(4, partsInt.size());
+    assertEquals(intTest, primitivePartitioner.fromPartitions(partsInt, 0, PrimitiveTypePartitioner.INT));
+
+    ArrayList<BigInteger> partsIntMax = primitivePartitioner.toPartitions(Integer.MAX_VALUE, PrimitiveTypePartitioner.INT);
+    assertEquals(4, partsIntMax.size());
+    assertEquals(Integer.MAX_VALUE, primitivePartitioner.fromPartitions(partsIntMax, 0, PrimitiveTypePartitioner.INT));
+
+    // Test long
+    long longTest = Long.parseLong("56789");
+    ArrayList<BigInteger> partsLong = primitivePartitioner.toPartitions(longTest, PrimitiveTypePartitioner.LONG);
+    assertEquals(8, partsLong.size());
+    assertEquals(longTest, primitivePartitioner.fromPartitions(partsLong, 0, PrimitiveTypePartitioner.LONG));
+
+    ArrayList<BigInteger> partsLongMax = primitivePartitioner.toPartitions(Long.MAX_VALUE, PrimitiveTypePartitioner.LONG);
+    assertEquals(8, partsLongMax.size());
+    assertEquals(Long.MAX_VALUE, primitivePartitioner.fromPartitions(partsLongMax, 0, PrimitiveTypePartitioner.LONG));
+
+    // Test float
+    float floatTest = Float.parseFloat("567.77");
+    ArrayList<BigInteger> partsFloat = primitivePartitioner.toPartitions(floatTest, PrimitiveTypePartitioner.FLOAT);
+    assertEquals(4, partsFloat.size());
+    assertEquals(floatTest, primitivePartitioner.fromPartitions(partsFloat, 0, PrimitiveTypePartitioner.FLOAT));
+
+    ArrayList<BigInteger> partsFloatMax = primitivePartitioner.toPartitions(Float.MAX_VALUE, PrimitiveTypePartitioner.FLOAT);
+    assertEquals(4, partsFloatMax.size());
+    assertEquals(Float.MAX_VALUE, primitivePartitioner.fromPartitions(partsFloatMax, 0, PrimitiveTypePartitioner.FLOAT));
+
+    // Test double
+    double doubleTest = Double.parseDouble("567.77");
+    ArrayList<BigInteger> partsDouble = primitivePartitioner.toPartitions(doubleTest, PrimitiveTypePartitioner.DOUBLE);
+    assertEquals(8, partsDouble.size());
+    assertEquals(doubleTest, primitivePartitioner.fromPartitions(partsDouble, 0, PrimitiveTypePartitioner.DOUBLE));
+
+    ArrayList<BigInteger> partsDoubleMax = primitivePartitioner.toPartitions(Double.MAX_VALUE, PrimitiveTypePartitioner.DOUBLE);
+    assertEquals(8, partsDoubleMax.size());
+    assertEquals(Double.MAX_VALUE, primitivePartitioner.fromPartitions(partsDoubleMax, 0, PrimitiveTypePartitioner.DOUBLE));
+
+    // Test char
+    char charTest = 'b';
+    ArrayList<BigInteger> partsChar = primitivePartitioner.toPartitions(charTest, PrimitiveTypePartitioner.CHAR);
+    assertEquals(2, partsChar.size());
+    assertEquals(charTest, primitivePartitioner.fromPartitions(partsChar, 0, PrimitiveTypePartitioner.CHAR));
+
+    ArrayList<BigInteger> partsCharMax = primitivePartitioner.toPartitions(Character.MAX_VALUE, PrimitiveTypePartitioner.CHAR);
+    assertEquals(2, partsCharMax.size());
+    assertEquals(Character.MAX_VALUE, primitivePartitioner.fromPartitions(partsCharMax, 0, PrimitiveTypePartitioner.CHAR));
+
+    logger.info("Sucessfully completed testToPartitions:");
+  }
+
+  private void testString(String testString) throws Exception
+  {
+    PrimitiveTypePartitioner ptp = new PrimitiveTypePartitioner();
+
+    ArrayList<BigInteger> partsString = ptp.toPartitions(testString, PrimitiveTypePartitioner.STRING);
+    int numParts = Integer.parseInt(SystemConfiguration.getProperty("pir.stringBits")) / 8;
+    assertEquals(numParts, partsString.size());
+
+    logger.info("testString.getBytes().length = " + testString.getBytes().length);
+    int offset = numParts;
+    if (testString.getBytes().length < numParts)
+    {
+      offset = testString.getBytes().length;
+    }
+    String element = new String(testString.getBytes(), 0, offset);
+    assertEquals(element, ptp.fromPartitions(partsString, 0, PrimitiveTypePartitioner.STRING));
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/org/apache/pirk/general/QueryParserUtilsTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/pirk/general/QueryParserUtilsTest.java b/src/test/java/org/apache/pirk/general/QueryParserUtilsTest.java
new file mode 100644
index 0000000..9ac2522
--- /dev/null
+++ b/src/test/java/org/apache/pirk/general/QueryParserUtilsTest.java
@@ -0,0 +1,421 @@
+/*
+ * 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.pirk.general;
+
+import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.assertTrue;
+
+import java.util.ArrayList;
+import java.util.Map;
+
+import org.apache.hadoop.io.MapWritable;
+import org.apache.pirk.schema.data.DataSchema;
+import org.apache.pirk.schema.data.DataSchemaRegistry;
+import org.apache.pirk.schema.query.QuerySchemaRegistry;
+import org.apache.pirk.test.utils.Inputs;
+import org.apache.pirk.utils.QueryParserUtils;
+import org.apache.pirk.utils.StringUtils;
+import org.apache.pirk.utils.SystemConfiguration;
+import org.json.simple.JSONObject;
+import org.junit.AfterClass;
+import org.junit.BeforeClass;
+import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/**
+ * Class for testing the QueryParser methods
+ */
+public class QueryParserUtilsTest
+{
+  private static final Logger logger = LoggerFactory.getLogger(QueryParserUtilsTest.class);
+
+  private static MapWritable doc = null; // MapWritable with arrays in json string representation
+  private static MapWritable docWAW = null; // MapWritable with arrays as WritableArrayWritable objects
+  private static Map<String,Object> docMap = null; // arrays as ArrayList<String>
+
+  private static DataSchema dSchema = null;
+
+  @BeforeClass
+  public static void setup() throws Exception
+  {
+    ArrayList<JSONObject> dataElementsJSON = Inputs.createJSONDataElements();
+
+    // Reset the schema properties and registries
+    DataSchemaRegistry.clearRegistry();
+    QuerySchemaRegistry.clearRegistry();
+    SystemConfiguration.setProperty("data.schemas", "none");
+    SystemConfiguration.setProperty("query.schemas", "none");
+
+    Inputs.createSchemaFiles(null, false, null);
+
+    dSchema = DataSchemaRegistry.get(Inputs.TEST_DATA_SCHEMA_NAME);
+
+    // ProcessBuilder pAdd1 = new ProcessBuilder("curl", "-XPUT", indexTypeNum1, "-d",
+    // "{\"qname\":\"a.b.c.com\",\"date\":\"2016-02-20T23:29:05.000Z\",\"qtype\":[\"1\"]"
+    // + ",\"rcode\":\"0\",\"src_ip\":\"55.55.55.55\",\"dest_ip\":\"1.2.3.6\"" + ",\"ip\":[\"10.20.30.40\",\"10.20.30.60\"]}");
+    //
+    doc = StringUtils.jsonStringToMapWritableWithArrayWritable(dataElementsJSON.get(0).toJSONString(), dSchema);
+    docWAW = StringUtils.jsonStringToMapWritableWithWritableArrayWritable(dataElementsJSON.get(0).toJSONString(), dSchema);
+    docMap = StringUtils.jsonStringToMap(dataElementsJSON.get(0).toJSONString(), dSchema);
+  }
+
+  @AfterClass
+  public static void teardown()
+  {
+    // Reset the schema properties and registries
+    DataSchemaRegistry.clearRegistry();
+    QuerySchemaRegistry.clearRegistry();
+    SystemConfiguration.setProperty("data.schemas", "none");
+    SystemConfiguration.setProperty("query.schemas", "none");
+  }
+
+  @Test
+  public void testSingleQuery()
+  {
+    String query1 = "?q=src_ip:55.55.55.55";
+    assertTrue(QueryParserUtils.checkRecord(query1, doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable(query1, docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecord(query1, docMap, dSchema));
+
+    String query2 = "?q=qname:a.b.c.com";
+    assertTrue(QueryParserUtils.checkRecord(query2, doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable(query2, docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecord(query2, docMap, dSchema));
+
+    String query3 = "?q=qname:d.b.c.com";
+    assertFalse(QueryParserUtils.checkRecord(query3, doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable(query3, docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecord(query3, docMap, dSchema));
+  }
+
+  @Test
+  public void testQueryFieldDoesNotExist()
+  {
+    logger.info("running testQueryFieldDoesNotExist");
+
+    // Field does not exist, this should not be found
+    String query = "?q=nonexistent-field:*check*";
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable(query, docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecord(query, doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecord(query, docMap, dSchema));
+
+    // First field does not exist, but second should be found
+    String query2 = "?q=nonexistent-field:*check*+OR+qname:*a.b.c.com*";
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable(query2, docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecord(query2, doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord(query2, docMap, dSchema));
+
+    // First field does not exist, second field does, but AND operator makes query false
+    String query3 = "?q=nonexistent-field:*check*+AND+qname:*a.b.c.com*";
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable(query3, docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecord(query3, doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecord(query3, docMap, dSchema));
+
+    logger.info("completed testQueryFieldDoesNotExist");
+  }
+
+  @Test
+  public void testIgnoreCase()
+  {
+    logger.info("running testIgnoreCase");
+
+    // with case sensitivity, should NOT be found
+    String query = "?q=qname:*A.b.c.com*";
+    assertFalse(QueryParserUtils.checkRecord(query, doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable(query, docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecord(query, docMap, dSchema));
+
+    // with case sensitivity, should be found
+    String query2 = "?q=qname:*a.b.c.com*";
+    assertTrue(QueryParserUtils.checkRecord(query2, doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable(query2, docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecord(query2, docMap, dSchema));
+
+    // adds @ flag = case insensitivity, thus should be found
+    String query3 = "?q=qname@:*A.b.c.com*";
+    assertTrue(QueryParserUtils.checkRecord(query3, doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable(query3, docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecord(query3, docMap, dSchema));
+
+    logger.info("completed testIgnoreCase");
+  }
+
+  @Test
+  public void testSingleValueRangeQuery()
+  {
+    testSingleValueRangeQueryMapWritable();
+    testSingleValueRangeQueryMap();
+    testSingleValueRangeQueryMapWritableWAW();
+  }
+
+  private void testSingleValueRangeQueryMapWritable()
+  {
+    assertTrue(QueryParserUtils.checkRecord("?q=rcode:[0+TO+2]", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=rcode:{-1+TO+2}", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=rcode:[-1+TO+0]", doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=rcode:{0+TO+3}", doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=rcode:[3+TO+10]", doc, dSchema));
+  }
+
+  private void testSingleValueRangeQueryMap()
+  {
+    assertTrue(QueryParserUtils.checkRecord("?q=rcode:[0+TO+2]", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=rcode:{-1+TO+2}", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=rcode:[-1+TO+0]", docMap, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=rcode:{0+TO+3}", docMap, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=rcode:[3+TO+10]", docMap, dSchema));
+  }
+
+  private void testSingleValueRangeQueryMapWritableWAW()
+  {
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=rcode:[0+TO+2]", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=rcode:{-1+TO+2}", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=rcode:[-1+TO+0]", docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=rcode:{0+TO+3}", docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=rcode:[3+TO+10]", docWAW, dSchema));
+  }
+
+  @Test
+  public void testIPRangeQuery()
+  {
+    testIPRangeQueryMapWritable();
+    testIPRangeQueryMap();
+    testIPRangeQueryMapWritableWAW();
+  }
+
+  public void testIPRangeQueryMapWritable()
+  {
+    // src_ip: 55.55.55.55
+    // ip: 10.20.30.40,10.20.30.60
+    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:[55.55.55.0+TO+173.248.255.255]", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:[55.55.55.0+TO+55.55.55.100]", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:[55.55.55.2+TO+55.55.55.55]", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:{55.55.55.2+TO+55.55.55.57}", doc, dSchema));
+
+    assertFalse(QueryParserUtils.checkRecord("?q=src_ip:{173.248.188.0+TO+173.248.188.10}", doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=src_ip:{55.55.55.2+TO+55.55.55.55}", doc, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecord("?q=ip:[10.20.30.50+TO+10.20.30.69]", doc, dSchema));
+  }
+
+  public void testIPRangeQueryMapWritableWAW()
+  {
+    // src_ip: 55.55.55.55
+    // ip: 10.20.30.40,10.20.30.60
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=src_ip:[55.55.55.0+TO+173.248.255.255]", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=src_ip:[55.55.55.0+TO+55.55.55.100]", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=src_ip:[55.55.55.2+TO+55.55.55.55]", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=src_ip:{55.55.55.2+TO+55.55.55.57}", docWAW, dSchema));
+
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=src_ip:{173.248.188.0+TO+173.248.188.10}", docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=src_ip:{55.55.55.2+TO+55.55.55.55}", docWAW, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=ip:[10.20.30.50+TO+10.20.30.69]", docWAW, dSchema));
+  }
+
+  public void testIPRangeQueryMap()
+  {
+    // src_ip: 55.55.55.55
+    // ip: 10.20.30.40,10.20.30.60
+    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:[55.55.55.0+TO+173.248.255.255]", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:[55.55.55.0+TO+55.55.55.100]", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:[55.55.55.2+TO+55.55.55.55]", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=src_ip:{55.55.55.2+TO+55.55.55.57}", docMap, dSchema));
+
+    assertFalse(QueryParserUtils.checkRecord("?q=src_ip:{173.248.188.0+TO+173.248.188.10}", docMap, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=src_ip:{55.55.55.2+TO+55.55.55.55}", docMap, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecord("?q=ip:[10.20.30.50+TO+10.20.30.69]", docMap, dSchema));
+  }
+
+  @Test
+  public void testDateRangeQuery()
+  {
+    testDateRangeQueryMapWritable();
+    testDateRangeQueryMapWritableWAW();
+    testDateRangeQueryMap();
+  }
+
+  private void testDateRangeQueryMapWritable()
+  {
+    // date: 2016-02-20T23:29:05.000Z
+
+    assertTrue(QueryParserUtils.checkRecord("?q=date:[2014-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=date:[2015-05-05T20:33:07.000Z+TO+2016-04-20T23:29:05.000Z]", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=date:[2016-02-20T23:29:05.000Z+TO+2017-02-20T23:29:05.000Z]", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=date:{2015-06-05T20:33:07.000Z+TO+2016-02-20T23:30:05.000Z}", doc, dSchema));
+
+    assertFalse(QueryParserUtils.checkRecord("?q=date:[2013-05-05T20:33:07.000Z+TO+2014-07-05T20:33:07.000Z]", doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=date:{2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z}", doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=date:{2015-06-05T20:33:07.000Z+TO+2015-07-05T20:33:07.000Z}", doc, dSchema));
+  }
+
+  private void testDateRangeQueryMap()
+  {
+    // date: 2016-02-20T23:29:05.000Z
+
+    assertTrue(QueryParserUtils.checkRecord("?q=date:[2014-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=date:[2015-05-05T20:33:07.000Z+TO+2016-04-20T23:29:05.000Z]", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=date:[2016-02-20T23:29:05.000Z+TO+2017-02-20T23:29:05.000Z]", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=date:{2015-06-05T20:33:07.000Z+TO+2016-02-20T23:30:05.000Z}", docMap, dSchema));
+
+    assertFalse(QueryParserUtils.checkRecord("?q=date:[2013-05-05T20:33:07.000Z+TO+2014-07-05T20:33:07.000Z]", docMap, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=date:{2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z}", docMap, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=date:{2015-06-05T20:33:07.000Z+TO+2015-07-05T20:33:07.000Z}", docMap, dSchema));
+  }
+
+  private void testDateRangeQueryMapWritableWAW()
+  {
+    // date: 2016-02-20T23:29:05.000Z
+
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:[2014-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:[2015-05-05T20:33:07.000Z+TO+2016-04-20T23:29:05.000Z]", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:[2016-02-20T23:29:05.000Z+TO+2017-02-20T23:29:05.000Z]", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:{2015-06-05T20:33:07.000Z+TO+2016-02-20T23:30:05.000Z}", docWAW, dSchema));
+
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:[2013-05-05T20:33:07.000Z+TO+2014-07-05T20:33:07.000Z]", docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:{2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z}", docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=date:{2015-06-05T20:33:07.000Z+TO+2015-07-05T20:33:07.000Z}", docWAW, dSchema));
+  }
+
+  @Test
+  public void testBooleanQuery()
+  {
+    testBooleanQueryMapWritable();
+    testBooleanQueryMapMapWritableWAW();
+    testBooleanQueryMap();
+  }
+
+  private void testBooleanQueryMapWritable()
+  {
+    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=qtype:5+OR+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", doc, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+rcode:0+AND+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", doc, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+rcode:0+OR+date:[2013-05-05T20:33:07.000Z+TO+2014-07-05T20:33:07.000Z]", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+rcode:1+OR+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", doc, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecord("?q=qtype:5+OR+qtype:2+OR+rcode:0", doc, dSchema));
+  }
+
+  private void testBooleanQueryMap()
+  {
+    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=qtype:5+OR+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docMap, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+rcode:0+AND+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docMap, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+rcode:0+OR+date:[2013-05-05T20:33:07.000Z+TO+2014-07-05T20:33:07.000Z]", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=qtype:1+AND+rcode:1+OR+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docMap, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecord("?q=qtype:5+OR+qtype:2+OR+rcode:0", docMap, dSchema));
+  }
+
+  private void testBooleanQueryMapMapWritableWAW()
+  {
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qtype:1+AND+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qtype:5+OR+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]", docWAW, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qtype:1+AND+rcode:0+AND+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]",
+        docWAW, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qtype:1+AND+rcode:0+OR+date:[2013-05-05T20:33:07.000Z+TO+2014-07-05T20:33:07.000Z]",
+        docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qtype:1+AND+rcode:1+OR+date:[2015-05-05T20:33:07.000Z+TO+2016-02-20T23:29:05.000Z]",
+        docWAW, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qtype:5+OR+qtype:2+OR+rcode:0", docWAW, dSchema));
+  }
+
+  @Test
+  public void testAllQuery()
+  {
+    assertTrue(QueryParserUtils.checkRecord("?q=*", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=*", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=*", docWAW, dSchema));
+  }
+
+  @Test
+  public void testWildcardQuery()
+  {
+    testWildcardQueryMapWritable();
+    testWildcardQueryMap();
+    testWildcardQueryMapWritableWAW();
+  }
+
+  private void testWildcardQueryMapWritable()
+  {
+    assertTrue(QueryParserUtils.checkRecord("?q=qname:*.com", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b.c.c*m", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b*", doc, dSchema));
+
+    assertFalse(QueryParserUtils.checkRecord("?q=qname:*.org", doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=qname:mrtf*", doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=qname:nedeljnik*.uk", doc, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b.c.c?m", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b.?.com", doc, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=qname:?.b.c.com", doc, dSchema));
+
+    assertFalse(QueryParserUtils.checkRecord("?q=qname:medelj?ikafera.com", doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=qname:nedeljntkafer?.com", doc, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=qname:?edeljnikrfera.com", doc, dSchema));
+  }
+
+  private void testWildcardQueryMap()
+  {
+    assertTrue(QueryParserUtils.checkRecord("?q=qname:*.com", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b.c.c*m", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b*", docMap, dSchema));
+
+    assertFalse(QueryParserUtils.checkRecord("?q=qname:*.org", docMap, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=qname:mrtf*", docMap, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=qname:nedeljnik*.uk", docMap, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b.c.c?m", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=qname:a.b.?.com", docMap, dSchema));
+    assertTrue(QueryParserUtils.checkRecord("?q=qname:?.b.c.com", docMap, dSchema));
+
+    assertFalse(QueryParserUtils.checkRecord("?q=qname:medelj?ikafera.com", docMap, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=qname:nedeljntkafer?.com", docMap, dSchema));
+    assertFalse(QueryParserUtils.checkRecord("?q=qname:?edeljnikrfera.com", docMap, dSchema));
+  }
+
+  private void testWildcardQueryMapWritableWAW()
+  {
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:*.com", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:a.b.c.c*m", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:a.b*", docWAW, dSchema));
+
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:*.org", docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:mrtf*", docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:nedeljnik*.uk", docWAW, dSchema));
+
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:a.b.c.c?m", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:a.b.?.com", docWAW, dSchema));
+    assertTrue(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:?.b.c.com", docWAW, dSchema));
+
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:medelj?ikafera.com", docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:nedeljntkafer?.com", docWAW, dSchema));
+    assertFalse(QueryParserUtils.checkRecordWritableArrayWritable("?q=qname:?edeljnikrfera.com", docWAW, dSchema));
+
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/org/apache/pirk/schema/data/LoadDataSchemaTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/pirk/schema/data/LoadDataSchemaTest.java b/src/test/java/org/apache/pirk/schema/data/LoadDataSchemaTest.java
new file mode 100644
index 0000000..3aa500b
--- /dev/null
+++ b/src/test/java/org/apache/pirk/schema/data/LoadDataSchemaTest.java
@@ -0,0 +1,324 @@
+/*
+ * 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.pirk.schema.data;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertTrue;
+import static org.junit.Assert.fail;
+
+import java.io.File;
+import java.io.IOException;
+
+import javax.xml.parsers.DocumentBuilder;
+import javax.xml.parsers.DocumentBuilderFactory;
+import javax.xml.transform.Transformer;
+import javax.xml.transform.TransformerFactory;
+import javax.xml.transform.dom.DOMSource;
+import javax.xml.transform.stream.StreamResult;
+
+import org.apache.pirk.schema.data.partitioner.IPDataPartitioner;
+import org.apache.pirk.schema.data.partitioner.PrimitiveTypePartitioner;
+import org.apache.pirk.test.utils.TestUtils;
+import org.apache.pirk.utils.SystemConfiguration;
+import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+import org.w3c.dom.Document;
+import org.w3c.dom.Element;
+
+/**
+ * Test suite for LoadDataSchema and DataSchema
+ */
+public class LoadDataSchemaTest
+{
+  private static final Logger logger = LoggerFactory.getLogger(LoadDataSchemaTest.class);
+
+  private String dataSchemaName = "fakeDataSchema";
+
+  private String element1 = "elementName1";
+  private String element2 = "elementName2";
+  private String element3 = "elementName3";
+
+  @Test
+  public void testGeneralSchemaLoad() throws Exception
+  {
+    // Pull off the property and reset upon completion
+    String schemasProp = SystemConfiguration.getProperty("data.schemas", "none");
+
+    // Write the schema file
+    try
+    {
+      createDataSchema("schemaFile");
+    } catch (IOException e)
+    {
+      e.printStackTrace();
+      fail(e.toString());
+    }
+
+    // Force the schema to load
+    DataSchemaLoader.initialize();
+
+    // Check the entries
+    DataSchema dSchema = DataSchemaRegistry.get(dataSchemaName);
+
+    assertEquals(dataSchemaName, dSchema.getSchemaName());
+
+    assertEquals(3, dSchema.getElementNames().size());
+
+    // TODO: check Hadoop text names
+
+    assertEquals(PrimitiveTypePartitioner.STRING, dSchema.getElementType(element1));
+    assertEquals(PrimitiveTypePartitioner.INT, dSchema.getElementType(element2));
+    assertEquals(PrimitiveTypePartitioner.STRING, dSchema.getElementType(element3));
+
+    assertEquals(PrimitiveTypePartitioner.class.getName(), dSchema.getPartitionerTypeName(element1));
+    if (!(dSchema.getPartitionerForElement(element1) instanceof PrimitiveTypePartitioner))
+    {
+      fail("Partitioner instance for element1 must be PrimitiveTypePartitioner");
+    }
+    assertEquals(IPDataPartitioner.class.getName(), dSchema.getPartitionerTypeName(element3));
+    if (!(dSchema.getPartitionerForElement(element3) instanceof IPDataPartitioner))
+    {
+      fail("Partitioner instance for element3 must be IPDataPartitioner");
+    }
+
+    assertEquals(2, dSchema.getArrayElements().size());
+    assertTrue(dSchema.getArrayElements().contains(element2));
+    assertTrue(dSchema.getArrayElements().contains(element3));
+
+    assertEquals(1, dSchema.getNonArrayElements().size());
+    assertTrue(dSchema.getNonArrayElements().contains(element1));
+
+    // Reset original data.schemas property
+    SystemConfiguration.setProperty("data.schemas", schemasProp);
+
+    // Force the schema to load
+    if (!schemasProp.equals("none"))
+    {
+      DataSchemaLoader.initialize();
+    }
+  }
+
+  @Test
+  public void testIncorrectJavaType() throws Exception
+  {
+    // Pull off the property and reset upon completion
+    String schemasProp = SystemConfiguration.getProperty("data.schemas");
+
+    // Write the schema file
+    try
+    {
+      createDataSchemaIncorrectJavaType("wrongJavaType");
+    } catch (IOException e)
+    {
+      e.printStackTrace();
+      fail(e.toString());
+    }
+
+    try
+    {
+      // Force the schema to load
+      DataSchemaLoader.initialize();
+      fail("DataSchemaLoader did not throw exception for incorrect javaType");
+    } catch (Exception ignore)
+    {}
+
+    // Reset original data.schemas property
+    SystemConfiguration.setProperty("data.schemas", schemasProp);
+
+    // Force the schema to load
+    DataSchemaLoader.initialize();
+  }
+
+  @Test
+  public void testUnknownPartitioner() throws Exception
+  {
+    // Pull off the property and reset upon completion
+    String schemasProp = SystemConfiguration.getProperty("data.schemas");
+
+    // Write the schema file
+    try
+    {
+      createDataSchemaUnknownPartitioner("unknownPartitioner");
+    } catch (IOException e)
+    {
+      e.printStackTrace();
+      fail(e.toString());
+    }
+
+    try
+    {
+      // Force the schema to load
+      DataSchemaLoader.initialize();
+      fail("DataSchemaLoader did not throw exception for unknown partitioner");
+    } catch (Exception ignore)
+    {}
+
+    // Reset original data.schemas property
+    SystemConfiguration.setProperty("data.schemas", schemasProp);
+
+    // Force the schema to load
+    DataSchemaLoader.initialize();
+  }
+
+  // Create the file that contains an unknown partitioner
+  private void createDataSchemaUnknownPartitioner(String schemaFile) throws IOException
+  {
+    // Create a temporary file for the test schema, set in the properties
+    File file = File.createTempFile(schemaFile, ".xml");
+    file.deleteOnExit();
+    logger.info("file = " + file.toString());
+    SystemConfiguration.setProperty("data.schemas", file.toString());
+
+    // Write to the file
+    try
+    {
+      DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();
+      DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();
+      Document doc = dBuilder.newDocument();
+
+      // root element
+      Element rootElement = doc.createElement("schema");
+      doc.appendChild(rootElement);
+
+      // Add the schemaName
+      Element schemaNameElement = doc.createElement("schemaName");
+      schemaNameElement.appendChild(doc.createTextNode(dataSchemaName));
+      rootElement.appendChild(schemaNameElement);
+
+      // Add the element - unknown partitioner
+      TestUtils.addElement(doc, rootElement, element1, PrimitiveTypePartitioner.INT, "false", "fakePartitioner");
+
+      // Write to a xml file
+      TransformerFactory transformerFactory = TransformerFactory.newInstance();
+      Transformer transformer = transformerFactory.newTransformer();
+      DOMSource source = new DOMSource(doc);
+      StreamResult result = new StreamResult(file);
+      transformer.transform(source, result);
+
+      // Output for testing
+      StreamResult consoleResult = new StreamResult(System.out);
+      transformer.transform(source, consoleResult);
+      System.out.println();
+    } catch (Exception e)
+    {
+      e.printStackTrace();
+    }
+  }
+
+  // Create the test data schema file
+  private void createDataSchema(String schemaFile) throws IOException
+  {
+    // Create a temporary file for the test schema, set in the properties
+    File file = File.createTempFile(schemaFile, ".xml");
+    file.deleteOnExit();
+    logger.info("file = " + file.toString());
+    SystemConfiguration.setProperty("data.schemas", file.toString());
+
+    // Write to the file
+    try
+    {
+      DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();
+      DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();
+      Document doc = dBuilder.newDocument();
+
+      // root element
+      Element rootElement = doc.createElement("schema");
+      doc.appendChild(rootElement);
+
+      // Add the schemaName
+      Element schemaNameElement = doc.createElement("schemaName");
+      schemaNameElement.appendChild(doc.createTextNode(dataSchemaName));
+      rootElement.appendChild(schemaNameElement);
+
+      // Add the elements
+      // element1 -- single String
+      // TestUtils.addElement(doc, rootElement, element1, PrimitiveTypePartitioner.STRING, "false", PrimitiveTypePartitioner.class.getName());
+      TestUtils.addElement(doc, rootElement, element1, PrimitiveTypePartitioner.STRING, "false", null);
+
+      // element2 - -- array of Integers
+      TestUtils.addElement(doc, rootElement, element2, PrimitiveTypePartitioner.INT, "true", PrimitiveTypePartitioner.class.getName());
+
+      // element3 -- array of IP addresses
+      TestUtils.addElement(doc, rootElement, element3, PrimitiveTypePartitioner.STRING, "true", IPDataPartitioner.class.getName());
+
+      // Write to a xml file
+      TransformerFactory transformerFactory = TransformerFactory.newInstance();
+      Transformer transformer = transformerFactory.newTransformer();
+      DOMSource source = new DOMSource(doc);
+      StreamResult result = new StreamResult(file);
+      transformer.transform(source, result);
+
+      // Output for testing
+      StreamResult consoleResult = new StreamResult(System.out);
+      transformer.transform(source, consoleResult);
+      System.out.println();
+
+    } catch (Exception e)
+    {
+      e.printStackTrace();
+    }
+  }
+
+  // Create the test schema file
+  private void createDataSchemaIncorrectJavaType(String schemaFile) throws IOException
+  {
+    // Create a temporary file for the test schema, set in the properties
+    File file = File.createTempFile(schemaFile, ".xml");
+    file.deleteOnExit();
+    logger.info("file = " + file.toString());
+    SystemConfiguration.setProperty("data.schemas", file.toString());
+
+    // Write to the file
+    try
+    {
+      DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();
+      DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();
+      Document doc = dBuilder.newDocument();
+
+      // root element
+      Element rootElement = doc.createElement("schema");
+      doc.appendChild(rootElement);
+
+      // Add the schemaName
+      Element schemaNameElement = doc.createElement("schemaName");
+      schemaNameElement.appendChild(doc.createTextNode(dataSchemaName));
+      rootElement.appendChild(schemaNameElement);
+
+      // Add the element - unknown Java type
+      TestUtils.addElement(doc, rootElement, element1, "bogus", "false", PrimitiveTypePartitioner.class.getName());
+
+      // Write to a xml file
+      TransformerFactory transformerFactory = TransformerFactory.newInstance();
+      Transformer transformer = transformerFactory.newTransformer();
+      DOMSource source = new DOMSource(doc);
+      StreamResult result = new StreamResult(file);
+      transformer.transform(source, result);
+
+      // Output for testing
+      StreamResult consoleResult = new StreamResult(System.out);
+      transformer.transform(source, consoleResult);
+      System.out.println();
+
+    } catch (Exception e)
+    {
+      e.printStackTrace();
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/org/apache/pirk/schema/query/LoadQuerySchemaTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/pirk/schema/query/LoadQuerySchemaTest.java b/src/test/java/org/apache/pirk/schema/query/LoadQuerySchemaTest.java
new file mode 100644
index 0000000..55cb0a9
--- /dev/null
+++ b/src/test/java/org/apache/pirk/schema/query/LoadQuerySchemaTest.java
@@ -0,0 +1,368 @@
+/*
+ * 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.pirk.schema.query;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.fail;
+
+import java.io.File;
+import java.io.IOException;
+import java.util.Arrays;
+import java.util.Collections;
+import java.util.List;
+
+import javax.xml.parsers.DocumentBuilder;
+import javax.xml.parsers.DocumentBuilderFactory;
+import javax.xml.transform.Transformer;
+import javax.xml.transform.TransformerFactory;
+import javax.xml.transform.dom.DOMSource;
+import javax.xml.transform.stream.StreamResult;
+
+import org.apache.pirk.schema.data.DataSchemaLoader;
+import org.apache.pirk.schema.data.partitioner.IPDataPartitioner;
+import org.apache.pirk.schema.data.partitioner.PrimitiveTypePartitioner;
+import org.apache.pirk.schema.query.filter.StopListFilter;
+import org.apache.pirk.test.utils.Inputs;
+import org.apache.pirk.test.utils.TestUtils;
+import org.apache.pirk.utils.PIRException;
+import org.apache.pirk.utils.SystemConfiguration;
+import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+import org.w3c.dom.Document;
+import org.w3c.dom.Element;
+
+/**
+ * Test suite for LoadQuerySchema and QuerySchema
+ */
+public class LoadQuerySchemaTest
+{
+  private static final Logger logger = LoggerFactory.getLogger(LoadQuerySchemaTest.class);
+
+  private String querySchemaFile = "querySchemaFile";
+  private String dataSchemaName = "fakeDataSchema";
+  private String querySchemaName = "fakeQuerySchema";
+
+  private String element1 = "elementName1";
+  private String element2 = "elementName2";
+  private String element3 = "elementName3";
+  private String element4 = "elementName4";
+
+  private List<String> queryElements = Arrays.asList(element1, element2, element3);
+  private List<String> filterElements = Collections.singletonList(element2);
+
+  @Test
+  public void testGeneralSchemaLoad() throws Exception
+  {
+    logger.info("Starting testGeneralSchemaLoad: ");
+
+    // Pull off the properties and reset upon completion
+    String dataSchemasProp = SystemConfiguration.getProperty("data.schemas", "none");
+    String querySchemasProp = SystemConfiguration.getProperty("query.schemas", "none");
+    String stopListFileProp = SystemConfiguration.getProperty("pir.stopListFile");
+
+    // Create the stoplist file
+    createStopListFile();
+
+    // Create the data schema used and force it to load
+    try
+    {
+      createDataSchema("dataSchemaFile");
+    } catch (Exception e)
+    {
+      e.printStackTrace();
+      fail(e.toString());
+    }
+    DataSchemaLoader.initialize();
+
+    // Create the query schema used and force it to load
+    try
+    {
+      TestUtils.createQuerySchema(querySchemaFile, querySchemaName, dataSchemaName, element4, queryElements, filterElements, StopListFilter.class.getName());
+
+    } catch (IOException e)
+    {
+      e.printStackTrace();
+      fail(e.toString());
+    }
+    QuerySchemaLoader.initialize();
+
+    // Check the entries
+    QuerySchema qSchema = QuerySchemaRegistry.get(querySchemaName);
+
+    assertEquals(querySchemaName, qSchema.getSchemaName());
+    assertEquals(dataSchemaName, qSchema.getDataSchemaName());
+    assertEquals(element4, qSchema.getSelectorName());
+
+    assertEquals(StopListFilter.class.getName(), qSchema.getFilterTypeName());
+    if (!(qSchema.getFilter() instanceof StopListFilter))
+    {
+      fail("Filter class instance must be StopListFilter");
+    }
+
+    assertEquals(3, qSchema.getElementNames().size());
+    for (String item : qSchema.getElementNames())
+    {
+      if (!(item.equals(element1) || item.equals(element2) || item.equals(element3)))
+      {
+        fail("elementNames: item = " + item + " must equal one of: " + element1 + ", " + element2 + ", or " + element3);
+      }
+    }
+    assertEquals(1, qSchema.getFilteredElementNames().size());
+    for (String item : qSchema.getFilteredElementNames())
+    {
+      if (!item.equals(element2))
+      {
+        fail("filterElementNames: item = " + item + " must equal " + element2);
+      }
+    }
+
+    // one string, array IPs, array integers
+    int stringSize = Integer.parseInt(SystemConfiguration.getProperty("pir.stringBits"));
+    int arrayMult = Integer.parseInt(SystemConfiguration.getProperty("pir.numReturnArrayElements"));
+    int dataElementSize = stringSize + 32 * arrayMult + 32 * arrayMult;
+    assertEquals(dataElementSize, qSchema.getDataElementSize());
+
+    // Reset original query and data schema properties
+    SystemConfiguration.setProperty("data.schemas", dataSchemasProp);
+    SystemConfiguration.setProperty("query.schemas", querySchemasProp);
+    SystemConfiguration.setProperty("pir.stopListFile", stopListFileProp);
+
+    // Force the query and data schemas to load their original values
+    if (!dataSchemasProp.equals("none"))
+    {
+      DataSchemaLoader.initialize();
+    }
+
+    if (!querySchemasProp.equals("none"))
+    {
+      QuerySchemaLoader.initialize();
+    }
+
+    logger.info("Finished testGeneralSchemaLoad: ");
+  }
+
+  @Test
+  public void testUnknownFilterClass() throws Exception
+  {
+    // Pull off the properties and reset upon completion
+    String dataSchemasProp = SystemConfiguration.getProperty("data.schemas", "none");
+    String querySchemasProp = SystemConfiguration.getProperty("query.schemas", "none");
+
+    // Create the data schema used and force it to load
+    try
+    {
+      createDataSchema("dataSchemaFile");
+    } catch (Exception e)
+    {
+      e.printStackTrace();
+      fail(e.toString());
+    }
+    DataSchemaLoader.initialize();
+
+    // Create the query schema used and force it to load
+    try
+    {
+      TestUtils.createQuerySchema(querySchemaFile, querySchemaName, dataSchemaName, "nonExistentElement", queryElements, filterElements, "bogusFilterClass");
+
+    } catch (IOException e)
+    {
+      e.printStackTrace();
+      fail(e.toString());
+    }
+    try
+    {
+      QuerySchemaLoader.initialize();
+      fail("QuerySchemaLoader did not throw exception for bogus filter class");
+    } catch (Exception ignore)
+    {}
+
+    // Reset original query and data schema properties
+    SystemConfiguration.setProperty("data.schemas", dataSchemasProp);
+    SystemConfiguration.setProperty("query.schemas", querySchemasProp);
+
+    // Force the query and data schemas to load their original values
+    if (!dataSchemasProp.equals("none"))
+    {
+      DataSchemaLoader.initialize();
+    }
+
+    if (!querySchemasProp.equals("none"))
+    {
+      QuerySchemaLoader.initialize();
+    }
+
+    logger.info("Finished testFunkyFilterScenarios");
+  }
+
+  @Test
+  public void testDataSchemaDoesNotExist() throws Exception
+  {
+    logger.info("Starting testDataSchemaDoesNotExist: ");
+
+    // Pull off the properties and reset upon completion
+    String querySchemasProp = SystemConfiguration.getProperty("query.schemas", "none");
+
+    // Create the query schema used and force it to load
+    try
+    {
+      TestUtils.createQuerySchema(querySchemaFile, querySchemaName, dataSchemaName, element4, queryElements, filterElements, null);
+
+    } catch (IOException e)
+    {
+      e.printStackTrace();
+      fail(e.toString());
+    }
+    try
+    {
+      QuerySchemaLoader.initialize();
+      fail("QuerySchemaLoader did not throw exception for non-existent DataSchema");
+    } catch (Exception ignore)
+    {}
+
+    // Reset original query properties and force to load
+    SystemConfiguration.setProperty("query.schemas", querySchemasProp);
+    if (!querySchemasProp.equals("none"))
+    {
+      QuerySchemaLoader.initialize();
+    }
+
+    logger.info("Finished testDataSchemaDoesNotExist ");
+  }
+
+  @Test
+  public void testSelectorDoesNotExistInDataSchema() throws Exception
+  {
+    logger.info("Starting testSelectorDoesNotExistInDataSchema: ");
+
+    // Pull off the properties and reset upon completion
+    String dataSchemasProp = SystemConfiguration.getProperty("data.schemas", "none");
+    String querySchemasProp = SystemConfiguration.getProperty("query.schemas", "none");
+
+    // Create the data schema used and force it to load
+    try
+    {
+      createDataSchema("dataSchemaFile");
+    } catch (Exception e)
+    {
+      e.printStackTrace();
+      fail(e.toString());
+    }
+    DataSchemaLoader.initialize();
+
+    // Create the query schema used and force it to load
+    try
+    {
+      TestUtils.createQuerySchema(querySchemaFile, querySchemaName, dataSchemaName, "nonExistentElement", queryElements, filterElements,
+          StopListFilter.class.getName());
+
+    } catch (IOException e)
+    {
+      e.printStackTrace();
+      fail(e.toString());
+    }
+    try
+    {
+      QuerySchemaLoader.initialize();
+      fail("QuerySchemaLoader did not throw exception for non-existent selectorName");
+    } catch (Exception ignore)
+    {}
+
+    // Reset original query and data schema properties
+    SystemConfiguration.setProperty("data.schemas", dataSchemasProp);
+    SystemConfiguration.setProperty("query.schemas", querySchemasProp);
+
+    // Force the query and data schemas to load their original values
+    if (!dataSchemasProp.equals("none"))
+    {
+      DataSchemaLoader.initialize();
+    }
+
+    if (!querySchemasProp.equals("none"))
+    {
+      QuerySchemaLoader.initialize();
+    }
+
+    logger.info("Finished testSelectorDoesNotExistInDataSchema ");
+  }
+
+  // Create the stoplist file and alter the properties accordingly
+  private void createStopListFile() throws IOException, PIRException
+  {
+    SystemConfiguration.setProperty("pir.stopListFile", "testStopListFile");
+    String newSLFile = Inputs.createPIRStopList(null, false);
+    SystemConfiguration.setProperty("pir.stopListFile", newSLFile);
+  }
+
+  // Create the test data schema file
+  private void createDataSchema(String schemaFile) throws IOException
+  {
+    // Create a temporary file for the test schema, set in the properties
+    File file = File.createTempFile(schemaFile, ".xml");
+    file.deleteOnExit();
+    logger.info("file = " + file.toString());
+    SystemConfiguration.setProperty("data.schemas", file.toString());
+
+    // Write to the file
+    try
+    {
+      DocumentBuilderFactory dbFactory = DocumentBuilderFactory.newInstance();
+      DocumentBuilder dBuilder = dbFactory.newDocumentBuilder();
+      Document doc = dBuilder.newDocument();
+
+      // root element
+      Element rootElement = doc.createElement("schema");
+      doc.appendChild(rootElement);
+
+      // Add the schemaName
+      Element schemaNameElement = doc.createElement("schemaName");
+      schemaNameElement.appendChild(doc.createTextNode(dataSchemaName));
+      rootElement.appendChild(schemaNameElement);
+
+      // Add the elements
+      // element1 -- single String
+      TestUtils.addElement(doc, rootElement, element1, PrimitiveTypePartitioner.STRING, "false", PrimitiveTypePartitioner.class.getName());
+
+      // element2 - -- array of Integers
+      TestUtils.addElement(doc, rootElement, element2, PrimitiveTypePartitioner.INT, "true", PrimitiveTypePartitioner.class.getName());
+
+      // element3 -- array of IP addresses
+      TestUtils.addElement(doc, rootElement, element3, PrimitiveTypePartitioner.STRING, "true", IPDataPartitioner.class.getName());
+
+      // element4 -- single byte type
+      TestUtils.addElement(doc, rootElement, element4, PrimitiveTypePartitioner.BYTE, "false", PrimitiveTypePartitioner.class.getName());
+
+      // Write to a xml file
+      TransformerFactory transformerFactory = TransformerFactory.newInstance();
+      Transformer transformer = transformerFactory.newTransformer();
+      DOMSource source = new DOMSource(doc);
+      StreamResult result = new StreamResult(file);
+      transformer.transform(source, result);
+
+      // Output for testing
+      StreamResult consoleResult = new StreamResult(System.out);
+      transformer.transform(source, consoleResult);
+      System.out.println();
+
+    } catch (Exception e)
+    {
+      e.printStackTrace();
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/org/apache/pirk/wideskies/standalone/StandaloneTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/pirk/wideskies/standalone/StandaloneTest.java b/src/test/java/org/apache/pirk/wideskies/standalone/StandaloneTest.java
new file mode 100644
index 0000000..06c2bff
--- /dev/null
+++ b/src/test/java/org/apache/pirk/wideskies/standalone/StandaloneTest.java
@@ -0,0 +1,128 @@
+/*
+ * 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.pirk.wideskies.standalone;
+
+import java.util.ArrayList;
+
+import org.apache.pirk.schema.data.DataSchemaRegistry;
+import org.apache.pirk.schema.query.QuerySchemaRegistry;
+import org.apache.pirk.schema.query.filter.StopListFilter;
+import org.apache.pirk.test.utils.BaseTests;
+import org.apache.pirk.test.utils.Inputs;
+import org.apache.pirk.utils.SystemConfiguration;
+import org.json.simple.JSONObject;
+import org.junit.AfterClass;
+import org.junit.BeforeClass;
+import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/**
+ * Functional test suite for stand alone testing - non Spark applications
+ * <p>
+ * Tests low side module and basic encryption, decryption mechanisms
+ * <p>
+ * Using a fixed 8-bit data partition size (consistent with the currently codebase)
+ * <p>
+ * Runs with useExpLookupTable = false as generating the lookup table takes too long for normal in-memory builds
+ * 
+ */
+public class StandaloneTest
+{
+  private static final Logger logger = LoggerFactory.getLogger(StandaloneTest.class);
+
+  private static final String STOPLIST_FILE = "testStopListFile";
+
+  private static String stopListFileProp = null;
+
+  @BeforeClass
+  public static void setup() throws Exception
+  {
+    // Reset the schema properties and registries
+    DataSchemaRegistry.clearRegistry();
+    QuerySchemaRegistry.clearRegistry();
+    SystemConfiguration.setProperty("data.schemas", "none");
+    SystemConfiguration.setProperty("query.schemas", "none");
+
+    // Create the stoplist file
+    stopListFileProp = SystemConfiguration.getProperty("pir.stopListFile");
+    SystemConfiguration.setProperty("pir.stopListFile", STOPLIST_FILE);
+    String newSLFile = Inputs.createPIRStopList(null, false);
+    SystemConfiguration.setProperty("pir.stopListFile", newSLFile);
+    logger.info("stopListFileProp = " + stopListFileProp + " new prop = " + SystemConfiguration.getProperty("pir.stopListFile"));
+
+    // Create data and query schemas
+    Inputs.createSchemaFiles(StopListFilter.class.getName());
+  }
+
+  @AfterClass
+  public static void teardown()
+  {
+    // Reset the schema properties and registries
+    DataSchemaRegistry.clearRegistry();
+    QuerySchemaRegistry.clearRegistry();
+    SystemConfiguration.setProperty("data.schemas", "none");
+    SystemConfiguration.setProperty("query.schemas", "none");
+  }
+
+  @Test
+  public void runTests() throws Exception
+  {
+    ArrayList<JSONObject> dataElements = Inputs.createJSONDataElements();
+    ArrayList<JSONObject> dataElementsRcode3 = Inputs.getRcode3JSONDataElements();
+
+    SystemConfiguration.setProperty("pir.allowAdHocQuerySchemas", "false");
+    SystemConfiguration.setProperty("pir.embedQuerySchema", "false");
+
+    // Run tests and use the embedded selector
+    SystemConfiguration.setProperty("pirTest.embedSelector", "true");
+    BaseTests.testDNSHostnameQuery(dataElements, 1, false);
+    BaseTests.testSRCIPQuery(dataElements, 2);
+    BaseTests.testDNSIPQuery(dataElements, 3); // numThreads % num elements to encrypt != 0
+    BaseTests.testDNSNXDOMAINQuery(dataElementsRcode3, 4); // numThreads % num elements to encrypt = 0
+
+    // Test embedded QuerySchema
+    SystemConfiguration.setProperty("pir.allowAdHocQuerySchemas", "true");
+    SystemConfiguration.setProperty("pir.embedQuerySchema", "false");
+    BaseTests.testDNSHostnameQuery(dataElements, 1, false);
+
+    SystemConfiguration.setProperty("pir.allowAdHocQuerySchemas", "true");
+    SystemConfiguration.setProperty("pir.embedQuerySchema", "true");
+    BaseTests.testDNSHostnameQuery(dataElements, 1, false);
+
+    SystemConfiguration.setProperty("pir.allowAdHocQuerySchemas", "false");
+    SystemConfiguration.setProperty("pir.embedQuerySchema", "true");
+    BaseTests.testDNSHostnameQuery(dataElements, 1, false);
+    SystemConfiguration.setProperty("pir.embedQuerySchema", "false");
+
+    // Run tests without using the embedded selector
+    SystemConfiguration.setProperty("pirTest.embedSelector", "false");
+    BaseTests.testDNSHostnameQuery(dataElements, 1, false);
+    BaseTests.testSRCIPQuery(dataElements, 2);
+    BaseTests.testDNSIPQuery(dataElements, 3);
+    BaseTests.testDNSNXDOMAINQuery(dataElementsRcode3, 4);
+
+    // Run using a false positive
+    SystemConfiguration.setProperty("pirTest.embedSelector", "true");
+    BaseTests.testDNSHostnameQuery(dataElements, 1, true);
+
+    // Reset the stoplist file property
+    SystemConfiguration.setProperty("pir.stopListFile", stopListFileProp);
+  }
+}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/test/general/ISO8601DateParserTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/test/general/ISO8601DateParserTest.java b/src/test/java/test/general/ISO8601DateParserTest.java
deleted file mode 100644
index 02391d4..0000000
--- a/src/test/java/test/general/ISO8601DateParserTest.java
+++ /dev/null
@@ -1,50 +0,0 @@
-/*
- * 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 test.general;
-
-import static org.junit.Assert.assertEquals;
-
-import java.text.ParseException;
-
-import org.apache.pirk.utils.ISO8601DateParser;
-import org.junit.Test;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * Class to test basic functionality of ISO8601DateParser class
- */
-public class ISO8601DateParserTest
-{
-  private static final Logger logger = LoggerFactory.getLogger(ISO8601DateParserTest.class);
-
-  @Test
-  public void testDateParsing() throws ParseException
-  {
-    logger.info("Starting testDateParsing: ");
-
-    String date = "2016-02-20T23:29:05.000Z";
-    long longDate = Long.parseLong("1456010945000"); // date in UTC
-
-    assertEquals(longDate, ISO8601DateParser.getLongDate(date));
-    assertEquals(date, ISO8601DateParser.fromLongDate(longDate));
-
-    logger.info("Successfully completed testDateParsing");
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/test/general/KeyedHashTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/test/general/KeyedHashTest.java b/src/test/java/test/general/KeyedHashTest.java
deleted file mode 100644
index 6f69b38..0000000
--- a/src/test/java/test/general/KeyedHashTest.java
+++ /dev/null
@@ -1,83 +0,0 @@
-/*
- * 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 test.general;
-
-import static org.junit.Assert.assertEquals;
-
-import org.apache.pirk.utils.KeyedHash;
-import org.junit.Test;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-/**
- * Basic functional tests for KeyedHash
- * 
- */
-public class KeyedHashTest
-{
-  private static final Logger logger = LoggerFactory.getLogger(KeyedHashTest.class);
-
-  @Test
-  public void testKeyedHash()
-  {
-    logger.info("Starting testKeyedHash: ");
-
-    int hash1 = KeyedHash.hash("someKey", 12, "someInput");
-    logger.info("hash1 = " + hash1 + " hash1 = " + Integer.toString(hash1, 2));
-
-    int hash2 = KeyedHash.hash("someKey", 32, "someInput");
-    logger.info("hash2 = " + hash2 + " hash2 = " + Integer.toString(hash2, 2));
-
-    int hash3 = KeyedHash.hash("someKey", 34, "someInput");
-    logger.info("hash3 = " + hash3 + " hash3 = " + Integer.toString(hash3, 2));
-
-    assertEquals(hash2, hash3);
-    assertEquals(hash1, hash2 & 0xFFF);
-
-    logger.info("Successfully completed testKeyedHash");
-  }
-
-  @Test
-  public void testKeyedHashWithType()
-  {
-    testKeyedHashType("MD5");
-    testKeyedHashType("SHA-1");
-    testKeyedHashType("SHA-256");
-    testKeyedHashType("FAKE-HASH-TYPE");
-  }
-
-  private void testKeyedHashType(String type)
-  {
-    logger.info("Starting testKeyedHashType with type: " + type);
-
-    int hash1 = KeyedHash.hash("someKey", 12, "someInput", type);
-    logger.info("hash1 = " + hash1 + " hash1 = " + Integer.toString(hash1, 2));
-
-    int hash2 = KeyedHash.hash("someKey", 32, "someInput", type);
-    logger.info("hash2 = " + hash2 + " hash2 = " + Integer.toString(hash2, 2));
-
-    int hash3 = KeyedHash.hash("someKey", 34, "someInput", type);
-    logger.info("hash3 = " + hash3 + " hash3 = " + Integer.toString(hash3, 2));
-
-    assertEquals(hash2, hash3);
-    assertEquals(hash1, hash2 & 0xFFF);
-
-    logger.info("Successfully completed testKeyedHashType with type: " + type);
-  }
-}


[6/9] incubator-pirk git commit: [PIRK-37]: Rename package for test classes to be org.apache.pirk.* -- closes apache/incubator-pirk#39

Posted by ea...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/package-tree.html b/docs/org/apache/pirk/inputformat/hadoop/package-tree.html
index 55973ff..41f6212 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/package-tree.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.inputformat.hadoop Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -36,7 +36,7 @@
 </div>
 <div class="subNav">
 <ul class="navList">
-<li><a href="../../../../../org/apache/pirk/encryption/package-tree.html">Prev</a></li>
+<li><a href="../../../../../org/apache/pirk/general/package-tree.html">Prev</a></li>
 <li><a href="../../../../../org/apache/pirk/inputformat/hadoop/json/package-tree.html">Next</a></li>
 </ul>
 <ul class="navList">
@@ -109,7 +109,7 @@
 </div>
 <div class="subNav">
 <ul class="navList">
-<li><a href="../../../../../org/apache/pirk/encryption/package-tree.html">Prev</a></li>
+<li><a href="../../../../../org/apache/pirk/general/package-tree.html">Prev</a></li>
 <li><a href="../../../../../org/apache/pirk/inputformat/hadoop/json/package-tree.html">Next</a></li>
 </ul>
 <ul class="navList">

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/package-use.html b/docs/org/apache/pirk/inputformat/hadoop/package-use.html
index a2a8237..baa70c7 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/package-use.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.inputformat.hadoop</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/Querier.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/Querier.html b/docs/org/apache/pirk/querier/wideskies/Querier.html
index 72706b0..a8d81d8 100644
--- a/docs/org/apache/pirk/querier/wideskies/Querier.html
+++ b/docs/org/apache/pirk/querier/wideskies/Querier.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>Querier</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/QuerierConst.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/QuerierConst.html b/docs/org/apache/pirk/querier/wideskies/QuerierConst.html
index 03f44f8..00a04a5 100644
--- a/docs/org/apache/pirk/querier/wideskies/QuerierConst.html
+++ b/docs/org/apache/pirk/querier/wideskies/QuerierConst.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>QuerierConst</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/QuerierDriver.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/QuerierDriver.html b/docs/org/apache/pirk/querier/wideskies/QuerierDriver.html
index f9f2563..00cf14b 100644
--- a/docs/org/apache/pirk/querier/wideskies/QuerierDriver.html
+++ b/docs/org/apache/pirk/querier/wideskies/QuerierDriver.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>QuerierDriver</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/QuerierDriverCLI.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/QuerierDriverCLI.html b/docs/org/apache/pirk/querier/wideskies/QuerierDriverCLI.html
index 5ca1cd7..9adf6eb 100644
--- a/docs/org/apache/pirk/querier/wideskies/QuerierDriverCLI.html
+++ b/docs/org/apache/pirk/querier/wideskies/QuerierDriverCLI.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>QuerierDriverCLI</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/QuerierProps.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/QuerierProps.html b/docs/org/apache/pirk/querier/wideskies/QuerierProps.html
index 4fac99e..ed82812 100644
--- a/docs/org/apache/pirk/querier/wideskies/QuerierProps.html
+++ b/docs/org/apache/pirk/querier/wideskies/QuerierProps.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>QuerierProps</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/class-use/Querier.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/class-use/Querier.html b/docs/org/apache/pirk/querier/wideskies/class-use/Querier.html
index 3c19fec..ff8e333 100644
--- a/docs/org/apache/pirk/querier/wideskies/class-use/Querier.html
+++ b/docs/org/apache/pirk/querier/wideskies/class-use/Querier.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.querier.wideskies.Querier</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/class-use/QuerierConst.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/class-use/QuerierConst.html b/docs/org/apache/pirk/querier/wideskies/class-use/QuerierConst.html
index 825f893..40fff0b 100644
--- a/docs/org/apache/pirk/querier/wideskies/class-use/QuerierConst.html
+++ b/docs/org/apache/pirk/querier/wideskies/class-use/QuerierConst.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.querier.wideskies.QuerierConst</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/class-use/QuerierDriver.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/class-use/QuerierDriver.html b/docs/org/apache/pirk/querier/wideskies/class-use/QuerierDriver.html
index 97f75c5..83fc433 100644
--- a/docs/org/apache/pirk/querier/wideskies/class-use/QuerierDriver.html
+++ b/docs/org/apache/pirk/querier/wideskies/class-use/QuerierDriver.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.querier.wideskies.QuerierDriver</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/class-use/QuerierDriverCLI.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/class-use/QuerierDriverCLI.html b/docs/org/apache/pirk/querier/wideskies/class-use/QuerierDriverCLI.html
index 0c0347e..96a2aa3 100644
--- a/docs/org/apache/pirk/querier/wideskies/class-use/QuerierDriverCLI.html
+++ b/docs/org/apache/pirk/querier/wideskies/class-use/QuerierDriverCLI.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.querier.wideskies.QuerierDriverCLI</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/class-use/QuerierProps.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/class-use/QuerierProps.html b/docs/org/apache/pirk/querier/wideskies/class-use/QuerierProps.html
index 4735faf..0c93abc 100644
--- a/docs/org/apache/pirk/querier/wideskies/class-use/QuerierProps.html
+++ b/docs/org/apache/pirk/querier/wideskies/class-use/QuerierProps.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.querier.wideskies.QuerierProps</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/decrypt/DecryptResponse.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/decrypt/DecryptResponse.html b/docs/org/apache/pirk/querier/wideskies/decrypt/DecryptResponse.html
index 7d94051..151e8bb 100644
--- a/docs/org/apache/pirk/querier/wideskies/decrypt/DecryptResponse.html
+++ b/docs/org/apache/pirk/querier/wideskies/decrypt/DecryptResponse.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>DecryptResponse</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/decrypt/DecryptResponseRunnable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/decrypt/DecryptResponseRunnable.html b/docs/org/apache/pirk/querier/wideskies/decrypt/DecryptResponseRunnable.html
index 5398e79..a58af01 100644
--- a/docs/org/apache/pirk/querier/wideskies/decrypt/DecryptResponseRunnable.html
+++ b/docs/org/apache/pirk/querier/wideskies/decrypt/DecryptResponseRunnable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>DecryptResponseRunnable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/decrypt/class-use/DecryptResponse.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/decrypt/class-use/DecryptResponse.html b/docs/org/apache/pirk/querier/wideskies/decrypt/class-use/DecryptResponse.html
index 22c1062..368daab 100644
--- a/docs/org/apache/pirk/querier/wideskies/decrypt/class-use/DecryptResponse.html
+++ b/docs/org/apache/pirk/querier/wideskies/decrypt/class-use/DecryptResponse.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.querier.wideskies.decrypt.DecryptResponse</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/decrypt/class-use/DecryptResponseRunnable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/decrypt/class-use/DecryptResponseRunnable.html b/docs/org/apache/pirk/querier/wideskies/decrypt/class-use/DecryptResponseRunnable.html
index 149b0a6..5b6a490 100644
--- a/docs/org/apache/pirk/querier/wideskies/decrypt/class-use/DecryptResponseRunnable.html
+++ b/docs/org/apache/pirk/querier/wideskies/decrypt/class-use/DecryptResponseRunnable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.querier.wideskies.decrypt.DecryptResponseRunnable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/decrypt/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/decrypt/package-frame.html b/docs/org/apache/pirk/querier/wideskies/decrypt/package-frame.html
index 7fe3d80..fccca54 100644
--- a/docs/org/apache/pirk/querier/wideskies/decrypt/package-frame.html
+++ b/docs/org/apache/pirk/querier/wideskies/decrypt/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.querier.wideskies.decrypt</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/decrypt/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/decrypt/package-summary.html b/docs/org/apache/pirk/querier/wideskies/decrypt/package-summary.html
index 6acc86b..6ce032c 100644
--- a/docs/org/apache/pirk/querier/wideskies/decrypt/package-summary.html
+++ b/docs/org/apache/pirk/querier/wideskies/decrypt/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.querier.wideskies.decrypt</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/decrypt/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/decrypt/package-tree.html b/docs/org/apache/pirk/querier/wideskies/decrypt/package-tree.html
index 75b37c0..c5cf9c8 100644
--- a/docs/org/apache/pirk/querier/wideskies/decrypt/package-tree.html
+++ b/docs/org/apache/pirk/querier/wideskies/decrypt/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.querier.wideskies.decrypt Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/decrypt/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/decrypt/package-use.html b/docs/org/apache/pirk/querier/wideskies/decrypt/package-use.html
index 0e8d6b0..eb51065 100644
--- a/docs/org/apache/pirk/querier/wideskies/decrypt/package-use.html
+++ b/docs/org/apache/pirk/querier/wideskies/decrypt/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.querier.wideskies.decrypt</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/encrypt/EncryptQuery.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/encrypt/EncryptQuery.html b/docs/org/apache/pirk/querier/wideskies/encrypt/EncryptQuery.html
index d3a1381..0480fa5 100644
--- a/docs/org/apache/pirk/querier/wideskies/encrypt/EncryptQuery.html
+++ b/docs/org/apache/pirk/querier/wideskies/encrypt/EncryptQuery.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>EncryptQuery</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/encrypt/EncryptQueryRunnable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/encrypt/EncryptQueryRunnable.html b/docs/org/apache/pirk/querier/wideskies/encrypt/EncryptQueryRunnable.html
index d47e8c9..e61ca56 100644
--- a/docs/org/apache/pirk/querier/wideskies/encrypt/EncryptQueryRunnable.html
+++ b/docs/org/apache/pirk/querier/wideskies/encrypt/EncryptQueryRunnable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>EncryptQueryRunnable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/encrypt/ExpTableRunnable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/encrypt/ExpTableRunnable.html b/docs/org/apache/pirk/querier/wideskies/encrypt/ExpTableRunnable.html
index 2e6995d..fb4ab35 100644
--- a/docs/org/apache/pirk/querier/wideskies/encrypt/ExpTableRunnable.html
+++ b/docs/org/apache/pirk/querier/wideskies/encrypt/ExpTableRunnable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>ExpTableRunnable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/EncryptQuery.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/EncryptQuery.html b/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/EncryptQuery.html
index 623a27c..425164e 100644
--- a/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/EncryptQuery.html
+++ b/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/EncryptQuery.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.querier.wideskies.encrypt.EncryptQuery</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/EncryptQueryRunnable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/EncryptQueryRunnable.html b/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/EncryptQueryRunnable.html
index bcd6092..8743c35 100644
--- a/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/EncryptQueryRunnable.html
+++ b/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/EncryptQueryRunnable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.querier.wideskies.encrypt.EncryptQueryRunnable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/ExpTableRunnable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/ExpTableRunnable.html b/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/ExpTableRunnable.html
index a3253b6..1b6bdb4 100644
--- a/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/ExpTableRunnable.html
+++ b/docs/org/apache/pirk/querier/wideskies/encrypt/class-use/ExpTableRunnable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.querier.wideskies.encrypt.ExpTableRunnable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/encrypt/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/encrypt/package-frame.html b/docs/org/apache/pirk/querier/wideskies/encrypt/package-frame.html
index 0567885..10c64cc 100644
--- a/docs/org/apache/pirk/querier/wideskies/encrypt/package-frame.html
+++ b/docs/org/apache/pirk/querier/wideskies/encrypt/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.querier.wideskies.encrypt</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/encrypt/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/encrypt/package-summary.html b/docs/org/apache/pirk/querier/wideskies/encrypt/package-summary.html
index a50e824..918ab82 100644
--- a/docs/org/apache/pirk/querier/wideskies/encrypt/package-summary.html
+++ b/docs/org/apache/pirk/querier/wideskies/encrypt/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.querier.wideskies.encrypt</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/encrypt/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/encrypt/package-tree.html b/docs/org/apache/pirk/querier/wideskies/encrypt/package-tree.html
index b57312e..939910b 100644
--- a/docs/org/apache/pirk/querier/wideskies/encrypt/package-tree.html
+++ b/docs/org/apache/pirk/querier/wideskies/encrypt/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.querier.wideskies.encrypt Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/encrypt/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/encrypt/package-use.html b/docs/org/apache/pirk/querier/wideskies/encrypt/package-use.html
index a437d01..ec98f7f 100644
--- a/docs/org/apache/pirk/querier/wideskies/encrypt/package-use.html
+++ b/docs/org/apache/pirk/querier/wideskies/encrypt/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.querier.wideskies.encrypt</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/package-frame.html b/docs/org/apache/pirk/querier/wideskies/package-frame.html
index a6ddac7..f44a061 100644
--- a/docs/org/apache/pirk/querier/wideskies/package-frame.html
+++ b/docs/org/apache/pirk/querier/wideskies/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.querier.wideskies</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/package-summary.html b/docs/org/apache/pirk/querier/wideskies/package-summary.html
index 885e8d9..7fd9865 100644
--- a/docs/org/apache/pirk/querier/wideskies/package-summary.html
+++ b/docs/org/apache/pirk/querier/wideskies/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.querier.wideskies</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/package-tree.html b/docs/org/apache/pirk/querier/wideskies/package-tree.html
index c597cd4..a83ebca 100644
--- a/docs/org/apache/pirk/querier/wideskies/package-tree.html
+++ b/docs/org/apache/pirk/querier/wideskies/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.querier.wideskies Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/querier/wideskies/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/querier/wideskies/package-use.html b/docs/org/apache/pirk/querier/wideskies/package-use.html
index 0a60120..d79ac85 100644
--- a/docs/org/apache/pirk/querier/wideskies/package-use.html
+++ b/docs/org/apache/pirk/querier/wideskies/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.querier.wideskies</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/query/wideskies/Query.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/query/wideskies/Query.html b/docs/org/apache/pirk/query/wideskies/Query.html
index a7a3bd1..a3638ff 100644
--- a/docs/org/apache/pirk/query/wideskies/Query.html
+++ b/docs/org/apache/pirk/query/wideskies/Query.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>Query</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/query/wideskies/QueryInfo.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/query/wideskies/QueryInfo.html b/docs/org/apache/pirk/query/wideskies/QueryInfo.html
index 0c0570f..107c1bf 100644
--- a/docs/org/apache/pirk/query/wideskies/QueryInfo.html
+++ b/docs/org/apache/pirk/query/wideskies/QueryInfo.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>QueryInfo</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/query/wideskies/QueryUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/query/wideskies/QueryUtils.html b/docs/org/apache/pirk/query/wideskies/QueryUtils.html
index f653d34..67ebd67 100644
--- a/docs/org/apache/pirk/query/wideskies/QueryUtils.html
+++ b/docs/org/apache/pirk/query/wideskies/QueryUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>QueryUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/query/wideskies/class-use/Query.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/query/wideskies/class-use/Query.html b/docs/org/apache/pirk/query/wideskies/class-use/Query.html
index 34222d3..c3c318a 100644
--- a/docs/org/apache/pirk/query/wideskies/class-use/Query.html
+++ b/docs/org/apache/pirk/query/wideskies/class-use/Query.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.query.wideskies.Query</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/query/wideskies/class-use/QueryInfo.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/query/wideskies/class-use/QueryInfo.html b/docs/org/apache/pirk/query/wideskies/class-use/QueryInfo.html
index d79c7a2..cdcad12 100644
--- a/docs/org/apache/pirk/query/wideskies/class-use/QueryInfo.html
+++ b/docs/org/apache/pirk/query/wideskies/class-use/QueryInfo.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.query.wideskies.QueryInfo</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/query/wideskies/class-use/QueryUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/query/wideskies/class-use/QueryUtils.html b/docs/org/apache/pirk/query/wideskies/class-use/QueryUtils.html
index e32cc47..332f469 100644
--- a/docs/org/apache/pirk/query/wideskies/class-use/QueryUtils.html
+++ b/docs/org/apache/pirk/query/wideskies/class-use/QueryUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.query.wideskies.QueryUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/query/wideskies/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/query/wideskies/package-frame.html b/docs/org/apache/pirk/query/wideskies/package-frame.html
index e6816b8..ba47e93 100644
--- a/docs/org/apache/pirk/query/wideskies/package-frame.html
+++ b/docs/org/apache/pirk/query/wideskies/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.query.wideskies</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/query/wideskies/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/query/wideskies/package-summary.html b/docs/org/apache/pirk/query/wideskies/package-summary.html
index 29728ed..f294061 100644
--- a/docs/org/apache/pirk/query/wideskies/package-summary.html
+++ b/docs/org/apache/pirk/query/wideskies/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.query.wideskies</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/query/wideskies/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/query/wideskies/package-tree.html b/docs/org/apache/pirk/query/wideskies/package-tree.html
index 70642c6..b0c311a 100644
--- a/docs/org/apache/pirk/query/wideskies/package-tree.html
+++ b/docs/org/apache/pirk/query/wideskies/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.query.wideskies Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/query/wideskies/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/query/wideskies/package-use.html b/docs/org/apache/pirk/query/wideskies/package-use.html
index b408ea2..e62141d 100644
--- a/docs/org/apache/pirk/query/wideskies/package-use.html
+++ b/docs/org/apache/pirk/query/wideskies/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.query.wideskies</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/ResponderCLI.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/ResponderCLI.html b/docs/org/apache/pirk/responder/wideskies/ResponderCLI.html
index d6c275d..6264e68 100644
--- a/docs/org/apache/pirk/responder/wideskies/ResponderCLI.html
+++ b/docs/org/apache/pirk/responder/wideskies/ResponderCLI.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>ResponderCLI</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/ResponderDriver.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/ResponderDriver.html b/docs/org/apache/pirk/responder/wideskies/ResponderDriver.html
index 16bdd77..c5aa3fb 100644
--- a/docs/org/apache/pirk/responder/wideskies/ResponderDriver.html
+++ b/docs/org/apache/pirk/responder/wideskies/ResponderDriver.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>ResponderDriver</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/ResponderProps.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/ResponderProps.html b/docs/org/apache/pirk/responder/wideskies/ResponderProps.html
index 42f691b..937479a 100644
--- a/docs/org/apache/pirk/responder/wideskies/ResponderProps.html
+++ b/docs/org/apache/pirk/responder/wideskies/ResponderProps.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>ResponderProps</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/class-use/ResponderCLI.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/class-use/ResponderCLI.html b/docs/org/apache/pirk/responder/wideskies/class-use/ResponderCLI.html
index 13da48e..4275151 100644
--- a/docs/org/apache/pirk/responder/wideskies/class-use/ResponderCLI.html
+++ b/docs/org/apache/pirk/responder/wideskies/class-use/ResponderCLI.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.ResponderCLI</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/class-use/ResponderDriver.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/class-use/ResponderDriver.html b/docs/org/apache/pirk/responder/wideskies/class-use/ResponderDriver.html
index e75e839..8929baf 100644
--- a/docs/org/apache/pirk/responder/wideskies/class-use/ResponderDriver.html
+++ b/docs/org/apache/pirk/responder/wideskies/class-use/ResponderDriver.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.ResponderDriver</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/class-use/ResponderProps.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/class-use/ResponderProps.html b/docs/org/apache/pirk/responder/wideskies/class-use/ResponderProps.html
index 7902afa..2d01f09 100644
--- a/docs/org/apache/pirk/responder/wideskies/class-use/ResponderProps.html
+++ b/docs/org/apache/pirk/responder/wideskies/class-use/ResponderProps.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.ResponderProps</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/common/ComputeEncryptedRow.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/common/ComputeEncryptedRow.html b/docs/org/apache/pirk/responder/wideskies/common/ComputeEncryptedRow.html
index 2edb089..b75572c 100644
--- a/docs/org/apache/pirk/responder/wideskies/common/ComputeEncryptedRow.html
+++ b/docs/org/apache/pirk/responder/wideskies/common/ComputeEncryptedRow.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>ComputeEncryptedRow</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/common/HashSelectorAndPartitionData.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/common/HashSelectorAndPartitionData.html b/docs/org/apache/pirk/responder/wideskies/common/HashSelectorAndPartitionData.html
index 5e2b18c..55d6bef 100644
--- a/docs/org/apache/pirk/responder/wideskies/common/HashSelectorAndPartitionData.html
+++ b/docs/org/apache/pirk/responder/wideskies/common/HashSelectorAndPartitionData.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>HashSelectorAndPartitionData</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/common/class-use/ComputeEncryptedRow.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/common/class-use/ComputeEncryptedRow.html b/docs/org/apache/pirk/responder/wideskies/common/class-use/ComputeEncryptedRow.html
index 1df9ecd..3414710 100644
--- a/docs/org/apache/pirk/responder/wideskies/common/class-use/ComputeEncryptedRow.html
+++ b/docs/org/apache/pirk/responder/wideskies/common/class-use/ComputeEncryptedRow.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.common.ComputeEncryptedRow</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/common/class-use/HashSelectorAndPartitionData.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/common/class-use/HashSelectorAndPartitionData.html b/docs/org/apache/pirk/responder/wideskies/common/class-use/HashSelectorAndPartitionData.html
index 8534356..7017efc 100644
--- a/docs/org/apache/pirk/responder/wideskies/common/class-use/HashSelectorAndPartitionData.html
+++ b/docs/org/apache/pirk/responder/wideskies/common/class-use/HashSelectorAndPartitionData.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.common.HashSelectorAndPartitionData</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/common/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/common/package-frame.html b/docs/org/apache/pirk/responder/wideskies/common/package-frame.html
index 632f01e..0161254 100644
--- a/docs/org/apache/pirk/responder/wideskies/common/package-frame.html
+++ b/docs/org/apache/pirk/responder/wideskies/common/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies.common</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/common/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/common/package-summary.html b/docs/org/apache/pirk/responder/wideskies/common/package-summary.html
index 957675a..59cf0f1 100644
--- a/docs/org/apache/pirk/responder/wideskies/common/package-summary.html
+++ b/docs/org/apache/pirk/responder/wideskies/common/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies.common</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/common/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/common/package-tree.html b/docs/org/apache/pirk/responder/wideskies/common/package-tree.html
index a125f98..3b6b5a2 100644
--- a/docs/org/apache/pirk/responder/wideskies/common/package-tree.html
+++ b/docs/org/apache/pirk/responder/wideskies/common/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies.common Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/common/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/common/package-use.html b/docs/org/apache/pirk/responder/wideskies/common/package-use.html
index e435b8c..f96f94d 100644
--- a/docs/org/apache/pirk/responder/wideskies/common/package-use.html
+++ b/docs/org/apache/pirk/responder/wideskies/common/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.responder.wideskies.common</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/ColumnMultMapper.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/ColumnMultMapper.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/ColumnMultMapper.html
index 5921842..47b6c59 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/ColumnMultMapper.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/ColumnMultMapper.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>ColumnMultMapper</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/ColumnMultReducer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/ColumnMultReducer.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/ColumnMultReducer.html
index 18385e9..8eaa4fa 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/ColumnMultReducer.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/ColumnMultReducer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>ColumnMultReducer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/ComputeResponseTool.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/ComputeResponseTool.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/ComputeResponseTool.html
index e61deaa..accdb44 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/ComputeResponseTool.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/ComputeResponseTool.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>ComputeResponseTool</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/ExpTableMapper.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/ExpTableMapper.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/ExpTableMapper.html
index 04d8443..687c1b3 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/ExpTableMapper.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/ExpTableMapper.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>ExpTableMapper</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/ExpTableReducer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/ExpTableReducer.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/ExpTableReducer.html
index 44b6983..ba5f286 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/ExpTableReducer.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/ExpTableReducer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>ExpTableReducer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/FinalResponseReducer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/FinalResponseReducer.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/FinalResponseReducer.html
index 4abd458..e8be7ee 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/FinalResponseReducer.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/FinalResponseReducer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>FinalResponseReducer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/HashSelectorsAndPartitionDataMapper.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/HashSelectorsAndPartitionDataMapper.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/HashSelectorsAndPartitionDataMapper.html
index a04daa1..4761dab 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/HashSelectorsAndPartitionDataMapper.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/HashSelectorsAndPartitionDataMapper.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>HashSelectorsAndPartitionDataMapper</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/MRStats.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/MRStats.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/MRStats.html
index 46502c0..6fb9899 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/MRStats.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/MRStats.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>MRStats</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/RowCalcReducer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/RowCalcReducer.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/RowCalcReducer.html
index c0c6aef..5e503b8 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/RowCalcReducer.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/RowCalcReducer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>RowCalcReducer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ColumnMultMapper.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ColumnMultMapper.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ColumnMultMapper.html
index ef493e9..6933f6d 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ColumnMultMapper.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ColumnMultMapper.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.mapreduce.ColumnMultMapper</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ColumnMultReducer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ColumnMultReducer.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ColumnMultReducer.html
index b1fd366..ebbed3c 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ColumnMultReducer.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ColumnMultReducer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.mapreduce.ColumnMultReducer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ComputeResponseTool.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ComputeResponseTool.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ComputeResponseTool.html
index 0750145..de55075 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ComputeResponseTool.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ComputeResponseTool.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.mapreduce.ComputeResponseTool</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ExpTableMapper.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ExpTableMapper.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ExpTableMapper.html
index 55bd47d..c45ea85 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ExpTableMapper.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ExpTableMapper.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.mapreduce.ExpTableMapper</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ExpTableReducer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ExpTableReducer.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ExpTableReducer.html
index a228710..040bd97 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ExpTableReducer.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/ExpTableReducer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.mapreduce.ExpTableReducer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/FinalResponseReducer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/FinalResponseReducer.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/FinalResponseReducer.html
index 82c6135..171612b 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/FinalResponseReducer.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/FinalResponseReducer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.mapreduce.FinalResponseReducer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/HashSelectorsAndPartitionDataMapper.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/HashSelectorsAndPartitionDataMapper.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/HashSelectorsAndPartitionDataMapper.html
index c00583d..8d45cc3 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/HashSelectorsAndPartitionDataMapper.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/HashSelectorsAndPartitionDataMapper.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.mapreduce.HashSelectorsAndPartitionDataMapper</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/MRStats.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/MRStats.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/MRStats.html
index 71c4cd5..01f7448 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/MRStats.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/MRStats.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.mapreduce.MRStats</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/RowCalcReducer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/RowCalcReducer.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/RowCalcReducer.html
index 808a506..a189c7d 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/RowCalcReducer.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/class-use/RowCalcReducer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.mapreduce.RowCalcReducer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/package-frame.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/package-frame.html
index 2661597..1b3c293 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/package-frame.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies.mapreduce</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/package-summary.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/package-summary.html
index 9cf9ac5..932a330 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/package-summary.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies.mapreduce</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/package-tree.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/package-tree.html
index e5e80c9..fc8cd9e 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/package-tree.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies.mapreduce Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/mapreduce/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/mapreduce/package-use.html b/docs/org/apache/pirk/responder/wideskies/mapreduce/package-use.html
index 83c6bdd..e43db99 100644
--- a/docs/org/apache/pirk/responder/wideskies/mapreduce/package-use.html
+++ b/docs/org/apache/pirk/responder/wideskies/mapreduce/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.responder.wideskies.mapreduce</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/package-frame.html b/docs/org/apache/pirk/responder/wideskies/package-frame.html
index c1dc93d..4af049d 100644
--- a/docs/org/apache/pirk/responder/wideskies/package-frame.html
+++ b/docs/org/apache/pirk/responder/wideskies/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/package-summary.html b/docs/org/apache/pirk/responder/wideskies/package-summary.html
index ac440c9..875c0bb 100644
--- a/docs/org/apache/pirk/responder/wideskies/package-summary.html
+++ b/docs/org/apache/pirk/responder/wideskies/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/package-tree.html b/docs/org/apache/pirk/responder/wideskies/package-tree.html
index a7ce78f..9cd66d3 100644
--- a/docs/org/apache/pirk/responder/wideskies/package-tree.html
+++ b/docs/org/apache/pirk/responder/wideskies/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/package-use.html b/docs/org/apache/pirk/responder/wideskies/package-use.html
index bfd146b..f897a0a 100644
--- a/docs/org/apache/pirk/responder/wideskies/package-use.html
+++ b/docs/org/apache/pirk/responder/wideskies/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.responder.wideskies</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/Accumulators.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/Accumulators.html b/docs/org/apache/pirk/responder/wideskies/spark/Accumulators.html
index 1de1b73..45c759e 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/Accumulators.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/Accumulators.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>Accumulators</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/BroadcastVars.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/BroadcastVars.html b/docs/org/apache/pirk/responder/wideskies/spark/BroadcastVars.html
index 0445427..a26321c 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/BroadcastVars.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/BroadcastVars.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>BroadcastVars</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/ComputeExpLookupTable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/ComputeExpLookupTable.html b/docs/org/apache/pirk/responder/wideskies/spark/ComputeExpLookupTable.html
index c01b297..b9da90c 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/ComputeExpLookupTable.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/ComputeExpLookupTable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>ComputeExpLookupTable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>



[5/9] incubator-pirk git commit: [PIRK-37]: Rename package for test classes to be org.apache.pirk.* -- closes apache/incubator-pirk#39

Posted by ea...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/ComputeResponse.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/ComputeResponse.html b/docs/org/apache/pirk/responder/wideskies/spark/ComputeResponse.html
index e6d087f..c72941d 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/ComputeResponse.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/ComputeResponse.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>ComputeResponse</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/EncColMultGroupedMapper.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/EncColMultGroupedMapper.html b/docs/org/apache/pirk/responder/wideskies/spark/EncColMultGroupedMapper.html
index 2eda1eb..0cd256b 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/EncColMultGroupedMapper.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/EncColMultGroupedMapper.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>EncColMultGroupedMapper</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/EncColMultReducer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/EncColMultReducer.html b/docs/org/apache/pirk/responder/wideskies/spark/EncColMultReducer.html
index 2d7803a..957998c 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/EncColMultReducer.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/EncColMultReducer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>EncColMultReducer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/EncRowCalc.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/EncRowCalc.html b/docs/org/apache/pirk/responder/wideskies/spark/EncRowCalc.html
index 8cd40bc..4eba9e5 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/EncRowCalc.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/EncRowCalc.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>EncRowCalc</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/EncRowCalcPrecomputedCache.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/EncRowCalcPrecomputedCache.html b/docs/org/apache/pirk/responder/wideskies/spark/EncRowCalcPrecomputedCache.html
index 5866d1b..6b78403 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/EncRowCalcPrecomputedCache.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/EncRowCalcPrecomputedCache.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>EncRowCalcPrecomputedCache</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/ExpKeyFilenameMap.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/ExpKeyFilenameMap.html b/docs/org/apache/pirk/responder/wideskies/spark/ExpKeyFilenameMap.html
index 3935af5..7983987 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/ExpKeyFilenameMap.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/ExpKeyFilenameMap.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>ExpKeyFilenameMap</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/ExpTableGenerator.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/ExpTableGenerator.html b/docs/org/apache/pirk/responder/wideskies/spark/ExpTableGenerator.html
index 79fad7e..d925773 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/ExpTableGenerator.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/ExpTableGenerator.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>ExpTableGenerator</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/FilterData.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/FilterData.html b/docs/org/apache/pirk/responder/wideskies/spark/FilterData.html
index 09726a2..84717b6 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/FilterData.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/FilterData.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>FilterData</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/HashSelectorsAndPartitionData.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/HashSelectorsAndPartitionData.html b/docs/org/apache/pirk/responder/wideskies/spark/HashSelectorsAndPartitionData.html
index 7981858..002c57e 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/HashSelectorsAndPartitionData.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/HashSelectorsAndPartitionData.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>HashSelectorsAndPartitionData</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/class-use/Accumulators.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/class-use/Accumulators.html b/docs/org/apache/pirk/responder/wideskies/spark/class-use/Accumulators.html
index 47cd34d..80283e4 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/class-use/Accumulators.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/class-use/Accumulators.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.spark.Accumulators</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/class-use/BroadcastVars.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/class-use/BroadcastVars.html b/docs/org/apache/pirk/responder/wideskies/spark/class-use/BroadcastVars.html
index e42ec1c..c5fa4ed 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/class-use/BroadcastVars.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/class-use/BroadcastVars.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.spark.BroadcastVars</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/class-use/ComputeExpLookupTable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/class-use/ComputeExpLookupTable.html b/docs/org/apache/pirk/responder/wideskies/spark/class-use/ComputeExpLookupTable.html
index 1cbdef4..274c7ab 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/class-use/ComputeExpLookupTable.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/class-use/ComputeExpLookupTable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.spark.ComputeExpLookupTable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/class-use/ComputeResponse.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/class-use/ComputeResponse.html b/docs/org/apache/pirk/responder/wideskies/spark/class-use/ComputeResponse.html
index 8ac65c4..93cd418 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/class-use/ComputeResponse.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/class-use/ComputeResponse.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.spark.ComputeResponse</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncColMultGroupedMapper.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncColMultGroupedMapper.html b/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncColMultGroupedMapper.html
index b309036..e79a0bb 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncColMultGroupedMapper.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncColMultGroupedMapper.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.spark.EncColMultGroupedMapper</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncColMultReducer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncColMultReducer.html b/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncColMultReducer.html
index 88e29a8..ec98743 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncColMultReducer.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncColMultReducer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.spark.EncColMultReducer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncRowCalc.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncRowCalc.html b/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncRowCalc.html
index cf0a24c..27347d4 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncRowCalc.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncRowCalc.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.spark.EncRowCalc</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncRowCalcPrecomputedCache.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncRowCalcPrecomputedCache.html b/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncRowCalcPrecomputedCache.html
index 7f12435..2a0f501 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncRowCalcPrecomputedCache.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/class-use/EncRowCalcPrecomputedCache.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.spark.EncRowCalcPrecomputedCache</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/class-use/ExpKeyFilenameMap.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/class-use/ExpKeyFilenameMap.html b/docs/org/apache/pirk/responder/wideskies/spark/class-use/ExpKeyFilenameMap.html
index 9229f43..8a32b36 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/class-use/ExpKeyFilenameMap.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/class-use/ExpKeyFilenameMap.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.spark.ExpKeyFilenameMap</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/class-use/ExpTableGenerator.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/class-use/ExpTableGenerator.html b/docs/org/apache/pirk/responder/wideskies/spark/class-use/ExpTableGenerator.html
index 5c33549..fa161aa 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/class-use/ExpTableGenerator.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/class-use/ExpTableGenerator.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.spark.ExpTableGenerator</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/class-use/FilterData.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/class-use/FilterData.html b/docs/org/apache/pirk/responder/wideskies/spark/class-use/FilterData.html
index 2843d12..c661881 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/class-use/FilterData.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/class-use/FilterData.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.spark.FilterData</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/class-use/HashSelectorsAndPartitionData.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/class-use/HashSelectorsAndPartitionData.html b/docs/org/apache/pirk/responder/wideskies/spark/class-use/HashSelectorsAndPartitionData.html
index d1d1618..504eeb1 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/class-use/HashSelectorsAndPartitionData.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/class-use/HashSelectorsAndPartitionData.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.spark.HashSelectorsAndPartitionData</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/package-frame.html b/docs/org/apache/pirk/responder/wideskies/spark/package-frame.html
index d2059b5..72218ed 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/package-frame.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies.spark</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/package-summary.html b/docs/org/apache/pirk/responder/wideskies/spark/package-summary.html
index 0a12d33..a3f2556 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/package-summary.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies.spark</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/package-tree.html b/docs/org/apache/pirk/responder/wideskies/spark/package-tree.html
index a4f81fb..20939c3 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/package-tree.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies.spark Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/spark/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/spark/package-use.html b/docs/org/apache/pirk/responder/wideskies/spark/package-use.html
index 109ff6d..52e8303 100644
--- a/docs/org/apache/pirk/responder/wideskies/spark/package-use.html
+++ b/docs/org/apache/pirk/responder/wideskies/spark/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.responder.wideskies.spark</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/standalone/Responder.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/standalone/Responder.html b/docs/org/apache/pirk/responder/wideskies/standalone/Responder.html
index 9e57dea..66477c6 100644
--- a/docs/org/apache/pirk/responder/wideskies/standalone/Responder.html
+++ b/docs/org/apache/pirk/responder/wideskies/standalone/Responder.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>Responder</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/standalone/class-use/Responder.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/standalone/class-use/Responder.html b/docs/org/apache/pirk/responder/wideskies/standalone/class-use/Responder.html
index a3bb2b6..80c1600 100644
--- a/docs/org/apache/pirk/responder/wideskies/standalone/class-use/Responder.html
+++ b/docs/org/apache/pirk/responder/wideskies/standalone/class-use/Responder.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.responder.wideskies.standalone.Responder</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/standalone/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/standalone/package-frame.html b/docs/org/apache/pirk/responder/wideskies/standalone/package-frame.html
index c38ea2b..03f7788 100644
--- a/docs/org/apache/pirk/responder/wideskies/standalone/package-frame.html
+++ b/docs/org/apache/pirk/responder/wideskies/standalone/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies.standalone</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/standalone/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/standalone/package-summary.html b/docs/org/apache/pirk/responder/wideskies/standalone/package-summary.html
index dec4475..2461a89 100644
--- a/docs/org/apache/pirk/responder/wideskies/standalone/package-summary.html
+++ b/docs/org/apache/pirk/responder/wideskies/standalone/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies.standalone</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/standalone/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/standalone/package-tree.html b/docs/org/apache/pirk/responder/wideskies/standalone/package-tree.html
index d211132..47f428a 100644
--- a/docs/org/apache/pirk/responder/wideskies/standalone/package-tree.html
+++ b/docs/org/apache/pirk/responder/wideskies/standalone/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.responder.wideskies.standalone Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/responder/wideskies/standalone/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/responder/wideskies/standalone/package-use.html b/docs/org/apache/pirk/responder/wideskies/standalone/package-use.html
index ce241a5..26e092c 100644
--- a/docs/org/apache/pirk/responder/wideskies/standalone/package-use.html
+++ b/docs/org/apache/pirk/responder/wideskies/standalone/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.responder.wideskies.standalone</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/response/wideskies/Response.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/response/wideskies/Response.html b/docs/org/apache/pirk/response/wideskies/Response.html
index 2f36a2e..1c4d686 100644
--- a/docs/org/apache/pirk/response/wideskies/Response.html
+++ b/docs/org/apache/pirk/response/wideskies/Response.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>Response</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/response/wideskies/class-use/Response.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/response/wideskies/class-use/Response.html b/docs/org/apache/pirk/response/wideskies/class-use/Response.html
index 80eea6a..34c0e74 100644
--- a/docs/org/apache/pirk/response/wideskies/class-use/Response.html
+++ b/docs/org/apache/pirk/response/wideskies/class-use/Response.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.response.wideskies.Response</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/response/wideskies/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/response/wideskies/package-frame.html b/docs/org/apache/pirk/response/wideskies/package-frame.html
index 9d0532a..1801588 100644
--- a/docs/org/apache/pirk/response/wideskies/package-frame.html
+++ b/docs/org/apache/pirk/response/wideskies/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.response.wideskies</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/response/wideskies/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/response/wideskies/package-summary.html b/docs/org/apache/pirk/response/wideskies/package-summary.html
index 11c5953..0d748be 100644
--- a/docs/org/apache/pirk/response/wideskies/package-summary.html
+++ b/docs/org/apache/pirk/response/wideskies/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.response.wideskies</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/response/wideskies/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/response/wideskies/package-tree.html b/docs/org/apache/pirk/response/wideskies/package-tree.html
index 8ba611c..32a56aa 100644
--- a/docs/org/apache/pirk/response/wideskies/package-tree.html
+++ b/docs/org/apache/pirk/response/wideskies/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.response.wideskies Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/response/wideskies/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/response/wideskies/package-use.html b/docs/org/apache/pirk/response/wideskies/package-use.html
index 8ce15b4..5bf8267 100644
--- a/docs/org/apache/pirk/response/wideskies/package-use.html
+++ b/docs/org/apache/pirk/response/wideskies/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.response.wideskies</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/DataSchema.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/DataSchema.html b/docs/org/apache/pirk/schema/data/DataSchema.html
index 07ce5e8..5bb2366 100644
--- a/docs/org/apache/pirk/schema/data/DataSchema.html
+++ b/docs/org/apache/pirk/schema/data/DataSchema.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>DataSchema</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/DataSchemaLoader.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/DataSchemaLoader.html b/docs/org/apache/pirk/schema/data/DataSchemaLoader.html
index b234bca..e9985eb 100644
--- a/docs/org/apache/pirk/schema/data/DataSchemaLoader.html
+++ b/docs/org/apache/pirk/schema/data/DataSchemaLoader.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>DataSchemaLoader</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/DataSchemaRegistry.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/DataSchemaRegistry.html b/docs/org/apache/pirk/schema/data/DataSchemaRegistry.html
index 05fff02..ad22835 100644
--- a/docs/org/apache/pirk/schema/data/DataSchemaRegistry.html
+++ b/docs/org/apache/pirk/schema/data/DataSchemaRegistry.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>DataSchemaRegistry</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -37,7 +37,7 @@
 <div class="subNav">
 <ul class="navList">
 <li><a href="../../../../../org/apache/pirk/schema/data/DataSchemaLoader.html" title="class in org.apache.pirk.schema.data"><span class="strong">Prev Class</span></a></li>
-<li>Next Class</li>
+<li><a href="../../../../../org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data"><span class="strong">Next Class</span></a></li>
 </ul>
 <ul class="navList">
 <li><a href="../../../../../index.html?org/apache/pirk/schema/data/DataSchemaRegistry.html" target="_top">Frames</a></li>
@@ -120,18 +120,24 @@ extends java.lang.Object</pre>
 <th class="colLast" scope="col">Method and Description</th>
 </tr>
 <tr class="altColor">
+<td class="colFirst"><code>static void</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/data/DataSchemaRegistry.html#clearRegistry()">clearRegistry</a></strong>()</code>
+<div class="block">Clear the registry</div>
+</td>
+</tr>
+<tr class="rowColor">
 <td class="colFirst"><code>static <a href="../../../../../org/apache/pirk/schema/data/DataSchema.html" title="class in org.apache.pirk.schema.data">DataSchema</a></code></td>
 <td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/data/DataSchemaRegistry.html#get(java.lang.String)">get</a></strong>(java.lang.String&nbsp;schemaName)</code>
 <div class="block">Returns the data schema with the given name.</div>
 </td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code>static java.util.Set&lt;java.lang.String&gt;</code></td>
 <td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/data/DataSchemaRegistry.html#getNames()">getNames</a></strong>()</code>
 <div class="block">Returns the set of data schema names held in the registry.</div>
 </td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>static <a href="../../../../../org/apache/pirk/schema/data/DataSchema.html" title="class in org.apache.pirk.schema.data">DataSchema</a></code></td>
 <td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/data/DataSchemaRegistry.html#put(org.apache.pirk.schema.data.DataSchema)">put</a></strong>(<a href="../../../../../org/apache/pirk/schema/data/DataSchema.html" title="class in org.apache.pirk.schema.data">DataSchema</a>&nbsp;schema)</code>
 <div class="block">Adds the given data schema to the registry.</div>
@@ -188,7 +194,7 @@ extends java.lang.Object</pre>
 <a name="getNames()">
 <!--   -->
 </a>
-<ul class="blockListLast">
+<ul class="blockList">
 <li class="blockList">
 <h4>getNames</h4>
 <pre>public static&nbsp;java.util.Set&lt;java.lang.String&gt;&nbsp;getNames()</pre>
@@ -196,6 +202,16 @@ extends java.lang.Object</pre>
 <dl><dt><span class="strong">Returns:</span></dt><dd>The possibly empty set of data schema names.</dd></dl>
 </li>
 </ul>
+<a name="clearRegistry()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>clearRegistry</h4>
+<pre>public static&nbsp;void&nbsp;clearRegistry()</pre>
+<div class="block">Clear the registry</div>
+</li>
+</ul>
 </li>
 </ul>
 </li>
@@ -223,7 +239,7 @@ extends java.lang.Object</pre>
 <div class="subNav">
 <ul class="navList">
 <li><a href="../../../../../org/apache/pirk/schema/data/DataSchemaLoader.html" title="class in org.apache.pirk.schema.data"><span class="strong">Prev Class</span></a></li>
-<li>Next Class</li>
+<li><a href="../../../../../org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data"><span class="strong">Next Class</span></a></li>
 </ul>
 <ul class="navList">
 <li><a href="../../../../../index.html?org/apache/pirk/schema/data/DataSchemaRegistry.html" target="_top">Frames</a></li>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/LoadDataSchemaTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/LoadDataSchemaTest.html b/docs/org/apache/pirk/schema/data/LoadDataSchemaTest.html
new file mode 100644
index 0000000..8e66b94
--- /dev/null
+++ b/docs/org/apache/pirk/schema/data/LoadDataSchemaTest.html
@@ -0,0 +1,292 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
+<title>LoadDataSchemaTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="LoadDataSchemaTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/LoadDataSchemaTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../../org/apache/pirk/schema/data/DataSchemaRegistry.html" title="class in org.apache.pirk.schema.data"><span class="strong">Prev Class</span></a></li>
+<li>Next Class</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/schema/data/LoadDataSchemaTest.html" target="_top">Frames</a></li>
+<li><a href="LoadDataSchemaTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<!-- ======== START OF CLASS DATA ======== -->
+<div class="header">
+<div class="subTitle">org.apache.pirk.schema.data</div>
+<h2 title="Class LoadDataSchemaTest" class="title">Class LoadDataSchemaTest</h2>
+</div>
+<div class="contentContainer">
+<ul class="inheritance">
+<li>java.lang.Object</li>
+<li>
+<ul class="inheritance">
+<li>org.apache.pirk.schema.data.LoadDataSchemaTest</li>
+</ul>
+</li>
+</ul>
+<div class="description">
+<ul class="blockList">
+<li class="blockList">
+<hr>
+<br>
+<pre>public class <span class="strong">LoadDataSchemaTest</span>
+extends java.lang.Object</pre>
+<div class="block">Test suite for LoadDataSchema and DataSchema</div>
+</li>
+</ul>
+</div>
+<div class="summary">
+<ul class="blockList">
+<li class="blockList">
+<!-- ======== CONSTRUCTOR SUMMARY ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_summary">
+<!--   -->
+</a>
+<h3>Constructor Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Constructor Summary table, listing constructors, and an explanation">
+<caption><span>Constructors</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colOne" scope="col">Constructor and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colOne"><code><strong><a href="../../../../../org/apache/pirk/schema/data/LoadDataSchemaTest.html#LoadDataSchemaTest()">LoadDataSchemaTest</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+</li>
+</ul>
+<!-- ========== METHOD SUMMARY =========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_summary">
+<!--   -->
+</a>
+<h3>Method Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Method Summary table, listing methods, and an explanation">
+<caption><span>Methods</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th class="colLast" scope="col">Method and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/data/LoadDataSchemaTest.html#testGeneralSchemaLoad()">testGeneralSchemaLoad</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/data/LoadDataSchemaTest.html#testIncorrectJavaType()">testIncorrectJavaType</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/data/LoadDataSchemaTest.html#testUnknownPartitioner()">testUnknownPartitioner</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+<ul class="blockList">
+<li class="blockList"><a name="methods_inherited_from_class_java.lang.Object">
+<!--   -->
+</a>
+<h3>Methods inherited from class&nbsp;java.lang.Object</h3>
+<code>equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait</code></li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+<div class="details">
+<ul class="blockList">
+<li class="blockList">
+<!-- ========= CONSTRUCTOR DETAIL ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_detail">
+<!--   -->
+</a>
+<h3>Constructor Detail</h3>
+<a name="LoadDataSchemaTest()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>LoadDataSchemaTest</h4>
+<pre>public&nbsp;LoadDataSchemaTest()</pre>
+</li>
+</ul>
+</li>
+</ul>
+<!-- ============ METHOD DETAIL ========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_detail">
+<!--   -->
+</a>
+<h3>Method Detail</h3>
+<a name="testGeneralSchemaLoad()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testGeneralSchemaLoad</h4>
+<pre>public&nbsp;void&nbsp;testGeneralSchemaLoad()
+                           throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+<a name="testIncorrectJavaType()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testIncorrectJavaType</h4>
+<pre>public&nbsp;void&nbsp;testIncorrectJavaType()
+                           throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+<a name="testUnknownPartitioner()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>testUnknownPartitioner</h4>
+<pre>public&nbsp;void&nbsp;testUnknownPartitioner()
+                            throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+</div>
+<!-- ========= END OF CLASS DATA ========= -->
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/LoadDataSchemaTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../../org/apache/pirk/schema/data/DataSchemaRegistry.html" title="class in org.apache.pirk.schema.data"><span class="strong">Prev Class</span></a></li>
+<li>Next Class</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/schema/data/LoadDataSchemaTest.html" target="_top">Frames</a></li>
+<li><a href="LoadDataSchemaTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/class-use/DataSchema.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/class-use/DataSchema.html b/docs/org/apache/pirk/schema/data/class-use/DataSchema.html
index 1f6ca0d..22d2de0 100644
--- a/docs/org/apache/pirk/schema/data/class-use/DataSchema.html
+++ b/docs/org/apache/pirk/schema/data/class-use/DataSchema.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.schema.data.DataSchema</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/class-use/DataSchemaLoader.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/class-use/DataSchemaLoader.html b/docs/org/apache/pirk/schema/data/class-use/DataSchemaLoader.html
index 6f1f685..2a84c5a 100644
--- a/docs/org/apache/pirk/schema/data/class-use/DataSchemaLoader.html
+++ b/docs/org/apache/pirk/schema/data/class-use/DataSchemaLoader.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.schema.data.DataSchemaLoader</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/class-use/DataSchemaRegistry.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/class-use/DataSchemaRegistry.html b/docs/org/apache/pirk/schema/data/class-use/DataSchemaRegistry.html
index 4193a87..4fbd6c9 100644
--- a/docs/org/apache/pirk/schema/data/class-use/DataSchemaRegistry.html
+++ b/docs/org/apache/pirk/schema/data/class-use/DataSchemaRegistry.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.schema.data.DataSchemaRegistry</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/class-use/LoadDataSchemaTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/class-use/LoadDataSchemaTest.html b/docs/org/apache/pirk/schema/data/class-use/LoadDataSchemaTest.html
new file mode 100644
index 0000000..c87f326
--- /dev/null
+++ b/docs/org/apache/pirk/schema/data/class-use/LoadDataSchemaTest.html
@@ -0,0 +1,115 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>Uses of Class org.apache.pirk.schema.data.LoadDataSchemaTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="Uses of Class org.apache.pirk.schema.data.LoadDataSchemaTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../../org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../../index.html?org/apache/pirk/schema/data/class-use/LoadDataSchemaTest.html" target="_top">Frames</a></li>
+<li><a href="LoadDataSchemaTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h2 title="Uses of Class org.apache.pirk.schema.data.LoadDataSchemaTest" class="title">Uses of Class<br>org.apache.pirk.schema.data.LoadDataSchemaTest</h2>
+</div>
+<div class="classUseContainer">No usage of org.apache.pirk.schema.data.LoadDataSchemaTest</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../../org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../../index.html?org/apache/pirk/schema/data/class-use/LoadDataSchemaTest.html" target="_top">Frames</a></li>
+<li><a href="LoadDataSchemaTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/package-frame.html b/docs/org/apache/pirk/schema/data/package-frame.html
index d577a25..7a6d7ce 100644
--- a/docs/org/apache/pirk/schema/data/package-frame.html
+++ b/docs/org/apache/pirk/schema/data/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.schema.data</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -15,6 +15,7 @@
 <li><a href="DataSchema.html" title="class in org.apache.pirk.schema.data" target="classFrame">DataSchema</a></li>
 <li><a href="DataSchemaLoader.html" title="class in org.apache.pirk.schema.data" target="classFrame">DataSchemaLoader</a></li>
 <li><a href="DataSchemaRegistry.html" title="class in org.apache.pirk.schema.data" target="classFrame">DataSchemaRegistry</a></li>
+<li><a href="LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data" target="classFrame">LoadDataSchemaTest</a></li>
 </ul>
 </div>
 </body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/package-summary.html b/docs/org/apache/pirk/schema/data/package-summary.html
index 384dcc1..e2c8536 100644
--- a/docs/org/apache/pirk/schema/data/package-summary.html
+++ b/docs/org/apache/pirk/schema/data/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.schema.data</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -93,6 +93,12 @@
 <div class="block">The data schema registry is a global location for data schema descriptors.</div>
 </td>
 </tr>
+<tr class="rowColor">
+<td class="colFirst"><a href="../../../../../org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data">LoadDataSchemaTest</a></td>
+<td class="colLast">
+<div class="block">Test suite for LoadDataSchema and DataSchema</div>
+</td>
+</tr>
 </tbody>
 </table>
 </li>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/package-tree.html b/docs/org/apache/pirk/schema/data/package-tree.html
index 8dd5350..e83bf06 100644
--- a/docs/org/apache/pirk/schema/data/package-tree.html
+++ b/docs/org/apache/pirk/schema/data/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.schema.data Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -77,6 +77,7 @@
 <li type="circle">org.apache.pirk.schema.data.<a href="../../../../../org/apache/pirk/schema/data/DataSchema.html" title="class in org.apache.pirk.schema.data"><span class="strong">DataSchema</span></a> (implements java.io.Serializable)</li>
 <li type="circle">org.apache.pirk.schema.data.<a href="../../../../../org/apache/pirk/schema/data/DataSchemaLoader.html" title="class in org.apache.pirk.schema.data"><span class="strong">DataSchemaLoader</span></a></li>
 <li type="circle">org.apache.pirk.schema.data.<a href="../../../../../org/apache/pirk/schema/data/DataSchemaRegistry.html" title="class in org.apache.pirk.schema.data"><span class="strong">DataSchemaRegistry</span></a></li>
+<li type="circle">org.apache.pirk.schema.data.<a href="../../../../../org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data"><span class="strong">LoadDataSchemaTest</span></a></li>
 </ul>
 </li>
 </ul>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/package-use.html b/docs/org/apache/pirk/schema/data/package-use.html
index dfc787a..b22036d 100644
--- a/docs/org/apache/pirk/schema/data/package-use.html
+++ b/docs/org/apache/pirk/schema/data/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.schema.data</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/partitioner/DataPartitioner.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/partitioner/DataPartitioner.html b/docs/org/apache/pirk/schema/data/partitioner/DataPartitioner.html
index 8853433..4e2f48a 100644
--- a/docs/org/apache/pirk/schema/data/partitioner/DataPartitioner.html
+++ b/docs/org/apache/pirk/schema/data/partitioner/DataPartitioner.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>DataPartitioner</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/partitioner/IPDataPartitioner.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/partitioner/IPDataPartitioner.html b/docs/org/apache/pirk/schema/data/partitioner/IPDataPartitioner.html
index 0e3bf2b..db238aa 100644
--- a/docs/org/apache/pirk/schema/data/partitioner/IPDataPartitioner.html
+++ b/docs/org/apache/pirk/schema/data/partitioner/IPDataPartitioner.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>IPDataPartitioner</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/partitioner/ISO8601DatePartitioner.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/partitioner/ISO8601DatePartitioner.html b/docs/org/apache/pirk/schema/data/partitioner/ISO8601DatePartitioner.html
index da6cbe8..d956e0a 100644
--- a/docs/org/apache/pirk/schema/data/partitioner/ISO8601DatePartitioner.html
+++ b/docs/org/apache/pirk/schema/data/partitioner/ISO8601DatePartitioner.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>ISO8601DatePartitioner</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/partitioner/PrimitiveTypePartitioner.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/partitioner/PrimitiveTypePartitioner.html b/docs/org/apache/pirk/schema/data/partitioner/PrimitiveTypePartitioner.html
index 3faa974..96863cc 100644
--- a/docs/org/apache/pirk/schema/data/partitioner/PrimitiveTypePartitioner.html
+++ b/docs/org/apache/pirk/schema/data/partitioner/PrimitiveTypePartitioner.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>PrimitiveTypePartitioner</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/partitioner/class-use/DataPartitioner.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/partitioner/class-use/DataPartitioner.html b/docs/org/apache/pirk/schema/data/partitioner/class-use/DataPartitioner.html
index 788de6f..76f25ef 100644
--- a/docs/org/apache/pirk/schema/data/partitioner/class-use/DataPartitioner.html
+++ b/docs/org/apache/pirk/schema/data/partitioner/class-use/DataPartitioner.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Interface org.apache.pirk.schema.data.partitioner.DataPartitioner</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/partitioner/class-use/IPDataPartitioner.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/partitioner/class-use/IPDataPartitioner.html b/docs/org/apache/pirk/schema/data/partitioner/class-use/IPDataPartitioner.html
index e84ff54..5bb6b2e 100644
--- a/docs/org/apache/pirk/schema/data/partitioner/class-use/IPDataPartitioner.html
+++ b/docs/org/apache/pirk/schema/data/partitioner/class-use/IPDataPartitioner.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.schema.data.partitioner.IPDataPartitioner</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/partitioner/class-use/ISO8601DatePartitioner.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/partitioner/class-use/ISO8601DatePartitioner.html b/docs/org/apache/pirk/schema/data/partitioner/class-use/ISO8601DatePartitioner.html
index a26d00c..9135b97 100644
--- a/docs/org/apache/pirk/schema/data/partitioner/class-use/ISO8601DatePartitioner.html
+++ b/docs/org/apache/pirk/schema/data/partitioner/class-use/ISO8601DatePartitioner.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.schema.data.partitioner.ISO8601DatePartitioner</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/partitioner/class-use/PrimitiveTypePartitioner.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/partitioner/class-use/PrimitiveTypePartitioner.html b/docs/org/apache/pirk/schema/data/partitioner/class-use/PrimitiveTypePartitioner.html
index f9948fe..1c5b5f2 100644
--- a/docs/org/apache/pirk/schema/data/partitioner/class-use/PrimitiveTypePartitioner.html
+++ b/docs/org/apache/pirk/schema/data/partitioner/class-use/PrimitiveTypePartitioner.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.schema.data.partitioner.PrimitiveTypePartitioner</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/partitioner/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/partitioner/package-frame.html b/docs/org/apache/pirk/schema/data/partitioner/package-frame.html
index f82aded..42ce041 100644
--- a/docs/org/apache/pirk/schema/data/partitioner/package-frame.html
+++ b/docs/org/apache/pirk/schema/data/partitioner/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.schema.data.partitioner</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/partitioner/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/partitioner/package-summary.html b/docs/org/apache/pirk/schema/data/partitioner/package-summary.html
index 82762dc..5d45a90 100644
--- a/docs/org/apache/pirk/schema/data/partitioner/package-summary.html
+++ b/docs/org/apache/pirk/schema/data/partitioner/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.schema.data.partitioner</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/partitioner/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/partitioner/package-tree.html b/docs/org/apache/pirk/schema/data/partitioner/package-tree.html
index db11eb2..20a88f4 100644
--- a/docs/org/apache/pirk/schema/data/partitioner/package-tree.html
+++ b/docs/org/apache/pirk/schema/data/partitioner/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.schema.data.partitioner Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/data/partitioner/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/data/partitioner/package-use.html b/docs/org/apache/pirk/schema/data/partitioner/package-use.html
index e2a6209..2eb4c2b 100644
--- a/docs/org/apache/pirk/schema/data/partitioner/package-use.html
+++ b/docs/org/apache/pirk/schema/data/partitioner/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.schema.data.partitioner</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>


[7/9] incubator-pirk git commit: [PIRK-37]: Rename package for test classes to be org.apache.pirk.* -- closes apache/incubator-pirk#39

Posted by ea...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/PartitionUtilsTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/PartitionUtilsTest.html b/docs/org/apache/pirk/general/PartitionUtilsTest.html
new file mode 100644
index 0000000..d14c6ec
--- /dev/null
+++ b/docs/org/apache/pirk/general/PartitionUtilsTest.html
@@ -0,0 +1,286 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
+<title>PartitionUtilsTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="PartitionUtilsTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/PartitionUtilsTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general"><span class="strong">Prev Class</span></a></li>
+<li><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general"><span class="strong">Next Class</span></a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/PartitionUtilsTest.html" target="_top">Frames</a></li>
+<li><a href="PartitionUtilsTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<!-- ======== START OF CLASS DATA ======== -->
+<div class="header">
+<div class="subTitle">org.apache.pirk.general</div>
+<h2 title="Class PartitionUtilsTest" class="title">Class PartitionUtilsTest</h2>
+</div>
+<div class="contentContainer">
+<ul class="inheritance">
+<li>java.lang.Object</li>
+<li>
+<ul class="inheritance">
+<li>org.apache.pirk.general.PartitionUtilsTest</li>
+</ul>
+</li>
+</ul>
+<div class="description">
+<ul class="blockList">
+<li class="blockList">
+<hr>
+<br>
+<pre>public class <span class="strong">PartitionUtilsTest</span>
+extends java.lang.Object</pre>
+<div class="block">Class to functionally test the bit conversion utils</div>
+</li>
+</ul>
+</div>
+<div class="summary">
+<ul class="blockList">
+<li class="blockList">
+<!-- ======== CONSTRUCTOR SUMMARY ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_summary">
+<!--   -->
+</a>
+<h3>Constructor Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Constructor Summary table, listing constructors, and an explanation">
+<caption><span>Constructors</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colOne" scope="col">Constructor and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colOne"><code><strong><a href="../../../../org/apache/pirk/general/PartitionUtilsTest.html#PartitionUtilsTest()">PartitionUtilsTest</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+</li>
+</ul>
+<!-- ========== METHOD SUMMARY =========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_summary">
+<!--   -->
+</a>
+<h3>Method Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Method Summary table, listing methods, and an explanation">
+<caption><span>Methods</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th class="colLast" scope="col">Method and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/PartitionUtilsTest.html#testMask()">testMask</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/PartitionUtilsTest.html#testPartitionBits()">testPartitionBits</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/PartitionUtilsTest.html#testPartitions()">testPartitions</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+<ul class="blockList">
+<li class="blockList"><a name="methods_inherited_from_class_java.lang.Object">
+<!--   -->
+</a>
+<h3>Methods inherited from class&nbsp;java.lang.Object</h3>
+<code>equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait</code></li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+<div class="details">
+<ul class="blockList">
+<li class="blockList">
+<!-- ========= CONSTRUCTOR DETAIL ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_detail">
+<!--   -->
+</a>
+<h3>Constructor Detail</h3>
+<a name="PartitionUtilsTest()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>PartitionUtilsTest</h4>
+<pre>public&nbsp;PartitionUtilsTest()</pre>
+</li>
+</ul>
+</li>
+</ul>
+<!-- ============ METHOD DETAIL ========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_detail">
+<!--   -->
+</a>
+<h3>Method Detail</h3>
+<a name="testMask()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testMask</h4>
+<pre>public&nbsp;void&nbsp;testMask()</pre>
+</li>
+</ul>
+<a name="testPartitionBits()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testPartitionBits</h4>
+<pre>public&nbsp;void&nbsp;testPartitionBits()</pre>
+</li>
+</ul>
+<a name="testPartitions()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>testPartitions</h4>
+<pre>public&nbsp;void&nbsp;testPartitions()
+                    throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+</div>
+<!-- ========= END OF CLASS DATA ========= -->
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/PartitionUtilsTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general"><span class="strong">Prev Class</span></a></li>
+<li><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general"><span class="strong">Next Class</span></a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/PartitionUtilsTest.html" target="_top">Frames</a></li>
+<li><a href="PartitionUtilsTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/QueryParserUtilsTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/QueryParserUtilsTest.html b/docs/org/apache/pirk/general/QueryParserUtilsTest.html
new file mode 100644
index 0000000..c35983f
--- /dev/null
+++ b/docs/org/apache/pirk/general/QueryParserUtilsTest.html
@@ -0,0 +1,429 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
+<title>QueryParserUtilsTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="QueryParserUtilsTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/QueryParserUtilsTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general"><span class="strong">Prev Class</span></a></li>
+<li>Next Class</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/QueryParserUtilsTest.html" target="_top">Frames</a></li>
+<li><a href="QueryParserUtilsTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<!-- ======== START OF CLASS DATA ======== -->
+<div class="header">
+<div class="subTitle">org.apache.pirk.general</div>
+<h2 title="Class QueryParserUtilsTest" class="title">Class QueryParserUtilsTest</h2>
+</div>
+<div class="contentContainer">
+<ul class="inheritance">
+<li>java.lang.Object</li>
+<li>
+<ul class="inheritance">
+<li>org.apache.pirk.general.QueryParserUtilsTest</li>
+</ul>
+</li>
+</ul>
+<div class="description">
+<ul class="blockList">
+<li class="blockList">
+<hr>
+<br>
+<pre>public class <span class="strong">QueryParserUtilsTest</span>
+extends java.lang.Object</pre>
+<div class="block">Class for testing the QueryParser methods</div>
+</li>
+</ul>
+</div>
+<div class="summary">
+<ul class="blockList">
+<li class="blockList">
+<!-- ======== CONSTRUCTOR SUMMARY ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_summary">
+<!--   -->
+</a>
+<h3>Constructor Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Constructor Summary table, listing constructors, and an explanation">
+<caption><span>Constructors</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colOne" scope="col">Constructor and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colOne"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#QueryParserUtilsTest()">QueryParserUtilsTest</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+</li>
+</ul>
+<!-- ========== METHOD SUMMARY =========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_summary">
+<!--   -->
+</a>
+<h3>Method Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Method Summary table, listing methods, and an explanation">
+<caption><span>Methods</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th class="colLast" scope="col">Method and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>static void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#setup()">setup</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>static void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#teardown()">teardown</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#testAllQuery()">testAllQuery</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#testBooleanQuery()">testBooleanQuery</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#testDateRangeQuery()">testDateRangeQuery</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#testIgnoreCase()">testIgnoreCase</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#testIPRangeQuery()">testIPRangeQuery</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#testIPRangeQueryMap()">testIPRangeQueryMap</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#testIPRangeQueryMapWritable()">testIPRangeQueryMapWritable</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#testIPRangeQueryMapWritableWAW()">testIPRangeQueryMapWritableWAW</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#testQueryFieldDoesNotExist()">testQueryFieldDoesNotExist</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#testSingleQuery()">testSingleQuery</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#testSingleValueRangeQuery()">testSingleValueRangeQuery</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html#testWildcardQuery()">testWildcardQuery</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+<ul class="blockList">
+<li class="blockList"><a name="methods_inherited_from_class_java.lang.Object">
+<!--   -->
+</a>
+<h3>Methods inherited from class&nbsp;java.lang.Object</h3>
+<code>equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait</code></li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+<div class="details">
+<ul class="blockList">
+<li class="blockList">
+<!-- ========= CONSTRUCTOR DETAIL ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_detail">
+<!--   -->
+</a>
+<h3>Constructor Detail</h3>
+<a name="QueryParserUtilsTest()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>QueryParserUtilsTest</h4>
+<pre>public&nbsp;QueryParserUtilsTest()</pre>
+</li>
+</ul>
+</li>
+</ul>
+<!-- ============ METHOD DETAIL ========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_detail">
+<!--   -->
+</a>
+<h3>Method Detail</h3>
+<a name="setup()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>setup</h4>
+<pre>public static&nbsp;void&nbsp;setup()
+                  throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+<a name="teardown()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>teardown</h4>
+<pre>public static&nbsp;void&nbsp;teardown()</pre>
+</li>
+</ul>
+<a name="testSingleQuery()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testSingleQuery</h4>
+<pre>public&nbsp;void&nbsp;testSingleQuery()</pre>
+</li>
+</ul>
+<a name="testQueryFieldDoesNotExist()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testQueryFieldDoesNotExist</h4>
+<pre>public&nbsp;void&nbsp;testQueryFieldDoesNotExist()</pre>
+</li>
+</ul>
+<a name="testIgnoreCase()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testIgnoreCase</h4>
+<pre>public&nbsp;void&nbsp;testIgnoreCase()</pre>
+</li>
+</ul>
+<a name="testSingleValueRangeQuery()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testSingleValueRangeQuery</h4>
+<pre>public&nbsp;void&nbsp;testSingleValueRangeQuery()</pre>
+</li>
+</ul>
+<a name="testIPRangeQuery()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testIPRangeQuery</h4>
+<pre>public&nbsp;void&nbsp;testIPRangeQuery()</pre>
+</li>
+</ul>
+<a name="testIPRangeQueryMapWritable()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testIPRangeQueryMapWritable</h4>
+<pre>public&nbsp;void&nbsp;testIPRangeQueryMapWritable()</pre>
+</li>
+</ul>
+<a name="testIPRangeQueryMapWritableWAW()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testIPRangeQueryMapWritableWAW</h4>
+<pre>public&nbsp;void&nbsp;testIPRangeQueryMapWritableWAW()</pre>
+</li>
+</ul>
+<a name="testIPRangeQueryMap()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testIPRangeQueryMap</h4>
+<pre>public&nbsp;void&nbsp;testIPRangeQueryMap()</pre>
+</li>
+</ul>
+<a name="testDateRangeQuery()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testDateRangeQuery</h4>
+<pre>public&nbsp;void&nbsp;testDateRangeQuery()</pre>
+</li>
+</ul>
+<a name="testBooleanQuery()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testBooleanQuery</h4>
+<pre>public&nbsp;void&nbsp;testBooleanQuery()</pre>
+</li>
+</ul>
+<a name="testAllQuery()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testAllQuery</h4>
+<pre>public&nbsp;void&nbsp;testAllQuery()</pre>
+</li>
+</ul>
+<a name="testWildcardQuery()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>testWildcardQuery</h4>
+<pre>public&nbsp;void&nbsp;testWildcardQuery()</pre>
+</li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+</div>
+<!-- ========= END OF CLASS DATA ========= -->
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/QueryParserUtilsTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general"><span class="strong">Prev Class</span></a></li>
+<li>Next Class</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/QueryParserUtilsTest.html" target="_top">Frames</a></li>
+<li><a href="QueryParserUtilsTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/class-use/ISO8601DateParserTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/class-use/ISO8601DateParserTest.html b/docs/org/apache/pirk/general/class-use/ISO8601DateParserTest.html
new file mode 100644
index 0000000..892ba2d
--- /dev/null
+++ b/docs/org/apache/pirk/general/class-use/ISO8601DateParserTest.html
@@ -0,0 +1,115 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>Uses of Class org.apache.pirk.general.ISO8601DateParserTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="Uses of Class org.apache.pirk.general.ISO8601DateParserTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../org/apache/pirk/general/ISO8601DateParserTest.html" title="class in org.apache.pirk.general">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/general/class-use/ISO8601DateParserTest.html" target="_top">Frames</a></li>
+<li><a href="ISO8601DateParserTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h2 title="Uses of Class org.apache.pirk.general.ISO8601DateParserTest" class="title">Uses of Class<br>org.apache.pirk.general.ISO8601DateParserTest</h2>
+</div>
+<div class="classUseContainer">No usage of org.apache.pirk.general.ISO8601DateParserTest</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../org/apache/pirk/general/ISO8601DateParserTest.html" title="class in org.apache.pirk.general">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/general/class-use/ISO8601DateParserTest.html" target="_top">Frames</a></li>
+<li><a href="ISO8601DateParserTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/class-use/KeyedHashTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/class-use/KeyedHashTest.html b/docs/org/apache/pirk/general/class-use/KeyedHashTest.html
new file mode 100644
index 0000000..b74dc1c
--- /dev/null
+++ b/docs/org/apache/pirk/general/class-use/KeyedHashTest.html
@@ -0,0 +1,115 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>Uses of Class org.apache.pirk.general.KeyedHashTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="Uses of Class org.apache.pirk.general.KeyedHashTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/general/class-use/KeyedHashTest.html" target="_top">Frames</a></li>
+<li><a href="KeyedHashTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h2 title="Uses of Class org.apache.pirk.general.KeyedHashTest" class="title">Uses of Class<br>org.apache.pirk.general.KeyedHashTest</h2>
+</div>
+<div class="classUseContainer">No usage of org.apache.pirk.general.KeyedHashTest</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/general/class-use/KeyedHashTest.html" target="_top">Frames</a></li>
+<li><a href="KeyedHashTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/class-use/PaillierTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/class-use/PaillierTest.html b/docs/org/apache/pirk/general/class-use/PaillierTest.html
new file mode 100644
index 0000000..b88eea4
--- /dev/null
+++ b/docs/org/apache/pirk/general/class-use/PaillierTest.html
@@ -0,0 +1,115 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>Uses of Class org.apache.pirk.general.PaillierTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="Uses of Class org.apache.pirk.general.PaillierTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/general/class-use/PaillierTest.html" target="_top">Frames</a></li>
+<li><a href="PaillierTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h2 title="Uses of Class org.apache.pirk.general.PaillierTest" class="title">Uses of Class<br>org.apache.pirk.general.PaillierTest</h2>
+</div>
+<div class="classUseContainer">No usage of org.apache.pirk.general.PaillierTest</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/general/class-use/PaillierTest.html" target="_top">Frames</a></li>
+<li><a href="PaillierTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/class-use/PartitionUtilsTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/class-use/PartitionUtilsTest.html b/docs/org/apache/pirk/general/class-use/PartitionUtilsTest.html
new file mode 100644
index 0000000..87349ec
--- /dev/null
+++ b/docs/org/apache/pirk/general/class-use/PartitionUtilsTest.html
@@ -0,0 +1,115 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>Uses of Class org.apache.pirk.general.PartitionUtilsTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="Uses of Class org.apache.pirk.general.PartitionUtilsTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/general/class-use/PartitionUtilsTest.html" target="_top">Frames</a></li>
+<li><a href="PartitionUtilsTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h2 title="Uses of Class org.apache.pirk.general.PartitionUtilsTest" class="title">Uses of Class<br>org.apache.pirk.general.PartitionUtilsTest</h2>
+</div>
+<div class="classUseContainer">No usage of org.apache.pirk.general.PartitionUtilsTest</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/general/class-use/PartitionUtilsTest.html" target="_top">Frames</a></li>
+<li><a href="PartitionUtilsTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/class-use/QueryParserUtilsTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/class-use/QueryParserUtilsTest.html b/docs/org/apache/pirk/general/class-use/QueryParserUtilsTest.html
new file mode 100644
index 0000000..9701a72
--- /dev/null
+++ b/docs/org/apache/pirk/general/class-use/QueryParserUtilsTest.html
@@ -0,0 +1,115 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>Uses of Class org.apache.pirk.general.QueryParserUtilsTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="Uses of Class org.apache.pirk.general.QueryParserUtilsTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/general/class-use/QueryParserUtilsTest.html" target="_top">Frames</a></li>
+<li><a href="QueryParserUtilsTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h2 title="Uses of Class org.apache.pirk.general.QueryParserUtilsTest" class="title">Uses of Class<br>org.apache.pirk.general.QueryParserUtilsTest</h2>
+</div>
+<div class="classUseContainer">No usage of org.apache.pirk.general.QueryParserUtilsTest</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/general/class-use/QueryParserUtilsTest.html" target="_top">Frames</a></li>
+<li><a href="QueryParserUtilsTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/package-frame.html b/docs/org/apache/pirk/general/package-frame.html
new file mode 100644
index 0000000..a7e9b0a
--- /dev/null
+++ b/docs/org/apache/pirk/general/package-frame.html
@@ -0,0 +1,23 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
+<title>org.apache.pirk.general</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<h1 class="bar"><a href="../../../../org/apache/pirk/general/package-summary.html" target="classFrame">org.apache.pirk.general</a></h1>
+<div class="indexContainer">
+<h2 title="Classes">Classes</h2>
+<ul title="Classes">
+<li><a href="ISO8601DateParserTest.html" title="class in org.apache.pirk.general" target="classFrame">ISO8601DateParserTest</a></li>
+<li><a href="KeyedHashTest.html" title="class in org.apache.pirk.general" target="classFrame">KeyedHashTest</a></li>
+<li><a href="PaillierTest.html" title="class in org.apache.pirk.general" target="classFrame">PaillierTest</a></li>
+<li><a href="PartitionUtilsTest.html" title="class in org.apache.pirk.general" target="classFrame">PartitionUtilsTest</a></li>
+<li><a href="QueryParserUtilsTest.html" title="class in org.apache.pirk.general" target="classFrame">QueryParserUtilsTest</a></li>
+</ul>
+</div>
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/package-summary.html b/docs/org/apache/pirk/general/package-summary.html
new file mode 100644
index 0000000..c390483
--- /dev/null
+++ b/docs/org/apache/pirk/general/package-summary.html
@@ -0,0 +1,159 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
+<title>org.apache.pirk.general</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="org.apache.pirk.general";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li class="navBarCell1Rev">Package</li>
+<li>Class</li>
+<li><a href="package-use.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../org/apache/pirk/encryption/package-summary.html">Prev Package</a></li>
+<li><a href="../../../../org/apache/pirk/inputformat/hadoop/package-summary.html">Next Package</a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/package-summary.html" target="_top">Frames</a></li>
+<li><a href="package-summary.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h1 title="Package" class="title">Package&nbsp;org.apache.pirk.general</h1>
+</div>
+<div class="contentContainer">
+<ul class="blockList">
+<li class="blockList">
+<table class="packageSummary" border="0" cellpadding="3" cellspacing="0" summary="Class Summary table, listing classes, and an explanation">
+<caption><span>Class Summary</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Class</th>
+<th class="colLast" scope="col">Description</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a href="../../../../org/apache/pirk/general/ISO8601DateParserTest.html" title="class in org.apache.pirk.general">ISO8601DateParserTest</a></td>
+<td class="colLast">
+<div class="block">Class to test basic functionality of ISO8601DateParser class</div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a href="../../../../org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general">KeyedHashTest</a></td>
+<td class="colLast">
+<div class="block">Basic functional tests for KeyedHash</div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a href="../../../../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general">PaillierTest</a></td>
+<td class="colLast">
+<div class="block">Basic test functionality for Paillier library</div>
+</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><a href="../../../../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general">PartitionUtilsTest</a></td>
+<td class="colLast">
+<div class="block">Class to functionally test the bit conversion utils</div>
+</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></td>
+<td class="colLast">
+<div class="block">Class for testing the QueryParser methods</div>
+</td>
+</tr>
+</tbody>
+</table>
+</li>
+</ul>
+</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li class="navBarCell1Rev">Package</li>
+<li>Class</li>
+<li><a href="package-use.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../org/apache/pirk/encryption/package-summary.html">Prev Package</a></li>
+<li><a href="../../../../org/apache/pirk/inputformat/hadoop/package-summary.html">Next Package</a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/package-summary.html" target="_top">Frames</a></li>
+<li><a href="package-summary.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/package-tree.html b/docs/org/apache/pirk/general/package-tree.html
new file mode 100644
index 0000000..28dc5f6
--- /dev/null
+++ b/docs/org/apache/pirk/general/package-tree.html
@@ -0,0 +1,132 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
+<title>org.apache.pirk.general Class Hierarchy</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="org.apache.pirk.general Class Hierarchy";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li>Class</li>
+<li>Use</li>
+<li class="navBarCell1Rev">Tree</li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../org/apache/pirk/encryption/package-tree.html">Prev</a></li>
+<li><a href="../../../../org/apache/pirk/inputformat/hadoop/package-tree.html">Next</a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/package-tree.html" target="_top">Frames</a></li>
+<li><a href="package-tree.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h1 class="title">Hierarchy For Package org.apache.pirk.general</h1>
+<span class="strong">Package Hierarchies:</span>
+<ul class="horizontal">
+<li><a href="../../../../overview-tree.html">All Packages</a></li>
+</ul>
+</div>
+<div class="contentContainer">
+<h2 title="Class Hierarchy">Class Hierarchy</h2>
+<ul>
+<li type="circle">java.lang.Object
+<ul>
+<li type="circle">org.apache.pirk.general.<a href="../../../../org/apache/pirk/general/ISO8601DateParserTest.html" title="class in org.apache.pirk.general"><span class="strong">ISO8601DateParserTest</span></a></li>
+<li type="circle">org.apache.pirk.general.<a href="../../../../org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general"><span class="strong">KeyedHashTest</span></a></li>
+<li type="circle">org.apache.pirk.general.<a href="../../../../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general"><span class="strong">PaillierTest</span></a></li>
+<li type="circle">org.apache.pirk.general.<a href="../../../../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general"><span class="strong">PartitionUtilsTest</span></a></li>
+<li type="circle">org.apache.pirk.general.<a href="../../../../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general"><span class="strong">QueryParserUtilsTest</span></a></li>
+</ul>
+</li>
+</ul>
+</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li>Class</li>
+<li>Use</li>
+<li class="navBarCell1Rev">Tree</li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../org/apache/pirk/encryption/package-tree.html">Prev</a></li>
+<li><a href="../../../../org/apache/pirk/inputformat/hadoop/package-tree.html">Next</a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/package-tree.html" target="_top">Frames</a></li>
+<li><a href="package-tree.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/package-use.html b/docs/org/apache/pirk/general/package-use.html
new file mode 100644
index 0000000..783cf71
--- /dev/null
+++ b/docs/org/apache/pirk/general/package-use.html
@@ -0,0 +1,115 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>Uses of Package org.apache.pirk.general</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="Uses of Package org.apache.pirk.general";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li>Class</li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/package-use.html" target="_top">Frames</a></li>
+<li><a href="package-use.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h1 title="Uses of Package org.apache.pirk.general" class="title">Uses of Package<br>org.apache.pirk.general</h1>
+</div>
+<div class="contentContainer">No usage of org.apache.pirk.general</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li>Class</li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/package-use.html" target="_top">Frames</a></li>
+<li><a href="package-use.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/BaseInputFormat.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/BaseInputFormat.html b/docs/org/apache/pirk/inputformat/hadoop/BaseInputFormat.html
index 3880274..e6cb100 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/BaseInputFormat.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/BaseInputFormat.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>BaseInputFormat</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/BytesArrayWritable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/BytesArrayWritable.html b/docs/org/apache/pirk/inputformat/hadoop/BytesArrayWritable.html
index 93447f6..f2c468c 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/BytesArrayWritable.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/BytesArrayWritable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>BytesArrayWritable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/InputFormatConst.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/InputFormatConst.html b/docs/org/apache/pirk/inputformat/hadoop/InputFormatConst.html
index d9b940f..f7ada45 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/InputFormatConst.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/InputFormatConst.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>InputFormatConst</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/TextArrayWritable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/TextArrayWritable.html b/docs/org/apache/pirk/inputformat/hadoop/TextArrayWritable.html
index 01a6d03..7f8d328 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/TextArrayWritable.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/TextArrayWritable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>TextArrayWritable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/class-use/BaseInputFormat.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/class-use/BaseInputFormat.html b/docs/org/apache/pirk/inputformat/hadoop/class-use/BaseInputFormat.html
index 24af365..f61b36b 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/class-use/BaseInputFormat.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/class-use/BaseInputFormat.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.inputformat.hadoop.BaseInputFormat</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/class-use/BytesArrayWritable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/class-use/BytesArrayWritable.html b/docs/org/apache/pirk/inputformat/hadoop/class-use/BytesArrayWritable.html
index 09784d3..e03e5be 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/class-use/BytesArrayWritable.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/class-use/BytesArrayWritable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.inputformat.hadoop.BytesArrayWritable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/class-use/InputFormatConst.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/class-use/InputFormatConst.html b/docs/org/apache/pirk/inputformat/hadoop/class-use/InputFormatConst.html
index 927c084..6e1f082 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/class-use/InputFormatConst.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/class-use/InputFormatConst.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.inputformat.hadoop.InputFormatConst</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/class-use/TextArrayWritable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/class-use/TextArrayWritable.html b/docs/org/apache/pirk/inputformat/hadoop/class-use/TextArrayWritable.html
index 51ed643..0cbeb79 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/class-use/TextArrayWritable.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/class-use/TextArrayWritable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.inputformat.hadoop.TextArrayWritable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/json/JSONInputFormat.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/json/JSONInputFormat.html b/docs/org/apache/pirk/inputformat/hadoop/json/JSONInputFormat.html
index 465cf61..63147d1 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/json/JSONInputFormat.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/json/JSONInputFormat.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>JSONInputFormat</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/json/JSONInputFormatBase.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/json/JSONInputFormatBase.html b/docs/org/apache/pirk/inputformat/hadoop/json/JSONInputFormatBase.html
index ad5ba98..e88e4db 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/json/JSONInputFormatBase.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/json/JSONInputFormatBase.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>JSONInputFormatBase</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/json/JSONRecordReader.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/json/JSONRecordReader.html b/docs/org/apache/pirk/inputformat/hadoop/json/JSONRecordReader.html
index 020a412..ec5e08e 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/json/JSONRecordReader.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/json/JSONRecordReader.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>JSONRecordReader</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONInputFormat.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONInputFormat.html b/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONInputFormat.html
index 5860165..c1c0e1b 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONInputFormat.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONInputFormat.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.inputformat.hadoop.json.JSONInputFormat</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONInputFormatBase.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONInputFormatBase.html b/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONInputFormatBase.html
index 3eb0b11..c2c6e29 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONInputFormatBase.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONInputFormatBase.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.inputformat.hadoop.json.JSONInputFormatBase</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONRecordReader.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONRecordReader.html b/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONRecordReader.html
index 5ac92b8..cdbb769 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONRecordReader.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/json/class-use/JSONRecordReader.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.inputformat.hadoop.json.JSONRecordReader</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/json/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/json/package-frame.html b/docs/org/apache/pirk/inputformat/hadoop/json/package-frame.html
index 0bee5a1..16d9a96 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/json/package-frame.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/json/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.inputformat.hadoop.json</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/json/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/json/package-summary.html b/docs/org/apache/pirk/inputformat/hadoop/json/package-summary.html
index 22ede97..ad5dd5a 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/json/package-summary.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/json/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.inputformat.hadoop.json</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/json/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/json/package-tree.html b/docs/org/apache/pirk/inputformat/hadoop/json/package-tree.html
index 07761c2..98d4996 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/json/package-tree.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/json/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.inputformat.hadoop.json Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/json/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/json/package-use.html b/docs/org/apache/pirk/inputformat/hadoop/json/package-use.html
index f5ac33a..93851be 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/json/package-use.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/json/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.inputformat.hadoop.json</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/package-frame.html b/docs/org/apache/pirk/inputformat/hadoop/package-frame.html
index 70dfe07..0da72a0 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/package-frame.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.inputformat.hadoop</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/inputformat/hadoop/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/inputformat/hadoop/package-summary.html b/docs/org/apache/pirk/inputformat/hadoop/package-summary.html
index a5ee4c8..0ca6898 100644
--- a/docs/org/apache/pirk/inputformat/hadoop/package-summary.html
+++ b/docs/org/apache/pirk/inputformat/hadoop/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.inputformat.hadoop</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -36,7 +36,7 @@
 </div>
 <div class="subNav">
 <ul class="navList">
-<li><a href="../../../../../org/apache/pirk/encryption/package-summary.html">Prev Package</a></li>
+<li><a href="../../../../../org/apache/pirk/general/package-summary.html">Prev Package</a></li>
 <li><a href="../../../../../org/apache/pirk/inputformat/hadoop/json/package-summary.html">Next Package</a></li>
 </ul>
 <ul class="navList">
@@ -123,7 +123,7 @@
 </div>
 <div class="subNav">
 <ul class="navList">
-<li><a href="../../../../../org/apache/pirk/encryption/package-summary.html">Prev Package</a></li>
+<li><a href="../../../../../org/apache/pirk/general/package-summary.html">Prev Package</a></li>
 <li><a href="../../../../../org/apache/pirk/inputformat/hadoop/json/package-summary.html">Next Package</a></li>
 </ul>
 <ul class="navList">



[8/9] incubator-pirk git commit: [PIRK-37]: Rename package for test classes to be org.apache.pirk.* -- closes apache/incubator-pirk#39

Posted by ea...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-20.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-20.html b/docs/index-files/index-20.html
index 8d111bb..1a3ce8a 100644
--- a/docs/index-files/index-20.html
+++ b/docs/index-files/index-20.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>T-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>
@@ -67,29 +67,25 @@
 </a>
 <h2 class="title">T</h2>
 <dl>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#teardown()">teardown()</a></span> - Static method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
+<dd>&nbsp;</dd>
+<dt><span class="strong"><a href="../org/apache/pirk/wideskies/standalone/StandaloneTest.html#teardown()">teardown()</a></span> - Static method in class org.apache.pirk.wideskies.standalone.<a href="../org/apache/pirk/wideskies/standalone/StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone">StandaloneTest</a></dt>
+<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/test/distributed/DistributedTestDriver.html#test(org.apache.hadoop.fs.FileSystem,%20org.apache.pirk.test.distributed.DistributedTestCLI,%20java.util.ArrayList)">test(FileSystem, DistributedTestCLI, ArrayList&lt;JSONObject&gt;)</a></span> - Static method in class org.apache.pirk.test.distributed.<a href="../org/apache/pirk/test/distributed/DistributedTestDriver.html" title="class in org.apache.pirk.test.distributed">DistributedTestDriver</a></dt>
 <dd>
 <div class="block">Execute Tests</div>
 </dd>
-<dt><a href="../test/general/package-summary.html">test.general</a> - package test.general</dt>
-<dd>&nbsp;</dd>
-<dt><a href="../test/schema/data/package-summary.html">test.schema.data</a> - package test.schema.data</dt>
-<dd>&nbsp;</dd>
-<dt><a href="../test/schema/query/package-summary.html">test.schema.query</a> - package test.schema.query</dt>
-<dd>&nbsp;</dd>
-<dt><a href="../test/wideskies/standalone/package-summary.html">test.wideskies.standalone</a> - package test.wideskies.standalone</dt>
-<dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/test/utils/Inputs.html#TEST_DATA_SCHEMA_NAME">TEST_DATA_SCHEMA_NAME</a></span> - Static variable in class org.apache.pirk.test.utils.<a href="../org/apache/pirk/test/utils/Inputs.html" title="class in org.apache.pirk.test.utils">Inputs</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#testAllQuery()">testAllQuery()</a></span> - Method in class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#testAllQuery()">testAllQuery()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#testBooleanQuery()">testBooleanQuery()</a></span> - Method in class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#testBooleanQuery()">testBooleanQuery()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/schema/query/LoadQuerySchemaTest.html#testDataSchemaDoesNotExist()">testDataSchemaDoesNotExist()</a></span> - Method in class test.schema.query.<a href="../test/schema/query/LoadQuerySchemaTest.html" title="class in test.schema.query">LoadQuerySchemaTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/schema/query/LoadQuerySchemaTest.html#testDataSchemaDoesNotExist()">testDataSchemaDoesNotExist()</a></span> - Method in class org.apache.pirk.schema.query.<a href="../org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query">LoadQuerySchemaTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/ISO8601DateParserTest.html#testDateParsing()">testDateParsing()</a></span> - Method in class test.general.<a href="../test/general/ISO8601DateParserTest.html" title="class in test.general">ISO8601DateParserTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/ISO8601DateParserTest.html#testDateParsing()">testDateParsing()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/ISO8601DateParserTest.html" title="class in org.apache.pirk.general">ISO8601DateParserTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#testDateRangeQuery()">testDateRangeQuery()</a></span> - Method in class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#testDateRangeQuery()">testDateRangeQuery()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/test/utils/BaseTests.html#testDNSHostnameQuery(java.util.ArrayList,%20int,%20boolean)">testDNSHostnameQuery(ArrayList&lt;JSONObject&gt;, int, boolean)</a></span> - Static method in class org.apache.pirk.test.utils.<a href="../org/apache/pirk/test/utils/BaseTests.html" title="class in org.apache.pirk.test.utils">BaseTests</a></dt>
 <dd>&nbsp;</dd>
@@ -109,53 +105,53 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/test/distributed/testsuite/DistTestSuite.html#testESInputSpark(org.apache.hadoop.fs.FileSystem,%20java.util.ArrayList)">testESInputSpark(FileSystem, ArrayList&lt;JSONObject&gt;)</a></span> - Static method in class org.apache.pirk.test.distributed.testsuite.<a href="../org/apache/pirk/test/distributed/testsuite/DistTestSuite.html" title="class in org.apache.pirk.test.distributed.testsuite">DistTestSuite</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/schema/data/LoadDataSchemaTest.html#testGeneralSchemaLoad()">testGeneralSchemaLoad()</a></span> - Method in class test.schema.data.<a href="../test/schema/data/LoadDataSchemaTest.html" title="class in test.schema.data">LoadDataSchemaTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/schema/data/LoadDataSchemaTest.html#testGeneralSchemaLoad()">testGeneralSchemaLoad()</a></span> - Method in class org.apache.pirk.schema.data.<a href="../org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data">LoadDataSchemaTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/schema/query/LoadQuerySchemaTest.html#testGeneralSchemaLoad()">testGeneralSchemaLoad()</a></span> - Method in class test.schema.query.<a href="../test/schema/query/LoadQuerySchemaTest.html" title="class in test.schema.query">LoadQuerySchemaTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/schema/query/LoadQuerySchemaTest.html#testGeneralSchemaLoad()">testGeneralSchemaLoad()</a></span> - Method in class org.apache.pirk.schema.query.<a href="../org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query">LoadQuerySchemaTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#testIgnoreCase()">testIgnoreCase()</a></span> - Method in class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#testIgnoreCase()">testIgnoreCase()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/schema/data/LoadDataSchemaTest.html#testIncorrectJavaType()">testIncorrectJavaType()</a></span> - Method in class test.schema.data.<a href="../test/schema/data/LoadDataSchemaTest.html" title="class in test.schema.data">LoadDataSchemaTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/schema/data/LoadDataSchemaTest.html#testIncorrectJavaType()">testIncorrectJavaType()</a></span> - Method in class org.apache.pirk.schema.data.<a href="../org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data">LoadDataSchemaTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#testIPRangeQuery()">testIPRangeQuery()</a></span> - Method in class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#testIPRangeQuery()">testIPRangeQuery()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#testIPRangeQueryMap()">testIPRangeQueryMap()</a></span> - Method in class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#testIPRangeQueryMap()">testIPRangeQueryMap()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#testIPRangeQueryMapWritable()">testIPRangeQueryMapWritable()</a></span> - Method in class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#testIPRangeQueryMapWritable()">testIPRangeQueryMapWritable()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#testIPRangeQueryMapWritableWAW()">testIPRangeQueryMapWritableWAW()</a></span> - Method in class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#testIPRangeQueryMapWritableWAW()">testIPRangeQueryMapWritableWAW()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/test/distributed/testsuite/DistTestSuite.html#testJSONInputMR(org.apache.hadoop.fs.FileSystem,%20java.util.ArrayList)">testJSONInputMR(FileSystem, ArrayList&lt;JSONObject&gt;)</a></span> - Static method in class org.apache.pirk.test.distributed.testsuite.<a href="../org/apache/pirk/test/distributed/testsuite/DistTestSuite.html" title="class in org.apache.pirk.test.distributed.testsuite">DistTestSuite</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/test/distributed/testsuite/DistTestSuite.html#testJSONInputSpark(org.apache.hadoop.fs.FileSystem,%20java.util.ArrayList)">testJSONInputSpark(FileSystem, ArrayList&lt;JSONObject&gt;)</a></span> - Static method in class org.apache.pirk.test.distributed.testsuite.<a href="../org/apache/pirk/test/distributed/testsuite/DistTestSuite.html" title="class in org.apache.pirk.test.distributed.testsuite">DistTestSuite</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/KeyedHashTest.html#testKeyedHash()">testKeyedHash()</a></span> - Method in class test.general.<a href="../test/general/KeyedHashTest.html" title="class in test.general">KeyedHashTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/KeyedHashTest.html#testKeyedHash()">testKeyedHash()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general">KeyedHashTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/KeyedHashTest.html#testKeyedHashWithType()">testKeyedHashWithType()</a></span> - Method in class test.general.<a href="../test/general/KeyedHashTest.html" title="class in test.general">KeyedHashTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/KeyedHashTest.html#testKeyedHashWithType()">testKeyedHashWithType()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general">KeyedHashTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/PartitionUtilsTest.html#testMask()">testMask()</a></span> - Method in class test.general.<a href="../test/general/PartitionUtilsTest.html" title="class in test.general">PartitionUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/PartitionUtilsTest.html#testMask()">testMask()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general">PartitionUtilsTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/PaillierTest.html#testPaillerWithKeyGenerationGeneral()">testPaillerWithKeyGenerationGeneral()</a></span> - Method in class test.general.<a href="../test/general/PaillierTest.html" title="class in test.general">PaillierTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/PaillierTest.html#testPaillerWithKeyGenerationGeneral()">testPaillerWithKeyGenerationGeneral()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general">PaillierTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/PaillierTest.html#testPaillierGivenAllParameters()">testPaillierGivenAllParameters()</a></span> - Method in class test.general.<a href="../test/general/PaillierTest.html" title="class in test.general">PaillierTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/PaillierTest.html#testPaillierGivenAllParameters()">testPaillierGivenAllParameters()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general">PaillierTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/PaillierTest.html#testPaillierWithKeyGeneration()">testPaillierWithKeyGeneration()</a></span> - Method in class test.general.<a href="../test/general/PaillierTest.html" title="class in test.general">PaillierTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/PaillierTest.html#testPaillierWithKeyGeneration()">testPaillierWithKeyGeneration()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general">PaillierTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/PaillierTest.html#testPaillierWithKeyGenerationBitSetOption(int)">testPaillierWithKeyGenerationBitSetOption(int)</a></span> - Method in class test.general.<a href="../test/general/PaillierTest.html" title="class in test.general">PaillierTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/PaillierTest.html#testPaillierWithKeyGenerationBitSetOption(int)">testPaillierWithKeyGenerationBitSetOption(int)</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general">PaillierTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/PartitionUtilsTest.html#testPartitionBits()">testPartitionBits()</a></span> - Method in class test.general.<a href="../test/general/PartitionUtilsTest.html" title="class in test.general">PartitionUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/PartitionUtilsTest.html#testPartitionBits()">testPartitionBits()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general">PartitionUtilsTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/PartitionUtilsTest.html#testPartitions()">testPartitions()</a></span> - Method in class test.general.<a href="../test/general/PartitionUtilsTest.html" title="class in test.general">PartitionUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/PartitionUtilsTest.html#testPartitions()">testPartitions()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general">PartitionUtilsTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/PaillierTest.html#testPIRExceptions()">testPIRExceptions()</a></span> - Method in class test.general.<a href="../test/general/PaillierTest.html" title="class in test.general">PaillierTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/PaillierTest.html#testPIRExceptions()">testPIRExceptions()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general">PaillierTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#testQueryFieldDoesNotExist()">testQueryFieldDoesNotExist()</a></span> - Method in class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#testQueryFieldDoesNotExist()">testQueryFieldDoesNotExist()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/schema/query/LoadQuerySchemaTest.html#testSelectorDoesNotExistInDataSchema()">testSelectorDoesNotExistInDataSchema()</a></span> - Method in class test.schema.query.<a href="../test/schema/query/LoadQuerySchemaTest.html" title="class in test.schema.query">LoadQuerySchemaTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/schema/query/LoadQuerySchemaTest.html#testSelectorDoesNotExistInDataSchema()">testSelectorDoesNotExistInDataSchema()</a></span> - Method in class org.apache.pirk.schema.query.<a href="../org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query">LoadQuerySchemaTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#testSingleQuery()">testSingleQuery()</a></span> - Method in class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#testSingleQuery()">testSingleQuery()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#testSingleValueRangeQuery()">testSingleValueRangeQuery()</a></span> - Method in class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#testSingleValueRangeQuery()">testSingleValueRangeQuery()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/test/utils/BaseTests.html#testSRCIPQuery(java.util.ArrayList,%20int)">testSRCIPQuery(ArrayList&lt;JSONObject&gt;, int)</a></span> - Static method in class org.apache.pirk.test.utils.<a href="../org/apache/pirk/test/utils/BaseTests.html" title="class in org.apache.pirk.test.utils">BaseTests</a></dt>
 <dd>&nbsp;</dd>
@@ -163,9 +159,9 @@
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/test/utils/BaseTests.html#testSRCIPQueryNoFilter(java.util.ArrayList,%20org.apache.hadoop.fs.FileSystem,%20boolean,%20boolean,%20int)">testSRCIPQueryNoFilter(ArrayList&lt;JSONObject&gt;, FileSystem, boolean, boolean, int)</a></span> - Static method in class org.apache.pirk.test.utils.<a href="../org/apache/pirk/test/utils/BaseTests.html" title="class in org.apache.pirk.test.utils">BaseTests</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/schema/query/LoadQuerySchemaTest.html#testUnknownFilterClass()">testUnknownFilterClass()</a></span> - Method in class test.schema.query.<a href="../test/schema/query/LoadQuerySchemaTest.html" title="class in test.schema.query">LoadQuerySchemaTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/schema/query/LoadQuerySchemaTest.html#testUnknownFilterClass()">testUnknownFilterClass()</a></span> - Method in class org.apache.pirk.schema.query.<a href="../org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query">LoadQuerySchemaTest</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/schema/data/LoadDataSchemaTest.html#testUnknownPartitioner()">testUnknownPartitioner()</a></span> - Method in class test.schema.data.<a href="../test/schema/data/LoadDataSchemaTest.html" title="class in test.schema.data">LoadDataSchemaTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/schema/data/LoadDataSchemaTest.html#testUnknownPartitioner()">testUnknownPartitioner()</a></span> - Method in class org.apache.pirk.schema.data.<a href="../org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data">LoadDataSchemaTest</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="../org/apache/pirk/test/utils/TestUtils.html" title="class in org.apache.pirk.test.utils"><span class="strong">TestUtils</span></a> - Class in <a href="../org/apache/pirk/test/utils/package-summary.html">org.apache.pirk.test.utils</a></dt>
 <dd>
@@ -173,7 +169,7 @@
 </dd>
 <dt><span class="strong"><a href="../org/apache/pirk/test/utils/TestUtils.html#TestUtils()">TestUtils()</a></span> - Constructor for class org.apache.pirk.test.utils.<a href="../org/apache/pirk/test/utils/TestUtils.html" title="class in org.apache.pirk.test.utils">TestUtils</a></dt>
 <dd>&nbsp;</dd>
-<dt><span class="strong"><a href="../test/general/QueryParserUtilsTest.html#testWildcardQuery()">testWildcardQuery()</a></span> - Method in class test.general.<a href="../test/general/QueryParserUtilsTest.html" title="class in test.general">QueryParserUtilsTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/QueryParserUtilsTest.html#testWildcardQuery()">testWildcardQuery()</a></span> - Method in class org.apache.pirk.general.<a href="../org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general">QueryParserUtilsTest</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/benchmark/PaillierBenchmark.html#testWithGMP(org.apache.pirk.benchmark.PaillierBenchmark.PaillierBenchmarkState)">testWithGMP(PaillierBenchmark.PaillierBenchmarkState)</a></span> - Method in class org.apache.pirk.benchmark.<a href="../org/apache/pirk/benchmark/PaillierBenchmark.html" title="class in org.apache.pirk.benchmark">PaillierBenchmark</a></dt>
 <dd>&nbsp;</dd>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-21.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-21.html b/docs/index-files/index-21.html
index f037197..8ecac31 100644
--- a/docs/index-files/index-21.html
+++ b/docs/index-files/index-21.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>U-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-22.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-22.html b/docs/index-files/index-22.html
index cdc30d1..e3d0ba3 100644
--- a/docs/index-files/index-22.html
+++ b/docs/index-files/index-22.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>V-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-23.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-23.html b/docs/index-files/index-23.html
index 2405cbf..bbe4bfa 100644
--- a/docs/index-files/index-23.html
+++ b/docs/index-files/index-23.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>W-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-3.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-3.html b/docs/index-files/index-3.html
index fd06893..ea5437c 100644
--- a/docs/index-files/index-3.html
+++ b/docs/index-files/index-3.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>C-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>
@@ -127,6 +127,14 @@
 <dd>
 <div class="block">Clear the properties</div>
 </dd>
+<dt><span class="strong"><a href="../org/apache/pirk/schema/data/DataSchemaRegistry.html#clearRegistry()">clearRegistry()</a></span> - Static method in class org.apache.pirk.schema.data.<a href="../org/apache/pirk/schema/data/DataSchemaRegistry.html" title="class in org.apache.pirk.schema.data">DataSchemaRegistry</a></dt>
+<dd>
+<div class="block">Clear the registry</div>
+</dd>
+<dt><span class="strong"><a href="../org/apache/pirk/schema/query/QuerySchemaRegistry.html#clearRegistry()">clearRegistry()</a></span> - Static method in class org.apache.pirk.schema.query.<a href="../org/apache/pirk/schema/query/QuerySchemaRegistry.html" title="class in org.apache.pirk.schema.query">QuerySchemaRegistry</a></dt>
+<dd>
+<div class="block">Clear the registry</div>
+</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/encryption/Paillier.html#clone()">clone()</a></span> - Method in class org.apache.pirk.encryption.<a href="../org/apache/pirk/encryption/Paillier.html" title="class in org.apache.pirk.encryption">Paillier</a></dt>
 <dd>&nbsp;</dd>
 <dt><span class="strong"><a href="../org/apache/pirk/inputformat/hadoop/json/JSONRecordReader.html#close()">close()</a></span> - Method in class org.apache.pirk.inputformat.hadoop.json.<a href="../org/apache/pirk/inputformat/hadoop/json/JSONRecordReader.html" title="class in org.apache.pirk.inputformat.hadoop.json">JSONRecordReader</a></dt>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-4.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-4.html b/docs/index-files/index-4.html
index 7801804..41732ea 100644
--- a/docs/index-files/index-4.html
+++ b/docs/index-files/index-4.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>D-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-5.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-5.html b/docs/index-files/index-5.html
index 363ab56..b069def 100644
--- a/docs/index-files/index-5.html
+++ b/docs/index-files/index-5.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>E-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-6.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-6.html b/docs/index-files/index-6.html
index 7d696c4..f3c2cb3 100644
--- a/docs/index-files/index-6.html
+++ b/docs/index-files/index-6.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>F-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-7.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-7.html b/docs/index-files/index-7.html
index e826717..6e87b5a 100644
--- a/docs/index-files/index-7.html
+++ b/docs/index-files/index-7.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>G-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-8.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-8.html b/docs/index-files/index-8.html
index 523121f..1b62607 100644
--- a/docs/index-files/index-8.html
+++ b/docs/index-files/index-8.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>H-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index-files/index-9.html
----------------------------------------------------------------------
diff --git a/docs/index-files/index-9.html b/docs/index-files/index-9.html
index 36c34e5..cecad00 100644
--- a/docs/index-files/index-9.html
+++ b/docs/index-files/index-9.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>I-Index</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../stylesheet.css" title="Style">
 </head>
 <body>
@@ -137,11 +137,11 @@
 </dd>
 <dt><span class="strong"><a href="../org/apache/pirk/utils/ISO8601DateParser.html#ISO8601DateParser()">ISO8601DateParser()</a></span> - Constructor for class org.apache.pirk.utils.<a href="../org/apache/pirk/utils/ISO8601DateParser.html" title="class in org.apache.pirk.utils">ISO8601DateParser</a></dt>
 <dd>&nbsp;</dd>
-<dt><a href="../test/general/ISO8601DateParserTest.html" title="class in test.general"><span class="strong">ISO8601DateParserTest</span></a> - Class in <a href="../test/general/package-summary.html">test.general</a></dt>
+<dt><a href="../org/apache/pirk/general/ISO8601DateParserTest.html" title="class in org.apache.pirk.general"><span class="strong">ISO8601DateParserTest</span></a> - Class in <a href="../org/apache/pirk/general/package-summary.html">org.apache.pirk.general</a></dt>
 <dd>
 <div class="block">Class to test basic functionality of ISO8601DateParser class</div>
 </dd>
-<dt><span class="strong"><a href="../test/general/ISO8601DateParserTest.html#ISO8601DateParserTest()">ISO8601DateParserTest()</a></span> - Constructor for class test.general.<a href="../test/general/ISO8601DateParserTest.html" title="class in test.general">ISO8601DateParserTest</a></dt>
+<dt><span class="strong"><a href="../org/apache/pirk/general/ISO8601DateParserTest.html#ISO8601DateParserTest()">ISO8601DateParserTest()</a></span> - Constructor for class org.apache.pirk.general.<a href="../org/apache/pirk/general/ISO8601DateParserTest.html" title="class in org.apache.pirk.general">ISO8601DateParserTest</a></dt>
 <dd>&nbsp;</dd>
 <dt><a href="../org/apache/pirk/schema/data/partitioner/ISO8601DatePartitioner.html" title="class in org.apache.pirk.schema.data.partitioner"><span class="strong">ISO8601DatePartitioner</span></a> - Class in <a href="../org/apache/pirk/schema/data/partitioner/package-summary.html">org.apache.pirk.schema.data.partitioner</a></dt>
 <dd>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/index.html
----------------------------------------------------------------------
diff --git a/docs/index.html b/docs/index.html
index f73a4c1..4b2fb36 100644
--- a/docs/index.html
+++ b/docs/index.html
@@ -2,7 +2,7 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Generated Documentation (Untitled)</title>
 <script type="text/javascript">
     targetPage = "" + window.location.search;

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/benchmark/BenchmarkDriver.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/benchmark/BenchmarkDriver.html b/docs/org/apache/pirk/benchmark/BenchmarkDriver.html
index 4d8bff5..631d1c7 100644
--- a/docs/org/apache/pirk/benchmark/BenchmarkDriver.html
+++ b/docs/org/apache/pirk/benchmark/BenchmarkDriver.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>BenchmarkDriver</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/benchmark/PaillierBenchmark.PaillierBenchmarkState.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/benchmark/PaillierBenchmark.PaillierBenchmarkState.html b/docs/org/apache/pirk/benchmark/PaillierBenchmark.PaillierBenchmarkState.html
index 7f87710..7ad5680 100644
--- a/docs/org/apache/pirk/benchmark/PaillierBenchmark.PaillierBenchmarkState.html
+++ b/docs/org/apache/pirk/benchmark/PaillierBenchmark.PaillierBenchmarkState.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>PaillierBenchmark.PaillierBenchmarkState</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/benchmark/PaillierBenchmark.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/benchmark/PaillierBenchmark.html b/docs/org/apache/pirk/benchmark/PaillierBenchmark.html
index d2fb08d..009cbf9 100644
--- a/docs/org/apache/pirk/benchmark/PaillierBenchmark.html
+++ b/docs/org/apache/pirk/benchmark/PaillierBenchmark.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>PaillierBenchmark</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/benchmark/class-use/BenchmarkDriver.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/benchmark/class-use/BenchmarkDriver.html b/docs/org/apache/pirk/benchmark/class-use/BenchmarkDriver.html
index ae6ed65..c5504f4 100644
--- a/docs/org/apache/pirk/benchmark/class-use/BenchmarkDriver.html
+++ b/docs/org/apache/pirk/benchmark/class-use/BenchmarkDriver.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.benchmark.BenchmarkDriver</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/benchmark/class-use/PaillierBenchmark.PaillierBenchmarkState.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/benchmark/class-use/PaillierBenchmark.PaillierBenchmarkState.html b/docs/org/apache/pirk/benchmark/class-use/PaillierBenchmark.PaillierBenchmarkState.html
index 40429d6..cea7e46 100644
--- a/docs/org/apache/pirk/benchmark/class-use/PaillierBenchmark.PaillierBenchmarkState.html
+++ b/docs/org/apache/pirk/benchmark/class-use/PaillierBenchmark.PaillierBenchmarkState.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.benchmark.PaillierBenchmark.PaillierBenchmarkState</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/benchmark/class-use/PaillierBenchmark.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/benchmark/class-use/PaillierBenchmark.html b/docs/org/apache/pirk/benchmark/class-use/PaillierBenchmark.html
index 800d84c..2209e45 100644
--- a/docs/org/apache/pirk/benchmark/class-use/PaillierBenchmark.html
+++ b/docs/org/apache/pirk/benchmark/class-use/PaillierBenchmark.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.benchmark.PaillierBenchmark</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/benchmark/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/benchmark/package-frame.html b/docs/org/apache/pirk/benchmark/package-frame.html
index c471c81..2c59a93 100644
--- a/docs/org/apache/pirk/benchmark/package-frame.html
+++ b/docs/org/apache/pirk/benchmark/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.benchmark</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/benchmark/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/benchmark/package-summary.html b/docs/org/apache/pirk/benchmark/package-summary.html
index de80e40..f4bacc1 100644
--- a/docs/org/apache/pirk/benchmark/package-summary.html
+++ b/docs/org/apache/pirk/benchmark/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.benchmark</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/benchmark/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/benchmark/package-tree.html b/docs/org/apache/pirk/benchmark/package-tree.html
index 3aa3617..90af91f 100644
--- a/docs/org/apache/pirk/benchmark/package-tree.html
+++ b/docs/org/apache/pirk/benchmark/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.benchmark Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/benchmark/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/benchmark/package-use.html b/docs/org/apache/pirk/benchmark/package-use.html
index a841bc3..49e569d 100644
--- a/docs/org/apache/pirk/benchmark/package-use.html
+++ b/docs/org/apache/pirk/benchmark/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.benchmark</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/encryption/ModPowAbstraction.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/encryption/ModPowAbstraction.html b/docs/org/apache/pirk/encryption/ModPowAbstraction.html
index 4ceca3a..96857b6 100644
--- a/docs/org/apache/pirk/encryption/ModPowAbstraction.html
+++ b/docs/org/apache/pirk/encryption/ModPowAbstraction.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>ModPowAbstraction</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/encryption/Paillier.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/encryption/Paillier.html b/docs/org/apache/pirk/encryption/Paillier.html
index cefdb00..c69f67b 100644
--- a/docs/org/apache/pirk/encryption/Paillier.html
+++ b/docs/org/apache/pirk/encryption/Paillier.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>Paillier</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/encryption/PrimeGenerator.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/encryption/PrimeGenerator.html b/docs/org/apache/pirk/encryption/PrimeGenerator.html
index 7205155..3c806f3 100644
--- a/docs/org/apache/pirk/encryption/PrimeGenerator.html
+++ b/docs/org/apache/pirk/encryption/PrimeGenerator.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>PrimeGenerator</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/encryption/class-use/ModPowAbstraction.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/encryption/class-use/ModPowAbstraction.html b/docs/org/apache/pirk/encryption/class-use/ModPowAbstraction.html
index ece7db3..9e9dda3 100644
--- a/docs/org/apache/pirk/encryption/class-use/ModPowAbstraction.html
+++ b/docs/org/apache/pirk/encryption/class-use/ModPowAbstraction.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.encryption.ModPowAbstraction</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/encryption/class-use/Paillier.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/encryption/class-use/Paillier.html b/docs/org/apache/pirk/encryption/class-use/Paillier.html
index 1f06afd..88bafe6 100644
--- a/docs/org/apache/pirk/encryption/class-use/Paillier.html
+++ b/docs/org/apache/pirk/encryption/class-use/Paillier.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.encryption.Paillier</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/encryption/class-use/PrimeGenerator.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/encryption/class-use/PrimeGenerator.html b/docs/org/apache/pirk/encryption/class-use/PrimeGenerator.html
index c31fb82..f1e5f26 100644
--- a/docs/org/apache/pirk/encryption/class-use/PrimeGenerator.html
+++ b/docs/org/apache/pirk/encryption/class-use/PrimeGenerator.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.encryption.PrimeGenerator</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/encryption/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/encryption/package-frame.html b/docs/org/apache/pirk/encryption/package-frame.html
index 6b30f51..8a9ce71 100644
--- a/docs/org/apache/pirk/encryption/package-frame.html
+++ b/docs/org/apache/pirk/encryption/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.encryption</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/encryption/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/encryption/package-summary.html b/docs/org/apache/pirk/encryption/package-summary.html
index 0299cd1..c3e830a 100644
--- a/docs/org/apache/pirk/encryption/package-summary.html
+++ b/docs/org/apache/pirk/encryption/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.encryption</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -37,7 +37,7 @@
 <div class="subNav">
 <ul class="navList">
 <li><a href="../../../../org/apache/pirk/benchmark/package-summary.html">Prev Package</a></li>
-<li><a href="../../../../org/apache/pirk/inputformat/hadoop/package-summary.html">Next Package</a></li>
+<li><a href="../../../../org/apache/pirk/general/package-summary.html">Next Package</a></li>
 </ul>
 <ul class="navList">
 <li><a href="../../../../index.html?org/apache/pirk/encryption/package-summary.html" target="_top">Frames</a></li>
@@ -118,7 +118,7 @@
 <div class="subNav">
 <ul class="navList">
 <li><a href="../../../../org/apache/pirk/benchmark/package-summary.html">Prev Package</a></li>
-<li><a href="../../../../org/apache/pirk/inputformat/hadoop/package-summary.html">Next Package</a></li>
+<li><a href="../../../../org/apache/pirk/general/package-summary.html">Next Package</a></li>
 </ul>
 <ul class="navList">
 <li><a href="../../../../index.html?org/apache/pirk/encryption/package-summary.html" target="_top">Frames</a></li>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/encryption/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/encryption/package-tree.html b/docs/org/apache/pirk/encryption/package-tree.html
index 6394786..d8fa439 100644
--- a/docs/org/apache/pirk/encryption/package-tree.html
+++ b/docs/org/apache/pirk/encryption/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>org.apache.pirk.encryption Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -37,7 +37,7 @@
 <div class="subNav">
 <ul class="navList">
 <li><a href="../../../../org/apache/pirk/benchmark/package-tree.html">Prev</a></li>
-<li><a href="../../../../org/apache/pirk/inputformat/hadoop/package-tree.html">Next</a></li>
+<li><a href="../../../../org/apache/pirk/general/package-tree.html">Next</a></li>
 </ul>
 <ul class="navList">
 <li><a href="../../../../index.html?org/apache/pirk/encryption/package-tree.html" target="_top">Frames</a></li>
@@ -101,7 +101,7 @@
 <div class="subNav">
 <ul class="navList">
 <li><a href="../../../../org/apache/pirk/benchmark/package-tree.html">Prev</a></li>
-<li><a href="../../../../org/apache/pirk/inputformat/hadoop/package-tree.html">Next</a></li>
+<li><a href="../../../../org/apache/pirk/general/package-tree.html">Next</a></li>
 </ul>
 <ul class="navList">
 <li><a href="../../../../index.html?org/apache/pirk/encryption/package-tree.html" target="_top">Frames</a></li>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/encryption/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/encryption/package-use.html b/docs/org/apache/pirk/encryption/package-use.html
index 5ce099f..943ebc6 100644
--- a/docs/org/apache/pirk/encryption/package-use.html
+++ b/docs/org/apache/pirk/encryption/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.encryption</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/ISO8601DateParserTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/ISO8601DateParserTest.html b/docs/org/apache/pirk/general/ISO8601DateParserTest.html
new file mode 100644
index 0000000..bd89b5c
--- /dev/null
+++ b/docs/org/apache/pirk/general/ISO8601DateParserTest.html
@@ -0,0 +1,260 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
+<title>ISO8601DateParserTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="ISO8601DateParserTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/ISO8601DateParserTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev Class</li>
+<li><a href="../../../../org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general"><span class="strong">Next Class</span></a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/ISO8601DateParserTest.html" target="_top">Frames</a></li>
+<li><a href="ISO8601DateParserTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<!-- ======== START OF CLASS DATA ======== -->
+<div class="header">
+<div class="subTitle">org.apache.pirk.general</div>
+<h2 title="Class ISO8601DateParserTest" class="title">Class ISO8601DateParserTest</h2>
+</div>
+<div class="contentContainer">
+<ul class="inheritance">
+<li>java.lang.Object</li>
+<li>
+<ul class="inheritance">
+<li>org.apache.pirk.general.ISO8601DateParserTest</li>
+</ul>
+</li>
+</ul>
+<div class="description">
+<ul class="blockList">
+<li class="blockList">
+<hr>
+<br>
+<pre>public class <span class="strong">ISO8601DateParserTest</span>
+extends java.lang.Object</pre>
+<div class="block">Class to test basic functionality of ISO8601DateParser class</div>
+</li>
+</ul>
+</div>
+<div class="summary">
+<ul class="blockList">
+<li class="blockList">
+<!-- ======== CONSTRUCTOR SUMMARY ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_summary">
+<!--   -->
+</a>
+<h3>Constructor Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Constructor Summary table, listing constructors, and an explanation">
+<caption><span>Constructors</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colOne" scope="col">Constructor and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colOne"><code><strong><a href="../../../../org/apache/pirk/general/ISO8601DateParserTest.html#ISO8601DateParserTest()">ISO8601DateParserTest</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+</li>
+</ul>
+<!-- ========== METHOD SUMMARY =========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_summary">
+<!--   -->
+</a>
+<h3>Method Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Method Summary table, listing methods, and an explanation">
+<caption><span>Methods</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th class="colLast" scope="col">Method and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/ISO8601DateParserTest.html#testDateParsing()">testDateParsing</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+<ul class="blockList">
+<li class="blockList"><a name="methods_inherited_from_class_java.lang.Object">
+<!--   -->
+</a>
+<h3>Methods inherited from class&nbsp;java.lang.Object</h3>
+<code>equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait</code></li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+<div class="details">
+<ul class="blockList">
+<li class="blockList">
+<!-- ========= CONSTRUCTOR DETAIL ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_detail">
+<!--   -->
+</a>
+<h3>Constructor Detail</h3>
+<a name="ISO8601DateParserTest()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>ISO8601DateParserTest</h4>
+<pre>public&nbsp;ISO8601DateParserTest()</pre>
+</li>
+</ul>
+</li>
+</ul>
+<!-- ============ METHOD DETAIL ========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_detail">
+<!--   -->
+</a>
+<h3>Method Detail</h3>
+<a name="testDateParsing()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>testDateParsing</h4>
+<pre>public&nbsp;void&nbsp;testDateParsing()
+                     throws java.text.ParseException</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.text.ParseException</code></dd></dl>
+</li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+</div>
+<!-- ========= END OF CLASS DATA ========= -->
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/ISO8601DateParserTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev Class</li>
+<li><a href="../../../../org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general"><span class="strong">Next Class</span></a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/ISO8601DateParserTest.html" target="_top">Frames</a></li>
+<li><a href="ISO8601DateParserTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/KeyedHashTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/KeyedHashTest.html b/docs/org/apache/pirk/general/KeyedHashTest.html
new file mode 100644
index 0000000..d7daa8f
--- /dev/null
+++ b/docs/org/apache/pirk/general/KeyedHashTest.html
@@ -0,0 +1,270 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
+<title>KeyedHashTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="KeyedHashTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/KeyedHashTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../org/apache/pirk/general/ISO8601DateParserTest.html" title="class in org.apache.pirk.general"><span class="strong">Prev Class</span></a></li>
+<li><a href="../../../../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general"><span class="strong">Next Class</span></a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/KeyedHashTest.html" target="_top">Frames</a></li>
+<li><a href="KeyedHashTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<!-- ======== START OF CLASS DATA ======== -->
+<div class="header">
+<div class="subTitle">org.apache.pirk.general</div>
+<h2 title="Class KeyedHashTest" class="title">Class KeyedHashTest</h2>
+</div>
+<div class="contentContainer">
+<ul class="inheritance">
+<li>java.lang.Object</li>
+<li>
+<ul class="inheritance">
+<li>org.apache.pirk.general.KeyedHashTest</li>
+</ul>
+</li>
+</ul>
+<div class="description">
+<ul class="blockList">
+<li class="blockList">
+<hr>
+<br>
+<pre>public class <span class="strong">KeyedHashTest</span>
+extends java.lang.Object</pre>
+<div class="block">Basic functional tests for KeyedHash</div>
+</li>
+</ul>
+</div>
+<div class="summary">
+<ul class="blockList">
+<li class="blockList">
+<!-- ======== CONSTRUCTOR SUMMARY ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_summary">
+<!--   -->
+</a>
+<h3>Constructor Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Constructor Summary table, listing constructors, and an explanation">
+<caption><span>Constructors</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colOne" scope="col">Constructor and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colOne"><code><strong><a href="../../../../org/apache/pirk/general/KeyedHashTest.html#KeyedHashTest()">KeyedHashTest</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+</li>
+</ul>
+<!-- ========== METHOD SUMMARY =========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_summary">
+<!--   -->
+</a>
+<h3>Method Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Method Summary table, listing methods, and an explanation">
+<caption><span>Methods</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th class="colLast" scope="col">Method and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/KeyedHashTest.html#testKeyedHash()">testKeyedHash</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/KeyedHashTest.html#testKeyedHashWithType()">testKeyedHashWithType</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+<ul class="blockList">
+<li class="blockList"><a name="methods_inherited_from_class_java.lang.Object">
+<!--   -->
+</a>
+<h3>Methods inherited from class&nbsp;java.lang.Object</h3>
+<code>equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait</code></li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+<div class="details">
+<ul class="blockList">
+<li class="blockList">
+<!-- ========= CONSTRUCTOR DETAIL ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_detail">
+<!--   -->
+</a>
+<h3>Constructor Detail</h3>
+<a name="KeyedHashTest()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>KeyedHashTest</h4>
+<pre>public&nbsp;KeyedHashTest()</pre>
+</li>
+</ul>
+</li>
+</ul>
+<!-- ============ METHOD DETAIL ========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_detail">
+<!--   -->
+</a>
+<h3>Method Detail</h3>
+<a name="testKeyedHash()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testKeyedHash</h4>
+<pre>public&nbsp;void&nbsp;testKeyedHash()</pre>
+</li>
+</ul>
+<a name="testKeyedHashWithType()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>testKeyedHashWithType</h4>
+<pre>public&nbsp;void&nbsp;testKeyedHashWithType()</pre>
+</li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+</div>
+<!-- ========= END OF CLASS DATA ========= -->
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/KeyedHashTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../org/apache/pirk/general/ISO8601DateParserTest.html" title="class in org.apache.pirk.general"><span class="strong">Prev Class</span></a></li>
+<li><a href="../../../../org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general"><span class="strong">Next Class</span></a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/KeyedHashTest.html" target="_top">Frames</a></li>
+<li><a href="KeyedHashTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/general/PaillierTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/general/PaillierTest.html b/docs/org/apache/pirk/general/PaillierTest.html
new file mode 100644
index 0000000..fbb989b
--- /dev/null
+++ b/docs/org/apache/pirk/general/PaillierTest.html
@@ -0,0 +1,334 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
+<title>PaillierTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="PaillierTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/PaillierTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general"><span class="strong">Prev Class</span></a></li>
+<li><a href="../../../../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general"><span class="strong">Next Class</span></a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/PaillierTest.html" target="_top">Frames</a></li>
+<li><a href="PaillierTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<!-- ======== START OF CLASS DATA ======== -->
+<div class="header">
+<div class="subTitle">org.apache.pirk.general</div>
+<h2 title="Class PaillierTest" class="title">Class PaillierTest</h2>
+</div>
+<div class="contentContainer">
+<ul class="inheritance">
+<li>java.lang.Object</li>
+<li>
+<ul class="inheritance">
+<li>org.apache.pirk.general.PaillierTest</li>
+</ul>
+</li>
+</ul>
+<div class="description">
+<ul class="blockList">
+<li class="blockList">
+<hr>
+<br>
+<pre>public class <span class="strong">PaillierTest</span>
+extends java.lang.Object</pre>
+<div class="block">Basic test functionality for Paillier library</div>
+</li>
+</ul>
+</div>
+<div class="summary">
+<ul class="blockList">
+<li class="blockList">
+<!-- ======== CONSTRUCTOR SUMMARY ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_summary">
+<!--   -->
+</a>
+<h3>Constructor Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Constructor Summary table, listing constructors, and an explanation">
+<caption><span>Constructors</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colOne" scope="col">Constructor and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colOne"><code><strong><a href="../../../../org/apache/pirk/general/PaillierTest.html#PaillierTest()">PaillierTest</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+</li>
+</ul>
+<!-- ========== METHOD SUMMARY =========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_summary">
+<!--   -->
+</a>
+<h3>Method Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Method Summary table, listing methods, and an explanation">
+<caption><span>Methods</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th class="colLast" scope="col">Method and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>static void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/PaillierTest.html#setup()">setup</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/PaillierTest.html#testPaillerWithKeyGenerationGeneral()">testPaillerWithKeyGenerationGeneral</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/PaillierTest.html#testPaillierGivenAllParameters()">testPaillierGivenAllParameters</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/PaillierTest.html#testPaillierWithKeyGeneration()">testPaillierWithKeyGeneration</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/PaillierTest.html#testPaillierWithKeyGenerationBitSetOption(int)">testPaillierWithKeyGenerationBitSetOption</a></strong>(int&nbsp;ensureBitSet)</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../org/apache/pirk/general/PaillierTest.html#testPIRExceptions()">testPIRExceptions</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+<ul class="blockList">
+<li class="blockList"><a name="methods_inherited_from_class_java.lang.Object">
+<!--   -->
+</a>
+<h3>Methods inherited from class&nbsp;java.lang.Object</h3>
+<code>equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait</code></li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+<div class="details">
+<ul class="blockList">
+<li class="blockList">
+<!-- ========= CONSTRUCTOR DETAIL ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_detail">
+<!--   -->
+</a>
+<h3>Constructor Detail</h3>
+<a name="PaillierTest()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>PaillierTest</h4>
+<pre>public&nbsp;PaillierTest()</pre>
+</li>
+</ul>
+</li>
+</ul>
+<!-- ============ METHOD DETAIL ========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_detail">
+<!--   -->
+</a>
+<h3>Method Detail</h3>
+<a name="setup()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>setup</h4>
+<pre>public static&nbsp;void&nbsp;setup()</pre>
+</li>
+</ul>
+<a name="testPIRExceptions()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testPIRExceptions</h4>
+<pre>public&nbsp;void&nbsp;testPIRExceptions()</pre>
+</li>
+</ul>
+<a name="testPaillierGivenAllParameters()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testPaillierGivenAllParameters</h4>
+<pre>public&nbsp;void&nbsp;testPaillierGivenAllParameters()
+                                    throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+<a name="testPaillierWithKeyGeneration()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testPaillierWithKeyGeneration</h4>
+<pre>public&nbsp;void&nbsp;testPaillierWithKeyGeneration()
+                                   throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+<a name="testPaillerWithKeyGenerationGeneral()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testPaillerWithKeyGenerationGeneral</h4>
+<pre>public&nbsp;void&nbsp;testPaillerWithKeyGenerationGeneral()
+                                         throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+<a name="testPaillierWithKeyGenerationBitSetOption(int)">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>testPaillierWithKeyGenerationBitSetOption</h4>
+<pre>public&nbsp;void&nbsp;testPaillierWithKeyGenerationBitSetOption(int&nbsp;ensureBitSet)
+                                               throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+</div>
+<!-- ========= END OF CLASS DATA ========= -->
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/PaillierTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general"><span class="strong">Prev Class</span></a></li>
+<li><a href="../../../../org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general"><span class="strong">Next Class</span></a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../index.html?org/apache/pirk/general/PaillierTest.html" target="_top">Frames</a></li>
+<li><a href="PaillierTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>



[3/9] incubator-pirk git commit: [PIRK-37]: Rename package for test classes to be org.apache.pirk.* -- closes apache/incubator-pirk#39

Posted by ea...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/EpochDateParser.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/EpochDateParser.html b/docs/org/apache/pirk/utils/EpochDateParser.html
index 1af7867..d2603c6 100644
--- a/docs/org/apache/pirk/utils/EpochDateParser.html
+++ b/docs/org/apache/pirk/utils/EpochDateParser.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>EpochDateParser</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/FileConst.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/FileConst.html b/docs/org/apache/pirk/utils/FileConst.html
index d50c051..40b55dd 100644
--- a/docs/org/apache/pirk/utils/FileConst.html
+++ b/docs/org/apache/pirk/utils/FileConst.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>FileConst</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/FileIOUtils.Callable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/FileIOUtils.Callable.html b/docs/org/apache/pirk/utils/FileIOUtils.Callable.html
index 5267ec3..638aefd 100644
--- a/docs/org/apache/pirk/utils/FileIOUtils.Callable.html
+++ b/docs/org/apache/pirk/utils/FileIOUtils.Callable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>FileIOUtils.Callable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/FileIOUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/FileIOUtils.html b/docs/org/apache/pirk/utils/FileIOUtils.html
index 02db718..bc7d6cb 100644
--- a/docs/org/apache/pirk/utils/FileIOUtils.html
+++ b/docs/org/apache/pirk/utils/FileIOUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>FileIOUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/HDFS.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/HDFS.html b/docs/org/apache/pirk/utils/HDFS.html
index 3259dfd..6bee89f 100644
--- a/docs/org/apache/pirk/utils/HDFS.html
+++ b/docs/org/apache/pirk/utils/HDFS.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>HDFS</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/ISO8601DateParser.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/ISO8601DateParser.html b/docs/org/apache/pirk/utils/ISO8601DateParser.html
index 23ace43..6459f61 100644
--- a/docs/org/apache/pirk/utils/ISO8601DateParser.html
+++ b/docs/org/apache/pirk/utils/ISO8601DateParser.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>ISO8601DateParser</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/KeyedHash.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/KeyedHash.html b/docs/org/apache/pirk/utils/KeyedHash.html
index b9324bb..f33fe3c 100644
--- a/docs/org/apache/pirk/utils/KeyedHash.html
+++ b/docs/org/apache/pirk/utils/KeyedHash.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>KeyedHash</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/PIRException.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/PIRException.html b/docs/org/apache/pirk/utils/PIRException.html
index c1e5b9c..9f0a21d 100644
--- a/docs/org/apache/pirk/utils/PIRException.html
+++ b/docs/org/apache/pirk/utils/PIRException.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>PIRException</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/QueryParserUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/QueryParserUtils.html b/docs/org/apache/pirk/utils/QueryParserUtils.html
index 6396fcf..e37ec00 100644
--- a/docs/org/apache/pirk/utils/QueryParserUtils.html
+++ b/docs/org/apache/pirk/utils/QueryParserUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>QueryParserUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/StopListUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/StopListUtils.html b/docs/org/apache/pirk/utils/StopListUtils.html
index 711292e..c5c2053 100644
--- a/docs/org/apache/pirk/utils/StopListUtils.html
+++ b/docs/org/apache/pirk/utils/StopListUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>StopListUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/StringUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/StringUtils.html b/docs/org/apache/pirk/utils/StringUtils.html
index a8733e9..b21050c 100644
--- a/docs/org/apache/pirk/utils/StringUtils.html
+++ b/docs/org/apache/pirk/utils/StringUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>StringUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/SystemConfiguration.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/SystemConfiguration.html b/docs/org/apache/pirk/utils/SystemConfiguration.html
index 74feecc..4f62eb7 100644
--- a/docs/org/apache/pirk/utils/SystemConfiguration.html
+++ b/docs/org/apache/pirk/utils/SystemConfiguration.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>SystemConfiguration</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/CSVOutputUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/CSVOutputUtils.html b/docs/org/apache/pirk/utils/class-use/CSVOutputUtils.html
index 6024c43..11f2103 100644
--- a/docs/org/apache/pirk/utils/class-use/CSVOutputUtils.html
+++ b/docs/org/apache/pirk/utils/class-use/CSVOutputUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.utils.CSVOutputUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/EpochDateParser.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/EpochDateParser.html b/docs/org/apache/pirk/utils/class-use/EpochDateParser.html
index 8914f14..5dc6112 100644
--- a/docs/org/apache/pirk/utils/class-use/EpochDateParser.html
+++ b/docs/org/apache/pirk/utils/class-use/EpochDateParser.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.utils.EpochDateParser</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/FileConst.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/FileConst.html b/docs/org/apache/pirk/utils/class-use/FileConst.html
index 27d8018..ec9795b 100644
--- a/docs/org/apache/pirk/utils/class-use/FileConst.html
+++ b/docs/org/apache/pirk/utils/class-use/FileConst.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.utils.FileConst</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/FileIOUtils.Callable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/FileIOUtils.Callable.html b/docs/org/apache/pirk/utils/class-use/FileIOUtils.Callable.html
index 7007b59..19dd9e4 100644
--- a/docs/org/apache/pirk/utils/class-use/FileIOUtils.Callable.html
+++ b/docs/org/apache/pirk/utils/class-use/FileIOUtils.Callable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Interface org.apache.pirk.utils.FileIOUtils.Callable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/FileIOUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/FileIOUtils.html b/docs/org/apache/pirk/utils/class-use/FileIOUtils.html
index 5a55c85..6892b7f 100644
--- a/docs/org/apache/pirk/utils/class-use/FileIOUtils.html
+++ b/docs/org/apache/pirk/utils/class-use/FileIOUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.utils.FileIOUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/HDFS.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/HDFS.html b/docs/org/apache/pirk/utils/class-use/HDFS.html
index 2bf7d03..9880f45 100644
--- a/docs/org/apache/pirk/utils/class-use/HDFS.html
+++ b/docs/org/apache/pirk/utils/class-use/HDFS.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.utils.HDFS</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/ISO8601DateParser.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/ISO8601DateParser.html b/docs/org/apache/pirk/utils/class-use/ISO8601DateParser.html
index 72e7513..4f04d44 100644
--- a/docs/org/apache/pirk/utils/class-use/ISO8601DateParser.html
+++ b/docs/org/apache/pirk/utils/class-use/ISO8601DateParser.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.utils.ISO8601DateParser</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/KeyedHash.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/KeyedHash.html b/docs/org/apache/pirk/utils/class-use/KeyedHash.html
index ecc7e5e..0cd3f24 100644
--- a/docs/org/apache/pirk/utils/class-use/KeyedHash.html
+++ b/docs/org/apache/pirk/utils/class-use/KeyedHash.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.utils.KeyedHash</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/PIRException.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/PIRException.html b/docs/org/apache/pirk/utils/class-use/PIRException.html
index 8accf4d..fd0a839 100644
--- a/docs/org/apache/pirk/utils/class-use/PIRException.html
+++ b/docs/org/apache/pirk/utils/class-use/PIRException.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.utils.PIRException</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/QueryParserUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/QueryParserUtils.html b/docs/org/apache/pirk/utils/class-use/QueryParserUtils.html
index e3bd732..c169a8e 100644
--- a/docs/org/apache/pirk/utils/class-use/QueryParserUtils.html
+++ b/docs/org/apache/pirk/utils/class-use/QueryParserUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.utils.QueryParserUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/StopListUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/StopListUtils.html b/docs/org/apache/pirk/utils/class-use/StopListUtils.html
index 55f9722..c316c3b 100644
--- a/docs/org/apache/pirk/utils/class-use/StopListUtils.html
+++ b/docs/org/apache/pirk/utils/class-use/StopListUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.utils.StopListUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/StringUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/StringUtils.html b/docs/org/apache/pirk/utils/class-use/StringUtils.html
index bad0da6..b9b2bab 100644
--- a/docs/org/apache/pirk/utils/class-use/StringUtils.html
+++ b/docs/org/apache/pirk/utils/class-use/StringUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.utils.StringUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/class-use/SystemConfiguration.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/class-use/SystemConfiguration.html b/docs/org/apache/pirk/utils/class-use/SystemConfiguration.html
index 1dd2818..5114f93 100644
--- a/docs/org/apache/pirk/utils/class-use/SystemConfiguration.html
+++ b/docs/org/apache/pirk/utils/class-use/SystemConfiguration.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.utils.SystemConfiguration</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/package-frame.html b/docs/org/apache/pirk/utils/package-frame.html
index 3998bba..b9bff79 100644
--- a/docs/org/apache/pirk/utils/package-frame.html
+++ b/docs/org/apache/pirk/utils/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.utils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/package-summary.html b/docs/org/apache/pirk/utils/package-summary.html
index ebd1265..b5c64d0 100644
--- a/docs/org/apache/pirk/utils/package-summary.html
+++ b/docs/org/apache/pirk/utils/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.utils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -37,7 +37,7 @@
 <div class="subNav">
 <ul class="navList">
 <li><a href="../../../../org/apache/pirk/test/utils/package-summary.html">Prev Package</a></li>
-<li><a href="../../../../test/general/package-summary.html">Next Package</a></li>
+<li><a href="../../../../org/apache/pirk/wideskies/standalone/package-summary.html">Next Package</a></li>
 </ul>
 <ul class="navList">
 <li><a href="../../../../index.html?org/apache/pirk/utils/package-summary.html" target="_top">Frames</a></li>
@@ -198,7 +198,7 @@
 <div class="subNav">
 <ul class="navList">
 <li><a href="../../../../org/apache/pirk/test/utils/package-summary.html">Prev Package</a></li>
-<li><a href="../../../../test/general/package-summary.html">Next Package</a></li>
+<li><a href="../../../../org/apache/pirk/wideskies/standalone/package-summary.html">Next Package</a></li>
 </ul>
 <ul class="navList">
 <li><a href="../../../../index.html?org/apache/pirk/utils/package-summary.html" target="_top">Frames</a></li>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/package-tree.html b/docs/org/apache/pirk/utils/package-tree.html
index a879fce..238ccee 100644
--- a/docs/org/apache/pirk/utils/package-tree.html
+++ b/docs/org/apache/pirk/utils/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.utils Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -37,7 +37,7 @@
 <div class="subNav">
 <ul class="navList">
 <li><a href="../../../../org/apache/pirk/test/utils/package-tree.html">Prev</a></li>
-<li><a href="../../../../test/general/package-tree.html">Next</a></li>
+<li><a href="../../../../org/apache/pirk/wideskies/standalone/package-tree.html">Next</a></li>
 </ul>
 <ul class="navList">
 <li><a href="../../../../index.html?org/apache/pirk/utils/package-tree.html" target="_top">Frames</a></li>
@@ -122,7 +122,7 @@
 <div class="subNav">
 <ul class="navList">
 <li><a href="../../../../org/apache/pirk/test/utils/package-tree.html">Prev</a></li>
-<li><a href="../../../../test/general/package-tree.html">Next</a></li>
+<li><a href="../../../../org/apache/pirk/wideskies/standalone/package-tree.html">Next</a></li>
 </ul>
 <ul class="navList">
 <li><a href="../../../../index.html?org/apache/pirk/utils/package-tree.html" target="_top">Frames</a></li>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/package-use.html b/docs/org/apache/pirk/utils/package-use.html
index 5d50442..b727011 100644
--- a/docs/org/apache/pirk/utils/package-use.html
+++ b/docs/org/apache/pirk/utils/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.utils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/wideskies/standalone/StandaloneTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/wideskies/standalone/StandaloneTest.html b/docs/org/apache/pirk/wideskies/standalone/StandaloneTest.html
new file mode 100644
index 0000000..b1e205d
--- /dev/null
+++ b/docs/org/apache/pirk/wideskies/standalone/StandaloneTest.html
@@ -0,0 +1,295 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
+<title>StandaloneTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="StandaloneTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/StandaloneTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev Class</li>
+<li>Next Class</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/wideskies/standalone/StandaloneTest.html" target="_top">Frames</a></li>
+<li><a href="StandaloneTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<!-- ======== START OF CLASS DATA ======== -->
+<div class="header">
+<div class="subTitle">org.apache.pirk.wideskies.standalone</div>
+<h2 title="Class StandaloneTest" class="title">Class StandaloneTest</h2>
+</div>
+<div class="contentContainer">
+<ul class="inheritance">
+<li>java.lang.Object</li>
+<li>
+<ul class="inheritance">
+<li>org.apache.pirk.wideskies.standalone.StandaloneTest</li>
+</ul>
+</li>
+</ul>
+<div class="description">
+<ul class="blockList">
+<li class="blockList">
+<hr>
+<br>
+<pre>public class <span class="strong">StandaloneTest</span>
+extends java.lang.Object</pre>
+<div class="block">Functional test suite for stand alone testing - non Spark applications
+ <p>
+ Tests low side module and basic encryption, decryption mechanisms
+ <p>
+ Using a fixed 8-bit data partition size (consistent with the currently codebase)
+ <p>
+ Runs with useExpLookupTable = false as generating the lookup table takes too long for normal in-memory builds</div>
+</li>
+</ul>
+</div>
+<div class="summary">
+<ul class="blockList">
+<li class="blockList">
+<!-- ======== CONSTRUCTOR SUMMARY ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_summary">
+<!--   -->
+</a>
+<h3>Constructor Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Constructor Summary table, listing constructors, and an explanation">
+<caption><span>Constructors</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colOne" scope="col">Constructor and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colOne"><code><strong><a href="../../../../../org/apache/pirk/wideskies/standalone/StandaloneTest.html#StandaloneTest()">StandaloneTest</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+</li>
+</ul>
+<!-- ========== METHOD SUMMARY =========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_summary">
+<!--   -->
+</a>
+<h3>Method Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Method Summary table, listing methods, and an explanation">
+<caption><span>Methods</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th class="colLast" scope="col">Method and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/wideskies/standalone/StandaloneTest.html#runTests()">runTests</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>static void</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/wideskies/standalone/StandaloneTest.html#setup()">setup</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>static void</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/wideskies/standalone/StandaloneTest.html#teardown()">teardown</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+<ul class="blockList">
+<li class="blockList"><a name="methods_inherited_from_class_java.lang.Object">
+<!--   -->
+</a>
+<h3>Methods inherited from class&nbsp;java.lang.Object</h3>
+<code>equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait</code></li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+<div class="details">
+<ul class="blockList">
+<li class="blockList">
+<!-- ========= CONSTRUCTOR DETAIL ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_detail">
+<!--   -->
+</a>
+<h3>Constructor Detail</h3>
+<a name="StandaloneTest()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>StandaloneTest</h4>
+<pre>public&nbsp;StandaloneTest()</pre>
+</li>
+</ul>
+</li>
+</ul>
+<!-- ============ METHOD DETAIL ========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_detail">
+<!--   -->
+</a>
+<h3>Method Detail</h3>
+<a name="setup()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>setup</h4>
+<pre>public static&nbsp;void&nbsp;setup()
+                  throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+<a name="teardown()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>teardown</h4>
+<pre>public static&nbsp;void&nbsp;teardown()</pre>
+</li>
+</ul>
+<a name="runTests()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>runTests</h4>
+<pre>public&nbsp;void&nbsp;runTests()
+              throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+</div>
+<!-- ========= END OF CLASS DATA ========= -->
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/StandaloneTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev Class</li>
+<li>Next Class</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/wideskies/standalone/StandaloneTest.html" target="_top">Frames</a></li>
+<li><a href="StandaloneTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/wideskies/standalone/class-use/StandaloneTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/wideskies/standalone/class-use/StandaloneTest.html b/docs/org/apache/pirk/wideskies/standalone/class-use/StandaloneTest.html
new file mode 100644
index 0000000..b81e40d
--- /dev/null
+++ b/docs/org/apache/pirk/wideskies/standalone/class-use/StandaloneTest.html
@@ -0,0 +1,115 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>Uses of Class org.apache.pirk.wideskies.standalone.StandaloneTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="Uses of Class org.apache.pirk.wideskies.standalone.StandaloneTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../../org/apache/pirk/wideskies/standalone/StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../../index.html?org/apache/pirk/wideskies/standalone/class-use/StandaloneTest.html" target="_top">Frames</a></li>
+<li><a href="StandaloneTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h2 title="Uses of Class org.apache.pirk.wideskies.standalone.StandaloneTest" class="title">Uses of Class<br>org.apache.pirk.wideskies.standalone.StandaloneTest</h2>
+</div>
+<div class="classUseContainer">No usage of org.apache.pirk.wideskies.standalone.StandaloneTest</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../../org/apache/pirk/wideskies/standalone/StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../../index.html?org/apache/pirk/wideskies/standalone/class-use/StandaloneTest.html" target="_top">Frames</a></li>
+<li><a href="StandaloneTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/wideskies/standalone/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/wideskies/standalone/package-frame.html b/docs/org/apache/pirk/wideskies/standalone/package-frame.html
new file mode 100644
index 0000000..72ee28f
--- /dev/null
+++ b/docs/org/apache/pirk/wideskies/standalone/package-frame.html
@@ -0,0 +1,19 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>org.apache.pirk.wideskies.standalone</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<h1 class="bar"><a href="../../../../../org/apache/pirk/wideskies/standalone/package-summary.html" target="classFrame">org.apache.pirk.wideskies.standalone</a></h1>
+<div class="indexContainer">
+<h2 title="Classes">Classes</h2>
+<ul title="Classes">
+<li><a href="StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone" target="classFrame">StandaloneTest</a></li>
+</ul>
+</div>
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/wideskies/standalone/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/wideskies/standalone/package-summary.html b/docs/org/apache/pirk/wideskies/standalone/package-summary.html
new file mode 100644
index 0000000..e5ebf26
--- /dev/null
+++ b/docs/org/apache/pirk/wideskies/standalone/package-summary.html
@@ -0,0 +1,135 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>org.apache.pirk.wideskies.standalone</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="org.apache.pirk.wideskies.standalone";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li class="navBarCell1Rev">Package</li>
+<li>Class</li>
+<li><a href="package-use.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../../org/apache/pirk/utils/package-summary.html">Prev Package</a></li>
+<li>Next Package</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/wideskies/standalone/package-summary.html" target="_top">Frames</a></li>
+<li><a href="package-summary.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h1 title="Package" class="title">Package&nbsp;org.apache.pirk.wideskies.standalone</h1>
+</div>
+<div class="contentContainer">
+<ul class="blockList">
+<li class="blockList">
+<table class="packageSummary" border="0" cellpadding="3" cellspacing="0" summary="Class Summary table, listing classes, and an explanation">
+<caption><span>Class Summary</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Class</th>
+<th class="colLast" scope="col">Description</th>
+</tr>
+<tbody>
+<tr class="altColor">
+<td class="colFirst"><a href="../../../../../org/apache/pirk/wideskies/standalone/StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone">StandaloneTest</a></td>
+<td class="colLast">
+<div class="block">Functional test suite for stand alone testing - non Spark applications</div>
+</td>
+</tr>
+</tbody>
+</table>
+</li>
+</ul>
+</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li class="navBarCell1Rev">Package</li>
+<li>Class</li>
+<li><a href="package-use.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../../org/apache/pirk/utils/package-summary.html">Prev Package</a></li>
+<li>Next Package</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/wideskies/standalone/package-summary.html" target="_top">Frames</a></li>
+<li><a href="package-summary.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/wideskies/standalone/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/wideskies/standalone/package-tree.html b/docs/org/apache/pirk/wideskies/standalone/package-tree.html
new file mode 100644
index 0000000..ac1818f
--- /dev/null
+++ b/docs/org/apache/pirk/wideskies/standalone/package-tree.html
@@ -0,0 +1,128 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>org.apache.pirk.wideskies.standalone Class Hierarchy</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="org.apache.pirk.wideskies.standalone Class Hierarchy";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li>Class</li>
+<li>Use</li>
+<li class="navBarCell1Rev">Tree</li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../../org/apache/pirk/utils/package-tree.html">Prev</a></li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/wideskies/standalone/package-tree.html" target="_top">Frames</a></li>
+<li><a href="package-tree.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h1 class="title">Hierarchy For Package org.apache.pirk.wideskies.standalone</h1>
+<span class="strong">Package Hierarchies:</span>
+<ul class="horizontal">
+<li><a href="../../../../../overview-tree.html">All Packages</a></li>
+</ul>
+</div>
+<div class="contentContainer">
+<h2 title="Class Hierarchy">Class Hierarchy</h2>
+<ul>
+<li type="circle">java.lang.Object
+<ul>
+<li type="circle">org.apache.pirk.wideskies.standalone.<a href="../../../../../org/apache/pirk/wideskies/standalone/StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone"><span class="strong">StandaloneTest</span></a></li>
+</ul>
+</li>
+</ul>
+</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li>Class</li>
+<li>Use</li>
+<li class="navBarCell1Rev">Tree</li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li><a href="../../../../../org/apache/pirk/utils/package-tree.html">Prev</a></li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/wideskies/standalone/package-tree.html" target="_top">Frames</a></li>
+<li><a href="package-tree.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/wideskies/standalone/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/wideskies/standalone/package-use.html b/docs/org/apache/pirk/wideskies/standalone/package-use.html
new file mode 100644
index 0000000..98ba478
--- /dev/null
+++ b/docs/org/apache/pirk/wideskies/standalone/package-use.html
@@ -0,0 +1,115 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>Uses of Package org.apache.pirk.wideskies.standalone</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="Uses of Package org.apache.pirk.wideskies.standalone";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li>Class</li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/wideskies/standalone/package-use.html" target="_top">Frames</a></li>
+<li><a href="package-use.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h1 title="Uses of Package org.apache.pirk.wideskies.standalone" class="title">Uses of Package<br>org.apache.pirk.wideskies.standalone</h1>
+</div>
+<div class="contentContainer">No usage of org.apache.pirk.wideskies.standalone</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li>Class</li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/wideskies/standalone/package-use.html" target="_top">Frames</a></li>
+<li><a href="package-use.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/overview-frame.html
----------------------------------------------------------------------
diff --git a/docs/overview-frame.html b/docs/overview-frame.html
index 2525399..610bbc7 100644
--- a/docs/overview-frame.html
+++ b/docs/overview-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>Overview List</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>
@@ -14,6 +14,7 @@
 <ul title="Packages">
 <li><a href="org/apache/pirk/benchmark/package-frame.html" target="packageFrame">org.apache.pirk.benchmark</a></li>
 <li><a href="org/apache/pirk/encryption/package-frame.html" target="packageFrame">org.apache.pirk.encryption</a></li>
+<li><a href="org/apache/pirk/general/package-frame.html" target="packageFrame">org.apache.pirk.general</a></li>
 <li><a href="org/apache/pirk/inputformat/hadoop/package-frame.html" target="packageFrame">org.apache.pirk.inputformat.hadoop</a></li>
 <li><a href="org/apache/pirk/inputformat/hadoop/json/package-frame.html" target="packageFrame">org.apache.pirk.inputformat.hadoop.json</a></li>
 <li><a href="org/apache/pirk/querier/wideskies/package-frame.html" target="packageFrame">org.apache.pirk.querier.wideskies</a></li>
@@ -36,10 +37,7 @@
 <li><a href="org/apache/pirk/test/distributed/testsuite/package-frame.html" target="packageFrame">org.apache.pirk.test.distributed.testsuite</a></li>
 <li><a href="org/apache/pirk/test/utils/package-frame.html" target="packageFrame">org.apache.pirk.test.utils</a></li>
 <li><a href="org/apache/pirk/utils/package-frame.html" target="packageFrame">org.apache.pirk.utils</a></li>
-<li><a href="test/general/package-frame.html" target="packageFrame">test.general</a></li>
-<li><a href="test/schema/data/package-frame.html" target="packageFrame">test.schema.data</a></li>
-<li><a href="test/schema/query/package-frame.html" target="packageFrame">test.schema.query</a></li>
-<li><a href="test/wideskies/standalone/package-frame.html" target="packageFrame">test.wideskies.standalone</a></li>
+<li><a href="org/apache/pirk/wideskies/standalone/package-frame.html" target="packageFrame">org.apache.pirk.wideskies.standalone</a></li>
 </ul>
 </div>
 <p>&nbsp;</p>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/overview-summary.html
----------------------------------------------------------------------
diff --git a/docs/overview-summary.html b/docs/overview-summary.html
index 1f5a56d..d9fecc0 100644
--- a/docs/overview-summary.html
+++ b/docs/overview-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Overview</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>
@@ -79,107 +79,99 @@
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a href="org/apache/pirk/inputformat/hadoop/package-summary.html">org.apache.pirk.inputformat.hadoop</a></td>
+<td class="colFirst"><a href="org/apache/pirk/general/package-summary.html">org.apache.pirk.general</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a href="org/apache/pirk/inputformat/hadoop/json/package-summary.html">org.apache.pirk.inputformat.hadoop.json</a></td>
-<td class="colLast">&nbsp;</td>
-</tr>
-<tr class="altColor">
-<td class="colFirst"><a href="org/apache/pirk/querier/wideskies/package-summary.html">org.apache.pirk.querier.wideskies</a></td>
-<td class="colLast">&nbsp;</td>
-</tr>
-<tr class="rowColor">
-<td class="colFirst"><a href="org/apache/pirk/querier/wideskies/decrypt/package-summary.html">org.apache.pirk.querier.wideskies.decrypt</a></td>
+<td class="colFirst"><a href="org/apache/pirk/inputformat/hadoop/package-summary.html">org.apache.pirk.inputformat.hadoop</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a href="org/apache/pirk/querier/wideskies/encrypt/package-summary.html">org.apache.pirk.querier.wideskies.encrypt</a></td>
+<td class="colFirst"><a href="org/apache/pirk/inputformat/hadoop/json/package-summary.html">org.apache.pirk.inputformat.hadoop.json</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a href="org/apache/pirk/query/wideskies/package-summary.html">org.apache.pirk.query.wideskies</a></td>
+<td class="colFirst"><a href="org/apache/pirk/querier/wideskies/package-summary.html">org.apache.pirk.querier.wideskies</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a href="org/apache/pirk/responder/wideskies/package-summary.html">org.apache.pirk.responder.wideskies</a></td>
+<td class="colFirst"><a href="org/apache/pirk/querier/wideskies/decrypt/package-summary.html">org.apache.pirk.querier.wideskies.decrypt</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a href="org/apache/pirk/responder/wideskies/common/package-summary.html">org.apache.pirk.responder.wideskies.common</a></td>
+<td class="colFirst"><a href="org/apache/pirk/querier/wideskies/encrypt/package-summary.html">org.apache.pirk.querier.wideskies.encrypt</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a href="org/apache/pirk/responder/wideskies/mapreduce/package-summary.html">org.apache.pirk.responder.wideskies.mapreduce</a></td>
+<td class="colFirst"><a href="org/apache/pirk/query/wideskies/package-summary.html">org.apache.pirk.query.wideskies</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a href="org/apache/pirk/responder/wideskies/spark/package-summary.html">org.apache.pirk.responder.wideskies.spark</a></td>
+<td class="colFirst"><a href="org/apache/pirk/responder/wideskies/package-summary.html">org.apache.pirk.responder.wideskies</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a href="org/apache/pirk/responder/wideskies/standalone/package-summary.html">org.apache.pirk.responder.wideskies.standalone</a></td>
+<td class="colFirst"><a href="org/apache/pirk/responder/wideskies/common/package-summary.html">org.apache.pirk.responder.wideskies.common</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a href="org/apache/pirk/response/wideskies/package-summary.html">org.apache.pirk.response.wideskies</a></td>
+<td class="colFirst"><a href="org/apache/pirk/responder/wideskies/mapreduce/package-summary.html">org.apache.pirk.responder.wideskies.mapreduce</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a href="org/apache/pirk/schema/data/package-summary.html">org.apache.pirk.schema.data</a></td>
+<td class="colFirst"><a href="org/apache/pirk/responder/wideskies/spark/package-summary.html">org.apache.pirk.responder.wideskies.spark</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a href="org/apache/pirk/schema/data/partitioner/package-summary.html">org.apache.pirk.schema.data.partitioner</a></td>
+<td class="colFirst"><a href="org/apache/pirk/responder/wideskies/standalone/package-summary.html">org.apache.pirk.responder.wideskies.standalone</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a href="org/apache/pirk/schema/query/package-summary.html">org.apache.pirk.schema.query</a></td>
+<td class="colFirst"><a href="org/apache/pirk/response/wideskies/package-summary.html">org.apache.pirk.response.wideskies</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a href="org/apache/pirk/schema/query/filter/package-summary.html">org.apache.pirk.schema.query.filter</a></td>
+<td class="colFirst"><a href="org/apache/pirk/schema/data/package-summary.html">org.apache.pirk.schema.data</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a href="org/apache/pirk/schema/response/package-summary.html">org.apache.pirk.schema.response</a></td>
+<td class="colFirst"><a href="org/apache/pirk/schema/data/partitioner/package-summary.html">org.apache.pirk.schema.data.partitioner</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a href="org/apache/pirk/serialization/package-summary.html">org.apache.pirk.serialization</a></td>
+<td class="colFirst"><a href="org/apache/pirk/schema/query/package-summary.html">org.apache.pirk.schema.query</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a href="org/apache/pirk/test/distributed/package-summary.html">org.apache.pirk.test.distributed</a></td>
+<td class="colFirst"><a href="org/apache/pirk/schema/query/filter/package-summary.html">org.apache.pirk.schema.query.filter</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a href="org/apache/pirk/test/distributed/testsuite/package-summary.html">org.apache.pirk.test.distributed.testsuite</a></td>
+<td class="colFirst"><a href="org/apache/pirk/schema/response/package-summary.html">org.apache.pirk.schema.response</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a href="org/apache/pirk/test/utils/package-summary.html">org.apache.pirk.test.utils</a></td>
+<td class="colFirst"><a href="org/apache/pirk/serialization/package-summary.html">org.apache.pirk.serialization</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a href="org/apache/pirk/utils/package-summary.html">org.apache.pirk.utils</a></td>
+<td class="colFirst"><a href="org/apache/pirk/test/distributed/package-summary.html">org.apache.pirk.test.distributed</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a href="test/general/package-summary.html">test.general</a></td>
+<td class="colFirst"><a href="org/apache/pirk/test/distributed/testsuite/package-summary.html">org.apache.pirk.test.distributed.testsuite</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a href="test/schema/data/package-summary.html">test.schema.data</a></td>
+<td class="colFirst"><a href="org/apache/pirk/test/utils/package-summary.html">org.apache.pirk.test.utils</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="altColor">
-<td class="colFirst"><a href="test/schema/query/package-summary.html">test.schema.query</a></td>
+<td class="colFirst"><a href="org/apache/pirk/utils/package-summary.html">org.apache.pirk.utils</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 <tr class="rowColor">
-<td class="colFirst"><a href="test/wideskies/standalone/package-summary.html">test.wideskies.standalone</a></td>
+<td class="colFirst"><a href="org/apache/pirk/wideskies/standalone/package-summary.html">org.apache.pirk.wideskies.standalone</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>
 </tbody>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/overview-tree.html
----------------------------------------------------------------------
diff --git a/docs/overview-tree.html b/docs/overview-tree.html
index f6c6f68..41cd050 100644
--- a/docs/overview-tree.html
+++ b/docs/overview-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>
@@ -68,6 +68,7 @@
 <ul class="horizontal">
 <li><a href="org/apache/pirk/benchmark/package-tree.html">org.apache.pirk.benchmark</a>, </li>
 <li><a href="org/apache/pirk/encryption/package-tree.html">org.apache.pirk.encryption</a>, </li>
+<li><a href="org/apache/pirk/general/package-tree.html">org.apache.pirk.general</a>, </li>
 <li><a href="org/apache/pirk/inputformat/hadoop/package-tree.html">org.apache.pirk.inputformat.hadoop</a>, </li>
 <li><a href="org/apache/pirk/inputformat/hadoop/json/package-tree.html">org.apache.pirk.inputformat.hadoop.json</a>, </li>
 <li><a href="org/apache/pirk/querier/wideskies/package-tree.html">org.apache.pirk.querier.wideskies</a>, </li>
@@ -90,10 +91,7 @@
 <li><a href="org/apache/pirk/test/distributed/testsuite/package-tree.html">org.apache.pirk.test.distributed.testsuite</a>, </li>
 <li><a href="org/apache/pirk/test/utils/package-tree.html">org.apache.pirk.test.utils</a>, </li>
 <li><a href="org/apache/pirk/utils/package-tree.html">org.apache.pirk.utils</a>, </li>
-<li><a href="test/general/package-tree.html">test.general</a>, </li>
-<li><a href="test/schema/data/package-tree.html">test.schema.data</a>, </li>
-<li><a href="test/schema/query/package-tree.html">test.schema.query</a>, </li>
-<li><a href="test/wideskies/standalone/package-tree.html">test.wideskies.standalone</a></li>
+<li><a href="org/apache/pirk/wideskies/standalone/package-tree.html">org.apache.pirk.wideskies.standalone</a></li>
 </ul>
 </div>
 <div class="contentContainer">
@@ -164,12 +162,12 @@
 <li type="circle">org.apache.pirk.test.utils.<a href="org/apache/pirk/test/utils/Inputs.html" title="class in org.apache.pirk.test.utils"><span class="strong">Inputs</span></a></li>
 <li type="circle">org.apache.pirk.schema.data.partitioner.<a href="org/apache/pirk/schema/data/partitioner/IPDataPartitioner.html" title="class in org.apache.pirk.schema.data.partitioner"><span class="strong">IPDataPartitioner</span></a> (implements org.apache.pirk.schema.data.partitioner.<a href="org/apache/pirk/schema/data/partitioner/DataPartitioner.html" title="interface in org.apache.pirk.schema.data.partitioner">DataPartitioner</a>)</li>
 <li type="circle">org.apache.pirk.utils.<a href="org/apache/pirk/utils/ISO8601DateParser.html" title="class in org.apache.pirk.utils"><span class="strong">ISO8601DateParser</span></a></li>
-<li type="circle">test.general.<a href="test/general/ISO8601DateParserTest.html" title="class in test.general"><span class="strong">ISO8601DateParserTest</span></a></li>
+<li type="circle">org.apache.pirk.general.<a href="org/apache/pirk/general/ISO8601DateParserTest.html" title="class in org.apache.pirk.general"><span class="strong">ISO8601DateParserTest</span></a></li>
 <li type="circle">org.apache.pirk.schema.data.partitioner.<a href="org/apache/pirk/schema/data/partitioner/ISO8601DatePartitioner.html" title="class in org.apache.pirk.schema.data.partitioner"><span class="strong">ISO8601DatePartitioner</span></a> (implements org.apache.pirk.schema.data.partitioner.<a href="org/apache/pirk/schema/data/partitioner/DataPartitioner.html" title="interface in org.apache.pirk.schema.data.partitioner">DataPartitioner</a>)</li>
 <li type="circle">org.apache.pirk.utils.<a href="org/apache/pirk/utils/KeyedHash.html" title="class in org.apache.pirk.utils"><span class="strong">KeyedHash</span></a></li>
-<li type="circle">test.general.<a href="test/general/KeyedHashTest.html" title="class in test.general"><span class="strong">KeyedHashTest</span></a></li>
-<li type="circle">test.schema.data.<a href="test/schema/data/LoadDataSchemaTest.html" title="class in test.schema.data"><span class="strong">LoadDataSchemaTest</span></a></li>
-<li type="circle">test.schema.query.<a href="test/schema/query/LoadQuerySchemaTest.html" title="class in test.schema.query"><span class="strong">LoadQuerySchemaTest</span></a></li>
+<li type="circle">org.apache.pirk.general.<a href="org/apache/pirk/general/KeyedHashTest.html" title="class in org.apache.pirk.general"><span class="strong">KeyedHashTest</span></a></li>
+<li type="circle">org.apache.pirk.schema.data.<a href="org/apache/pirk/schema/data/LoadDataSchemaTest.html" title="class in org.apache.pirk.schema.data"><span class="strong">LoadDataSchemaTest</span></a></li>
+<li type="circle">org.apache.pirk.schema.query.<a href="org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query"><span class="strong">LoadQuerySchemaTest</span></a></li>
 <li type="circle">org.apache.pirk.serialization.<a href="org/apache/pirk/serialization/LocalFileSystemStore.html" title="class in org.apache.pirk.serialization"><span class="strong">LocalFileSystemStore</span></a></li>
 <li type="circle">org.apache.hadoop.mapreduce.Mapper&lt;KEYIN,VALUEIN,KEYOUT,VALUEOUT&gt;
 <ul>
@@ -182,8 +180,8 @@
 <li type="circle">org.apache.pirk.encryption.<a href="org/apache/pirk/encryption/Paillier.html" title="class in org.apache.pirk.encryption"><span class="strong">Paillier</span></a> (implements java.lang.Cloneable, java.io.Serializable)</li>
 <li type="circle">org.apache.pirk.benchmark.<a href="org/apache/pirk/benchmark/PaillierBenchmark.html" title="class in org.apache.pirk.benchmark"><span class="strong">PaillierBenchmark</span></a></li>
 <li type="circle">org.apache.pirk.benchmark.<a href="org/apache/pirk/benchmark/PaillierBenchmark.PaillierBenchmarkState.html" title="class in org.apache.pirk.benchmark"><span class="strong">PaillierBenchmark.PaillierBenchmarkState</span></a></li>
-<li type="circle">test.general.<a href="test/general/PaillierTest.html" title="class in test.general"><span class="strong">PaillierTest</span></a></li>
-<li type="circle">test.general.<a href="test/general/PartitionUtilsTest.html" title="class in test.general"><span class="strong">PartitionUtilsTest</span></a></li>
+<li type="circle">org.apache.pirk.general.<a href="org/apache/pirk/general/PaillierTest.html" title="class in org.apache.pirk.general"><span class="strong">PaillierTest</span></a></li>
+<li type="circle">org.apache.pirk.general.<a href="org/apache/pirk/general/PartitionUtilsTest.html" title="class in org.apache.pirk.general"><span class="strong">PartitionUtilsTest</span></a></li>
 <li type="circle">org.apache.pirk.encryption.<a href="org/apache/pirk/encryption/PrimeGenerator.html" title="class in org.apache.pirk.encryption"><span class="strong">PrimeGenerator</span></a></li>
 <li type="circle">org.apache.pirk.schema.data.partitioner.<a href="org/apache/pirk/schema/data/partitioner/PrimitiveTypePartitioner.html" title="class in org.apache.pirk.schema.data.partitioner"><span class="strong">PrimitiveTypePartitioner</span></a> (implements org.apache.pirk.schema.data.partitioner.<a href="org/apache/pirk/schema/data/partitioner/DataPartitioner.html" title="interface in org.apache.pirk.schema.data.partitioner">DataPartitioner</a>)</li>
 <li type="circle">org.apache.pirk.querier.wideskies.<a href="org/apache/pirk/querier/wideskies/Querier.html" title="class in org.apache.pirk.querier.wideskies"><span class="strong">Querier</span></a> (implements java.io.Serializable, org.apache.pirk.serialization.<a href="org/apache/pirk/serialization/Storable.html" title="interface in org.apache.pirk.serialization">Storable</a>)</li>
@@ -194,7 +192,7 @@
 <li type="circle">org.apache.pirk.query.wideskies.<a href="org/apache/pirk/query/wideskies/Query.html" title="class in org.apache.pirk.query.wideskies"><span class="strong">Query</span></a> (implements java.io.Serializable, org.apache.pirk.serialization.<a href="org/apache/pirk/serialization/Storable.html" title="interface in org.apache.pirk.serialization">Storable</a>)</li>
 <li type="circle">org.apache.pirk.query.wideskies.<a href="org/apache/pirk/query/wideskies/QueryInfo.html" title="class in org.apache.pirk.query.wideskies"><span class="strong">QueryInfo</span></a> (implements java.io.Serializable)</li>
 <li type="circle">org.apache.pirk.utils.<a href="org/apache/pirk/utils/QueryParserUtils.html" title="class in org.apache.pirk.utils"><span class="strong">QueryParserUtils</span></a></li>
-<li type="circle">test.general.<a href="test/general/QueryParserUtilsTest.html" title="class in test.general"><span class="strong">QueryParserUtilsTest</span></a></li>
+<li type="circle">org.apache.pirk.general.<a href="org/apache/pirk/general/QueryParserUtilsTest.html" title="class in org.apache.pirk.general"><span class="strong">QueryParserUtilsTest</span></a></li>
 <li type="circle">org.apache.pirk.schema.response.<a href="org/apache/pirk/schema/response/QueryResponseJSON.html" title="class in org.apache.pirk.schema.response"><span class="strong">QueryResponseJSON</span></a> (implements java.io.Serializable)</li>
 <li type="circle">org.apache.pirk.schema.query.<a href="org/apache/pirk/schema/query/QuerySchema.html" title="class in org.apache.pirk.schema.query"><span class="strong">QuerySchema</span></a> (implements java.io.Serializable)</li>
 <li type="circle">org.apache.pirk.schema.query.<a href="org/apache/pirk/schema/query/QuerySchemaLoader.html" title="class in org.apache.pirk.schema.query"><span class="strong">QuerySchemaLoader</span></a></li>
@@ -225,7 +223,7 @@
 </ul>
 </li>
 <li type="circle">org.apache.pirk.test.utils.<a href="org/apache/pirk/test/utils/StandaloneQuery.html" title="class in org.apache.pirk.test.utils"><span class="strong">StandaloneQuery</span></a></li>
-<li type="circle">test.wideskies.standalone.<a href="test/wideskies/standalone/StandaloneTest.html" title="class in test.wideskies.standalone"><span class="strong">StandaloneTest</span></a></li>
+<li type="circle">org.apache.pirk.wideskies.standalone.<a href="org/apache/pirk/wideskies/standalone/StandaloneTest.html" title="class in org.apache.pirk.wideskies.standalone"><span class="strong">StandaloneTest</span></a></li>
 <li type="circle">org.apache.pirk.schema.query.filter.<a href="org/apache/pirk/schema/query/filter/StopListFilter.html" title="class in org.apache.pirk.schema.query.filter"><span class="strong">StopListFilter</span></a> (implements org.apache.pirk.schema.query.filter.<a href="org/apache/pirk/schema/query/filter/DataFilter.html" title="interface in org.apache.pirk.schema.query.filter">DataFilter</a>)</li>
 <li type="circle">org.apache.pirk.utils.<a href="org/apache/pirk/utils/StopListUtils.html" title="class in org.apache.pirk.utils"><span class="strong">StopListUtils</span></a></li>
 <li type="circle">org.apache.pirk.utils.<a href="org/apache/pirk/utils/StringUtils.html" title="class in org.apache.pirk.utils"><span class="strong">StringUtils</span></a></li>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/package-list
----------------------------------------------------------------------
diff --git a/docs/package-list b/docs/package-list
index c517554..66c9a80 100644
--- a/docs/package-list
+++ b/docs/package-list
@@ -1,5 +1,6 @@
 org.apache.pirk.benchmark
 org.apache.pirk.encryption
+org.apache.pirk.general
 org.apache.pirk.inputformat.hadoop
 org.apache.pirk.inputformat.hadoop.json
 org.apache.pirk.querier.wideskies
@@ -22,7 +23,4 @@ org.apache.pirk.test.distributed
 org.apache.pirk.test.distributed.testsuite
 org.apache.pirk.test.utils
 org.apache.pirk.utils
-test.general
-test.schema.data
-test.schema.query
-test.wideskies.standalone
+org.apache.pirk.wideskies.standalone

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/serialized-form.html
----------------------------------------------------------------------
diff --git a/docs/serialized-form.html b/docs/serialized-form.html
index e4aa68f..792790d 100644
--- a/docs/serialized-form.html
+++ b/docs/serialized-form.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Serialized Form</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 969d025..11450b3 100644
--- a/pom.xml
+++ b/pom.xml
@@ -499,6 +499,17 @@
 						</execution>
 					</executions>
 				</plugin>
+
+				<plugin>
+					<groupId>org.apache.maven.plugins</groupId>
+					<artifactId>maven-javadoc-plugin</artifactId>
+					<version>2.10.4</version>
+					<configuration>
+						<javadocDirectory>docs</javadocDirectory>
+						<testJavadocDirectory>docs/test</testJavadocDirectory>
+						<javadocVersion>1.8</javadocVersion>
+					</configuration>
+				</plugin>
 			</plugins>
 		</pluginManagement>
 
@@ -511,7 +522,7 @@
 			be explicitly provided. -->
 			<id>integration-tests</id>
 			<build>
-				<plugins>
+			<plugins>
 					<plugin>
 						<groupId>org.apache.maven.plugins</groupId>
 						<artifactId>maven-failsafe-plugin</artifactId>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/main/java/org/apache/pirk/utils/CSVOutputUtils.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/pirk/utils/CSVOutputUtils.java b/src/main/java/org/apache/pirk/utils/CSVOutputUtils.java
index 311fe87..ab77622 100644
--- a/src/main/java/org/apache/pirk/utils/CSVOutputUtils.java
+++ b/src/main/java/org/apache/pirk/utils/CSVOutputUtils.java
@@ -71,14 +71,12 @@ public class CSVOutputUtils
   public static String[] extractCSVOutput(Text value)
   {
     String csvOut = value.toString();
-    String tokens[] = csvOut.split(",(?=([^\"]*\"[^\"]*\")*[^\"]*$)", -1);
-    return tokens;
+    return csvOut.split(",(?=([^\"]*\"[^\"]*\")*[^\"]*$)", -1);
   }
 
   public static String[] extractCSVOutput(String value)
   {
-    String tokens[] = value.split(",(?=([^\"]*\"[^\"]*\")*[^\"]*$)", -1);
-    return tokens;
+    return value.split(",(?=([^\"]*\"[^\"]*\")*[^\"]*$)", -1);
   }
 
   public static void extractCSVOutputIdentity(Text key, Text value, Text input)

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/src/test/java/org/apache/pirk/general/ISO8601DateParserTest.java
----------------------------------------------------------------------
diff --git a/src/test/java/org/apache/pirk/general/ISO8601DateParserTest.java b/src/test/java/org/apache/pirk/general/ISO8601DateParserTest.java
new file mode 100644
index 0000000..786f289
--- /dev/null
+++ b/src/test/java/org/apache/pirk/general/ISO8601DateParserTest.java
@@ -0,0 +1,50 @@
+/*
+ * 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.pirk.general;
+
+import static org.junit.Assert.assertEquals;
+
+import java.text.ParseException;
+
+import org.apache.pirk.utils.ISO8601DateParser;
+import org.junit.Test;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/**
+ * Class to test basic functionality of ISO8601DateParser class
+ */
+public class ISO8601DateParserTest
+{
+  private static final Logger logger = LoggerFactory.getLogger(ISO8601DateParserTest.class);
+
+  @Test
+  public void testDateParsing() throws ParseException
+  {
+    logger.info("Starting testDateParsing: ");
+
+    String date = "2016-02-20T23:29:05.000Z";
+    long longDate = Long.parseLong("1456010945000"); // date in UTC
+
+    assertEquals(longDate, ISO8601DateParser.getLongDate(date));
+    assertEquals(date, ISO8601DateParser.fromLongDate(longDate));
+
+    logger.info("Successfully completed testDateParsing");
+  }
+}


[4/9] incubator-pirk git commit: [PIRK-37]: Rename package for test classes to be org.apache.pirk.* -- closes apache/incubator-pirk#39

Posted by ea...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/LoadQuerySchemaTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/LoadQuerySchemaTest.html b/docs/org/apache/pirk/schema/query/LoadQuerySchemaTest.html
new file mode 100644
index 0000000..a8f63a8
--- /dev/null
+++ b/docs/org/apache/pirk/schema/query/LoadQuerySchemaTest.html
@@ -0,0 +1,308 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:31 EDT 2016 -->
+<title>LoadQuerySchemaTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="LoadQuerySchemaTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/LoadQuerySchemaTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev Class</li>
+<li><a href="../../../../../org/apache/pirk/schema/query/QuerySchema.html" title="class in org.apache.pirk.schema.query"><span class="strong">Next Class</span></a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/schema/query/LoadQuerySchemaTest.html" target="_top">Frames</a></li>
+<li><a href="LoadQuerySchemaTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<!-- ======== START OF CLASS DATA ======== -->
+<div class="header">
+<div class="subTitle">org.apache.pirk.schema.query</div>
+<h2 title="Class LoadQuerySchemaTest" class="title">Class LoadQuerySchemaTest</h2>
+</div>
+<div class="contentContainer">
+<ul class="inheritance">
+<li>java.lang.Object</li>
+<li>
+<ul class="inheritance">
+<li>org.apache.pirk.schema.query.LoadQuerySchemaTest</li>
+</ul>
+</li>
+</ul>
+<div class="description">
+<ul class="blockList">
+<li class="blockList">
+<hr>
+<br>
+<pre>public class <span class="strong">LoadQuerySchemaTest</span>
+extends java.lang.Object</pre>
+<div class="block">Test suite for LoadQuerySchema and QuerySchema</div>
+</li>
+</ul>
+</div>
+<div class="summary">
+<ul class="blockList">
+<li class="blockList">
+<!-- ======== CONSTRUCTOR SUMMARY ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_summary">
+<!--   -->
+</a>
+<h3>Constructor Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Constructor Summary table, listing constructors, and an explanation">
+<caption><span>Constructors</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colOne" scope="col">Constructor and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colOne"><code><strong><a href="../../../../../org/apache/pirk/schema/query/LoadQuerySchemaTest.html#LoadQuerySchemaTest()">LoadQuerySchemaTest</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+</li>
+</ul>
+<!-- ========== METHOD SUMMARY =========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_summary">
+<!--   -->
+</a>
+<h3>Method Summary</h3>
+<table class="overviewSummary" border="0" cellpadding="3" cellspacing="0" summary="Method Summary table, listing methods, and an explanation">
+<caption><span>Methods</span><span class="tabEnd">&nbsp;</span></caption>
+<tr>
+<th class="colFirst" scope="col">Modifier and Type</th>
+<th class="colLast" scope="col">Method and Description</th>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/query/LoadQuerySchemaTest.html#testDataSchemaDoesNotExist()">testDataSchemaDoesNotExist</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/query/LoadQuerySchemaTest.html#testGeneralSchemaLoad()">testGeneralSchemaLoad</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="altColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/query/LoadQuerySchemaTest.html#testSelectorDoesNotExistInDataSchema()">testSelectorDoesNotExistInDataSchema</a></strong>()</code>&nbsp;</td>
+</tr>
+<tr class="rowColor">
+<td class="colFirst"><code>void</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/query/LoadQuerySchemaTest.html#testUnknownFilterClass()">testUnknownFilterClass</a></strong>()</code>&nbsp;</td>
+</tr>
+</table>
+<ul class="blockList">
+<li class="blockList"><a name="methods_inherited_from_class_java.lang.Object">
+<!--   -->
+</a>
+<h3>Methods inherited from class&nbsp;java.lang.Object</h3>
+<code>equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait</code></li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+<div class="details">
+<ul class="blockList">
+<li class="blockList">
+<!-- ========= CONSTRUCTOR DETAIL ======== -->
+<ul class="blockList">
+<li class="blockList"><a name="constructor_detail">
+<!--   -->
+</a>
+<h3>Constructor Detail</h3>
+<a name="LoadQuerySchemaTest()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>LoadQuerySchemaTest</h4>
+<pre>public&nbsp;LoadQuerySchemaTest()</pre>
+</li>
+</ul>
+</li>
+</ul>
+<!-- ============ METHOD DETAIL ========== -->
+<ul class="blockList">
+<li class="blockList"><a name="method_detail">
+<!--   -->
+</a>
+<h3>Method Detail</h3>
+<a name="testGeneralSchemaLoad()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testGeneralSchemaLoad</h4>
+<pre>public&nbsp;void&nbsp;testGeneralSchemaLoad()
+                           throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+<a name="testUnknownFilterClass()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testUnknownFilterClass</h4>
+<pre>public&nbsp;void&nbsp;testUnknownFilterClass()
+                            throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+<a name="testDataSchemaDoesNotExist()">
+<!--   -->
+</a>
+<ul class="blockList">
+<li class="blockList">
+<h4>testDataSchemaDoesNotExist</h4>
+<pre>public&nbsp;void&nbsp;testDataSchemaDoesNotExist()
+                                throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+<a name="testSelectorDoesNotExistInDataSchema()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>testSelectorDoesNotExistInDataSchema</h4>
+<pre>public&nbsp;void&nbsp;testSelectorDoesNotExistInDataSchema()
+                                          throws java.lang.Exception</pre>
+<dl><dt><span class="strong">Throws:</span></dt>
+<dd><code>java.lang.Exception</code></dd></dl>
+</li>
+</ul>
+</li>
+</ul>
+</li>
+</ul>
+</div>
+</div>
+<!-- ========= END OF CLASS DATA ========= -->
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../overview-summary.html">Overview</a></li>
+<li><a href="package-summary.html">Package</a></li>
+<li class="navBarCell1Rev">Class</li>
+<li><a href="class-use/LoadQuerySchemaTest.html">Use</a></li>
+<li><a href="package-tree.html">Tree</a></li>
+<li><a href="../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev Class</li>
+<li><a href="../../../../../org/apache/pirk/schema/query/QuerySchema.html" title="class in org.apache.pirk.schema.query"><span class="strong">Next Class</span></a></li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../index.html?org/apache/pirk/schema/query/LoadQuerySchemaTest.html" target="_top">Frames</a></li>
+<li><a href="LoadQuerySchemaTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<div>
+<ul class="subNavList">
+<li>Summary:&nbsp;</li>
+<li>Nested&nbsp;|&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_summary">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_summary">Method</a></li>
+</ul>
+<ul class="subNavList">
+<li>Detail:&nbsp;</li>
+<li>Field&nbsp;|&nbsp;</li>
+<li><a href="#constructor_detail">Constr</a>&nbsp;|&nbsp;</li>
+<li><a href="#method_detail">Method</a></li>
+</ul>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/QuerySchema.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/QuerySchema.html b/docs/org/apache/pirk/schema/query/QuerySchema.html
index 91dccf5..135a5f2 100644
--- a/docs/org/apache/pirk/schema/query/QuerySchema.html
+++ b/docs/org/apache/pirk/schema/query/QuerySchema.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:31 EDT 2016 -->
 <title>QuerySchema</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -36,7 +36,7 @@
 </div>
 <div class="subNav">
 <ul class="navList">
-<li>Prev Class</li>
+<li><a href="../../../../../org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query"><span class="strong">Prev Class</span></a></li>
 <li><a href="../../../../../org/apache/pirk/schema/query/QuerySchemaLoader.html" title="class in org.apache.pirk.schema.query"><span class="strong">Next Class</span></a></li>
 </ul>
 <ul class="navList">
@@ -313,7 +313,7 @@ implements java.io.Serializable</pre>
 </div>
 <div class="subNav">
 <ul class="navList">
-<li>Prev Class</li>
+<li><a href="../../../../../org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query"><span class="strong">Prev Class</span></a></li>
 <li><a href="../../../../../org/apache/pirk/schema/query/QuerySchemaLoader.html" title="class in org.apache.pirk.schema.query"><span class="strong">Next Class</span></a></li>
 </ul>
 <ul class="navList">

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/QuerySchemaLoader.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/QuerySchemaLoader.html b/docs/org/apache/pirk/schema/query/QuerySchemaLoader.html
index 0963f7d..49ace0c 100644
--- a/docs/org/apache/pirk/schema/query/QuerySchemaLoader.html
+++ b/docs/org/apache/pirk/schema/query/QuerySchemaLoader.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:31 EDT 2016 -->
 <title>QuerySchemaLoader</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/QuerySchemaRegistry.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/QuerySchemaRegistry.html b/docs/org/apache/pirk/schema/query/QuerySchemaRegistry.html
index 89349e5..7a8b16f 100644
--- a/docs/org/apache/pirk/schema/query/QuerySchemaRegistry.html
+++ b/docs/org/apache/pirk/schema/query/QuerySchemaRegistry.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>QuerySchemaRegistry</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -117,18 +117,24 @@ extends java.lang.Object</pre>
 <th class="colLast" scope="col">Method and Description</th>
 </tr>
 <tr class="altColor">
+<td class="colFirst"><code>static void</code></td>
+<td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/query/QuerySchemaRegistry.html#clearRegistry()">clearRegistry</a></strong>()</code>
+<div class="block">Clear the registry</div>
+</td>
+</tr>
+<tr class="rowColor">
 <td class="colFirst"><code>static <a href="../../../../../org/apache/pirk/schema/query/QuerySchema.html" title="class in org.apache.pirk.schema.query">QuerySchema</a></code></td>
 <td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/query/QuerySchemaRegistry.html#get(java.lang.String)">get</a></strong>(java.lang.String&nbsp;schemaName)</code>
 <div class="block">Returns the query schema with the given name.</div>
 </td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><code>static java.util.Set&lt;java.lang.String&gt;</code></td>
 <td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/query/QuerySchemaRegistry.html#getNames()">getNames</a></strong>()</code>
 <div class="block">Returns the set of query schema names held in the registry.</div>
 </td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><code>static <a href="../../../../../org/apache/pirk/schema/query/QuerySchema.html" title="class in org.apache.pirk.schema.query">QuerySchema</a></code></td>
 <td class="colLast"><code><strong><a href="../../../../../org/apache/pirk/schema/query/QuerySchemaRegistry.html#put(org.apache.pirk.schema.query.QuerySchema)">put</a></strong>(<a href="../../../../../org/apache/pirk/schema/query/QuerySchema.html" title="class in org.apache.pirk.schema.query">QuerySchema</a>&nbsp;schema)</code>
 <div class="block">Adds the given query schema to the registry.</div>
@@ -185,7 +191,7 @@ extends java.lang.Object</pre>
 <a name="getNames()">
 <!--   -->
 </a>
-<ul class="blockListLast">
+<ul class="blockList">
 <li class="blockList">
 <h4>getNames</h4>
 <pre>public static&nbsp;java.util.Set&lt;java.lang.String&gt;&nbsp;getNames()</pre>
@@ -193,6 +199,16 @@ extends java.lang.Object</pre>
 <dl><dt><span class="strong">Returns:</span></dt><dd>The possibly empty set of query schema names.</dd></dl>
 </li>
 </ul>
+<a name="clearRegistry()">
+<!--   -->
+</a>
+<ul class="blockListLast">
+<li class="blockList">
+<h4>clearRegistry</h4>
+<pre>public static&nbsp;void&nbsp;clearRegistry()</pre>
+<div class="block">Clear the registry</div>
+</li>
+</ul>
 </li>
 </ul>
 </li>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/class-use/LoadQuerySchemaTest.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/class-use/LoadQuerySchemaTest.html b/docs/org/apache/pirk/schema/query/class-use/LoadQuerySchemaTest.html
new file mode 100644
index 0000000..35e3362
--- /dev/null
+++ b/docs/org/apache/pirk/schema/query/class-use/LoadQuerySchemaTest.html
@@ -0,0 +1,115 @@
+<!DOCTYPE HTML PUBLIC "-//W3C//DTD HTML 4.01 Transitional//EN" "http://www.w3.org/TR/html4/loose.dtd">
+<!-- NewPage -->
+<html lang="en">
+<head>
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
+<title>Uses of Class org.apache.pirk.schema.query.LoadQuerySchemaTest</title>
+<meta name="date" content="2016-07-31">
+<link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
+</head>
+<body>
+<script type="text/javascript"><!--
+    if (location.href.indexOf('is-external=true') == -1) {
+        parent.document.title="Uses of Class org.apache.pirk.schema.query.LoadQuerySchemaTest";
+    }
+//-->
+</script>
+<noscript>
+<div>JavaScript is disabled on your browser.</div>
+</noscript>
+<!-- ========= START OF TOP NAVBAR ======= -->
+<div class="topNav"><a name="navbar_top">
+<!--   -->
+</a><a href="#skip-navbar_top" title="Skip navigation links"></a><a name="navbar_top_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../../org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../../index.html?org/apache/pirk/schema/query/class-use/LoadQuerySchemaTest.html" target="_top">Frames</a></li>
+<li><a href="LoadQuerySchemaTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_top">
+<li><a href="../../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_top");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_top">
+<!--   -->
+</a></div>
+<!-- ========= END OF TOP NAVBAR ========= -->
+<div class="header">
+<h2 title="Uses of Class org.apache.pirk.schema.query.LoadQuerySchemaTest" class="title">Uses of Class<br>org.apache.pirk.schema.query.LoadQuerySchemaTest</h2>
+</div>
+<div class="classUseContainer">No usage of org.apache.pirk.schema.query.LoadQuerySchemaTest</div>
+<!-- ======= START OF BOTTOM NAVBAR ====== -->
+<div class="bottomNav"><a name="navbar_bottom">
+<!--   -->
+</a><a href="#skip-navbar_bottom" title="Skip navigation links"></a><a name="navbar_bottom_firstrow">
+<!--   -->
+</a>
+<ul class="navList" title="Navigation">
+<li><a href="../../../../../../overview-summary.html">Overview</a></li>
+<li><a href="../package-summary.html">Package</a></li>
+<li><a href="../../../../../../org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query">Class</a></li>
+<li class="navBarCell1Rev">Use</li>
+<li><a href="../package-tree.html">Tree</a></li>
+<li><a href="../../../../../../deprecated-list.html">Deprecated</a></li>
+<li><a href="../../../../../../index-files/index-1.html">Index</a></li>
+<li><a href="../../../../../../help-doc.html">Help</a></li>
+</ul>
+</div>
+<div class="subNav">
+<ul class="navList">
+<li>Prev</li>
+<li>Next</li>
+</ul>
+<ul class="navList">
+<li><a href="../../../../../../index.html?org/apache/pirk/schema/query/class-use/LoadQuerySchemaTest.html" target="_top">Frames</a></li>
+<li><a href="LoadQuerySchemaTest.html" target="_top">No Frames</a></li>
+</ul>
+<ul class="navList" id="allclasses_navbar_bottom">
+<li><a href="../../../../../../allclasses-noframe.html">All Classes</a></li>
+</ul>
+<div>
+<script type="text/javascript"><!--
+  allClassesLink = document.getElementById("allclasses_navbar_bottom");
+  if(window==top) {
+    allClassesLink.style.display = "block";
+  }
+  else {
+    allClassesLink.style.display = "none";
+  }
+  //-->
+</script>
+</div>
+<a name="skip-navbar_bottom">
+<!--   -->
+</a></div>
+<!-- ======== END OF BOTTOM NAVBAR ======= -->
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/class-use/QuerySchema.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/class-use/QuerySchema.html b/docs/org/apache/pirk/schema/query/class-use/QuerySchema.html
index 5c5577b..0551fb7 100644
--- a/docs/org/apache/pirk/schema/query/class-use/QuerySchema.html
+++ b/docs/org/apache/pirk/schema/query/class-use/QuerySchema.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.schema.query.QuerySchema</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/class-use/QuerySchemaLoader.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/class-use/QuerySchemaLoader.html b/docs/org/apache/pirk/schema/query/class-use/QuerySchemaLoader.html
index 6ff67d1..06cb3d7 100644
--- a/docs/org/apache/pirk/schema/query/class-use/QuerySchemaLoader.html
+++ b/docs/org/apache/pirk/schema/query/class-use/QuerySchemaLoader.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.schema.query.QuerySchemaLoader</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/class-use/QuerySchemaRegistry.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/class-use/QuerySchemaRegistry.html b/docs/org/apache/pirk/schema/query/class-use/QuerySchemaRegistry.html
index bcbbe6d..ee10f0c 100644
--- a/docs/org/apache/pirk/schema/query/class-use/QuerySchemaRegistry.html
+++ b/docs/org/apache/pirk/schema/query/class-use/QuerySchemaRegistry.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.schema.query.QuerySchemaRegistry</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/filter/DataFilter.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/filter/DataFilter.html b/docs/org/apache/pirk/schema/query/filter/DataFilter.html
index 8313fcd..335467d 100644
--- a/docs/org/apache/pirk/schema/query/filter/DataFilter.html
+++ b/docs/org/apache/pirk/schema/query/filter/DataFilter.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>DataFilter</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/filter/FilterFactory.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/filter/FilterFactory.html b/docs/org/apache/pirk/schema/query/filter/FilterFactory.html
index aebd5e3..648cc2b 100644
--- a/docs/org/apache/pirk/schema/query/filter/FilterFactory.html
+++ b/docs/org/apache/pirk/schema/query/filter/FilterFactory.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>FilterFactory</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/filter/StopListFilter.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/filter/StopListFilter.html b/docs/org/apache/pirk/schema/query/filter/StopListFilter.html
index b2f8706..d320990 100644
--- a/docs/org/apache/pirk/schema/query/filter/StopListFilter.html
+++ b/docs/org/apache/pirk/schema/query/filter/StopListFilter.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>StopListFilter</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/filter/class-use/DataFilter.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/filter/class-use/DataFilter.html b/docs/org/apache/pirk/schema/query/filter/class-use/DataFilter.html
index a76f448..23c1743 100644
--- a/docs/org/apache/pirk/schema/query/filter/class-use/DataFilter.html
+++ b/docs/org/apache/pirk/schema/query/filter/class-use/DataFilter.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Interface org.apache.pirk.schema.query.filter.DataFilter</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/filter/class-use/FilterFactory.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/filter/class-use/FilterFactory.html b/docs/org/apache/pirk/schema/query/filter/class-use/FilterFactory.html
index e83256e..22d9904 100644
--- a/docs/org/apache/pirk/schema/query/filter/class-use/FilterFactory.html
+++ b/docs/org/apache/pirk/schema/query/filter/class-use/FilterFactory.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.schema.query.filter.FilterFactory</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/filter/class-use/StopListFilter.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/filter/class-use/StopListFilter.html b/docs/org/apache/pirk/schema/query/filter/class-use/StopListFilter.html
index f1561c8..084fb4e 100644
--- a/docs/org/apache/pirk/schema/query/filter/class-use/StopListFilter.html
+++ b/docs/org/apache/pirk/schema/query/filter/class-use/StopListFilter.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.schema.query.filter.StopListFilter</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/filter/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/filter/package-frame.html b/docs/org/apache/pirk/schema/query/filter/package-frame.html
index 1d2bcea..d504e22 100644
--- a/docs/org/apache/pirk/schema/query/filter/package-frame.html
+++ b/docs/org/apache/pirk/schema/query/filter/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.schema.query.filter</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/filter/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/filter/package-summary.html b/docs/org/apache/pirk/schema/query/filter/package-summary.html
index 20b4db0..7e453d2 100644
--- a/docs/org/apache/pirk/schema/query/filter/package-summary.html
+++ b/docs/org/apache/pirk/schema/query/filter/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.schema.query.filter</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/filter/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/filter/package-tree.html b/docs/org/apache/pirk/schema/query/filter/package-tree.html
index 87be25e..6bcd50f 100644
--- a/docs/org/apache/pirk/schema/query/filter/package-tree.html
+++ b/docs/org/apache/pirk/schema/query/filter/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.schema.query.filter Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/filter/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/filter/package-use.html b/docs/org/apache/pirk/schema/query/filter/package-use.html
index 238e26e..00c08b1 100644
--- a/docs/org/apache/pirk/schema/query/filter/package-use.html
+++ b/docs/org/apache/pirk/schema/query/filter/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.schema.query.filter</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/package-frame.html b/docs/org/apache/pirk/schema/query/package-frame.html
index f8bee6e..92cc0ae 100644
--- a/docs/org/apache/pirk/schema/query/package-frame.html
+++ b/docs/org/apache/pirk/schema/query/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.schema.query</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -12,6 +12,7 @@
 <div class="indexContainer">
 <h2 title="Classes">Classes</h2>
 <ul title="Classes">
+<li><a href="LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query" target="classFrame">LoadQuerySchemaTest</a></li>
 <li><a href="QuerySchema.html" title="class in org.apache.pirk.schema.query" target="classFrame">QuerySchema</a></li>
 <li><a href="QuerySchemaLoader.html" title="class in org.apache.pirk.schema.query" target="classFrame">QuerySchemaLoader</a></li>
 <li><a href="QuerySchemaRegistry.html" title="class in org.apache.pirk.schema.query" target="classFrame">QuerySchemaRegistry</a></li>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/package-summary.html b/docs/org/apache/pirk/schema/query/package-summary.html
index bd0c8ac..49e03de 100644
--- a/docs/org/apache/pirk/schema/query/package-summary.html
+++ b/docs/org/apache/pirk/schema/query/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.schema.query</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -76,18 +76,24 @@
 </tr>
 <tbody>
 <tr class="altColor">
+<td class="colFirst"><a href="../../../../../org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query">LoadQuerySchemaTest</a></td>
+<td class="colLast">
+<div class="block">Test suite for LoadQuerySchema and QuerySchema</div>
+</td>
+</tr>
+<tr class="rowColor">
 <td class="colFirst"><a href="../../../../../org/apache/pirk/schema/query/QuerySchema.html" title="class in org.apache.pirk.schema.query">QuerySchema</a></td>
 <td class="colLast">
 <div class="block">Class to hold a query schema</div>
 </td>
 </tr>
-<tr class="rowColor">
+<tr class="altColor">
 <td class="colFirst"><a href="../../../../../org/apache/pirk/schema/query/QuerySchemaLoader.html" title="class in org.apache.pirk.schema.query">QuerySchemaLoader</a></td>
 <td class="colLast">
 <div class="block">Class to load any query schemas specified in the properties file, 'query.schemas'</div>
 </td>
 </tr>
-<tr class="altColor">
+<tr class="rowColor">
 <td class="colFirst"><a href="../../../../../org/apache/pirk/schema/query/QuerySchemaRegistry.html" title="class in org.apache.pirk.schema.query">QuerySchemaRegistry</a></td>
 <td class="colLast">&nbsp;</td>
 </tr>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/package-tree.html b/docs/org/apache/pirk/schema/query/package-tree.html
index a66891b..a1b0f6e 100644
--- a/docs/org/apache/pirk/schema/query/package-tree.html
+++ b/docs/org/apache/pirk/schema/query/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.schema.query Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>
@@ -74,6 +74,7 @@
 <ul>
 <li type="circle">java.lang.Object
 <ul>
+<li type="circle">org.apache.pirk.schema.query.<a href="../../../../../org/apache/pirk/schema/query/LoadQuerySchemaTest.html" title="class in org.apache.pirk.schema.query"><span class="strong">LoadQuerySchemaTest</span></a></li>
 <li type="circle">org.apache.pirk.schema.query.<a href="../../../../../org/apache/pirk/schema/query/QuerySchema.html" title="class in org.apache.pirk.schema.query"><span class="strong">QuerySchema</span></a> (implements java.io.Serializable)</li>
 <li type="circle">org.apache.pirk.schema.query.<a href="../../../../../org/apache/pirk/schema/query/QuerySchemaLoader.html" title="class in org.apache.pirk.schema.query"><span class="strong">QuerySchemaLoader</span></a></li>
 <li type="circle">org.apache.pirk.schema.query.<a href="../../../../../org/apache/pirk/schema/query/QuerySchemaRegistry.html" title="class in org.apache.pirk.schema.query"><span class="strong">QuerySchemaRegistry</span></a></li>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/query/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/query/package-use.html b/docs/org/apache/pirk/schema/query/package-use.html
index 756d033..acf2769 100644
--- a/docs/org/apache/pirk/schema/query/package-use.html
+++ b/docs/org/apache/pirk/schema/query/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.schema.query</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/response/QueryResponseJSON.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/response/QueryResponseJSON.html b/docs/org/apache/pirk/schema/response/QueryResponseJSON.html
index 38df697..f58b902 100644
--- a/docs/org/apache/pirk/schema/response/QueryResponseJSON.html
+++ b/docs/org/apache/pirk/schema/response/QueryResponseJSON.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>QueryResponseJSON</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/response/class-use/QueryResponseJSON.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/response/class-use/QueryResponseJSON.html b/docs/org/apache/pirk/schema/response/class-use/QueryResponseJSON.html
index 520c07b..04f978e 100644
--- a/docs/org/apache/pirk/schema/response/class-use/QueryResponseJSON.html
+++ b/docs/org/apache/pirk/schema/response/class-use/QueryResponseJSON.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.schema.response.QueryResponseJSON</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/response/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/response/package-frame.html b/docs/org/apache/pirk/schema/response/package-frame.html
index 5ac161a..240ed84 100644
--- a/docs/org/apache/pirk/schema/response/package-frame.html
+++ b/docs/org/apache/pirk/schema/response/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.schema.response</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/response/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/response/package-summary.html b/docs/org/apache/pirk/schema/response/package-summary.html
index 9c7f1b8..63a7cc0 100644
--- a/docs/org/apache/pirk/schema/response/package-summary.html
+++ b/docs/org/apache/pirk/schema/response/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.schema.response</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/response/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/response/package-tree.html b/docs/org/apache/pirk/schema/response/package-tree.html
index c6a71f3..fee78e9 100644
--- a/docs/org/apache/pirk/schema/response/package-tree.html
+++ b/docs/org/apache/pirk/schema/response/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.schema.response Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/schema/response/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/schema/response/package-use.html b/docs/org/apache/pirk/schema/response/package-use.html
index 511acaf..43049e0 100644
--- a/docs/org/apache/pirk/schema/response/package-use.html
+++ b/docs/org/apache/pirk/schema/response/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.schema.response</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/HadoopFileSystemStore.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/HadoopFileSystemStore.html b/docs/org/apache/pirk/serialization/HadoopFileSystemStore.html
index 2e701bc..46b2472 100644
--- a/docs/org/apache/pirk/serialization/HadoopFileSystemStore.html
+++ b/docs/org/apache/pirk/serialization/HadoopFileSystemStore.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>HadoopFileSystemStore</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/JavaSerializer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/JavaSerializer.html b/docs/org/apache/pirk/serialization/JavaSerializer.html
index acf9a0a..ac4e8c6 100644
--- a/docs/org/apache/pirk/serialization/JavaSerializer.html
+++ b/docs/org/apache/pirk/serialization/JavaSerializer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>JavaSerializer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/JsonSerializer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/JsonSerializer.html b/docs/org/apache/pirk/serialization/JsonSerializer.html
index 2f0aa88..7cde1c3 100644
--- a/docs/org/apache/pirk/serialization/JsonSerializer.html
+++ b/docs/org/apache/pirk/serialization/JsonSerializer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>JsonSerializer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/LocalFileSystemStore.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/LocalFileSystemStore.html b/docs/org/apache/pirk/serialization/LocalFileSystemStore.html
index ab42906..4d2d9ed 100644
--- a/docs/org/apache/pirk/serialization/LocalFileSystemStore.html
+++ b/docs/org/apache/pirk/serialization/LocalFileSystemStore.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>LocalFileSystemStore</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/SerializationService.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/SerializationService.html b/docs/org/apache/pirk/serialization/SerializationService.html
index 550ecbf..df2b8fc 100644
--- a/docs/org/apache/pirk/serialization/SerializationService.html
+++ b/docs/org/apache/pirk/serialization/SerializationService.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>SerializationService</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/Storable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/Storable.html b/docs/org/apache/pirk/serialization/Storable.html
index 526c736..10a4f6d 100644
--- a/docs/org/apache/pirk/serialization/Storable.html
+++ b/docs/org/apache/pirk/serialization/Storable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>Storable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/class-use/HadoopFileSystemStore.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/class-use/HadoopFileSystemStore.html b/docs/org/apache/pirk/serialization/class-use/HadoopFileSystemStore.html
index 1ef91c0..c25e8ba 100644
--- a/docs/org/apache/pirk/serialization/class-use/HadoopFileSystemStore.html
+++ b/docs/org/apache/pirk/serialization/class-use/HadoopFileSystemStore.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.serialization.HadoopFileSystemStore</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/class-use/JavaSerializer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/class-use/JavaSerializer.html b/docs/org/apache/pirk/serialization/class-use/JavaSerializer.html
index a0b987a..104d3ae 100644
--- a/docs/org/apache/pirk/serialization/class-use/JavaSerializer.html
+++ b/docs/org/apache/pirk/serialization/class-use/JavaSerializer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.serialization.JavaSerializer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/class-use/JsonSerializer.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/class-use/JsonSerializer.html b/docs/org/apache/pirk/serialization/class-use/JsonSerializer.html
index a64f07d..8b60955 100644
--- a/docs/org/apache/pirk/serialization/class-use/JsonSerializer.html
+++ b/docs/org/apache/pirk/serialization/class-use/JsonSerializer.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.serialization.JsonSerializer</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/class-use/LocalFileSystemStore.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/class-use/LocalFileSystemStore.html b/docs/org/apache/pirk/serialization/class-use/LocalFileSystemStore.html
index 4f4eca4..088e714 100644
--- a/docs/org/apache/pirk/serialization/class-use/LocalFileSystemStore.html
+++ b/docs/org/apache/pirk/serialization/class-use/LocalFileSystemStore.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.serialization.LocalFileSystemStore</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/class-use/SerializationService.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/class-use/SerializationService.html b/docs/org/apache/pirk/serialization/class-use/SerializationService.html
index b2f88d8..5bce2c5 100644
--- a/docs/org/apache/pirk/serialization/class-use/SerializationService.html
+++ b/docs/org/apache/pirk/serialization/class-use/SerializationService.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.serialization.SerializationService</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/class-use/Storable.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/class-use/Storable.html b/docs/org/apache/pirk/serialization/class-use/Storable.html
index dcf016a..c9cf6b4 100644
--- a/docs/org/apache/pirk/serialization/class-use/Storable.html
+++ b/docs/org/apache/pirk/serialization/class-use/Storable.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Interface org.apache.pirk.serialization.Storable</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/package-frame.html b/docs/org/apache/pirk/serialization/package-frame.html
index 62e63e2..777f109 100644
--- a/docs/org/apache/pirk/serialization/package-frame.html
+++ b/docs/org/apache/pirk/serialization/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.serialization</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/package-summary.html b/docs/org/apache/pirk/serialization/package-summary.html
index 8645074..15b1e71 100644
--- a/docs/org/apache/pirk/serialization/package-summary.html
+++ b/docs/org/apache/pirk/serialization/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.serialization</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/package-tree.html b/docs/org/apache/pirk/serialization/package-tree.html
index ccb2e02..d5289bb 100644
--- a/docs/org/apache/pirk/serialization/package-tree.html
+++ b/docs/org/apache/pirk/serialization/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.serialization Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/serialization/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/serialization/package-use.html b/docs/org/apache/pirk/serialization/package-use.html
index 6315efd..000f257 100644
--- a/docs/org/apache/pirk/serialization/package-use.html
+++ b/docs/org/apache/pirk/serialization/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.serialization</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/DistributedTestCLI.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/DistributedTestCLI.html b/docs/org/apache/pirk/test/distributed/DistributedTestCLI.html
index a41e9c3..8d11419 100644
--- a/docs/org/apache/pirk/test/distributed/DistributedTestCLI.html
+++ b/docs/org/apache/pirk/test/distributed/DistributedTestCLI.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>DistributedTestCLI</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/DistributedTestDriver.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/DistributedTestDriver.html b/docs/org/apache/pirk/test/distributed/DistributedTestDriver.html
index 26e7c9c..3b4a388 100644
--- a/docs/org/apache/pirk/test/distributed/DistributedTestDriver.html
+++ b/docs/org/apache/pirk/test/distributed/DistributedTestDriver.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:35 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>DistributedTestDriver</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/class-use/DistributedTestCLI.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/class-use/DistributedTestCLI.html b/docs/org/apache/pirk/test/distributed/class-use/DistributedTestCLI.html
index a023389..157de0d 100644
--- a/docs/org/apache/pirk/test/distributed/class-use/DistributedTestCLI.html
+++ b/docs/org/apache/pirk/test/distributed/class-use/DistributedTestCLI.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.test.distributed.DistributedTestCLI</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/class-use/DistributedTestDriver.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/class-use/DistributedTestDriver.html b/docs/org/apache/pirk/test/distributed/class-use/DistributedTestDriver.html
index 461178d..d20c0f3 100644
--- a/docs/org/apache/pirk/test/distributed/class-use/DistributedTestDriver.html
+++ b/docs/org/apache/pirk/test/distributed/class-use/DistributedTestDriver.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.test.distributed.DistributedTestDriver</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/package-frame.html b/docs/org/apache/pirk/test/distributed/package-frame.html
index 22adaa5..20ce091 100644
--- a/docs/org/apache/pirk/test/distributed/package-frame.html
+++ b/docs/org/apache/pirk/test/distributed/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.test.distributed</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/package-summary.html b/docs/org/apache/pirk/test/distributed/package-summary.html
index c39eae0..2b7ef49 100644
--- a/docs/org/apache/pirk/test/distributed/package-summary.html
+++ b/docs/org/apache/pirk/test/distributed/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.test.distributed</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/package-tree.html b/docs/org/apache/pirk/test/distributed/package-tree.html
index f539a73..edf95f5 100644
--- a/docs/org/apache/pirk/test/distributed/package-tree.html
+++ b/docs/org/apache/pirk/test/distributed/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.test.distributed Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/package-use.html b/docs/org/apache/pirk/test/distributed/package-use.html
index 6f798ea..8ce1ad9 100644
--- a/docs/org/apache/pirk/test/distributed/package-use.html
+++ b/docs/org/apache/pirk/test/distributed/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.test.distributed</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/testsuite/DistTestSuite.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/testsuite/DistTestSuite.html b/docs/org/apache/pirk/test/distributed/testsuite/DistTestSuite.html
index e8bed4f..5373426 100644
--- a/docs/org/apache/pirk/test/distributed/testsuite/DistTestSuite.html
+++ b/docs/org/apache/pirk/test/distributed/testsuite/DistTestSuite.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>DistTestSuite</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/testsuite/class-use/DistTestSuite.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/testsuite/class-use/DistTestSuite.html b/docs/org/apache/pirk/test/distributed/testsuite/class-use/DistTestSuite.html
index be6a2f7..45efbd8 100644
--- a/docs/org/apache/pirk/test/distributed/testsuite/class-use/DistTestSuite.html
+++ b/docs/org/apache/pirk/test/distributed/testsuite/class-use/DistTestSuite.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.test.distributed.testsuite.DistTestSuite</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/testsuite/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/testsuite/package-frame.html b/docs/org/apache/pirk/test/distributed/testsuite/package-frame.html
index 7731f01..85ac102 100644
--- a/docs/org/apache/pirk/test/distributed/testsuite/package-frame.html
+++ b/docs/org/apache/pirk/test/distributed/testsuite/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.test.distributed.testsuite</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/testsuite/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/testsuite/package-summary.html b/docs/org/apache/pirk/test/distributed/testsuite/package-summary.html
index fdff016..4f85fdc 100644
--- a/docs/org/apache/pirk/test/distributed/testsuite/package-summary.html
+++ b/docs/org/apache/pirk/test/distributed/testsuite/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.test.distributed.testsuite</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/testsuite/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/testsuite/package-tree.html b/docs/org/apache/pirk/test/distributed/testsuite/package-tree.html
index e2e2088..f429984 100644
--- a/docs/org/apache/pirk/test/distributed/testsuite/package-tree.html
+++ b/docs/org/apache/pirk/test/distributed/testsuite/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.test.distributed.testsuite Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/distributed/testsuite/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/distributed/testsuite/package-use.html b/docs/org/apache/pirk/test/distributed/testsuite/package-use.html
index 17b1cf8..738466e 100644
--- a/docs/org/apache/pirk/test/distributed/testsuite/package-use.html
+++ b/docs/org/apache/pirk/test/distributed/testsuite/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.test.distributed.testsuite</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/utils/BaseTests.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/utils/BaseTests.html b/docs/org/apache/pirk/test/utils/BaseTests.html
index 41e8124..0724c90 100644
--- a/docs/org/apache/pirk/test/utils/BaseTests.html
+++ b/docs/org/apache/pirk/test/utils/BaseTests.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>BaseTests</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/utils/Inputs.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/utils/Inputs.html b/docs/org/apache/pirk/test/utils/Inputs.html
index 1ae39af..b66c8c9 100644
--- a/docs/org/apache/pirk/test/utils/Inputs.html
+++ b/docs/org/apache/pirk/test/utils/Inputs.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>Inputs</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/utils/StandaloneQuery.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/utils/StandaloneQuery.html b/docs/org/apache/pirk/test/utils/StandaloneQuery.html
index a7792ea..18a2e7a 100644
--- a/docs/org/apache/pirk/test/utils/StandaloneQuery.html
+++ b/docs/org/apache/pirk/test/utils/StandaloneQuery.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>StandaloneQuery</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/utils/TestUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/utils/TestUtils.html b/docs/org/apache/pirk/test/utils/TestUtils.html
index 7d86f6e..d67559b 100644
--- a/docs/org/apache/pirk/test/utils/TestUtils.html
+++ b/docs/org/apache/pirk/test/utils/TestUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:36 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:32 EDT 2016 -->
 <title>TestUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/utils/class-use/BaseTests.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/utils/class-use/BaseTests.html b/docs/org/apache/pirk/test/utils/class-use/BaseTests.html
index 8fdf9ad..49db0a6 100644
--- a/docs/org/apache/pirk/test/utils/class-use/BaseTests.html
+++ b/docs/org/apache/pirk/test/utils/class-use/BaseTests.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.test.utils.BaseTests</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/utils/class-use/Inputs.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/utils/class-use/Inputs.html b/docs/org/apache/pirk/test/utils/class-use/Inputs.html
index 65e6317..e2e3259 100644
--- a/docs/org/apache/pirk/test/utils/class-use/Inputs.html
+++ b/docs/org/apache/pirk/test/utils/class-use/Inputs.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.test.utils.Inputs</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/utils/class-use/StandaloneQuery.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/utils/class-use/StandaloneQuery.html b/docs/org/apache/pirk/test/utils/class-use/StandaloneQuery.html
index 807bf41..35fe48f 100644
--- a/docs/org/apache/pirk/test/utils/class-use/StandaloneQuery.html
+++ b/docs/org/apache/pirk/test/utils/class-use/StandaloneQuery.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.test.utils.StandaloneQuery</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/utils/class-use/TestUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/utils/class-use/TestUtils.html b/docs/org/apache/pirk/test/utils/class-use/TestUtils.html
index 98ee216..67f7836 100644
--- a/docs/org/apache/pirk/test/utils/class-use/TestUtils.html
+++ b/docs/org/apache/pirk/test/utils/class-use/TestUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Class org.apache.pirk.test.utils.TestUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/utils/package-frame.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/utils/package-frame.html b/docs/org/apache/pirk/test/utils/package-frame.html
index c568bff..004dc7b 100644
--- a/docs/org/apache/pirk/test/utils/package-frame.html
+++ b/docs/org/apache/pirk/test/utils/package-frame.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.test.utils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/utils/package-summary.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/utils/package-summary.html b/docs/org/apache/pirk/test/utils/package-summary.html
index 8900960..e60f86c 100644
--- a/docs/org/apache/pirk/test/utils/package-summary.html
+++ b/docs/org/apache/pirk/test/utils/package-summary.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.test.utils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/utils/package-tree.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/utils/package-tree.html b/docs/org/apache/pirk/test/utils/package-tree.html
index b7bd145..f813165 100644
--- a/docs/org/apache/pirk/test/utils/package-tree.html
+++ b/docs/org/apache/pirk/test/utils/package-tree.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>org.apache.pirk.test.utils Class Hierarchy</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/test/utils/package-use.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/test/utils/package-use.html b/docs/org/apache/pirk/test/utils/package-use.html
index 1bf374c..32dcbdd 100644
--- a/docs/org/apache/pirk/test/utils/package-use.html
+++ b/docs/org/apache/pirk/test/utils/package-use.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:38 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:34 EDT 2016 -->
 <title>Uses of Package org.apache.pirk.test.utils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../../stylesheet.css" title="Style">
 </head>
 <body>

http://git-wip-us.apache.org/repos/asf/incubator-pirk/blob/0912bb65/docs/org/apache/pirk/utils/CSVOutputUtils.html
----------------------------------------------------------------------
diff --git a/docs/org/apache/pirk/utils/CSVOutputUtils.html b/docs/org/apache/pirk/utils/CSVOutputUtils.html
index 36e6082..cd9d52f 100644
--- a/docs/org/apache/pirk/utils/CSVOutputUtils.html
+++ b/docs/org/apache/pirk/utils/CSVOutputUtils.html
@@ -2,9 +2,9 @@
 <!-- NewPage -->
 <html lang="en">
 <head>
-<!-- Generated by javadoc (version 1.7.0_80) on Fri Jul 29 15:37:37 EDT 2016 -->
+<!-- Generated by javadoc (version 1.7.0_80) on Sun Jul 31 18:59:33 EDT 2016 -->
 <title>CSVOutputUtils</title>
-<meta name="date" content="2016-07-29">
+<meta name="date" content="2016-07-31">
 <link rel="stylesheet" type="text/css" href="../../../../stylesheet.css" title="Style">
 </head>
 <body>